wasm-bpf/runtime/cpp/third_party/vmlinux/mips/vmlinux_610.h

91308 lines
1.7 MiB

#ifndef __VMLINUX_H__
#define __VMLINUX_H__
#ifndef BPF_NO_PRESERVE_ACCESS_INDEX
#pragma clang attribute push (__attribute__((preserve_access_index)), apply_to = record)
#endif
typedef unsigned char __u8;
typedef short unsigned int __u16;
typedef int __s32;
typedef unsigned int __u32;
typedef long long int __s64;
typedef long long unsigned int __u64;
typedef __u8 u8;
typedef __u16 u16;
typedef __s32 s32;
typedef __u32 u32;
typedef __s64 s64;
typedef __u64 u64;
enum {
false = 0,
true = 1,
};
typedef long int __kernel_long_t;
typedef int __kernel_pid_t;
typedef unsigned int __kernel_uid32_t;
typedef unsigned int __kernel_size_t;
typedef long long int __kernel_time64_t;
typedef __kernel_long_t __kernel_clock_t;
typedef int __kernel_timer_t;
typedef int __kernel_clockid_t;
typedef __kernel_pid_t pid_t;
typedef __kernel_clockid_t clockid_t;
typedef __kernel_size_t size_t;
typedef struct {
int counter;
} atomic_t;
struct list_head {
struct list_head *next;
struct list_head *prev;
};
struct hlist_node;
struct hlist_head {
struct hlist_node *first;
};
struct hlist_node {
struct hlist_node *next;
struct hlist_node **pprev;
};
struct callback_head {
struct callback_head *next;
void (*func)(struct callback_head *);
};
struct kernel_symbol {
long unsigned int value;
const char *name;
const char *namespace;
};
struct qspinlock {
union {
atomic_t val;
struct {
u8 locked;
u8 pending;
};
struct {
u16 locked_pending;
u16 tail;
};
};
};
typedef struct qspinlock arch_spinlock_t;
struct raw_spinlock {
arch_spinlock_t raw_lock;
};
typedef struct raw_spinlock raw_spinlock_t;
struct __kernel_timespec {
__kernel_time64_t tv_sec;
long long int tv_nsec;
};
typedef atomic_t atomic_long_t;
struct cpumask {
long unsigned int bits[1];
};
typedef struct cpumask cpumask_t;
struct llist_node {
struct llist_node *next;
};
struct __call_single_node {
struct llist_node llist;
union {
unsigned int u_flags;
atomic_t a_flags;
};
};
enum timespec_type {
TT_NONE = 0,
TT_NATIVE = 1,
TT_COMPAT = 2,
};
typedef s32 old_time32_t;
struct old_timespec32 {
old_time32_t tv_sec;
s32 tv_nsec;
};
struct pollfd;
struct restart_block {
long unsigned int arch_data;
long int (*fn)(struct restart_block *);
union {
struct {
u32 *uaddr;
u32 val;
u32 flags;
u32 bitset;
u64 time;
u32 *uaddr2;
long: 32;
} futex;
struct {
clockid_t clockid;
enum timespec_type type;
union {
struct __kernel_timespec *rmtp;
struct old_timespec32 *compat_rmtp;
};
long: 32;
u64 expires;
} nanosleep;
struct {
struct pollfd *ufds;
int nfds;
int has_timeout;
long unsigned int tv_sec;
long unsigned int tv_nsec;
} poll;
};
};
union fpureg {
__u32 val32[2];
__u64 val64[1];
};
struct mips_fpu_struct {
union fpureg fpr[32];
unsigned int fcr31;
unsigned int msacsr;
};
typedef long unsigned int dspreg_t;
struct mips_dsp_state {
dspreg_t dspr[6];
unsigned int dspcontrol;
};
struct mips3264_watch_reg_state {
long unsigned int watchlo[4];
u16 watchhi[4];
};
union mips_watch_reg_state {
struct mips3264_watch_reg_state mips3264;
};
struct mips_abi;
struct thread_struct {
long unsigned int reg16;
long unsigned int reg17;
long unsigned int reg18;
long unsigned int reg19;
long unsigned int reg20;
long unsigned int reg21;
long unsigned int reg22;
long unsigned int reg23;
long unsigned int reg29;
long unsigned int reg30;
long unsigned int reg31;
long unsigned int cp0_status;
struct mips_fpu_struct fpu;
atomic_t bd_emu_frame;
long unsigned int bd_emu_branch_pc;
long unsigned int bd_emu_cont_pc;
long unsigned int emulated_fp;
cpumask_t user_cpus_allowed;
struct mips_dsp_state dsp;
union mips_watch_reg_state watch;
long unsigned int cp0_badvaddr;
long unsigned int cp0_baduaddr;
long unsigned int error_code;
long unsigned int trap_nr;
struct mips_abi *abi;
long: 32;
};
struct task_struct;
struct pt_regs;
struct thread_info {
struct task_struct *task;
long unsigned int flags;
long unsigned int tp_value;
__u32 cpu;
int preempt_count;
struct pt_regs *regs;
long int syscall;
};
struct refcount_struct {
atomic_t refs;
};
typedef struct refcount_struct refcount_t;
struct load_weight {
long unsigned int weight;
u32 inv_weight;
};
struct rb_node {
long unsigned int __rb_parent_color;
struct rb_node *rb_right;
struct rb_node *rb_left;
};
struct util_est {
unsigned int enqueued;
unsigned int ewma;
};
struct sched_avg {
u64 last_update_time;
u64 load_sum;
u64 runnable_sum;
u32 util_sum;
u32 period_contrib;
long unsigned int load_avg;
long unsigned int runnable_avg;
long unsigned int util_avg;
long: 32;
struct util_est util_est;
long: 32;
long: 32;
};
struct sched_entity {
struct load_weight load;
struct rb_node run_node;
struct list_head group_node;
unsigned int on_rq;
u64 exec_start;
u64 sum_exec_runtime;
u64 vruntime;
u64 prev_sum_exec_runtime;
u64 nr_migrations;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct sched_avg avg;
};
struct sched_rt_entity {
struct list_head run_list;
long unsigned int timeout;
long unsigned int watchdog_stamp;
unsigned int time_slice;
short unsigned int on_rq;
short unsigned int on_list;
struct sched_rt_entity *back;
};
typedef s64 ktime_t;
struct timerqueue_node {
struct rb_node node;
long: 32;
ktime_t expires;
};
enum hrtimer_restart {
HRTIMER_NORESTART = 0,
HRTIMER_RESTART = 1,
};
struct hrtimer_clock_base;
struct hrtimer {
struct timerqueue_node node;
ktime_t _softexpires;
enum hrtimer_restart (*function)(struct hrtimer *);
struct hrtimer_clock_base *base;
u8 state;
u8 is_rel;
u8 is_soft;
u8 is_hard;
long: 32;
};
struct sched_dl_entity {
struct rb_node rb_node;
long: 32;
u64 dl_runtime;
u64 dl_deadline;
u64 dl_period;
u64 dl_bw;
u64 dl_density;
s64 runtime;
u64 deadline;
unsigned int flags;
unsigned int dl_throttled: 1;
unsigned int dl_yielded: 1;
unsigned int dl_non_contending: 1;
unsigned int dl_overrun: 1;
struct hrtimer dl_timer;
struct hrtimer inactive_timer;
struct sched_dl_entity *pi_se;
long: 32;
};
struct sched_statistics {};
union rcu_special {
struct {
u8 blocked;
u8 need_qs;
u8 exp_hint;
u8 need_mb;
} b;
u32 s;
};
struct sched_info {};
struct plist_node {
int prio;
struct list_head prio_list;
struct list_head node_list;
};
struct task_rss_stat {
int events;
int count[4];
};
struct prev_cputime {
u64 utime;
u64 stime;
raw_spinlock_t lock;
long: 32;
};
struct rb_root {
struct rb_node *rb_node;
};
struct rb_root_cached {
struct rb_root rb_root;
struct rb_node *rb_leftmost;
};
struct timerqueue_head {
struct rb_root_cached rb_root;
};
struct posix_cputimer_base {
u64 nextevt;
struct timerqueue_head tqhead;
};
struct posix_cputimers {
struct posix_cputimer_base bases[3];
unsigned int timers_active;
unsigned int expiry_active;
};
struct sem_undo_list;
struct sysv_sem {
struct sem_undo_list *undo_list;
};
struct sysv_shm {
struct list_head shm_clist;
};
typedef struct {
long unsigned int sig[4];
} sigset_t;
struct sigpending {
struct list_head list;
sigset_t signal;
};
struct seccomp_filter;
struct seccomp {
int mode;
atomic_t filter_count;
struct seccomp_filter *filter;
};
struct syscall_user_dispatch {};
struct spinlock {
union {
struct raw_spinlock rlock;
};
};
typedef struct spinlock spinlock_t;
struct wake_q_node {
struct wake_q_node *next;
};
struct task_io_accounting {};
struct mutex {
atomic_long_t owner;
raw_spinlock_t wait_lock;
struct list_head wait_list;
};
struct tlbflush_unmap_batch {};
struct page;
struct page_frag {
struct page *page;
__u16 offset;
__u16 size;
};
struct kmap_ctrl {};
struct timer_list {
struct hlist_node entry;
long unsigned int expires;
void (*function)(struct timer_list *);
u32 flags;
};
struct sched_class;
struct mm_struct;
struct pid;
struct completion;
struct cred;
struct key;
struct nameidata;
struct fs_struct;
struct files_struct;
struct io_uring_task;
struct nsproxy;
struct signal_struct;
struct sighand_struct;
struct rt_mutex_waiter;
struct bio_list;
struct blk_plug;
struct reclaim_state;
struct backing_dev_info;
struct io_context;
struct capture_control;
struct kernel_siginfo;
typedef struct kernel_siginfo kernel_siginfo_t;
struct css_set;
struct robust_list_head;
struct futex_pi_state;
struct perf_event_context;
struct rseq;
struct pipe_inode_info;
struct ftrace_ret_stack;
struct uprobe_task;
struct bpf_local_storage;
struct bpf_run_ctx;
struct task_struct {
unsigned int __state;
void *stack;
refcount_t usage;
unsigned int flags;
unsigned int ptrace;
int on_cpu;
struct __call_single_node wake_entry;
unsigned int wakee_flips;
long unsigned int wakee_flip_decay_ts;
struct task_struct *last_wakee;
int recent_used_cpu;
int wake_cpu;
int on_rq;
int prio;
int static_prio;
int normal_prio;
unsigned int rt_priority;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct sched_entity se;
struct sched_rt_entity rt;
long: 32;
struct sched_dl_entity dl;
const struct sched_class *sched_class;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct sched_statistics stats;
unsigned int btrace_seq;
unsigned int policy;
int nr_cpus_allowed;
const cpumask_t *cpus_ptr;
cpumask_t *user_cpus_ptr;
cpumask_t cpus_mask;
void *migration_pending;
short unsigned int migration_disabled;
short unsigned int migration_flags;
int trc_reader_nesting;
int trc_ipi_to_cpu;
union rcu_special trc_reader_special;
struct list_head trc_holdout_list;
struct list_head trc_blkd_node;
int trc_blkd_cpu;
struct sched_info sched_info;
struct list_head tasks;
struct plist_node pushable_tasks;
struct rb_node pushable_dl_tasks;
struct mm_struct *mm;
struct mm_struct *active_mm;
struct task_rss_stat rss_stat;
int exit_state;
int exit_code;
int exit_signal;
int pdeath_signal;
long unsigned int jobctl;
unsigned int personality;
unsigned int sched_reset_on_fork: 1;
unsigned int sched_contributes_to_load: 1;
unsigned int sched_migrated: 1;
long: 29;
unsigned int sched_remote_wakeup: 1;
unsigned int in_execve: 1;
unsigned int in_iowait: 1;
unsigned int no_cgroup_migration: 1;
unsigned int frozen: 1;
unsigned int in_eventfd: 1;
long unsigned int atomic_flags;
struct restart_block restart_block;
pid_t pid;
pid_t tgid;
long unsigned int stack_canary;
struct task_struct *real_parent;
struct task_struct *parent;
struct list_head children;
struct list_head sibling;
struct task_struct *group_leader;
struct list_head ptraced;
struct list_head ptrace_entry;
struct pid *thread_pid;
struct hlist_node pid_links[4];
struct list_head thread_group;
struct list_head thread_node;
struct completion *vfork_done;
int *set_child_tid;
int *clear_child_tid;
void *worker_private;
long: 32;
u64 utime;
u64 stime;
u64 gtime;
struct prev_cputime prev_cputime;
long unsigned int nvcsw;
long unsigned int nivcsw;
u64 start_time;
u64 start_boottime;
long unsigned int min_flt;
long unsigned int maj_flt;
struct posix_cputimers posix_cputimers;
const struct cred *ptracer_cred;
const struct cred *real_cred;
const struct cred *cred;
struct key *cached_requested_key;
char comm[16];
struct nameidata *nameidata;
struct sysv_sem sysvsem;
struct sysv_shm sysvshm;
struct fs_struct *fs;
struct files_struct *files;
struct io_uring_task *io_uring;
struct nsproxy *nsproxy;
struct signal_struct *signal;
struct sighand_struct *sighand;
sigset_t blocked;
sigset_t real_blocked;
sigset_t saved_sigmask;
struct sigpending pending;
long unsigned int sas_ss_sp;
size_t sas_ss_size;
unsigned int sas_ss_flags;
struct callback_head *task_works;
struct seccomp seccomp;
struct syscall_user_dispatch syscall_dispatch;
long: 32;
u64 parent_exec_id;
u64 self_exec_id;
spinlock_t alloc_lock;
raw_spinlock_t pi_lock;
struct wake_q_node wake_q;
struct rb_root_cached pi_waiters;
struct task_struct *pi_top_task;
struct rt_mutex_waiter *pi_blocked_on;
void *journal_info;
struct bio_list *bio_list;
struct blk_plug *plug;
struct reclaim_state *reclaim_state;
struct backing_dev_info *backing_dev_info;
struct io_context *io_context;
struct capture_control *capture_control;
long unsigned int ptrace_message;
kernel_siginfo_t *last_siginfo;
struct task_io_accounting ioac;
struct css_set *cgroups;
struct list_head cg_list;
struct robust_list_head *robust_list;
struct list_head pi_state_list;
struct futex_pi_state *pi_state_cache;
struct mutex futex_exit_mutex;
unsigned int futex_state;
struct perf_event_context *perf_event_ctxp[2];
struct mutex perf_event_mutex;
struct list_head perf_event_list;
struct rseq *rseq;
u32 rseq_sig;
long unsigned int rseq_event_mask;
struct tlbflush_unmap_batch tlb_ubc;
union {
refcount_t rcu_users;
struct callback_head rcu;
};
struct pipe_inode_info *splice_pipe;
struct page_frag task_frag;
int nr_dirtied;
int nr_dirtied_pause;
long unsigned int dirty_paused_when;
long: 32;
u64 timer_slack_ns;
u64 default_timer_slack_ns;
int curr_ret_stack;
int curr_ret_depth;
struct ftrace_ret_stack *ret_stack;
long: 32;
long long unsigned int ftrace_timestamp;
atomic_t trace_overrun;
atomic_t tracing_graph_pause;
long unsigned int trace_recursion;
struct uprobe_task *utask;
struct kmap_ctrl kmap_ctrl;
int pagefault_disabled;
struct task_struct *oom_reaper_list;
struct timer_list oom_reaper_timer;
void *security;
struct bpf_local_storage *bpf_storage;
struct bpf_run_ctx *bpf_ctx;
struct thread_struct thread;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct wait_queue_head {
spinlock_t lock;
struct list_head head;
};
typedef struct wait_queue_head wait_queue_head_t;
enum pcpu_fc {
PCPU_FC_AUTO = 0,
PCPU_FC_EMBED = 1,
PCPU_FC_PAGE = 2,
PCPU_FC_NR = 3,
};
struct seqcount {
unsigned int sequence;
};
typedef struct seqcount seqcount_t;
struct seqcount_raw_spinlock {
seqcount_t seqcount;
};
typedef struct seqcount_raw_spinlock seqcount_raw_spinlock_t;
struct hrtimer_cpu_base;
struct hrtimer_clock_base {
struct hrtimer_cpu_base *cpu_base;
unsigned int index;
clockid_t clockid;
seqcount_raw_spinlock_t seq;
struct hrtimer *running;
struct timerqueue_head active;
ktime_t (*get_time)();
ktime_t offset;
};
struct hrtimer_cpu_base {
raw_spinlock_t lock;
unsigned int cpu;
unsigned int active_bases;
unsigned int clock_was_set_seq;
unsigned int hres_active: 1;
unsigned int in_hrtirq: 1;
unsigned int hang_detected: 1;
unsigned int softirq_activated: 1;
unsigned int nr_events;
short unsigned int nr_retries;
short unsigned int nr_hangs;
unsigned int max_hang_time;
ktime_t expires_next;
struct hrtimer *next_timer;
long: 32;
ktime_t softirq_expires_next;
struct hrtimer *softirq_next_timer;
long: 32;
struct hrtimer_clock_base clock_base[8];
};
enum hrtimer_base_type {
HRTIMER_BASE_MONOTONIC = 0,
HRTIMER_BASE_REALTIME = 1,
HRTIMER_BASE_BOOTTIME = 2,
HRTIMER_BASE_TAI = 3,
HRTIMER_BASE_MONOTONIC_SOFT = 4,
HRTIMER_BASE_REALTIME_SOFT = 5,
HRTIMER_BASE_BOOTTIME_SOFT = 6,
HRTIMER_BASE_TAI_SOFT = 7,
HRTIMER_MAX_CLOCK_BASES = 8,
};
struct swait_queue_head {
raw_spinlock_t lock;
struct list_head task_list;
};
struct completion {
unsigned int done;
struct swait_queue_head wait;
};
enum pid_type {
PIDTYPE_PID = 0,
PIDTYPE_TGID = 1,
PIDTYPE_PGID = 2,
PIDTYPE_SID = 3,
PIDTYPE_MAX = 4,
};
struct pid_namespace;
struct upid {
int nr;
struct pid_namespace *ns;
};
struct pid {
refcount_t count;
unsigned int level;
spinlock_t lock;
struct hlist_head tasks[4];
struct hlist_head inodes;
wait_queue_head_t wait_pidfd;
struct callback_head rcu;
struct upid numbers[1];
};
enum node_states {
N_POSSIBLE = 0,
N_ONLINE = 1,
N_NORMAL_MEMORY = 2,
N_HIGH_MEMORY = 2,
N_MEMORY = 3,
N_CPU = 4,
N_GENERIC_INITIATOR = 5,
NR_NODE_STATES = 6,
};
union sigval {
int sival_int;
void *sival_ptr;
};
typedef union sigval sigval_t;
union __sifields {
struct {
__kernel_pid_t _pid;
__kernel_uid32_t _uid;
} _kill;
struct {
__kernel_timer_t _tid;
int _overrun;
sigval_t _sigval;
int _sys_private;
} _timer;
struct {
__kernel_pid_t _pid;
__kernel_uid32_t _uid;
sigval_t _sigval;
} _rt;
struct {
__kernel_pid_t _pid;
__kernel_uid32_t _uid;
int _status;
__kernel_clock_t _utime;
__kernel_clock_t _stime;
} _sigchld;
struct {
void *_addr;
union {
int _trapno;
short int _addr_lsb;
struct {
char _dummy_bnd[4];
void *_lower;
void *_upper;
} _addr_bnd;
struct {
char _dummy_pkey[4];
__u32 _pkey;
} _addr_pkey;
struct {
long unsigned int _data;
__u32 _type;
__u32 _flags;
} _perf;
};
} _sigfault;
struct {
long int _band;
int _fd;
} _sigpoll;
struct {
void *_call_addr;
int _syscall;
unsigned int _arch;
} _sigsys;
};
struct kernel_siginfo {
struct {
int si_signo;
int si_code;
int si_errno;
union __sifields _sifields;
};
};
enum {
MM_FILEPAGES = 0,
MM_ANONPAGES = 1,
MM_SWAPENTS = 2,
MM_SHMEMPAGES = 3,
NR_MM_COUNTERS = 4,
};
enum rseq_cs_flags_bit {
RSEQ_CS_FLAG_NO_RESTART_ON_PREEMPT_BIT = 0,
RSEQ_CS_FLAG_NO_RESTART_ON_SIGNAL_BIT = 1,
RSEQ_CS_FLAG_NO_RESTART_ON_MIGRATE_BIT = 2,
};
struct rseq {
__u32 cpu_id_start;
__u32 cpu_id;
__u64 rseq_cs;
__u32 flags;
long: 32;
long: 32;
long: 32;
};
enum {
TASK_COMM_LEN = 16,
};
enum perf_event_task_context {
perf_invalid_context = -1,
perf_hw_context = 0,
perf_sw_context = 1,
perf_nr_task_contexts = 2,
};
typedef _Bool bool;
struct rq;
struct rq_flags;
struct sched_class {
void (*enqueue_task)(struct rq *, struct task_struct *, int);
void (*dequeue_task)(struct rq *, struct task_struct *, int);
void (*yield_task)(struct rq *);
bool (*yield_to_task)(struct rq *, struct task_struct *);
void (*check_preempt_curr)(struct rq *, struct task_struct *, int);
struct task_struct * (*pick_next_task)(struct rq *);
void (*put_prev_task)(struct rq *, struct task_struct *);
void (*set_next_task)(struct rq *, struct task_struct *, bool);
int (*balance)(struct rq *, struct task_struct *, struct rq_flags *);
int (*select_task_rq)(struct task_struct *, int, int);
struct task_struct * (*pick_task)(struct rq *);
void (*migrate_task_rq)(struct task_struct *, int);
void (*task_woken)(struct rq *, struct task_struct *);
void (*set_cpus_allowed)(struct task_struct *, const struct cpumask *, u32);
void (*rq_online)(struct rq *);
void (*rq_offline)(struct rq *);
struct rq * (*find_lock_rq)(struct task_struct *, struct rq *);
void (*task_tick)(struct rq *, struct task_struct *, int);
void (*task_fork)(struct task_struct *);
void (*task_dead)(struct task_struct *);
void (*switched_from)(struct rq *, struct task_struct *);
void (*switched_to)(struct rq *, struct task_struct *);
void (*prio_changed)(struct rq *, struct task_struct *, int);
unsigned int (*get_rr_interval)(struct rq *, struct task_struct *);
void (*update_curr)(struct rq *);
};
typedef __kernel_uid32_t uid_t;
typedef struct {
uid_t val;
} kuid_t;
typedef unsigned int __kernel_gid32_t;
typedef __kernel_gid32_t gid_t;
typedef struct {
gid_t val;
} kgid_t;
struct kernel_cap_struct {
__u32 cap[2];
};
typedef struct kernel_cap_struct kernel_cap_t;
struct user_struct;
struct user_namespace;
struct ucounts;
struct group_info;
struct cred {
atomic_t usage;
kuid_t uid;
kgid_t gid;
kuid_t suid;
kgid_t sgid;
kuid_t euid;
kgid_t egid;
kuid_t fsuid;
kgid_t fsgid;
unsigned int securebits;
kernel_cap_t cap_inheritable;
kernel_cap_t cap_permitted;
kernel_cap_t cap_effective;
kernel_cap_t cap_bset;
kernel_cap_t cap_ambient;
unsigned char jit_keyring;
struct key *session_keyring;
struct key *process_keyring;
struct key *thread_keyring;
struct key *request_key_auth;
void *security;
struct user_struct *user;
struct user_namespace *user_ns;
struct ucounts *ucounts;
struct group_info *group_info;
union {
int non_rcu;
struct callback_head rcu;
};
};
enum rseq_event_mask_bits {
RSEQ_EVENT_PREEMPT_BIT = 0,
RSEQ_EVENT_SIGNAL_BIT = 1,
RSEQ_EVENT_MIGRATE_BIT = 2,
};
typedef signed char __s8;
typedef __s8 s8;
typedef long unsigned int __kernel_ulong_t;
typedef int __kernel_ssize_t;
typedef long long int __kernel_loff_t;
typedef unsigned int __poll_t;
typedef u32 __kernel_dev_t;
typedef __kernel_dev_t dev_t;
typedef short unsigned int umode_t;
typedef __kernel_loff_t loff_t;
typedef __kernel_ssize_t ssize_t;
typedef s32 int32_t;
typedef u32 uint32_t;
typedef u64 sector_t;
typedef u64 blkcnt_t;
typedef unsigned int gfp_t;
typedef unsigned int fmode_t;
typedef u32 phys_addr_t;
typedef phys_addr_t resource_size_t;
typedef int (*initcall_t)();
struct lock_class_key {};
struct fs_context;
struct fs_parameter_spec;
struct dentry;
struct super_block;
struct module;
struct file_system_type {
const char *name;
int fs_flags;
int (*init_fs_context)(struct fs_context *);
const struct fs_parameter_spec *parameters;
struct dentry * (*mount)(struct file_system_type *, int, const char *, void *);
void (*kill_sb)(struct super_block *);
struct module *owner;
struct file_system_type *next;
struct hlist_head fs_supers;
struct lock_class_key s_lock_key;
struct lock_class_key s_umount_key;
struct lock_class_key s_vfs_rename_key;
struct lock_class_key s_writers_key[3];
struct lock_class_key i_lock_key;
struct lock_class_key i_mutex_key;
struct lock_class_key invalidate_lock_key;
struct lock_class_key i_mutex_dir_key;
};
struct obs_kernel_param {
const char *str;
int (*setup_func)(char *);
int early;
};
struct resource {
resource_size_t start;
resource_size_t end;
const char *name;
long unsigned int flags;
long unsigned int desc;
struct resource *parent;
struct resource *sibling;
struct resource *child;
};
struct screen_info {
__u8 orig_x;
__u8 orig_y;
__u16 ext_mem_k;
__u16 orig_video_page;
__u8 orig_video_mode;
__u8 orig_video_cols;
__u8 flags;
__u8 unused2;
__u16 orig_video_ega_bx;
__u16 unused3;
__u8 orig_video_lines;
__u8 orig_video_isVGA;
__u16 orig_video_points;
__u16 lfb_width;
__u16 lfb_height;
__u16 lfb_depth;
__u32 lfb_base;
__u32 lfb_size;
__u16 cl_magic;
__u16 cl_offset;
__u16 lfb_linelength;
__u8 red_size;
__u8 red_pos;
__u8 green_size;
__u8 green_pos;
__u8 blue_size;
__u8 blue_pos;
__u8 rsvd_size;
__u8 rsvd_pos;
__u16 vesapm_seg;
__u16 vesapm_off;
__u16 pages;
__u16 vesa_attributes;
__u32 capabilities;
__u32 ext_lfb_base;
__u8 _reserved[2];
} __attribute__((packed));
struct qrwlock {
union {
atomic_t cnts;
struct {
u8 wlocked;
u8 __lstate[3];
};
};
arch_spinlock_t wait_lock;
};
typedef struct qrwlock arch_rwlock_t;
struct lockdep_map {};
struct ratelimit_state {
raw_spinlock_t lock;
int interval;
int burst;
int printed;
int missed;
long unsigned int begin;
long unsigned int flags;
};
typedef void *fl_owner_t;
struct file;
struct kiocb;
struct iov_iter;
struct io_comp_batch;
struct dir_context;
struct poll_table_struct;
struct vm_area_struct;
struct inode;
struct file_lock;
struct seq_file;
struct io_uring_cmd;
struct file_operations {
struct module *owner;
loff_t (*llseek)(struct file *, loff_t, int);
ssize_t (*read)(struct file *, char *, size_t, loff_t *);
ssize_t (*write)(struct file *, const char *, size_t, loff_t *);
ssize_t (*read_iter)(struct kiocb *, struct iov_iter *);
ssize_t (*write_iter)(struct kiocb *, struct iov_iter *);
int (*iopoll)(struct kiocb *, struct io_comp_batch *, unsigned int);
int (*iterate)(struct file *, struct dir_context *);
int (*iterate_shared)(struct file *, struct dir_context *);
__poll_t (*poll)(struct file *, struct poll_table_struct *);
long int (*unlocked_ioctl)(struct file *, unsigned int, long unsigned int);
long int (*compat_ioctl)(struct file *, unsigned int, long unsigned int);
int (*mmap)(struct file *, struct vm_area_struct *);
long unsigned int mmap_supported_flags;
int (*open)(struct inode *, struct file *);
int (*flush)(struct file *, fl_owner_t);
int (*release)(struct inode *, struct file *);
int (*fsync)(struct file *, loff_t, loff_t, int);
int (*fasync)(int, struct file *, int);
int (*lock)(struct file *, int, struct file_lock *);
ssize_t (*sendpage)(struct file *, struct page *, int, size_t, loff_t *, int);
long unsigned int (*get_unmapped_area)(struct file *, long unsigned int, long unsigned int, long unsigned int, long unsigned int);
int (*check_flags)(int);
int (*flock)(struct file *, int, struct file_lock *);
ssize_t (*splice_write)(struct pipe_inode_info *, struct file *, loff_t *, size_t, unsigned int);
ssize_t (*splice_read)(struct file *, loff_t *, struct pipe_inode_info *, size_t, unsigned int);
int (*setlease)(struct file *, long int, struct file_lock **, void **);
long int (*fallocate)(struct file *, int, loff_t, loff_t);
void (*show_fdinfo)(struct seq_file *, struct file *);
ssize_t (*copy_file_range)(struct file *, loff_t, struct file *, loff_t, size_t, unsigned int);
loff_t (*remap_file_range)(struct file *, loff_t, struct file *, loff_t, loff_t, unsigned int);
int (*fadvise)(struct file *, loff_t, loff_t, int);
int (*uring_cmd)(struct io_uring_cmd *, unsigned int);
int (*uring_cmd_iopoll)(struct io_uring_cmd *, struct io_comp_batch *, unsigned int);
};
struct cache_desc {
unsigned int waysize;
short unsigned int sets;
unsigned char ways;
unsigned char linesz;
unsigned char waybit;
unsigned char flags;
};
struct guest_info {
long unsigned int ases;
long unsigned int ases_dyn;
long long unsigned int options;
long long unsigned int options_dyn;
int tlbsize;
u8 conf;
u8 kscratch_mask;
};
struct cpuinfo_mips {
u64 asid_cache;
long unsigned int ases;
long: 32;
long long unsigned int options;
unsigned int udelay_val;
unsigned int processor_id;
unsigned int fpu_id;
unsigned int fpu_csr31;
unsigned int fpu_msk31;
unsigned int msa_id;
unsigned int cputype;
int isa_level;
int tlbsize;
int tlbsizevtlb;
int tlbsizeftlbsets;
int tlbsizeftlbways;
struct cache_desc icache;
struct cache_desc dcache;
struct cache_desc vcache;
struct cache_desc scache;
struct cache_desc tcache;
int srsets;
int package;
unsigned int globalnumber;
void *data;
unsigned int watch_reg_count;
unsigned int watch_reg_use_cnt;
u16 watch_reg_masks[4];
unsigned int kscratch_mask;
unsigned int writecombine;
unsigned int htw_seq;
struct guest_info guest;
unsigned int gtoffset_mask;
unsigned int guestid_mask;
unsigned int guestid_cache;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct seq_operations;
struct seq_file {
char *buf;
size_t size;
size_t from;
size_t count;
size_t pad_until;
long: 32;
loff_t index;
loff_t read_pos;
struct mutex lock;
const struct seq_operations *op;
int poll_event;
const struct file *file;
void *private;
};
typedef __s64 time64_t;
struct timespec64 {
time64_t tv_sec;
long int tv_nsec;
long: 32;
};
typedef struct {
s64 counter;
} atomic64_t;
struct static_call_key {
void *func;
};
struct pt_regs {
long unsigned int pad0[8];
long unsigned int regs[32];
long unsigned int cp0_status;
long unsigned int hi;
long unsigned int lo;
long unsigned int cp0_badvaddr;
long unsigned int cp0_cause;
long unsigned int cp0_epc;
long unsigned int __last[0];
};
typedef struct {
long unsigned int pte;
} pte_t;
typedef struct page *pgtable_t;
struct address_space;
struct page_pool;
struct dev_pagemap;
struct page {
long unsigned int flags;
union {
struct {
union {
struct list_head lru;
struct {
void *__filler;
unsigned int mlock_count;
};
struct list_head buddy_list;
struct list_head pcp_list;
};
struct address_space *mapping;
long unsigned int index;
long unsigned int private;
};
struct {
long unsigned int pp_magic;
struct page_pool *pp;
long unsigned int _pp_mapping_pad;
long unsigned int dma_addr;
union {
long unsigned int dma_addr_upper;
atomic_long_t pp_frag_count;
};
};
struct {
long unsigned int compound_head;
unsigned char compound_dtor;
unsigned char compound_order;
atomic_t compound_mapcount;
atomic_t compound_pincount;
};
struct {
long unsigned int _compound_pad_1;
long unsigned int _compound_pad_2;
struct list_head deferred_list;
};
struct {
long unsigned int _pt_pad_1;
pgtable_t pmd_huge_pte;
long unsigned int _pt_pad_2;
union {
struct mm_struct *pt_mm;
atomic_t pt_frag_refcount;
};
spinlock_t ptl;
};
struct {
struct dev_pagemap *pgmap;
void *zone_device_data;
};
struct callback_head callback_head;
};
union {
atomic_t _mapcount;
unsigned int page_type;
};
atomic_t _refcount;
};
typedef struct {
long unsigned int pgd;
} pgd_t;
typedef struct {
long unsigned int pgprot;
} pgprot_t;
struct plat_smp_ops {
void (*send_ipi_single)(int, unsigned int);
void (*send_ipi_mask)(const struct cpumask *, unsigned int);
void (*init_secondary)();
void (*smp_finish)();
int (*boot_secondary)(int, struct task_struct *);
void (*smp_setup)();
void (*prepare_cpus)(unsigned int);
void (*prepare_boot_cpu)();
};
typedef struct {
arch_rwlock_t raw_lock;
} rwlock_t;
struct seqcount_spinlock {
seqcount_t seqcount;
};
typedef struct seqcount_spinlock seqcount_spinlock_t;
typedef struct {
seqcount_spinlock_t seqcount;
spinlock_t lock;
} seqlock_t;
struct static_key {
atomic_t enabled;
};
struct mm_rss_stat {
atomic_long_t count[4];
};
struct kref {
refcount_t refcount;
};
typedef struct {} lockdep_map_p;
struct maple_tree {
union {
spinlock_t ma_lock;
lockdep_map_p ma_external_lock;
};
void *ma_root;
unsigned int ma_flags;
};
struct rw_semaphore {
atomic_long_t count;
atomic_long_t owner;
raw_spinlock_t wait_lock;
struct list_head wait_list;
};
typedef struct {
union {
u64 asid[8];
atomic64_t mmid;
};
void *vdso;
spinlock_t bd_emupage_lock;
long unsigned int *bd_emupage_allocmap;
wait_queue_head_t bd_emupage_queue;
} mm_context_t;
struct xol_area;
struct uprobes_state {
struct xol_area *xol_area;
};
struct work_struct;
typedef void (*work_func_t)(struct work_struct *);
struct work_struct {
atomic_long_t data;
struct list_head entry;
work_func_t func;
};
struct linux_binfmt;
struct kioctx_table;
struct mm_struct {
struct {
struct maple_tree mm_mt;
long unsigned int (*get_unmapped_area)(struct file *, long unsigned int, long unsigned int, long unsigned int, long unsigned int);
long unsigned int mmap_base;
long unsigned int mmap_legacy_base;
long unsigned int task_size;
pgd_t *pgd;
atomic_t membarrier_state;
atomic_t mm_users;
atomic_t mm_count;
atomic_long_t pgtables_bytes;
int map_count;
spinlock_t page_table_lock;
struct rw_semaphore mmap_lock;
struct list_head mmlist;
long unsigned int hiwater_rss;
long unsigned int hiwater_vm;
long unsigned int total_vm;
long unsigned int locked_vm;
long: 32;
atomic64_t pinned_vm;
long unsigned int data_vm;
long unsigned int exec_vm;
long unsigned int stack_vm;
long unsigned int def_flags;
seqcount_t write_protect_seq;
spinlock_t arg_lock;
long unsigned int start_code;
long unsigned int end_code;
long unsigned int start_data;
long unsigned int end_data;
long unsigned int start_brk;
long unsigned int brk;
long unsigned int start_stack;
long unsigned int arg_start;
long unsigned int arg_end;
long unsigned int env_start;
long unsigned int env_end;
long unsigned int saved_auxv[44];
struct mm_rss_stat rss_stat;
struct linux_binfmt *binfmt;
mm_context_t context;
long unsigned int flags;
spinlock_t ioctx_lock;
struct kioctx_table *ioctx_table;
struct user_namespace *user_ns;
struct file *exe_file;
atomic_t tlb_flush_pending;
struct uprobes_state uprobes_state;
struct work_struct async_put_work;
long: 32;
};
long unsigned int cpu_bitmap[0];
};
struct workqueue_struct;
struct delayed_work {
struct work_struct work;
struct timer_list timer;
struct workqueue_struct *wq;
int cpu;
};
struct rcu_segcblist {
struct callback_head *head;
struct callback_head **tails[4];
long unsigned int gp_seq[4];
long int len;
long int seglen[4];
u8 flags;
};
struct srcu_node;
struct srcu_struct;
struct srcu_data {
long unsigned int srcu_lock_count[2];
long unsigned int srcu_unlock_count[2];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
spinlock_t lock;
struct rcu_segcblist srcu_cblist;
long unsigned int srcu_gp_seq_needed;
long unsigned int srcu_gp_seq_needed_exp;
bool srcu_cblist_invoking;
struct timer_list delay_work;
struct work_struct work;
struct callback_head srcu_barrier_head;
struct srcu_node *mynode;
long unsigned int grpmask;
int cpu;
struct srcu_struct *ssp;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct srcu_node {
spinlock_t lock;
long unsigned int srcu_have_cbs[4];
long unsigned int srcu_data_have_cbs[4];
long unsigned int srcu_gp_seq_needed_exp;
struct srcu_node *srcu_parent;
int grplo;
int grphi;
};
struct srcu_struct {
struct srcu_node *node;
struct srcu_node *level[2];
int srcu_size_state;
struct mutex srcu_cb_mutex;
spinlock_t lock;
struct mutex srcu_gp_mutex;
unsigned int srcu_idx;
long unsigned int srcu_gp_seq;
long unsigned int srcu_gp_seq_needed;
long unsigned int srcu_gp_seq_needed_exp;
long unsigned int srcu_gp_start;
long unsigned int srcu_last_gp_end;
long unsigned int srcu_size_jiffies;
long unsigned int srcu_n_lock_retries;
long unsigned int srcu_n_exp_nodelay;
struct srcu_data *sda;
bool sda_is_static;
long unsigned int srcu_barrier_seq;
struct mutex srcu_barrier_mutex;
struct completion srcu_barrier_completion;
atomic_t srcu_barrier_cpu_cnt;
long unsigned int reschedule_jiffies;
long unsigned int reschedule_count;
struct delayed_work work;
struct lockdep_map dep_map;
};
struct arch_uprobe_task {
long unsigned int saved_trap_nr;
};
enum uprobe_task_state {
UTASK_RUNNING = 0,
UTASK_SSTEP = 1,
UTASK_SSTEP_ACK = 2,
UTASK_SSTEP_TRAPPED = 3,
};
struct uprobe;
struct return_instance;
struct uprobe_task {
enum uprobe_task_state state;
union {
struct {
struct arch_uprobe_task autask;
long unsigned int vaddr;
};
struct {
struct callback_head dup_xol_work;
long unsigned int dup_xol_addr;
};
};
struct uprobe *active_uprobe;
long unsigned int xol_vaddr;
struct return_instance *return_instances;
unsigned int depth;
};
struct return_instance {
struct uprobe *uprobe;
long unsigned int func;
long unsigned int stack;
long unsigned int orig_ret_vaddr;
bool chained;
struct return_instance *next;
};
struct xarray {
spinlock_t xa_lock;
gfp_t xa_flags;
void *xa_head;
};
typedef u32 errseq_t;
struct address_space_operations;
struct address_space {
struct inode *host;
struct xarray i_pages;
struct rw_semaphore invalidate_lock;
gfp_t gfp_mask;
atomic_t i_mmap_writable;
struct rb_root_cached i_mmap;
struct rw_semaphore i_mmap_rwsem;
long unsigned int nrpages;
long unsigned int writeback_index;
const struct address_space_operations *a_ops;
long unsigned int flags;
errseq_t wb_err;
spinlock_t private_lock;
struct list_head private_list;
void *private_data;
};
struct vmem_altmap {
long unsigned int base_pfn;
const long unsigned int end_pfn;
const long unsigned int reserve;
long unsigned int free;
long unsigned int align;
long unsigned int alloc;
};
struct percpu_ref_data;
struct percpu_ref {
long unsigned int percpu_count_ptr;
struct percpu_ref_data *data;
};
enum memory_type {
MEMORY_DEVICE_PRIVATE = 1,
MEMORY_DEVICE_COHERENT = 2,
MEMORY_DEVICE_FS_DAX = 3,
MEMORY_DEVICE_GENERIC = 4,
MEMORY_DEVICE_PCI_P2PDMA = 5,
};
struct range {
u64 start;
u64 end;
};
struct dev_pagemap_ops;
struct dev_pagemap {
struct vmem_altmap altmap;
struct percpu_ref ref;
struct completion done;
enum memory_type type;
unsigned int flags;
long unsigned int vmemmap_shift;
const struct dev_pagemap_ops *ops;
void *owner;
int nr_range;
union {
struct range range;
struct range ranges[0];
};
};
struct folio {
union {
struct {
long unsigned int flags;
union {
struct list_head lru;
struct {
void *__filler;
unsigned int mlock_count;
};
};
struct address_space *mapping;
long unsigned int index;
void *private;
atomic_t _mapcount;
atomic_t _refcount;
};
struct page page;
};
long unsigned int _flags_1;
long unsigned int __head;
unsigned char _folio_dtor;
unsigned char _folio_order;
atomic_t _total_mapcount;
atomic_t _pincount;
};
struct vfsmount;
struct path {
struct vfsmount *mnt;
struct dentry *dentry;
};
struct fown_struct {
rwlock_t lock;
struct pid *pid;
enum pid_type pid_type;
kuid_t uid;
kuid_t euid;
int signum;
};
struct file_ra_state {
long unsigned int start;
unsigned int size;
unsigned int async_size;
unsigned int ra_pages;
unsigned int mmap_miss;
long: 32;
loff_t prev_pos;
};
struct file {
union {
struct llist_node f_llist;
struct callback_head f_rcuhead;
unsigned int f_iocb_flags;
};
struct path f_path;
struct inode *f_inode;
const struct file_operations *f_op;
spinlock_t f_lock;
atomic_long_t f_count;
unsigned int f_flags;
fmode_t f_mode;
struct mutex f_pos_lock;
loff_t f_pos;
struct fown_struct f_owner;
const struct cred *f_cred;
struct file_ra_state f_ra;
u64 f_version;
void *f_security;
void *private_data;
struct hlist_head *f_ep;
struct address_space *f_mapping;
errseq_t f_wb_err;
errseq_t f_sb_err;
};
struct vm_userfaultfd_ctx {};
struct anon_vma_name {
struct kref kref;
char name[0];
};
struct anon_vma;
struct vm_operations_struct;
struct vm_area_struct {
long unsigned int vm_start;
long unsigned int vm_end;
struct mm_struct *vm_mm;
pgprot_t vm_page_prot;
long unsigned int vm_flags;
union {
struct {
struct rb_node rb;
long unsigned int rb_subtree_last;
} shared;
struct anon_vma_name *anon_name;
};
struct list_head anon_vma_chain;
struct anon_vma *anon_vma;
const struct vm_operations_struct *vm_ops;
long unsigned int vm_pgoff;
struct file *vm_file;
void *vm_private_data;
atomic_long_t swap_readahead_info;
struct vm_userfaultfd_ctx vm_userfaultfd_ctx;
};
typedef unsigned int vm_fault_t;
enum page_entry_size {
PE_SIZE_PTE = 0,
PE_SIZE_PMD = 1,
PE_SIZE_PUD = 2,
};
struct vm_fault;
struct vm_operations_struct {
void (*open)(struct vm_area_struct *);
void (*close)(struct vm_area_struct *);
int (*may_split)(struct vm_area_struct *, long unsigned int);
int (*mremap)(struct vm_area_struct *);
int (*mprotect)(struct vm_area_struct *, long unsigned int, long unsigned int, long unsigned int);
vm_fault_t (*fault)(struct vm_fault *);
vm_fault_t (*huge_fault)(struct vm_fault *, enum page_entry_size);
vm_fault_t (*map_pages)(struct vm_fault *, long unsigned int, long unsigned int);
long unsigned int (*pagesize)(struct vm_area_struct *);
vm_fault_t (*page_mkwrite)(struct vm_fault *);
vm_fault_t (*pfn_mkwrite)(struct vm_fault *);
int (*access)(struct vm_area_struct *, long unsigned int, void *, int, int);
const char * (*name)(struct vm_area_struct *);
struct page * (*find_special_page)(struct vm_area_struct *, long unsigned int);
};
enum fault_flag {
FAULT_FLAG_WRITE = 1,
FAULT_FLAG_MKWRITE = 2,
FAULT_FLAG_ALLOW_RETRY = 4,
FAULT_FLAG_RETRY_NOWAIT = 8,
FAULT_FLAG_KILLABLE = 16,
FAULT_FLAG_TRIED = 32,
FAULT_FLAG_USER = 64,
FAULT_FLAG_REMOTE = 128,
FAULT_FLAG_INSTRUCTION = 256,
FAULT_FLAG_INTERRUPTIBLE = 512,
FAULT_FLAG_UNSHARE = 1024,
FAULT_FLAG_ORIG_PTE_VALID = 2048,
};
typedef struct {
pgd_t pgd;
} p4d_t;
typedef struct {
p4d_t p4d;
} pud_t;
typedef struct {
pud_t pud;
} pmd_t;
struct vm_fault {
const struct {
struct vm_area_struct *vma;
gfp_t gfp_mask;
long unsigned int pgoff;
long unsigned int address;
long unsigned int real_address;
};
enum fault_flag flags;
pmd_t *pmd;
pud_t *pud;
union {
pte_t orig_pte;
pmd_t orig_pmd;
};
struct page *cow_page;
struct page *page;
pte_t *pte;
spinlock_t *ptl;
pgtable_t prealloc_pte;
};
enum migratetype {
MIGRATE_UNMOVABLE = 0,
MIGRATE_MOVABLE = 1,
MIGRATE_RECLAIMABLE = 2,
MIGRATE_PCPTYPES = 3,
MIGRATE_HIGHATOMIC = 3,
MIGRATE_TYPES = 4,
};
enum zone_stat_item {
NR_FREE_PAGES = 0,
NR_ZONE_LRU_BASE = 1,
NR_ZONE_INACTIVE_ANON = 1,
NR_ZONE_ACTIVE_ANON = 2,
NR_ZONE_INACTIVE_FILE = 3,
NR_ZONE_ACTIVE_FILE = 4,
NR_ZONE_UNEVICTABLE = 5,
NR_ZONE_WRITE_PENDING = 6,
NR_MLOCK = 7,
NR_BOUNCE = 8,
NR_FREE_CMA_PAGES = 9,
NR_VM_ZONE_STAT_ITEMS = 10,
};
enum node_stat_item {
NR_LRU_BASE = 0,
NR_INACTIVE_ANON = 0,
NR_ACTIVE_ANON = 1,
NR_INACTIVE_FILE = 2,
NR_ACTIVE_FILE = 3,
NR_UNEVICTABLE = 4,
NR_SLAB_RECLAIMABLE_B = 5,
NR_SLAB_UNRECLAIMABLE_B = 6,
NR_ISOLATED_ANON = 7,
NR_ISOLATED_FILE = 8,
WORKINGSET_NODES = 9,
WORKINGSET_REFAULT_BASE = 10,
WORKINGSET_REFAULT_ANON = 10,
WORKINGSET_REFAULT_FILE = 11,
WORKINGSET_ACTIVATE_BASE = 12,
WORKINGSET_ACTIVATE_ANON = 12,
WORKINGSET_ACTIVATE_FILE = 13,
WORKINGSET_RESTORE_BASE = 14,
WORKINGSET_RESTORE_ANON = 14,
WORKINGSET_RESTORE_FILE = 15,
WORKINGSET_NODERECLAIM = 16,
NR_ANON_MAPPED = 17,
NR_FILE_MAPPED = 18,
NR_FILE_PAGES = 19,
NR_FILE_DIRTY = 20,
NR_WRITEBACK = 21,
NR_WRITEBACK_TEMP = 22,
NR_SHMEM = 23,
NR_SHMEM_THPS = 24,
NR_SHMEM_PMDMAPPED = 25,
NR_FILE_THPS = 26,
NR_FILE_PMDMAPPED = 27,
NR_ANON_THPS = 28,
NR_VMSCAN_WRITE = 29,
NR_VMSCAN_IMMEDIATE = 30,
NR_DIRTIED = 31,
NR_WRITTEN = 32,
NR_THROTTLED_WRITTEN = 33,
NR_KERNEL_MISC_RECLAIMABLE = 34,
NR_FOLL_PIN_ACQUIRED = 35,
NR_FOLL_PIN_RELEASED = 36,
NR_KERNEL_STACK_KB = 37,
NR_PAGETABLE = 38,
NR_SECONDARY_PAGETABLE = 39,
NR_SWAPCACHE = 40,
NR_VM_NODE_STAT_ITEMS = 41,
};
enum lru_list {
LRU_INACTIVE_ANON = 0,
LRU_ACTIVE_ANON = 1,
LRU_INACTIVE_FILE = 2,
LRU_ACTIVE_FILE = 3,
LRU_UNEVICTABLE = 4,
NR_LRU_LISTS = 5,
};
enum vmscan_throttle_state {
VMSCAN_THROTTLE_WRITEBACK = 0,
VMSCAN_THROTTLE_ISOLATED = 1,
VMSCAN_THROTTLE_NOPROGRESS = 2,
VMSCAN_THROTTLE_CONGESTED = 3,
NR_VMSCAN_THROTTLE = 4,
};
enum zone_watermarks {
WMARK_MIN = 0,
WMARK_LOW = 1,
WMARK_HIGH = 2,
WMARK_PROMO = 3,
NR_WMARK = 4,
};
enum {
ZONELIST_FALLBACK = 0,
MAX_ZONELISTS = 1,
};
struct tracepoint_func {
void *func;
void *data;
int prio;
};
struct tracepoint {
const char *name;
struct static_key key;
struct static_call_key *static_call_key;
void *static_call_tramp;
void *iterator;
int (*regfunc)();
void (*unregfunc)();
struct tracepoint_func *funcs;
};
typedef struct tracepoint * const tracepoint_ptr_t;
struct bpf_raw_event_map {
struct tracepoint *tp;
void *bpf_func;
u32 num_args;
u32 writable_size;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef void percpu_ref_func_t(struct percpu_ref *);
struct percpu_ref_data {
atomic_long_t count;
percpu_ref_func_t *release;
percpu_ref_func_t *confirm_switch;
bool force_atomic: 1;
bool allow_reinit: 1;
struct callback_head rcu;
struct percpu_ref *ref;
};
struct mem_cgroup;
struct shrink_control {
gfp_t gfp_mask;
int nid;
long unsigned int nr_to_scan;
long unsigned int nr_scanned;
struct mem_cgroup *memcg;
};
struct shrinker {
long unsigned int (*count_objects)(struct shrinker *, struct shrink_control *);
long unsigned int (*scan_objects)(struct shrinker *, struct shrink_control *);
long int batch;
int seeks;
unsigned int flags;
struct list_head list;
atomic_long_t *nr_deferred;
};
struct rlimit {
__kernel_ulong_t rlim_cur;
__kernel_ulong_t rlim_max;
};
struct idr {
struct xarray idr_rt;
unsigned int idr_base;
unsigned int idr_next;
};
struct proc_ns_operations;
struct ns_common {
atomic_long_t stashed;
const struct proc_ns_operations *ops;
unsigned int inum;
refcount_t count;
};
struct kmem_cache;
struct pid_namespace {
struct idr idr;
struct callback_head rcu;
unsigned int pid_allocated;
struct task_struct *child_reaper;
struct kmem_cache *pid_cachep;
unsigned int level;
struct pid_namespace *parent;
struct user_namespace *user_ns;
struct ucounts *ucounts;
int reboot;
struct ns_common ns;
};
typedef void __signalfn_t(int);
typedef __signalfn_t *__sighandler_t;
struct sigaction {
unsigned int sa_flags;
__sighandler_t sa_handler;
sigset_t sa_mask;
};
struct k_sigaction {
struct sigaction sa;
};
struct cpu_itimer {
u64 expires;
u64 incr;
};
struct task_cputime_atomic {
atomic64_t utime;
atomic64_t stime;
atomic64_t sum_exec_runtime;
};
struct thread_group_cputimer {
struct task_cputime_atomic cputime_atomic;
};
struct core_state;
struct tty_struct;
struct signal_struct {
refcount_t sigcnt;
atomic_t live;
int nr_threads;
int quick_threads;
struct list_head thread_head;
wait_queue_head_t wait_chldexit;
struct task_struct *curr_target;
struct sigpending shared_pending;
struct hlist_head multiprocess;
int group_exit_code;
int notify_count;
struct task_struct *group_exec_task;
int group_stop_count;
unsigned int flags;
struct core_state *core_state;
unsigned int is_child_subreaper: 1;
unsigned int has_child_subreaper: 1;
int posix_timer_id;
struct list_head posix_timers;
long: 32;
struct hrtimer real_timer;
ktime_t it_real_incr;
struct cpu_itimer it[2];
struct thread_group_cputimer cputimer;
struct posix_cputimers posix_cputimers;
struct pid *pids[4];
struct pid *tty_old_pgrp;
int leader;
struct tty_struct *tty;
seqlock_t stats_lock;
long: 32;
u64 utime;
u64 stime;
u64 cutime;
u64 cstime;
u64 gtime;
u64 cgtime;
struct prev_cputime prev_cputime;
long unsigned int nvcsw;
long unsigned int nivcsw;
long unsigned int cnvcsw;
long unsigned int cnivcsw;
long unsigned int min_flt;
long unsigned int maj_flt;
long unsigned int cmin_flt;
long unsigned int cmaj_flt;
long unsigned int inblock;
long unsigned int oublock;
long unsigned int cinblock;
long unsigned int coublock;
long unsigned int maxrss;
long unsigned int cmaxrss;
struct task_io_accounting ioac;
long long unsigned int sum_sched_runtime;
struct rlimit rlim[16];
bool oom_flag_origin;
short int oom_score_adj;
short int oom_score_adj_min;
struct mm_struct *oom_mm;
struct mutex cred_guard_mutex;
struct rw_semaphore exec_update_lock;
};
typedef int32_t key_serial_t;
typedef uint32_t key_perm_t;
struct key_type;
struct key_tag;
struct keyring_index_key {
long unsigned int hash;
union {
struct {
u16 desc_len;
char desc[2];
};
long unsigned int x;
};
struct key_type *type;
struct key_tag *domain_tag;
const char *description;
};
union key_payload {
void *rcu_data0;
void *data[4];
};
struct assoc_array_ptr;
struct assoc_array {
struct assoc_array_ptr *root;
long unsigned int nr_leaves_on_tree;
};
struct key_user;
struct key_restriction;
struct key {
refcount_t usage;
key_serial_t serial;
union {
struct list_head graveyard_link;
struct rb_node serial_node;
};
struct rw_semaphore sem;
struct key_user *user;
void *security;
union {
time64_t expiry;
time64_t revoked_at;
};
time64_t last_used_at;
kuid_t uid;
kgid_t gid;
key_perm_t perm;
short unsigned int quotalen;
short unsigned int datalen;
short int state;
long unsigned int flags;
union {
struct keyring_index_key index_key;
struct {
long unsigned int hash;
long unsigned int len_desc;
struct key_type *type;
struct key_tag *domain_tag;
char *description;
};
};
union {
union key_payload payload;
struct {
struct list_head name_link;
struct assoc_array keys;
};
};
struct key_restriction *restrict_link;
};
struct uts_namespace;
struct ipc_namespace;
struct mnt_namespace;
struct net;
struct time_namespace;
struct cgroup_namespace;
struct nsproxy {
atomic_t count;
struct uts_namespace *uts_ns;
struct ipc_namespace *ipc_ns;
struct mnt_namespace *mnt_ns;
struct pid_namespace *pid_ns_for_children;
struct net *net_ns;
struct time_namespace *time_ns;
struct time_namespace *time_ns_for_children;
struct cgroup_namespace *cgroup_ns;
};
struct sighand_struct {
spinlock_t siglock;
refcount_t count;
wait_queue_head_t signalfd_wqh;
struct k_sigaction action[128];
};
struct io_context {
atomic_long_t refcount;
atomic_t active_ref;
short unsigned int ioprio;
};
struct dev_pagemap_ops {
void (*page_free)(struct page *);
vm_fault_t (*migrate_to_ram)(struct vm_fault *);
int (*memory_failure)(struct dev_pagemap *, long unsigned int, long unsigned int, int);
};
struct hlist_bl_node;
struct hlist_bl_head {
struct hlist_bl_node *first;
};
struct hlist_bl_node {
struct hlist_bl_node *next;
struct hlist_bl_node **pprev;
};
struct lockref {
union {
struct {
spinlock_t lock;
int count;
};
};
};
struct qstr {
union {
struct {
u32 hash;
u32 len;
};
u64 hash_len;
};
const unsigned char *name;
long: 32;
};
struct dentry_operations;
struct dentry {
unsigned int d_flags;
seqcount_spinlock_t d_seq;
struct hlist_bl_node d_hash;
struct dentry *d_parent;
long: 32;
struct qstr d_name;
struct inode *d_inode;
unsigned char d_iname[36];
struct lockref d_lockref;
const struct dentry_operations *d_op;
struct super_block *d_sb;
long unsigned int d_time;
void *d_fsdata;
union {
struct list_head d_lru;
wait_queue_head_t *d_wait;
};
struct list_head d_child;
struct list_head d_subdirs;
union {
struct hlist_node d_alias;
struct hlist_bl_node d_in_lookup_hash;
struct callback_head d_rcu;
} d_u;
};
struct posix_acl;
struct inode_operations;
struct file_lock_context;
struct cdev;
struct fsnotify_mark_connector;
struct inode {
umode_t i_mode;
short unsigned int i_opflags;
kuid_t i_uid;
kgid_t i_gid;
unsigned int i_flags;
struct posix_acl *i_acl;
struct posix_acl *i_default_acl;
const struct inode_operations *i_op;
struct super_block *i_sb;
struct address_space *i_mapping;
void *i_security;
long unsigned int i_ino;
union {
const unsigned int i_nlink;
unsigned int __i_nlink;
};
dev_t i_rdev;
long: 32;
loff_t i_size;
struct timespec64 i_atime;
struct timespec64 i_mtime;
struct timespec64 i_ctime;
spinlock_t i_lock;
short unsigned int i_bytes;
u8 i_blkbits;
u8 i_write_hint;
blkcnt_t i_blocks;
seqcount_t i_size_seqcount;
long unsigned int i_state;
struct rw_semaphore i_rwsem;
long unsigned int dirtied_when;
long unsigned int dirtied_time_when;
struct hlist_node i_hash;
struct list_head i_io_list;
struct list_head i_lru;
struct list_head i_sb_list;
struct list_head i_wb_list;
union {
struct hlist_head i_dentry;
struct callback_head i_rcu;
};
long: 32;
atomic64_t i_version;
atomic64_t i_sequence;
atomic_t i_count;
atomic_t i_dio_count;
atomic_t i_writecount;
atomic_t i_readcount;
union {
const struct file_operations *i_fop;
void (*free_inode)(struct inode *);
};
struct file_lock_context *i_flctx;
struct address_space i_data;
struct list_head i_devices;
union {
struct pipe_inode_info *i_pipe;
struct cdev *i_cdev;
char *i_link;
unsigned int i_dir_seq;
};
__u32 i_generation;
__u32 i_fsnotify_mask;
struct fsnotify_mark_connector *i_fsnotify_marks;
void *i_private;
};
struct dentry_operations {
int (*d_revalidate)(struct dentry *, unsigned int);
int (*d_weak_revalidate)(struct dentry *, unsigned int);
int (*d_hash)(const struct dentry *, struct qstr *);
int (*d_compare)(const struct dentry *, unsigned int, const char *, const struct qstr *);
int (*d_delete)(const struct dentry *);
int (*d_init)(struct dentry *);
void (*d_release)(struct dentry *);
void (*d_prune)(struct dentry *);
void (*d_iput)(struct dentry *, struct inode *);
char * (*d_dname)(struct dentry *, char *, int);
struct vfsmount * (*d_automount)(struct path *);
int (*d_manage)(const struct path *, bool);
struct dentry * (*d_real)(struct dentry *, const struct inode *);
long: 32;
long: 32;
long: 32;
};
typedef long long int qsize_t;
struct quota_format_type;
struct mem_dqinfo {
struct quota_format_type *dqi_format;
int dqi_fmt_id;
struct list_head dqi_dirty_list;
long unsigned int dqi_flags;
unsigned int dqi_bgrace;
unsigned int dqi_igrace;
long: 32;
qsize_t dqi_max_spc_limit;
qsize_t dqi_max_ino_limit;
void *dqi_priv;
long: 32;
};
struct quota_format_ops;
struct quota_info {
unsigned int flags;
struct rw_semaphore dqio_sem;
struct inode *files[3];
long: 32;
struct mem_dqinfo info[3];
const struct quota_format_ops *ops[3];
long: 32;
};
struct rcu_sync {
int gp_state;
int gp_count;
wait_queue_head_t gp_wait;
struct callback_head cb_head;
};
struct rcuwait {
struct task_struct *task;
};
struct percpu_rw_semaphore {
struct rcu_sync rss;
unsigned int *read_count;
struct rcuwait writer;
wait_queue_head_t waiters;
atomic_t block;
};
struct sb_writers {
int frozen;
wait_queue_head_t wait_unfrozen;
struct percpu_rw_semaphore rw_sem[3];
};
typedef struct {
__u8 b[16];
} uuid_t;
struct list_lru_node;
struct list_lru {
struct list_lru_node *node;
};
struct super_operations;
struct dquot_operations;
struct quotactl_ops;
struct export_operations;
struct xattr_handler;
struct block_device;
struct mtd_info;
struct super_block {
struct list_head s_list;
dev_t s_dev;
unsigned char s_blocksize_bits;
long unsigned int s_blocksize;
long: 32;
loff_t s_maxbytes;
struct file_system_type *s_type;
const struct super_operations *s_op;
const struct dquot_operations *dq_op;
const struct quotactl_ops *s_qcop;
const struct export_operations *s_export_op;
long unsigned int s_flags;
long unsigned int s_iflags;
long unsigned int s_magic;
struct dentry *s_root;
struct rw_semaphore s_umount;
int s_count;
atomic_t s_active;
void *s_security;
const struct xattr_handler **s_xattr;
struct hlist_bl_head s_roots;
struct list_head s_mounts;
struct block_device *s_bdev;
struct backing_dev_info *s_bdi;
struct mtd_info *s_mtd;
struct hlist_node s_instances;
unsigned int s_quota_types;
long: 32;
struct quota_info s_dquot;
struct sb_writers s_writers;
void *s_fs_info;
u32 s_time_gran;
long: 32;
time64_t s_time_min;
time64_t s_time_max;
__u32 s_fsnotify_mask;
struct fsnotify_mark_connector *s_fsnotify_marks;
char s_id[32];
uuid_t s_uuid;
unsigned int s_max_links;
fmode_t s_mode;
struct mutex s_vfs_rename_mutex;
const char *s_subtype;
const struct dentry_operations *s_d_op;
struct shrinker s_shrink;
atomic_long_t s_remove_count;
atomic_long_t s_fsnotify_connectors;
int s_readonly_remount;
errseq_t s_wb_err;
struct workqueue_struct *s_dio_done_wq;
struct hlist_head s_pins;
struct user_namespace *s_user_ns;
struct list_lru s_dentry_lru;
struct list_lru s_inode_lru;
struct callback_head rcu;
struct work_struct destroy_work;
struct mutex s_sync_lock;
int s_stack_depth;
spinlock_t s_inode_list_lock;
struct list_head s_inodes;
spinlock_t s_inode_wblist_lock;
struct list_head s_inodes_wb;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct vfsmount {
struct dentry *mnt_root;
struct super_block *mnt_sb;
int mnt_flags;
struct user_namespace *mnt_userns;
};
struct kstat {
u32 result_mask;
umode_t mode;
unsigned int nlink;
uint32_t blksize;
u64 attributes;
u64 attributes_mask;
u64 ino;
dev_t dev;
dev_t rdev;
kuid_t uid;
kgid_t gid;
loff_t size;
struct timespec64 atime;
struct timespec64 mtime;
struct timespec64 ctime;
struct timespec64 btime;
u64 blocks;
u64 mnt_id;
u32 dio_mem_align;
u32 dio_offset_align;
};
struct list_lru_one {
struct list_head list;
long int nr_items;
};
struct list_lru_node {
spinlock_t lock;
struct list_lru_one lru;
long int nr_items;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum migrate_mode {
MIGRATE_ASYNC = 0,
MIGRATE_SYNC_LIGHT = 1,
MIGRATE_SYNC = 2,
MIGRATE_SYNC_NO_COPY = 3,
};
struct exception_table_entry {
long unsigned int insn;
long unsigned int nextinsn;
};
struct key_tag {
struct callback_head rcu;
refcount_t usage;
bool removed;
};
typedef int (*request_key_actor_t)(struct key *, void *);
struct key_preparsed_payload;
struct key_match_data;
struct kernel_pkey_params;
struct kernel_pkey_query;
struct key_type {
const char *name;
size_t def_datalen;
unsigned int flags;
int (*vet_description)(const char *);
int (*preparse)(struct key_preparsed_payload *);
void (*free_preparse)(struct key_preparsed_payload *);
int (*instantiate)(struct key *, struct key_preparsed_payload *);
int (*update)(struct key *, struct key_preparsed_payload *);
int (*match_preparse)(struct key_match_data *);
void (*match_free)(struct key_match_data *);
void (*revoke)(struct key *);
void (*destroy)(struct key *);
void (*describe)(const struct key *, struct seq_file *);
long int (*read)(const struct key *, char *, size_t);
request_key_actor_t request_key;
struct key_restriction * (*lookup_restriction)(const char *);
int (*asym_query)(const struct kernel_pkey_params *, struct kernel_pkey_query *);
int (*asym_eds_op)(struct kernel_pkey_params *, const void *, void *);
int (*asym_verify_signature)(struct kernel_pkey_params *, const void *, const void *);
struct list_head link;
struct lock_class_key lock_class;
};
typedef int (*key_restrict_link_func_t)(struct key *, const struct key_type *, const union key_payload *, struct key *);
struct key_restriction {
key_restrict_link_func_t check;
struct key *key;
struct key_type *keytype;
};
struct percpu_counter {
raw_spinlock_t lock;
long: 32;
s64 count;
s32 *counters;
long: 32;
};
struct user_struct {
refcount_t __count;
long: 32;
struct percpu_counter epoll_watches;
long unsigned int unix_inflight;
atomic_long_t pipe_bufs;
struct hlist_node uidhash_node;
kuid_t uid;
atomic_long_t locked_vm;
struct ratelimit_state ratelimit;
long: 32;
};
struct group_info {
atomic_t usage;
int ngroups;
kgid_t gid[0];
};
struct core_thread {
struct task_struct *task;
struct core_thread *next;
};
struct core_state {
atomic_t nr_threads;
struct core_thread dumper;
struct completion startup;
};
struct delayed_call {
void (*fn)(void *);
void *arg;
};
typedef struct {
uid_t val;
} vfsuid_t;
typedef struct {
gid_t val;
} vfsgid_t;
enum kmalloc_cache_type {
KMALLOC_NORMAL = 0,
KMALLOC_CGROUP = 0,
KMALLOC_RECLAIM = 1,
KMALLOC_DMA = 2,
NR_KMALLOC_TYPES = 3,
};
struct wait_page_queue;
struct kiocb {
struct file *ki_filp;
long: 32;
loff_t ki_pos;
void (*ki_complete)(struct kiocb *, long int);
void *private;
int ki_flags;
u16 ki_ioprio;
struct wait_page_queue *ki_waitq;
long: 32;
};
struct iattr {
unsigned int ia_valid;
umode_t ia_mode;
union {
kuid_t ia_uid;
vfsuid_t ia_vfsuid;
};
union {
kgid_t ia_gid;
vfsgid_t ia_vfsgid;
};
loff_t ia_size;
struct timespec64 ia_atime;
struct timespec64 ia_mtime;
struct timespec64 ia_ctime;
struct file *ia_file;
long: 32;
};
typedef __kernel_uid32_t projid_t;
typedef struct {
projid_t val;
} kprojid_t;
enum quota_type {
USRQUOTA = 0,
GRPQUOTA = 1,
PRJQUOTA = 2,
};
struct kqid {
union {
kuid_t uid;
kgid_t gid;
kprojid_t projid;
};
enum quota_type type;
};
struct mem_dqblk {
qsize_t dqb_bhardlimit;
qsize_t dqb_bsoftlimit;
qsize_t dqb_curspace;
qsize_t dqb_rsvspace;
qsize_t dqb_ihardlimit;
qsize_t dqb_isoftlimit;
qsize_t dqb_curinodes;
time64_t dqb_btime;
time64_t dqb_itime;
};
struct dquot {
struct hlist_node dq_hash;
struct list_head dq_inuse;
struct list_head dq_free;
struct list_head dq_dirty;
struct mutex dq_lock;
spinlock_t dq_dqb_lock;
atomic_t dq_count;
struct super_block *dq_sb;
struct kqid dq_id;
long: 32;
loff_t dq_off;
long unsigned int dq_flags;
long: 32;
struct mem_dqblk dq_dqb;
};
enum {
DQF_ROOT_SQUASH_B = 0,
DQF_SYS_FILE_B = 16,
DQF_PRIVATE = 17,
};
struct quota_format_type {
int qf_fmt_id;
const struct quota_format_ops *qf_ops;
struct module *qf_owner;
struct quota_format_type *qf_next;
};
enum {
DQST_LOOKUPS = 0,
DQST_DROPS = 1,
DQST_READS = 2,
DQST_WRITES = 3,
DQST_CACHE_HITS = 4,
DQST_ALLOC_DQUOTS = 5,
DQST_FREE_DQUOTS = 6,
DQST_SYNCS = 7,
_DQST_DQSTAT_LAST = 8,
};
struct quota_format_ops {
int (*check_quota_file)(struct super_block *, int);
int (*read_file_info)(struct super_block *, int);
int (*write_file_info)(struct super_block *, int);
int (*free_file_info)(struct super_block *, int);
int (*read_dqblk)(struct dquot *);
int (*commit_dqblk)(struct dquot *);
int (*release_dqblk)(struct dquot *);
int (*get_next_id)(struct super_block *, struct kqid *);
};
struct dquot_operations {
int (*write_dquot)(struct dquot *);
struct dquot * (*alloc_dquot)(struct super_block *, int);
void (*destroy_dquot)(struct dquot *);
int (*acquire_dquot)(struct dquot *);
int (*release_dquot)(struct dquot *);
int (*mark_dirty)(struct dquot *);
int (*write_info)(struct super_block *, int);
qsize_t * (*get_reserved_space)(struct inode *);
int (*get_projid)(struct inode *, kprojid_t *);
int (*get_inode_usage)(struct inode *, qsize_t *);
int (*get_next_id)(struct super_block *, struct kqid *);
};
struct qc_dqblk {
int d_fieldmask;
long: 32;
u64 d_spc_hardlimit;
u64 d_spc_softlimit;
u64 d_ino_hardlimit;
u64 d_ino_softlimit;
u64 d_space;
u64 d_ino_count;
s64 d_ino_timer;
s64 d_spc_timer;
int d_ino_warns;
int d_spc_warns;
u64 d_rt_spc_hardlimit;
u64 d_rt_spc_softlimit;
u64 d_rt_space;
s64 d_rt_spc_timer;
int d_rt_spc_warns;
long: 32;
};
struct qc_type_state {
unsigned int flags;
unsigned int spc_timelimit;
unsigned int ino_timelimit;
unsigned int rt_spc_timelimit;
unsigned int spc_warnlimit;
unsigned int ino_warnlimit;
unsigned int rt_spc_warnlimit;
long: 32;
long long unsigned int ino;
blkcnt_t blocks;
blkcnt_t nextents;
};
struct qc_state {
unsigned int s_incoredqs;
long: 32;
struct qc_type_state s_state[3];
};
struct qc_info {
int i_fieldmask;
unsigned int i_flags;
unsigned int i_spc_timelimit;
unsigned int i_ino_timelimit;
unsigned int i_rt_spc_timelimit;
unsigned int i_spc_warnlimit;
unsigned int i_ino_warnlimit;
unsigned int i_rt_spc_warnlimit;
};
struct quotactl_ops {
int (*quota_on)(struct super_block *, int, int, const struct path *);
int (*quota_off)(struct super_block *, int);
int (*quota_enable)(struct super_block *, unsigned int);
int (*quota_disable)(struct super_block *, unsigned int);
int (*quota_sync)(struct super_block *, int);
int (*set_info)(struct super_block *, int, struct qc_info *);
int (*get_dqblk)(struct super_block *, struct kqid, struct qc_dqblk *);
int (*get_nextdqblk)(struct super_block *, struct kqid *, struct qc_dqblk *);
int (*set_dqblk)(struct super_block *, struct kqid, struct qc_dqblk *);
int (*get_state)(struct super_block *, struct qc_state *);
int (*rm_xquota)(struct super_block *, unsigned int);
};
enum module_state {
MODULE_STATE_LIVE = 0,
MODULE_STATE_COMING = 1,
MODULE_STATE_GOING = 2,
MODULE_STATE_UNFORMED = 3,
};
struct kset;
struct kobj_type;
struct kernfs_node;
struct kobject {
const char *name;
struct list_head entry;
struct kobject *parent;
struct kset *kset;
const struct kobj_type *ktype;
struct kernfs_node *sd;
struct kref kref;
unsigned int state_initialized: 1;
unsigned int state_in_sysfs: 1;
unsigned int state_add_uevent_sent: 1;
unsigned int state_remove_uevent_sent: 1;
unsigned int uevent_suppress: 1;
};
struct module_param_attrs;
struct module_kobject {
struct kobject kobj;
struct module *mod;
struct kobject *drivers_dir;
struct module_param_attrs *mp;
struct completion *kobj_completion;
};
struct latch_tree_node {
struct rb_node node[2];
};
struct mod_tree_node {
struct module *mod;
struct latch_tree_node node;
};
struct module_layout {
void *base;
unsigned int size;
unsigned int text_size;
unsigned int ro_size;
unsigned int ro_after_init_size;
struct mod_tree_node mtn;
};
struct mips_hi16;
struct mod_arch_specific {
struct list_head dbe_list;
const struct exception_table_entry *dbe_start;
const struct exception_table_entry *dbe_end;
struct mips_hi16 *r_mips_hi16_list;
};
struct elf32_sym;
typedef struct elf32_sym Elf32_Sym;
struct mod_kallsyms {
Elf32_Sym *symtab;
unsigned int num_symtab;
char *strtab;
char *typetab;
};
struct module_attribute;
struct kernel_param;
struct module_sect_attrs;
struct module_notes_attrs;
struct trace_event_call;
struct trace_eval_map;
struct module {
enum module_state state;
struct list_head list;
char name[60];
struct module_kobject mkobj;
struct module_attribute *modinfo_attrs;
const char *version;
const char *srcversion;
struct kobject *holders_dir;
const struct kernel_symbol *syms;
const s32 *crcs;
unsigned int num_syms;
struct mutex param_lock;
struct kernel_param *kp;
unsigned int num_kp;
unsigned int num_gpl_syms;
const struct kernel_symbol *gpl_syms;
const s32 *gpl_crcs;
bool using_gplonly_symbols;
bool async_probe_requested;
unsigned int num_exentries;
struct exception_table_entry *extable;
int (*init)();
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct module_layout core_layout;
struct module_layout init_layout;
struct mod_arch_specific arch;
long unsigned int taints;
struct mod_kallsyms *kallsyms;
struct mod_kallsyms core_kallsyms;
struct module_sect_attrs *sect_attrs;
struct module_notes_attrs *notes_attrs;
char *args;
void *percpu;
unsigned int percpu_size;
void *noinstr_text_start;
unsigned int noinstr_text_size;
unsigned int num_tracepoints;
tracepoint_ptr_t *tracepoints_ptrs;
unsigned int num_srcu_structs;
struct srcu_struct **srcu_struct_ptrs;
unsigned int num_bpf_raw_events;
struct bpf_raw_event_map *bpf_raw_events;
unsigned int btf_data_size;
void *btf_data;
unsigned int num_trace_bprintk_fmt;
const char **trace_bprintk_fmt_start;
struct trace_event_call **trace_events;
unsigned int num_trace_events;
struct trace_eval_map **trace_evals;
unsigned int num_trace_evals;
unsigned int num_ftrace_callsites;
long unsigned int *ftrace_callsites;
struct list_head source_list;
struct list_head target_list;
void (*exit)();
atomic_t refcnt;
};
struct writeback_control;
struct readahead_control;
struct swap_info_struct;
struct address_space_operations {
int (*writepage)(struct page *, struct writeback_control *);
int (*read_folio)(struct file *, struct folio *);
int (*writepages)(struct address_space *, struct writeback_control *);
bool (*dirty_folio)(struct address_space *, struct folio *);
void (*readahead)(struct readahead_control *);
int (*write_begin)(struct file *, struct address_space *, loff_t, unsigned int, struct page **, void **);
int (*write_end)(struct file *, struct address_space *, loff_t, unsigned int, unsigned int, struct page *, void *);
sector_t (*bmap)(struct address_space *, sector_t);
void (*invalidate_folio)(struct folio *, size_t, size_t);
bool (*release_folio)(struct folio *, gfp_t);
void (*free_folio)(struct folio *);
ssize_t (*direct_IO)(struct kiocb *, struct iov_iter *);
int (*migrate_folio)(struct address_space *, struct folio *, struct folio *, enum migrate_mode);
int (*launder_folio)(struct folio *);
bool (*is_partially_uptodate)(struct folio *, size_t, size_t);
void (*is_dirty_writeback)(struct folio *, bool *, bool *);
int (*error_remove_page)(struct address_space *, struct page *);
int (*swap_activate)(struct swap_info_struct *, struct file *, sector_t *);
void (*swap_deactivate)(struct file *);
int (*swap_rw)(struct kiocb *, struct iov_iter *);
};
struct fiemap_extent_info;
struct fileattr;
struct inode_operations {
struct dentry * (*lookup)(struct inode *, struct dentry *, unsigned int);
const char * (*get_link)(struct dentry *, struct inode *, struct delayed_call *);
int (*permission)(struct user_namespace *, struct inode *, int);
struct posix_acl * (*get_acl)(struct inode *, int, bool);
int (*readlink)(struct dentry *, char *, int);
int (*create)(struct user_namespace *, struct inode *, struct dentry *, umode_t, bool);
int (*link)(struct dentry *, struct inode *, struct dentry *);
int (*unlink)(struct inode *, struct dentry *);
int (*symlink)(struct user_namespace *, struct inode *, struct dentry *, const char *);
int (*mkdir)(struct user_namespace *, struct inode *, struct dentry *, umode_t);
int (*rmdir)(struct inode *, struct dentry *);
int (*mknod)(struct user_namespace *, struct inode *, struct dentry *, umode_t, dev_t);
int (*rename)(struct user_namespace *, struct inode *, struct dentry *, struct inode *, struct dentry *, unsigned int);
int (*setattr)(struct user_namespace *, struct dentry *, struct iattr *);
int (*getattr)(struct user_namespace *, const struct path *, struct kstat *, u32, unsigned int);
ssize_t (*listxattr)(struct dentry *, char *, size_t);
int (*fiemap)(struct inode *, struct fiemap_extent_info *, u64, u64);
int (*update_time)(struct inode *, struct timespec64 *, int);
int (*atomic_open)(struct inode *, struct dentry *, struct file *, unsigned int, umode_t);
int (*tmpfile)(struct user_namespace *, struct inode *, struct file *, umode_t);
int (*set_acl)(struct user_namespace *, struct inode *, struct posix_acl *, int);
int (*fileattr_set)(struct user_namespace *, struct dentry *, struct fileattr *);
int (*fileattr_get)(struct dentry *, struct fileattr *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct file_lock_context {
spinlock_t flc_lock;
struct list_head flc_flock;
struct list_head flc_posix;
struct list_head flc_lease;
};
struct file_lock_operations {
void (*fl_copy_lock)(struct file_lock *, struct file_lock *);
void (*fl_release_private)(struct file_lock *);
};
struct nlm_lockowner;
struct nfs_lock_info {
u32 state;
struct nlm_lockowner *owner;
struct list_head list;
};
struct nfs4_lock_state;
struct nfs4_lock_info {
struct nfs4_lock_state *owner;
};
struct fasync_struct;
struct lock_manager_operations;
struct file_lock {
struct file_lock *fl_blocker;
struct list_head fl_list;
struct hlist_node fl_link;
struct list_head fl_blocked_requests;
struct list_head fl_blocked_member;
fl_owner_t fl_owner;
unsigned int fl_flags;
unsigned char fl_type;
unsigned int fl_pid;
int fl_link_cpu;
wait_queue_head_t fl_wait;
struct file *fl_file;
loff_t fl_start;
loff_t fl_end;
struct fasync_struct *fl_fasync;
long unsigned int fl_break_time;
long unsigned int fl_downgrade_time;
const struct file_lock_operations *fl_ops;
const struct lock_manager_operations *fl_lmops;
union {
struct nfs_lock_info nfs_fl;
struct nfs4_lock_info nfs4_fl;
struct {
struct list_head link;
int state;
unsigned int debug_id;
} afs;
} fl_u;
long: 32;
};
struct lock_manager_operations {
void *lm_mod_owner;
fl_owner_t (*lm_get_owner)(fl_owner_t);
void (*lm_put_owner)(fl_owner_t);
void (*lm_notify)(struct file_lock *);
int (*lm_grant)(struct file_lock *, int);
bool (*lm_break)(struct file_lock *);
int (*lm_change)(struct file_lock *, int, struct list_head *);
void (*lm_setup)(struct file_lock *, void **);
bool (*lm_breaker_owns_lease)(struct file_lock *);
bool (*lm_lock_expirable)(struct file_lock *);
void (*lm_expire_lock)();
};
struct fasync_struct {
rwlock_t fa_lock;
int magic;
int fa_fd;
struct fasync_struct *fa_next;
struct file *fa_file;
struct callback_head fa_rcu;
};
enum {
SB_UNFROZEN = 0,
SB_FREEZE_WRITE = 1,
SB_FREEZE_PAGEFAULT = 2,
SB_FREEZE_FS = 3,
SB_FREEZE_COMPLETE = 4,
};
struct kstatfs;
struct super_operations {
struct inode * (*alloc_inode)(struct super_block *);
void (*destroy_inode)(struct inode *);
void (*free_inode)(struct inode *);
void (*dirty_inode)(struct inode *, int);
int (*write_inode)(struct inode *, struct writeback_control *);
int (*drop_inode)(struct inode *);
void (*evict_inode)(struct inode *);
void (*put_super)(struct super_block *);
int (*sync_fs)(struct super_block *, int);
int (*freeze_super)(struct super_block *);
int (*freeze_fs)(struct super_block *);
int (*thaw_super)(struct super_block *);
int (*unfreeze_fs)(struct super_block *);
int (*statfs)(struct dentry *, struct kstatfs *);
int (*remount_fs)(struct super_block *, int *, char *);
void (*umount_begin)(struct super_block *);
int (*show_options)(struct seq_file *, struct dentry *);
int (*show_devname)(struct seq_file *, struct dentry *);
int (*show_path)(struct seq_file *, struct dentry *);
int (*show_stats)(struct seq_file *, struct dentry *);
ssize_t (*quota_read)(struct super_block *, int, char *, size_t, loff_t);
ssize_t (*quota_write)(struct super_block *, int, const char *, size_t, loff_t);
struct dquot ** (*get_dquots)(struct inode *);
long int (*nr_cached_objects)(struct super_block *, struct shrink_control *);
long int (*free_cached_objects)(struct super_block *, struct shrink_control *);
};
struct fid;
struct iomap;
struct export_operations {
int (*encode_fh)(struct inode *, __u32 *, int *, struct inode *);
struct dentry * (*fh_to_dentry)(struct super_block *, struct fid *, int, int);
struct dentry * (*fh_to_parent)(struct super_block *, struct fid *, int, int);
int (*get_name)(struct dentry *, char *, struct dentry *);
struct dentry * (*get_parent)(struct dentry *);
int (*commit_metadata)(struct inode *);
int (*get_uuid)(struct super_block *, u8 *, u32 *, u64 *);
int (*map_blocks)(struct inode *, loff_t, u64, struct iomap *, bool, u32 *);
int (*commit_blocks)(struct inode *, struct iomap *, int, struct iattr *);
u64 (*fetch_iversion)(struct inode *);
long unsigned int flags;
};
struct xattr_handler {
const char *name;
const char *prefix;
int flags;
bool (*list)(struct dentry *);
int (*get)(const struct xattr_handler *, struct dentry *, struct inode *, const char *, void *, size_t);
int (*set)(const struct xattr_handler *, struct user_namespace *, struct dentry *, struct inode *, const char *, const void *, size_t, int);
};
typedef bool (*filldir_t)(struct dir_context *, const char *, int, loff_t, u64, unsigned int);
struct dir_context {
filldir_t actor;
long: 32;
loff_t pos;
};
struct p_log;
struct fs_parameter;
struct fs_parse_result;
typedef int fs_param_type(struct p_log *, const struct fs_parameter_spec *, struct fs_parameter *, struct fs_parse_result *);
struct fs_parameter_spec {
const char *name;
fs_param_type *type;
u8 opt;
short unsigned int flags;
const void *data;
};
enum compound_dtor_id {
NULL_COMPOUND_DTOR = 0,
COMPOUND_PAGE_DTOR = 1,
NR_COMPOUND_DTORS = 2,
};
enum vm_event_item {
PGPGIN = 0,
PGPGOUT = 1,
PSWPIN = 2,
PSWPOUT = 3,
PGALLOC_DMA = 4,
PGALLOC_NORMAL = 5,
PGALLOC_MOVABLE = 6,
ALLOCSTALL_DMA = 7,
ALLOCSTALL_NORMAL = 8,
ALLOCSTALL_MOVABLE = 9,
PGSCAN_SKIP_DMA = 10,
PGSCAN_SKIP_NORMAL = 11,
PGSCAN_SKIP_MOVABLE = 12,
PGFREE = 13,
PGACTIVATE = 14,
PGDEACTIVATE = 15,
PGLAZYFREE = 16,
PGFAULT = 17,
PGMAJFAULT = 18,
PGLAZYFREED = 19,
PGREFILL = 20,
PGREUSE = 21,
PGSTEAL_KSWAPD = 22,
PGSTEAL_DIRECT = 23,
PGDEMOTE_KSWAPD = 24,
PGDEMOTE_DIRECT = 25,
PGSCAN_KSWAPD = 26,
PGSCAN_DIRECT = 27,
PGSCAN_DIRECT_THROTTLE = 28,
PGSCAN_ANON = 29,
PGSCAN_FILE = 30,
PGSTEAL_ANON = 31,
PGSTEAL_FILE = 32,
PGINODESTEAL = 33,
SLABS_SCANNED = 34,
KSWAPD_INODESTEAL = 35,
KSWAPD_LOW_WMARK_HIT_QUICKLY = 36,
KSWAPD_HIGH_WMARK_HIT_QUICKLY = 37,
PAGEOUTRUN = 38,
PGROTATED = 39,
DROP_PAGECACHE = 40,
DROP_SLAB = 41,
OOM_KILL = 42,
PGMIGRATE_SUCCESS = 43,
PGMIGRATE_FAIL = 44,
THP_MIGRATION_SUCCESS = 45,
THP_MIGRATION_FAIL = 46,
THP_MIGRATION_SPLIT = 47,
COMPACTMIGRATE_SCANNED = 48,
COMPACTFREE_SCANNED = 49,
COMPACTISOLATED = 50,
COMPACTSTALL = 51,
COMPACTFAIL = 52,
COMPACTSUCCESS = 53,
KCOMPACTD_WAKE = 54,
KCOMPACTD_MIGRATE_SCANNED = 55,
KCOMPACTD_FREE_SCANNED = 56,
UNEVICTABLE_PGCULLED = 57,
UNEVICTABLE_PGSCANNED = 58,
UNEVICTABLE_PGRESCUED = 59,
UNEVICTABLE_PGMLOCKED = 60,
UNEVICTABLE_PGMUNLOCKED = 61,
UNEVICTABLE_PGCLEARED = 62,
UNEVICTABLE_PGSTRANDED = 63,
SWAP_RA = 64,
SWAP_RA_HIT = 65,
NR_VM_EVENT_ITEMS = 66,
};
enum memblock_flags {
MEMBLOCK_NONE = 0,
MEMBLOCK_HOTPLUG = 1,
MEMBLOCK_MIRROR = 2,
MEMBLOCK_NOMAP = 4,
MEMBLOCK_DRIVER_MANAGED = 8,
};
struct memblock_region {
phys_addr_t base;
phys_addr_t size;
enum memblock_flags flags;
};
struct memblock_type {
long unsigned int cnt;
long unsigned int max;
phys_addr_t total_size;
struct memblock_region *regions;
char *name;
};
struct memblock {
bool bottom_up;
phys_addr_t current_limit;
struct memblock_type memory;
struct memblock_type reserved;
};
enum {
Root_NFS = 255,
Root_CIFS = 254,
Root_RAM0 = 1048576,
Root_RAM1 = 1048577,
Root_FD0 = 2097152,
Root_HDA1 = 3145729,
Root_HDA2 = 3145730,
Root_SDA1 = 8388609,
Root_SDA2 = 8388610,
Root_HDC1 = 23068673,
Root_SR0 = 11534336,
};
struct kernfs_root;
struct kernfs_elem_dir {
long unsigned int subdirs;
struct rb_root children;
struct kernfs_root *root;
long unsigned int rev;
};
struct kernfs_elem_symlink {
struct kernfs_node *target_kn;
};
struct kernfs_ops;
struct kernfs_open_node;
struct kernfs_elem_attr {
const struct kernfs_ops *ops;
struct kernfs_open_node *open;
loff_t size;
struct kernfs_node *notify_next;
long: 32;
};
struct kernfs_iattrs;
struct kernfs_node {
atomic_t count;
atomic_t active;
struct kernfs_node *parent;
const char *name;
struct rb_node rb;
const void *ns;
unsigned int hash;
long: 32;
union {
struct kernfs_elem_dir dir;
struct kernfs_elem_symlink symlink;
struct kernfs_elem_attr attr;
};
void *priv;
long: 32;
u64 id;
short unsigned int flags;
umode_t mode;
struct kernfs_iattrs *iattr;
};
struct kernfs_open_file;
struct kernfs_ops {
int (*open)(struct kernfs_open_file *);
void (*release)(struct kernfs_open_file *);
int (*seq_show)(struct seq_file *, void *);
void * (*seq_start)(struct seq_file *, loff_t *);
void * (*seq_next)(struct seq_file *, void *, loff_t *);
void (*seq_stop)(struct seq_file *, void *);
ssize_t (*read)(struct kernfs_open_file *, char *, size_t, loff_t);
size_t atomic_write_len;
bool prealloc;
ssize_t (*write)(struct kernfs_open_file *, char *, size_t, loff_t);
__poll_t (*poll)(struct kernfs_open_file *, struct poll_table_struct *);
int (*mmap)(struct kernfs_open_file *, struct vm_area_struct *);
};
struct kernfs_open_file {
struct kernfs_node *kn;
struct file *file;
struct seq_file *seq_file;
void *priv;
struct mutex mutex;
struct mutex prealloc_mutex;
int event;
struct list_head list;
char *prealloc_buf;
size_t atomic_write_len;
bool mmapped: 1;
bool released: 1;
const struct vm_operations_struct *vm_ops;
};
enum kobj_ns_type {
KOBJ_NS_TYPE_NONE = 0,
KOBJ_NS_TYPE_NET = 1,
KOBJ_NS_TYPES = 2,
};
struct sock;
struct kobj_ns_type_operations {
enum kobj_ns_type type;
bool (*current_may_mount)();
void * (*grab_current_ns)();
const void * (*netlink_ns)(struct sock *);
const void * (*initial_ns)();
void (*drop_ns)(void *);
};
struct attribute {
const char *name;
umode_t mode;
};
struct bin_attribute;
struct attribute_group {
const char *name;
umode_t (*is_visible)(struct kobject *, struct attribute *, int);
umode_t (*is_bin_visible)(struct kobject *, struct bin_attribute *, int);
struct attribute **attrs;
struct bin_attribute **bin_attrs;
};
struct bin_attribute {
struct attribute attr;
size_t size;
void *private;
struct address_space * (*f_mapping)();
ssize_t (*read)(struct file *, struct kobject *, struct bin_attribute *, char *, loff_t, size_t);
ssize_t (*write)(struct file *, struct kobject *, struct bin_attribute *, char *, loff_t, size_t);
int (*mmap)(struct file *, struct kobject *, struct bin_attribute *, struct vm_area_struct *);
};
struct sysfs_ops {
ssize_t (*show)(struct kobject *, struct attribute *, char *);
ssize_t (*store)(struct kobject *, struct attribute *, const char *, size_t);
};
struct kset_uevent_ops;
struct kset {
struct list_head list;
spinlock_t list_lock;
struct kobject kobj;
const struct kset_uevent_ops *uevent_ops;
};
struct kobj_type {
void (*release)(struct kobject *);
const struct sysfs_ops *sysfs_ops;
const struct attribute_group **default_groups;
const struct kobj_ns_type_operations * (*child_ns_type)(struct kobject *);
const void * (*namespace)(struct kobject *);
void (*get_ownership)(struct kobject *, kuid_t *, kgid_t *);
};
struct kobj_uevent_env {
char *argv[3];
char *envp[64];
int envp_idx;
char buf[2048];
int buflen;
};
struct kset_uevent_ops {
int (* const filter)(struct kobject *);
const char * (* const name)(struct kobject *);
int (* const uevent)(struct kobject *, struct kobj_uevent_env *);
};
struct seq_operations {
void * (*start)(struct seq_file *, loff_t *);
void (*stop)(struct seq_file *, void *);
void * (*next)(struct seq_file *, void *, loff_t *);
int (*show)(struct seq_file *, void *);
};
struct nsset;
struct proc_ns_operations {
const char *name;
const char *real_ns_name;
int type;
struct ns_common * (*get)(struct task_struct *);
void (*put)(struct ns_common *);
int (*install)(struct nsset *, struct ns_common *);
struct user_namespace * (*owner)(struct ns_common *);
struct ns_common * (*get_parent)(struct ns_common *);
};
typedef __u32 Elf32_Addr;
typedef __u16 Elf32_Half;
typedef __u32 Elf32_Word;
struct elf32_sym {
Elf32_Word st_name;
Elf32_Addr st_value;
Elf32_Word st_size;
unsigned char st_info;
unsigned char st_other;
Elf32_Half st_shndx;
};
enum key_being_used_for {
VERIFYING_MODULE_SIGNATURE = 0,
VERIFYING_FIRMWARE_SIGNATURE = 1,
VERIFYING_KEXEC_PE_SIGNATURE = 2,
VERIFYING_KEY_SIGNATURE = 3,
VERIFYING_KEY_SELF_SIGNATURE = 4,
VERIFYING_UNSPECIFIED_SIGNATURE = 5,
NR__KEY_BEING_USED_FOR = 6,
};
enum {
__SD_BALANCE_NEWIDLE = 0,
__SD_BALANCE_EXEC = 1,
__SD_BALANCE_FORK = 2,
__SD_BALANCE_WAKE = 3,
__SD_WAKE_AFFINE = 4,
__SD_ASYM_CPUCAPACITY = 5,
__SD_ASYM_CPUCAPACITY_FULL = 6,
__SD_SHARE_CPUCAPACITY = 7,
__SD_SHARE_PKG_RESOURCES = 8,
__SD_SERIALIZE = 9,
__SD_ASYM_PACKING = 10,
__SD_PREFER_SIBLING = 11,
__SD_OVERLAP = 12,
__SD_NUMA = 13,
__SD_FLAG_CNT = 14,
};
struct kernel_param_ops {
unsigned int flags;
int (*set)(const char *, const struct kernel_param *);
int (*get)(char *, const struct kernel_param *);
void (*free)(void *);
};
struct kparam_string;
struct kparam_array;
struct kernel_param {
const char *name;
struct module *mod;
const struct kernel_param_ops *ops;
const u16 perm;
s8 level;
u8 flags;
union {
void *arg;
const struct kparam_string *str;
const struct kparam_array *arr;
};
};
struct kparam_string {
unsigned int maxlen;
char *string;
};
struct kparam_array {
unsigned int max;
unsigned int elemsize;
unsigned int *num;
const struct kernel_param_ops *ops;
void *elem;
};
struct module_attribute {
struct attribute attr;
ssize_t (*show)(struct module_attribute *, struct module_kobject *, char *);
ssize_t (*store)(struct module_attribute *, struct module_kobject *, const char *, size_t);
void (*setup)(struct module *, const char *);
int (*test)(struct module *);
void (*free)(struct module *);
};
struct pm_message {
int event;
};
typedef struct pm_message pm_message_t;
struct device;
struct dev_pm_ops {
int (*prepare)(struct device *);
void (*complete)(struct device *);
int (*suspend)(struct device *);
int (*resume)(struct device *);
int (*freeze)(struct device *);
int (*thaw)(struct device *);
int (*poweroff)(struct device *);
int (*restore)(struct device *);
int (*suspend_late)(struct device *);
int (*resume_early)(struct device *);
int (*freeze_late)(struct device *);
int (*thaw_early)(struct device *);
int (*poweroff_late)(struct device *);
int (*restore_early)(struct device *);
int (*suspend_noirq)(struct device *);
int (*resume_noirq)(struct device *);
int (*freeze_noirq)(struct device *);
int (*thaw_noirq)(struct device *);
int (*poweroff_noirq)(struct device *);
int (*restore_noirq)(struct device *);
int (*runtime_suspend)(struct device *);
int (*runtime_resume)(struct device *);
int (*runtime_idle)(struct device *);
};
enum dl_dev_state {
DL_DEV_NO_DRIVER = 0,
DL_DEV_PROBING = 1,
DL_DEV_DRIVER_BOUND = 2,
DL_DEV_UNBINDING = 3,
};
struct dev_links_info {
struct list_head suppliers;
struct list_head consumers;
struct list_head defer_sync;
enum dl_dev_state status;
};
struct pm_subsys_data;
struct dev_pm_qos;
struct dev_pm_info {
pm_message_t power_state;
unsigned int can_wakeup: 1;
unsigned int async_suspend: 1;
bool in_dpm_list: 1;
bool is_prepared: 1;
bool is_suspended: 1;
bool is_noirq_suspended: 1;
bool is_late_suspended: 1;
bool no_pm: 1;
bool early_init: 1;
bool direct_complete: 1;
u32 driver_flags;
spinlock_t lock;
unsigned int should_wakeup: 1;
struct pm_subsys_data *subsys_data;
void (*set_latency_tolerance)(struct device *, s32);
struct dev_pm_qos *qos;
};
struct dev_msi_info {};
struct dev_archdata {};
struct dev_iommu;
enum device_removable {
DEVICE_REMOVABLE_NOT_SUPPORTED = 0,
DEVICE_REMOVABLE_UNKNOWN = 1,
DEVICE_FIXED = 2,
DEVICE_REMOVABLE = 3,
};
struct device_private;
struct device_type;
struct bus_type;
struct device_driver;
struct dev_pm_domain;
struct bus_dma_region;
struct device_dma_parameters;
struct dma_coherent_mem;
struct device_node;
struct fwnode_handle;
struct class;
struct iommu_group;
struct device_physical_location;
struct device {
struct kobject kobj;
struct device *parent;
struct device_private *p;
const char *init_name;
const struct device_type *type;
struct bus_type *bus;
struct device_driver *driver;
void *platform_data;
void *driver_data;
struct mutex mutex;
struct dev_links_info links;
struct dev_pm_info power;
struct dev_pm_domain *pm_domain;
struct dev_msi_info msi;
u64 *dma_mask;
u64 coherent_dma_mask;
u64 bus_dma_limit;
const struct bus_dma_region *dma_range_map;
struct device_dma_parameters *dma_parms;
struct list_head dma_pools;
struct dma_coherent_mem *dma_mem;
struct dev_archdata archdata;
struct device_node *of_node;
struct fwnode_handle *fwnode;
dev_t devt;
u32 id;
spinlock_t devres_lock;
struct list_head devres_head;
struct class *class;
const struct attribute_group **groups;
void (*release)(struct device *);
struct iommu_group *iommu_group;
struct dev_iommu *iommu;
struct device_physical_location *physical_location;
enum device_removable removable;
bool offline_disabled: 1;
bool offline: 1;
bool of_node_reused: 1;
bool state_synced: 1;
bool can_match: 1;
bool dma_coherent: 1;
};
struct pm_subsys_data {
spinlock_t lock;
unsigned int refcount;
};
struct dev_pm_domain {
struct dev_pm_ops ops;
int (*start)(struct device *);
void (*detach)(struct device *, bool);
int (*activate)(struct device *);
void (*sync)(struct device *);
void (*dismiss)(struct device *);
};
struct iommu_ops;
struct subsys_private;
struct bus_type {
const char *name;
const char *dev_name;
struct device *dev_root;
const struct attribute_group **bus_groups;
const struct attribute_group **dev_groups;
const struct attribute_group **drv_groups;
int (*match)(struct device *, struct device_driver *);
int (*uevent)(struct device *, struct kobj_uevent_env *);
int (*probe)(struct device *);
void (*sync_state)(struct device *);
void (*remove)(struct device *);
void (*shutdown)(struct device *);
int (*online)(struct device *);
int (*offline)(struct device *);
int (*suspend)(struct device *, pm_message_t);
int (*resume)(struct device *);
int (*num_vf)(struct device *);
int (*dma_configure)(struct device *);
void (*dma_cleanup)(struct device *);
const struct dev_pm_ops *pm;
const struct iommu_ops *iommu_ops;
struct subsys_private *p;
struct lock_class_key lock_key;
bool need_parent_lock;
};
enum probe_type {
PROBE_DEFAULT_STRATEGY = 0,
PROBE_PREFER_ASYNCHRONOUS = 1,
PROBE_FORCE_SYNCHRONOUS = 2,
};
struct of_device_id;
struct acpi_device_id;
struct driver_private;
struct device_driver {
const char *name;
struct bus_type *bus;
struct module *owner;
const char *mod_name;
bool suppress_bind_attrs;
enum probe_type probe_type;
const struct of_device_id *of_match_table;
const struct acpi_device_id *acpi_match_table;
int (*probe)(struct device *);
void (*sync_state)(struct device *);
int (*remove)(struct device *);
void (*shutdown)(struct device *);
int (*suspend)(struct device *, pm_message_t);
int (*resume)(struct device *);
const struct attribute_group **groups;
const struct attribute_group **dev_groups;
const struct dev_pm_ops *pm;
void (*coredump)(struct device *);
struct driver_private *p;
};
struct iommu_ops {};
struct device_type {
const char *name;
const struct attribute_group **groups;
int (*uevent)(struct device *, struct kobj_uevent_env *);
char * (*devnode)(struct device *, umode_t *, kuid_t *, kgid_t *);
void (*release)(struct device *);
const struct dev_pm_ops *pm;
};
struct class {
const char *name;
struct module *owner;
const struct attribute_group **class_groups;
const struct attribute_group **dev_groups;
struct kobject *dev_kobj;
int (*dev_uevent)(struct device *, struct kobj_uevent_env *);
char * (*devnode)(struct device *, umode_t *);
void (*class_release)(struct class *);
void (*dev_release)(struct device *);
int (*shutdown_pre)(struct device *);
const struct kobj_ns_type_operations *ns_type;
const void * (*namespace)(struct device *);
void (*get_ownership)(struct device *, kuid_t *, kgid_t *);
const struct dev_pm_ops *pm;
struct subsys_private *p;
};
struct of_device_id {
char name[32];
char type[32];
char compatible[128];
const void *data;
};
typedef long unsigned int kernel_ulong_t;
struct acpi_device_id {
__u8 id[16];
kernel_ulong_t driver_data;
__u32 cls;
__u32 cls_msk;
};
struct device_dma_parameters {
unsigned int max_segment_size;
unsigned int min_align_mask;
long unsigned int segment_boundary_mask;
};
enum device_physical_location_panel {
DEVICE_PANEL_TOP = 0,
DEVICE_PANEL_BOTTOM = 1,
DEVICE_PANEL_LEFT = 2,
DEVICE_PANEL_RIGHT = 3,
DEVICE_PANEL_FRONT = 4,
DEVICE_PANEL_BACK = 5,
DEVICE_PANEL_UNKNOWN = 6,
};
enum device_physical_location_vertical_position {
DEVICE_VERT_POS_UPPER = 0,
DEVICE_VERT_POS_CENTER = 1,
DEVICE_VERT_POS_LOWER = 2,
};
enum device_physical_location_horizontal_position {
DEVICE_HORI_POS_LEFT = 0,
DEVICE_HORI_POS_CENTER = 1,
DEVICE_HORI_POS_RIGHT = 2,
};
struct device_physical_location {
enum device_physical_location_panel panel;
enum device_physical_location_vertical_position vertical_position;
enum device_physical_location_horizontal_position horizontal_position;
bool dock;
bool lid;
};
typedef u32 dma_addr_t;
struct bus_dma_region {
phys_addr_t cpu_start;
dma_addr_t dma_start;
u64 size;
u64 offset;
};
struct cpu {
int node_id;
int hotpluggable;
struct device dev;
};
struct pollfd {
int fd;
short int events;
short int revents;
};
typedef void (*poll_queue_proc)(struct file *, wait_queue_head_t *, struct poll_table_struct *);
struct poll_table_struct {
poll_queue_proc _qproc;
__poll_t _key;
};
enum clock_event_state {
CLOCK_EVT_STATE_DETACHED = 0,
CLOCK_EVT_STATE_SHUTDOWN = 1,
CLOCK_EVT_STATE_PERIODIC = 2,
CLOCK_EVT_STATE_ONESHOT = 3,
CLOCK_EVT_STATE_ONESHOT_STOPPED = 4,
};
struct clock_event_device {
void (*event_handler)(struct clock_event_device *);
int (*set_next_event)(long unsigned int, struct clock_event_device *);
int (*set_next_ktime)(ktime_t, struct clock_event_device *);
long: 32;
ktime_t next_event;
u64 max_delta_ns;
u64 min_delta_ns;
u32 mult;
u32 shift;
enum clock_event_state state_use_accessors;
unsigned int features;
long unsigned int retries;
int (*set_state_periodic)(struct clock_event_device *);
int (*set_state_oneshot)(struct clock_event_device *);
int (*set_state_oneshot_stopped)(struct clock_event_device *);
int (*set_state_shutdown)(struct clock_event_device *);
int (*tick_resume)(struct clock_event_device *);
void (*broadcast)(const struct cpumask *);
void (*suspend)(struct clock_event_device *);
void (*resume)(struct clock_event_device *);
long unsigned int min_delta_ticks;
long unsigned int max_delta_ticks;
const char *name;
int rating;
int irq;
int bound_on;
const struct cpumask *cpumask;
struct list_head list;
struct module *owner;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum irqreturn {
IRQ_NONE = 0,
IRQ_HANDLED = 1,
IRQ_WAKE_THREAD = 2,
};
typedef enum irqreturn irqreturn_t;
typedef irqreturn_t (*irq_handler_t)(int, void *);
enum {
HI_SOFTIRQ = 0,
TIMER_SOFTIRQ = 1,
NET_TX_SOFTIRQ = 2,
NET_RX_SOFTIRQ = 3,
BLOCK_SOFTIRQ = 4,
IRQ_POLL_SOFTIRQ = 5,
TASKLET_SOFTIRQ = 6,
SCHED_SOFTIRQ = 7,
HRTIMER_SOFTIRQ = 8,
RCU_SOFTIRQ = 9,
NR_SOFTIRQS = 10,
};
struct cdev {
struct kobject kobj;
struct module *owner;
const struct file_operations *ops;
struct list_head list;
dev_t dev;
unsigned int count;
};
typedef u64 uint64_t;
enum cpu_type_enum {
CPU_UNKNOWN = 0,
CPU_R2000 = 1,
CPU_R3000 = 2,
CPU_R3000A = 3,
CPU_R3041 = 4,
CPU_R3051 = 5,
CPU_R3052 = 6,
CPU_R3081 = 7,
CPU_R3081E = 8,
CPU_R4000PC = 9,
CPU_R4000SC = 10,
CPU_R4000MC = 11,
CPU_R4200 = 12,
CPU_R4300 = 13,
CPU_R4310 = 14,
CPU_R4400PC = 15,
CPU_R4400SC = 16,
CPU_R4400MC = 17,
CPU_R4600 = 18,
CPU_R4640 = 19,
CPU_R4650 = 20,
CPU_R4700 = 21,
CPU_R5000 = 22,
CPU_R5500 = 23,
CPU_NEVADA = 24,
CPU_R10000 = 25,
CPU_R12000 = 26,
CPU_R14000 = 27,
CPU_R16000 = 28,
CPU_RM7000 = 29,
CPU_SR71000 = 30,
CPU_TX49XX = 31,
CPU_4KC = 32,
CPU_4KEC = 33,
CPU_4KSC = 34,
CPU_24K = 35,
CPU_34K = 36,
CPU_1004K = 37,
CPU_74K = 38,
CPU_ALCHEMY = 39,
CPU_PR4450 = 40,
CPU_BMIPS32 = 41,
CPU_BMIPS3300 = 42,
CPU_BMIPS4350 = 43,
CPU_BMIPS4380 = 44,
CPU_BMIPS5000 = 45,
CPU_XBURST = 46,
CPU_LOONGSON32 = 47,
CPU_M14KC = 48,
CPU_M14KEC = 49,
CPU_INTERAPTIV = 50,
CPU_P5600 = 51,
CPU_PROAPTIV = 52,
CPU_1074K = 53,
CPU_M5150 = 54,
CPU_I6400 = 55,
CPU_P6600 = 56,
CPU_M6250 = 57,
CPU_5KC = 58,
CPU_5KE = 59,
CPU_20KC = 60,
CPU_25KF = 61,
CPU_SB1 = 62,
CPU_SB1A = 63,
CPU_LOONGSON2EF = 64,
CPU_LOONGSON64 = 65,
CPU_CAVIUM_OCTEON = 66,
CPU_CAVIUM_OCTEON_PLUS = 67,
CPU_CAVIUM_OCTEON2 = 68,
CPU_CAVIUM_OCTEON3 = 69,
CPU_I6500 = 70,
CPU_QEMU_GENERIC = 71,
CPU_LAST = 72,
};
struct bcache_ops {
void (*bc_enable)();
void (*bc_disable)();
void (*bc_wback_inv)(long unsigned int, long unsigned int);
void (*bc_inv)(long unsigned int, long unsigned int);
void (*bc_prefetch_enable)();
void (*bc_prefetch_disable)();
bool (*bc_prefetch_is_enabled)();
};
enum ingenic_machine_type {
MACH_INGENIC_UNKNOWN = 0,
MACH_INGENIC_JZ4720 = 1,
MACH_INGENIC_JZ4725 = 2,
MACH_INGENIC_JZ4725B = 3,
MACH_INGENIC_JZ4730 = 4,
MACH_INGENIC_JZ4740 = 5,
MACH_INGENIC_JZ4750 = 6,
MACH_INGENIC_JZ4755 = 7,
MACH_INGENIC_JZ4760 = 8,
MACH_INGENIC_JZ4760B = 9,
MACH_INGENIC_JZ4770 = 10,
MACH_INGENIC_JZ4775 = 11,
MACH_INGENIC_JZ4780 = 12,
MACH_INGENIC_X1000 = 13,
MACH_INGENIC_X1000E = 14,
MACH_INGENIC_X1830 = 15,
MACH_INGENIC_X2000 = 16,
MACH_INGENIC_X2000E = 17,
MACH_INGENIC_X2000H = 18,
MACH_INGENIC_X2100 = 19,
};
typedef long unsigned int uintptr_t;
struct uid_gid_extent {
u32 first;
u32 lower_first;
u32 count;
};
struct uid_gid_map {
u32 nr_extents;
union {
struct uid_gid_extent extent[5];
struct {
struct uid_gid_extent *forward;
struct uid_gid_extent *reverse;
};
};
};
struct ctl_table;
struct ctl_table_root;
struct ctl_table_set;
struct ctl_dir;
struct ctl_node;
struct ctl_table_header {
union {
struct {
struct ctl_table *ctl_table;
int used;
int count;
int nreg;
};
struct callback_head rcu;
};
struct completion *unregistering;
struct ctl_table *ctl_table_arg;
struct ctl_table_root *root;
struct ctl_table_set *set;
struct ctl_dir *parent;
struct ctl_node *node;
struct hlist_head inodes;
};
struct ctl_dir {
struct ctl_table_header header;
struct rb_root root;
};
struct ctl_table_set {
int (*is_seen)(struct ctl_table_set *);
struct ctl_dir dir;
};
struct user_namespace {
struct uid_gid_map uid_map;
struct uid_gid_map gid_map;
struct uid_gid_map projid_map;
struct user_namespace *parent;
int level;
kuid_t owner;
kgid_t group;
struct ns_common ns;
long unsigned int flags;
bool parent_could_setfcap;
struct list_head keyring_name_list;
struct key *user_keyring_register;
struct rw_semaphore keyring_sem;
struct work_struct work;
struct ctl_table_set set;
struct ctl_table_header *sysctls;
struct ucounts *ucounts;
long int ucount_max[10];
long int rlimit_max[4];
};
typedef struct cpumask cpumask_var_t[1];
struct wait_queue_entry;
typedef int (*wait_queue_func_t)(struct wait_queue_entry *, unsigned int, int, void *);
struct wait_queue_entry {
unsigned int flags;
void *private;
wait_queue_func_t func;
struct list_head entry;
};
typedef struct wait_queue_entry wait_queue_entry_t;
enum refcount_saturation_type {
REFCOUNT_ADD_NOT_ZERO_OVF = 0,
REFCOUNT_ADD_OVF = 1,
REFCOUNT_ADD_UAF = 2,
REFCOUNT_SUB_UAF = 3,
REFCOUNT_DEC_LEAK = 4,
};
struct rcu_work {
struct work_struct work;
struct callback_head rcu;
struct workqueue_struct *wq;
};
struct task_cputime {
u64 stime;
u64 utime;
long long unsigned int sum_exec_runtime;
};
struct siginfo {
union {
struct {
int si_signo;
int si_code;
int si_errno;
union __sifields _sifields;
};
int _si_pad[32];
};
};
typedef struct siginfo siginfo_t;
struct sigqueue {
struct list_head list;
int flags;
kernel_siginfo_t info;
struct ucounts *ucounts;
};
struct ucounts {
struct hlist_node node;
struct user_namespace *ns;
kuid_t uid;
atomic_t count;
atomic_long_t ucount[10];
atomic_long_t rlimit[4];
};
struct cgroup_subsys_state;
struct cgroup;
struct css_set {
struct cgroup_subsys_state *subsys[0];
refcount_t refcount;
struct css_set *dom_cset;
struct cgroup *dfl_cgrp;
int nr_tasks;
struct list_head tasks;
struct list_head mg_tasks;
struct list_head dying_tasks;
struct list_head task_iters;
struct list_head e_cset_node[0];
struct list_head threaded_csets;
struct list_head threaded_csets_node;
struct hlist_node hlist;
struct list_head cgrp_links;
struct list_head mg_src_preload_node;
struct list_head mg_dst_preload_node;
struct list_head mg_node;
struct cgroup *mg_src_cgrp;
struct cgroup *mg_dst_cgrp;
struct css_set *mg_dst_cset;
bool dead;
struct callback_head callback_head;
};
struct perf_event_groups {
struct rb_root tree;
long: 32;
u64 index;
};
typedef struct {
atomic_long_t a;
} local_t;
struct pmu;
struct perf_event_context {
struct pmu *pmu;
raw_spinlock_t lock;
struct mutex mutex;
struct list_head active_ctx_list;
struct perf_event_groups pinned_groups;
struct perf_event_groups flexible_groups;
struct list_head event_list;
struct list_head pinned_active;
struct list_head flexible_active;
int nr_events;
int nr_active;
int nr_user;
int is_active;
int nr_stat;
int nr_freq;
int rotate_disable;
int rotate_necessary;
refcount_t refcount;
struct task_struct *task;
u64 time;
u64 timestamp;
u64 timeoffset;
struct perf_event_context *parent_ctx;
long: 32;
u64 parent_gen;
u64 generation;
int pin_count;
void *task_ctx_data;
struct callback_head callback_head;
local_t nr_pending;
long: 32;
};
struct ftrace_ret_stack {
long unsigned int ret;
long unsigned int func;
long long unsigned int calltime;
long long unsigned int subtime;
};
struct __large_struct {
long unsigned int buf[100];
};
struct cgroup_subsys;
struct cgroup_subsys_state {
struct cgroup *cgroup;
struct cgroup_subsys *ss;
struct percpu_ref refcnt;
struct list_head sibling;
struct list_head children;
struct list_head rstat_css_node;
int id;
unsigned int flags;
u64 serial_nr;
atomic_t online_cnt;
struct work_struct destroy_work;
struct rcu_work destroy_rwork;
struct cgroup_subsys_state *parent;
long: 32;
};
struct cgroup_file {
struct kernfs_node *kn;
long unsigned int notified_at;
struct timer_list notify_timer;
};
struct cgroup_base_stat {
struct task_cputime cputime;
};
struct cgroup_bpf {};
struct cgroup_freezer_state {
bool freeze;
int e_freeze;
int nr_frozen_descendants;
int nr_frozen_tasks;
};
struct cgroup_root;
struct cgroup_rstat_cpu;
struct psi_group;
struct cgroup {
struct cgroup_subsys_state self;
long unsigned int flags;
int level;
int max_depth;
int nr_descendants;
int nr_dying_descendants;
int max_descendants;
int nr_populated_csets;
int nr_populated_domain_children;
int nr_populated_threaded_children;
int nr_threaded_children;
struct kernfs_node *kn;
struct cgroup_file procs_file;
struct cgroup_file events_file;
struct cgroup_file psi_files[0];
u16 subtree_control;
u16 subtree_ss_mask;
u16 old_subtree_control;
u16 old_subtree_ss_mask;
struct cgroup_subsys_state *subsys[0];
struct cgroup_root *root;
struct list_head cset_links;
struct list_head e_csets[0];
struct cgroup *dom_cgrp;
struct cgroup *old_dom_cgrp;
struct cgroup_rstat_cpu *rstat_cpu;
struct list_head rstat_css_list;
long: 32;
struct cgroup_base_stat last_bstat;
struct cgroup_base_stat bstat;
struct prev_cputime prev_cputime;
struct list_head pidlists;
struct mutex pidlist_mutex;
wait_queue_head_t offline_waitq;
struct work_struct release_agent_work;
struct psi_group *psi;
struct cgroup_bpf bpf;
atomic_t congestion_count;
struct cgroup_freezer_state freezer;
struct cgroup *ancestors[0];
long: 32;
};
struct wait_bit_key {
void *flags;
int bit_nr;
long unsigned int timeout;
};
typedef int wait_bit_action_f(struct wait_bit_key *, int);
typedef int proc_handler(struct ctl_table *, int, void *, size_t *, loff_t *);
struct ctl_table_poll;
struct ctl_table {
const char *procname;
void *data;
int maxlen;
umode_t mode;
struct ctl_table *child;
proc_handler *proc_handler;
struct ctl_table_poll *poll;
void *extra1;
void *extra2;
};
struct ctl_table_poll {
atomic_t event;
wait_queue_head_t wait;
};
struct ctl_node {
struct rb_node node;
struct ctl_table_header *header;
};
struct ctl_table_root {
struct ctl_table_set default_set;
struct ctl_table_set * (*lookup)(struct ctl_table_root *);
void (*set_ownership)(struct ctl_table_header *, struct ctl_table *, kuid_t *, kgid_t *);
int (*permissions)(struct ctl_table_header *, struct ctl_table *);
};
struct wait_page_queue {
struct folio *folio;
int bit_nr;
wait_queue_entry_t wait;
};
struct readahead_control {
struct file *file;
struct address_space *mapping;
struct file_ra_state *ra;
long unsigned int _index;
unsigned int _nr_pages;
unsigned int _batch_count;
bool _workingset;
long unsigned int _pflags;
};
struct iovec;
struct kvec;
struct bio_vec;
struct iov_iter {
u8 iter_type;
bool nofault;
bool data_source;
bool user_backed;
union {
size_t iov_offset;
int last_offset;
};
size_t count;
union {
const struct iovec *iov;
const struct kvec *kvec;
const struct bio_vec *bvec;
struct xarray *xarray;
struct pipe_inode_info *pipe;
void *ubuf;
};
union {
long unsigned int nr_segs;
struct {
unsigned int head;
unsigned int start_head;
};
loff_t xarray_start;
};
};
struct cgroup_namespace {
struct ns_common ns;
struct user_namespace *user_ns;
struct ucounts *ucounts;
struct css_set *root_cset;
};
struct ptrace_peeksiginfo_args {
__u64 off;
__u32 flags;
__s32 nr;
};
struct ptrace_syscall_info {
__u8 op;
__u8 pad[3];
__u32 arch;
__u64 instruction_pointer;
__u64 stack_pointer;
union {
struct {
__u64 nr;
__u64 args[6];
} entry;
struct {
__s64 rval;
__u8 is_error;
long: 32;
} exit;
struct {
__u64 nr;
__u64 args[6];
__u32 ret_data;
long: 32;
} seccomp;
};
};
struct ptrace_rseq_configuration {
__u64 rseq_abi_pointer;
__u32 rseq_abi_size;
__u32 signature;
__u32 flags;
__u32 pad;
};
struct iovec {
void *iov_base;
__kernel_size_t iov_len;
};
struct kvec {
void *iov_base;
size_t iov_len;
};
struct bio_vec {
struct page *bv_page;
unsigned int bv_len;
unsigned int bv_offset;
};
enum {
UNAME26 = 131072,
ADDR_NO_RANDOMIZE = 262144,
FDPIC_FUNCPTRS = 524288,
MMAP_PAGE_ZERO = 1048576,
ADDR_COMPAT_LAYOUT = 2097152,
READ_IMPLIES_EXEC = 4194304,
ADDR_LIMIT_32BIT = 8388608,
SHORT_INODE = 16777216,
WHOLE_SECONDS = 33554432,
STICKY_TIMEOUTS = 67108864,
ADDR_LIMIT_3GB = 134217728,
};
struct trace_event_functions;
struct trace_event {
struct hlist_node node;
struct list_head list;
int type;
struct trace_event_functions *funcs;
};
struct trace_event_class;
struct event_filter;
struct bpf_prog_array;
struct perf_event;
struct trace_event_call {
struct list_head list;
struct trace_event_class *class;
union {
char *name;
struct tracepoint *tp;
};
struct trace_event event;
char *print_fmt;
struct event_filter *filter;
union {
void *module;
atomic_t refcnt;
};
void *data;
int flags;
int perf_refcount;
struct hlist_head *perf_events;
struct bpf_prog_array *prog_array;
int (*perf_perm)(struct trace_event_call *, struct perf_event *);
};
struct trace_eval_map {
const char *system;
const char *eval_string;
long unsigned int eval_value;
};
struct seq_buf {
char *buffer;
size_t size;
size_t len;
long: 32;
loff_t readpos;
};
struct trace_seq {
char buffer[16384];
struct seq_buf seq;
int full;
long: 32;
};
enum perf_sw_ids {
PERF_COUNT_SW_CPU_CLOCK = 0,
PERF_COUNT_SW_TASK_CLOCK = 1,
PERF_COUNT_SW_PAGE_FAULTS = 2,
PERF_COUNT_SW_CONTEXT_SWITCHES = 3,
PERF_COUNT_SW_CPU_MIGRATIONS = 4,
PERF_COUNT_SW_PAGE_FAULTS_MIN = 5,
PERF_COUNT_SW_PAGE_FAULTS_MAJ = 6,
PERF_COUNT_SW_ALIGNMENT_FAULTS = 7,
PERF_COUNT_SW_EMULATION_FAULTS = 8,
PERF_COUNT_SW_DUMMY = 9,
PERF_COUNT_SW_BPF_OUTPUT = 10,
PERF_COUNT_SW_CGROUP_SWITCHES = 11,
PERF_COUNT_SW_MAX = 12,
};
enum perf_branch_sample_type_shift {
PERF_SAMPLE_BRANCH_USER_SHIFT = 0,
PERF_SAMPLE_BRANCH_KERNEL_SHIFT = 1,
PERF_SAMPLE_BRANCH_HV_SHIFT = 2,
PERF_SAMPLE_BRANCH_ANY_SHIFT = 3,
PERF_SAMPLE_BRANCH_ANY_CALL_SHIFT = 4,
PERF_SAMPLE_BRANCH_ANY_RETURN_SHIFT = 5,
PERF_SAMPLE_BRANCH_IND_CALL_SHIFT = 6,
PERF_SAMPLE_BRANCH_ABORT_TX_SHIFT = 7,
PERF_SAMPLE_BRANCH_IN_TX_SHIFT = 8,
PERF_SAMPLE_BRANCH_NO_TX_SHIFT = 9,
PERF_SAMPLE_BRANCH_COND_SHIFT = 10,
PERF_SAMPLE_BRANCH_CALL_STACK_SHIFT = 11,
PERF_SAMPLE_BRANCH_IND_JUMP_SHIFT = 12,
PERF_SAMPLE_BRANCH_CALL_SHIFT = 13,
PERF_SAMPLE_BRANCH_NO_FLAGS_SHIFT = 14,
PERF_SAMPLE_BRANCH_NO_CYCLES_SHIFT = 15,
PERF_SAMPLE_BRANCH_TYPE_SAVE_SHIFT = 16,
PERF_SAMPLE_BRANCH_HW_INDEX_SHIFT = 17,
PERF_SAMPLE_BRANCH_PRIV_SAVE_SHIFT = 18,
PERF_SAMPLE_BRANCH_MAX_SHIFT = 19,
};
struct perf_event_attr {
__u32 type;
__u32 size;
__u64 config;
union {
__u64 sample_period;
__u64 sample_freq;
};
__u64 sample_type;
__u64 read_format;
__u64 disabled: 1;
__u64 inherit: 1;
__u64 pinned: 1;
__u64 exclusive: 1;
__u64 exclude_user: 1;
__u64 exclude_kernel: 1;
__u64 exclude_hv: 1;
__u64 exclude_idle: 1;
__u64 mmap: 1;
__u64 comm: 1;
__u64 freq: 1;
__u64 inherit_stat: 1;
__u64 enable_on_exec: 1;
__u64 task: 1;
__u64 watermark: 1;
__u64 precise_ip: 2;
__u64 mmap_data: 1;
__u64 sample_id_all: 1;
__u64 exclude_host: 1;
__u64 exclude_guest: 1;
__u64 exclude_callchain_kernel: 1;
__u64 exclude_callchain_user: 1;
__u64 mmap2: 1;
__u64 comm_exec: 1;
__u64 use_clockid: 1;
__u64 context_switch: 1;
__u64 write_backward: 1;
__u64 namespaces: 1;
__u64 ksymbol: 1;
__u64 bpf_event: 1;
__u64 aux_output: 1;
__u64 cgroup: 1;
__u64 text_poke: 1;
__u64 build_id: 1;
__u64 inherit_thread: 1;
__u64 remove_on_exec: 1;
__u64 sigtrap: 1;
__u64 __reserved_1: 26;
union {
__u32 wakeup_events;
__u32 wakeup_watermark;
};
__u32 bp_type;
union {
__u64 bp_addr;
__u64 kprobe_func;
__u64 uprobe_path;
__u64 config1;
};
union {
__u64 bp_len;
__u64 kprobe_addr;
__u64 probe_offset;
__u64 config2;
};
__u64 branch_sample_type;
__u64 sample_regs_user;
__u32 sample_stack_user;
__s32 clockid;
__u64 sample_regs_intr;
__u32 aux_watermark;
__u16 sample_max_stack;
__u16 __reserved_2;
__u32 aux_sample_size;
__u32 __reserved_3;
__u64 sig_data;
};
union perf_mem_data_src {
__u64 val;
struct {
__u64 mem_op: 5;
__u64 mem_lvl: 14;
__u64 mem_snoop: 5;
__u64 mem_lock: 2;
__u64 mem_dtlb: 7;
__u64 mem_lvl_num: 4;
__u64 mem_remote: 1;
__u64 mem_snoopx: 2;
__u64 mem_blk: 3;
__u64 mem_hops: 3;
__u64 mem_rsvd: 18;
};
};
struct perf_branch_entry {
__u64 from;
__u64 to;
__u64 mispred: 1;
__u64 predicted: 1;
__u64 in_tx: 1;
__u64 abort: 1;
__u64 cycles: 16;
__u64 type: 4;
__u64 spec: 2;
__u64 new_type: 4;
__u64 priv: 3;
__u64 reserved: 31;
};
union perf_sample_weight {
__u64 full;
struct {
__u32 var1_dw;
__u16 var2_w;
__u16 var3_w;
};
};
typedef struct {
atomic64_t a;
} local64_t;
struct ftrace_regs {
struct pt_regs regs;
};
struct ftrace_ops;
typedef void (*ftrace_func_t)(long unsigned int, long unsigned int, struct ftrace_ops *, struct ftrace_regs *);
struct ftrace_hash;
struct ftrace_ops_hash {
struct ftrace_hash *notrace_hash;
struct ftrace_hash *filter_hash;
struct mutex regex_lock;
};
enum ftrace_ops_cmd {
FTRACE_OPS_CMD_ENABLE_SHARE_IPMODIFY_SELF = 0,
FTRACE_OPS_CMD_ENABLE_SHARE_IPMODIFY_PEER = 1,
FTRACE_OPS_CMD_DISABLE_SHARE_IPMODIFY_PEER = 2,
};
typedef int (*ftrace_ops_func_t)(struct ftrace_ops *, enum ftrace_ops_cmd);
struct ftrace_ops {
ftrace_func_t func;
struct ftrace_ops *next;
long unsigned int flags;
void *private;
ftrace_func_t saved_func;
struct ftrace_ops_hash local_hash;
struct ftrace_ops_hash *func_hash;
struct ftrace_ops_hash old_hash;
long unsigned int trampoline;
long unsigned int trampoline_size;
struct list_head list;
ftrace_ops_func_t ops_func;
};
struct irq_work {
struct __call_single_node node;
void (*func)(struct irq_work *);
struct rcuwait irqwait;
};
struct perf_regs {
__u64 abi;
struct pt_regs *regs;
long: 32;
};
enum {
TASKSTATS_CMD_UNSPEC = 0,
TASKSTATS_CMD_GET = 1,
TASKSTATS_CMD_NEW = 2,
__TASKSTATS_CMD_MAX = 3,
};
enum ucount_type {
UCOUNT_USER_NAMESPACES = 0,
UCOUNT_PID_NAMESPACES = 1,
UCOUNT_UTS_NAMESPACES = 2,
UCOUNT_IPC_NAMESPACES = 3,
UCOUNT_NET_NAMESPACES = 4,
UCOUNT_MNT_NAMESPACES = 5,
UCOUNT_CGROUP_NAMESPACES = 6,
UCOUNT_TIME_NAMESPACES = 7,
UCOUNT_INOTIFY_INSTANCES = 8,
UCOUNT_INOTIFY_WATCHES = 9,
UCOUNT_COUNTS = 10,
};
enum rlimit_type {
UCOUNT_RLIMIT_NPROC = 0,
UCOUNT_RLIMIT_MSGQUEUE = 1,
UCOUNT_RLIMIT_SIGPENDING = 2,
UCOUNT_RLIMIT_MEMLOCK = 3,
UCOUNT_RLIMIT_COUNTS = 4,
};
enum cpu_usage_stat {
CPUTIME_USER = 0,
CPUTIME_NICE = 1,
CPUTIME_SYSTEM = 2,
CPUTIME_SOFTIRQ = 3,
CPUTIME_IRQ = 4,
CPUTIME_IDLE = 5,
CPUTIME_IOWAIT = 6,
CPUTIME_STEAL = 7,
CPUTIME_GUEST = 8,
CPUTIME_GUEST_NICE = 9,
NR_STATS = 10,
};
struct u64_stats_sync {
seqcount_t seq;
};
struct psi_group {};
enum cgroup_subsys_id {
CGROUP_SUBSYS_COUNT = 0,
};
struct cgroup_taskset;
struct cftype;
struct cgroup_subsys {
struct cgroup_subsys_state * (*css_alloc)(struct cgroup_subsys_state *);
int (*css_online)(struct cgroup_subsys_state *);
void (*css_offline)(struct cgroup_subsys_state *);
void (*css_released)(struct cgroup_subsys_state *);
void (*css_free)(struct cgroup_subsys_state *);
void (*css_reset)(struct cgroup_subsys_state *);
void (*css_rstat_flush)(struct cgroup_subsys_state *, int);
int (*css_extra_stat_show)(struct seq_file *, struct cgroup_subsys_state *);
int (*can_attach)(struct cgroup_taskset *);
void (*cancel_attach)(struct cgroup_taskset *);
void (*attach)(struct cgroup_taskset *);
void (*post_attach)();
int (*can_fork)(struct task_struct *, struct css_set *);
void (*cancel_fork)(struct task_struct *, struct css_set *);
void (*fork)(struct task_struct *);
void (*exit)(struct task_struct *);
void (*release)(struct task_struct *);
void (*bind)(struct cgroup_subsys_state *);
bool early_init: 1;
bool implicit_on_dfl: 1;
bool threaded: 1;
int id;
const char *name;
const char *legacy_name;
struct cgroup_root *root;
struct idr css_idr;
struct list_head cfts;
struct cftype *dfl_cftypes;
struct cftype *legacy_cftypes;
unsigned int depends_on;
};
struct cgroup_rstat_cpu {
struct u64_stats_sync bsync;
long: 32;
struct cgroup_base_stat bstat;
struct cgroup_base_stat last_bstat;
struct cgroup *updated_children;
struct cgroup *updated_next;
};
struct cgroup_root {
struct kernfs_root *kf_root;
unsigned int subsys_mask;
int hierarchy_id;
long: 32;
struct cgroup cgrp;
struct cgroup *cgrp_ancestor_storage;
atomic_t nr_cgrps;
struct list_head root_list;
unsigned int flags;
char release_agent_path[4096];
char name[64];
long: 32;
};
struct cftype {
char name[64];
long unsigned int private;
size_t max_write_len;
unsigned int flags;
unsigned int file_offset;
struct cgroup_subsys *ss;
struct list_head node;
struct kernfs_ops *kf_ops;
int (*open)(struct kernfs_open_file *);
void (*release)(struct kernfs_open_file *);
u64 (*read_u64)(struct cgroup_subsys_state *, struct cftype *);
s64 (*read_s64)(struct cgroup_subsys_state *, struct cftype *);
int (*seq_show)(struct seq_file *, void *);
void * (*seq_start)(struct seq_file *, loff_t *);
void * (*seq_next)(struct seq_file *, void *, loff_t *);
void (*seq_stop)(struct seq_file *, void *);
int (*write_u64)(struct cgroup_subsys_state *, struct cftype *, u64);
int (*write_s64)(struct cgroup_subsys_state *, struct cftype *, s64);
ssize_t (*write)(struct kernfs_open_file *, char *, size_t, loff_t);
__poll_t (*poll)(struct kernfs_open_file *, struct poll_table_struct *);
};
struct perf_callchain_entry {
__u64 nr;
__u64 ip[0];
};
typedef long unsigned int (*perf_copy_f)(void *, const void *, long unsigned int, long unsigned int);
struct perf_raw_frag {
union {
struct perf_raw_frag *next;
long unsigned int pad;
};
perf_copy_f copy;
void *data;
u32 size;
};
struct perf_raw_record {
struct perf_raw_frag frag;
u32 size;
};
struct perf_branch_stack {
__u64 nr;
__u64 hw_idx;
struct perf_branch_entry entries[0];
};
struct hw_perf_event_extra {
u64 config;
unsigned int reg;
int alloc;
int idx;
long: 32;
};
struct hw_perf_event {
union {
struct {
u64 config;
u64 last_tag;
long unsigned int config_base;
long unsigned int event_base;
int event_base_rdpmc;
int idx;
int last_cpu;
int flags;
struct hw_perf_event_extra extra_reg;
struct hw_perf_event_extra branch_reg;
};
struct {
struct hrtimer hrtimer;
};
struct {
struct list_head tp_list;
};
struct {
u64 pwr_acc;
u64 ptsc;
};
struct {
u8 iommu_bank;
u8 iommu_cntr;
u16 padding;
long: 32;
u64 conf;
u64 conf1;
};
};
struct task_struct *target;
void *addr_filters;
long unsigned int addr_filters_gen;
int state;
local64_t prev_count;
u64 sample_period;
union {
struct {
u64 last_period;
local64_t period_left;
};
struct {
u64 saved_metric;
u64 saved_slots;
};
};
u64 interrupts_seq;
u64 interrupts;
u64 freq_time_stamp;
u64 freq_count_stamp;
};
struct perf_cpu_context;
struct perf_output_handle;
struct pmu {
struct list_head entry;
struct module *module;
struct device *dev;
const struct attribute_group **attr_groups;
const struct attribute_group **attr_update;
const char *name;
int type;
int capabilities;
int *pmu_disable_count;
struct perf_cpu_context *pmu_cpu_context;
atomic_t exclusive_cnt;
int task_ctx_nr;
int hrtimer_interval_ms;
unsigned int nr_addr_filters;
void (*pmu_enable)(struct pmu *);
void (*pmu_disable)(struct pmu *);
int (*event_init)(struct perf_event *);
void (*event_mapped)(struct perf_event *, struct mm_struct *);
void (*event_unmapped)(struct perf_event *, struct mm_struct *);
int (*add)(struct perf_event *, int);
void (*del)(struct perf_event *, int);
void (*start)(struct perf_event *, int);
void (*stop)(struct perf_event *, int);
void (*read)(struct perf_event *);
void (*start_txn)(struct pmu *, unsigned int);
int (*commit_txn)(struct pmu *);
void (*cancel_txn)(struct pmu *);
int (*event_idx)(struct perf_event *);
void (*sched_task)(struct perf_event_context *, bool);
struct kmem_cache *task_ctx_cache;
void (*swap_task_ctx)(struct perf_event_context *, struct perf_event_context *);
void * (*setup_aux)(struct perf_event *, void **, int, bool);
void (*free_aux)(void *);
long int (*snapshot_aux)(struct perf_event *, struct perf_output_handle *, long unsigned int);
int (*addr_filters_validate)(struct list_head *);
void (*addr_filters_sync)(struct perf_event *);
int (*aux_output_match)(struct perf_event *);
int (*filter_match)(struct perf_event *);
int (*check_period)(struct perf_event *, u64);
};
struct perf_cpu_context {
struct perf_event_context ctx;
struct perf_event_context *task_ctx;
int active_oncpu;
int exclusive;
raw_spinlock_t hrtimer_lock;
struct hrtimer hrtimer;
ktime_t hrtimer_interval;
unsigned int hrtimer_active;
struct list_head sched_cb_entry;
int sched_cb_usage;
int online;
int heap_size;
struct perf_event **heap;
struct perf_event *heap_default[2];
long: 32;
};
enum perf_event_state {
PERF_EVENT_STATE_DEAD = -4,
PERF_EVENT_STATE_EXIT = -3,
PERF_EVENT_STATE_ERROR = -2,
PERF_EVENT_STATE_OFF = -1,
PERF_EVENT_STATE_INACTIVE = 0,
PERF_EVENT_STATE_ACTIVE = 1,
};
struct perf_addr_filters_head {
struct list_head list;
raw_spinlock_t lock;
unsigned int nr_file_filters;
};
struct perf_sample_data;
typedef void (*perf_overflow_handler_t)(struct perf_event *, struct perf_sample_data *, struct pt_regs *);
struct perf_buffer;
struct perf_addr_filter_range;
struct bpf_prog;
struct perf_event {
struct list_head event_entry;
struct list_head sibling_list;
struct list_head active_list;
struct rb_node group_node;
long: 32;
u64 group_index;
struct list_head migrate_entry;
struct hlist_node hlist_entry;
struct list_head active_entry;
int nr_siblings;
int event_caps;
int group_caps;
struct perf_event *group_leader;
struct pmu *pmu;
void *pmu_private;
enum perf_event_state state;
unsigned int attach_state;
local64_t count;
atomic64_t child_count;
u64 total_time_enabled;
u64 total_time_running;
u64 tstamp;
struct perf_event_attr attr;
u16 header_size;
u16 id_header_size;
u16 read_size;
struct hw_perf_event hw;
struct perf_event_context *ctx;
atomic_long_t refcount;
atomic64_t child_total_time_enabled;
atomic64_t child_total_time_running;
struct mutex child_mutex;
struct list_head child_list;
struct perf_event *parent;
int oncpu;
int cpu;
struct list_head owner_entry;
struct task_struct *owner;
struct mutex mmap_mutex;
atomic_t mmap_count;
struct perf_buffer *rb;
struct list_head rb_entry;
long unsigned int rcu_batches;
int rcu_pending;
wait_queue_head_t waitq;
struct fasync_struct *fasync;
unsigned int pending_wakeup;
unsigned int pending_kill;
unsigned int pending_disable;
unsigned int pending_sigtrap;
long unsigned int pending_addr;
struct irq_work pending_irq;
struct callback_head pending_task;
unsigned int pending_work;
atomic_t event_limit;
struct perf_addr_filters_head addr_filters;
struct perf_addr_filter_range *addr_filter_ranges;
long unsigned int addr_filters_gen;
struct perf_event *aux_event;
void (*destroy)(struct perf_event *);
struct callback_head callback_head;
struct pid_namespace *ns;
u64 id;
atomic64_t lost_samples;
u64 (*clock)();
perf_overflow_handler_t overflow_handler;
void *overflow_handler_context;
perf_overflow_handler_t orig_overflow_handler;
struct bpf_prog *prog;
long: 32;
u64 bpf_cookie;
struct trace_event_call *tp_event;
struct event_filter *filter;
struct ftrace_ops ftrace_ops;
void *security;
struct list_head sb_list;
};
struct perf_output_handle {
struct perf_event *event;
struct perf_buffer *rb;
long unsigned int wakeup;
long unsigned int size;
u64 aux_flags;
union {
void *addr;
long unsigned int head;
};
int page;
};
struct perf_addr_filter_range {
long unsigned int start;
long unsigned int size;
};
struct perf_sample_data {
u64 sample_flags;
u64 period;
struct perf_branch_stack *br_stack;
long: 32;
union perf_sample_weight weight;
union perf_mem_data_src data_src;
u64 txn;
u64 addr;
struct perf_raw_record *raw;
long: 32;
u64 type;
u64 ip;
struct {
u32 pid;
u32 tid;
} tid_entry;
u64 time;
u64 id;
u64 stream_id;
struct {
u32 cpu;
u32 reserved;
} cpu_entry;
struct perf_callchain_entry *callchain;
long: 32;
u64 aux_size;
struct perf_regs regs_user;
struct perf_regs regs_intr;
u64 stack_user_size;
u64 phys_addr;
u64 cgroup;
u64 data_page_size;
u64 code_page_size;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct trace_entry {
short unsigned int type;
unsigned char flags;
unsigned char preempt_count;
int pid;
};
struct trace_array;
struct tracer;
struct array_buffer;
struct ring_buffer_iter;
struct trace_iterator {
struct trace_array *tr;
struct tracer *trace;
struct array_buffer *array_buffer;
void *private;
int cpu_file;
struct mutex mutex;
struct ring_buffer_iter **buffer_iter;
long unsigned int iter_flags;
void *temp;
unsigned int temp_size;
char *fmt;
unsigned int fmt_size;
long int wait_index;
struct trace_seq tmp_seq;
cpumask_var_t started;
bool snapshot;
struct trace_seq seq;
struct trace_entry *ent;
long unsigned int lost_events;
int leftover;
int ent_size;
int cpu;
long: 32;
u64 ts;
loff_t pos;
long int idx;
long: 32;
};
enum print_line_t {
TRACE_TYPE_PARTIAL_LINE = 0,
TRACE_TYPE_HANDLED = 1,
TRACE_TYPE_UNHANDLED = 2,
TRACE_TYPE_NO_CONSUME = 3,
};
typedef enum print_line_t (*trace_print_func)(struct trace_iterator *, int, struct trace_event *);
struct trace_event_functions {
trace_print_func trace;
trace_print_func raw;
trace_print_func hex;
trace_print_func binary;
};
enum trace_reg {
TRACE_REG_REGISTER = 0,
TRACE_REG_UNREGISTER = 1,
TRACE_REG_PERF_REGISTER = 2,
TRACE_REG_PERF_UNREGISTER = 3,
TRACE_REG_PERF_OPEN = 4,
TRACE_REG_PERF_CLOSE = 5,
TRACE_REG_PERF_ADD = 6,
TRACE_REG_PERF_DEL = 7,
};
struct trace_event_fields {
const char *type;
union {
struct {
const char *name;
const int size;
const int align;
const int is_signed;
const int filter_type;
};
int (*define_fields)(struct trace_event_call *);
};
};
struct trace_event_class {
const char *system;
void *probe;
void *perf_probe;
int (*reg)(struct trace_event_call *, enum trace_reg, void *);
struct trace_event_fields *fields_array;
struct list_head * (*get_fields)(struct trace_event_call *);
struct list_head fields;
int (*raw_init)(struct trace_event_call *);
};
enum {
TRACE_EVENT_FL_FILTERED_BIT = 0,
TRACE_EVENT_FL_CAP_ANY_BIT = 1,
TRACE_EVENT_FL_NO_SET_FILTER_BIT = 2,
TRACE_EVENT_FL_IGNORE_ENABLE_BIT = 3,
TRACE_EVENT_FL_TRACEPOINT_BIT = 4,
TRACE_EVENT_FL_DYNAMIC_BIT = 5,
TRACE_EVENT_FL_KPROBE_BIT = 6,
TRACE_EVENT_FL_UPROBE_BIT = 7,
TRACE_EVENT_FL_EPROBE_BIT = 8,
TRACE_EVENT_FL_CUSTOM_BIT = 9,
};
enum {
TRACE_EVENT_FL_FILTERED = 1,
TRACE_EVENT_FL_CAP_ANY = 2,
TRACE_EVENT_FL_NO_SET_FILTER = 4,
TRACE_EVENT_FL_IGNORE_ENABLE = 8,
TRACE_EVENT_FL_TRACEPOINT = 16,
TRACE_EVENT_FL_DYNAMIC = 32,
TRACE_EVENT_FL_KPROBE = 64,
TRACE_EVENT_FL_UPROBE = 128,
TRACE_EVENT_FL_EPROBE = 256,
TRACE_EVENT_FL_CUSTOM = 512,
};
enum {
EVENT_FILE_FL_ENABLED_BIT = 0,
EVENT_FILE_FL_RECORDED_CMD_BIT = 1,
EVENT_FILE_FL_RECORDED_TGID_BIT = 2,
EVENT_FILE_FL_FILTERED_BIT = 3,
EVENT_FILE_FL_NO_SET_FILTER_BIT = 4,
EVENT_FILE_FL_SOFT_MODE_BIT = 5,
EVENT_FILE_FL_SOFT_DISABLED_BIT = 6,
EVENT_FILE_FL_TRIGGER_MODE_BIT = 7,
EVENT_FILE_FL_TRIGGER_COND_BIT = 8,
EVENT_FILE_FL_PID_FILTER_BIT = 9,
EVENT_FILE_FL_WAS_ENABLED_BIT = 10,
};
struct syscall_metadata {
const char *name;
int syscall_nr;
int nb_args;
const char **types;
const char **args;
struct list_head enter_fields;
struct trace_event_call *enter_event;
struct trace_event_call *exit_event;
};
struct membuf {
void *p;
size_t left;
};
struct user_regset;
typedef int user_regset_active_fn(struct task_struct *, const struct user_regset *);
typedef int user_regset_get2_fn(struct task_struct *, const struct user_regset *, struct membuf);
typedef int user_regset_set_fn(struct task_struct *, const struct user_regset *, unsigned int, unsigned int, const void *, const void *);
typedef int user_regset_writeback_fn(struct task_struct *, const struct user_regset *, int);
struct user_regset {
user_regset_get2_fn *regset_get;
user_regset_set_fn *set;
user_regset_active_fn *active;
user_regset_writeback_fn *writeback;
unsigned int n;
unsigned int size;
unsigned int align;
unsigned int bias;
unsigned int core_note_type;
};
struct user_regset_view {
const char *name;
const struct user_regset *regsets;
unsigned int n;
u32 e_flags;
u16 e_machine;
u8 ei_osabi;
};
struct irq_desc;
typedef void (*irq_flow_handler_t)(struct irq_desc *);
struct msi_desc;
struct irq_common_data {
unsigned int state_use_accessors;
void *handler_data;
struct msi_desc *msi_desc;
cpumask_var_t affinity;
cpumask_var_t effective_affinity;
unsigned int ipi_offset;
};
struct irq_chip;
struct irq_domain;
struct irq_data {
u32 mask;
unsigned int irq;
long unsigned int hwirq;
struct irq_common_data *common;
struct irq_chip *chip;
struct irq_domain *domain;
struct irq_data *parent_data;
void *chip_data;
};
struct irqaction;
struct irq_affinity_notify;
struct proc_dir_entry;
struct irq_desc {
struct irq_common_data irq_common_data;
struct irq_data irq_data;
unsigned int *kstat_irqs;
irq_flow_handler_t handle_irq;
struct irqaction *action;
unsigned int status_use_accessors;
unsigned int core_internal_state__do_not_mess_with_it;
unsigned int depth;
unsigned int wake_depth;
unsigned int tot_count;
unsigned int irq_count;
long unsigned int last_unhandled;
unsigned int irqs_unhandled;
atomic_t threads_handled;
int threads_handled_last;
raw_spinlock_t lock;
struct cpumask *percpu_enabled;
const struct cpumask *percpu_affinity;
const struct cpumask *affinity_hint;
struct irq_affinity_notify *affinity_notify;
long unsigned int threads_oneshot;
atomic_t threads_active;
wait_queue_head_t wait_for_threads;
struct proc_dir_entry *dir;
struct mutex request_mutex;
int parent_irq;
struct module *owner;
const char *name;
long: 32;
long: 32;
long: 32;
};
enum {
IRQ_TYPE_NONE = 0,
IRQ_TYPE_EDGE_RISING = 1,
IRQ_TYPE_EDGE_FALLING = 2,
IRQ_TYPE_EDGE_BOTH = 3,
IRQ_TYPE_LEVEL_HIGH = 4,
IRQ_TYPE_LEVEL_LOW = 8,
IRQ_TYPE_LEVEL_MASK = 12,
IRQ_TYPE_SENSE_MASK = 15,
IRQ_TYPE_DEFAULT = 15,
IRQ_TYPE_PROBE = 16,
IRQ_LEVEL = 256,
IRQ_PER_CPU = 512,
IRQ_NOPROBE = 1024,
IRQ_NOREQUEST = 2048,
IRQ_NOAUTOEN = 4096,
IRQ_NO_BALANCING = 8192,
IRQ_MOVE_PCNTXT = 16384,
IRQ_NESTED_THREAD = 32768,
IRQ_NOTHREAD = 65536,
IRQ_PER_CPU_DEVID = 131072,
IRQ_IS_POLLED = 262144,
IRQ_DISABLE_UNLAZY = 524288,
IRQ_HIDDEN = 1048576,
IRQ_NO_DEBUG = 2097152,
};
enum irqchip_irq_state {
IRQCHIP_STATE_PENDING = 0,
IRQCHIP_STATE_ACTIVE = 1,
IRQCHIP_STATE_MASKED = 2,
IRQCHIP_STATE_LINE_LEVEL = 3,
};
struct msi_msg;
struct irq_chip {
const char *name;
unsigned int (*irq_startup)(struct irq_data *);
void (*irq_shutdown)(struct irq_data *);
void (*irq_enable)(struct irq_data *);
void (*irq_disable)(struct irq_data *);
void (*irq_ack)(struct irq_data *);
void (*irq_mask)(struct irq_data *);
void (*irq_mask_ack)(struct irq_data *);
void (*irq_unmask)(struct irq_data *);
void (*irq_eoi)(struct irq_data *);
int (*irq_set_affinity)(struct irq_data *, const struct cpumask *, bool);
int (*irq_retrigger)(struct irq_data *);
int (*irq_set_type)(struct irq_data *, unsigned int);
int (*irq_set_wake)(struct irq_data *, unsigned int);
void (*irq_bus_lock)(struct irq_data *);
void (*irq_bus_sync_unlock)(struct irq_data *);
void (*irq_suspend)(struct irq_data *);
void (*irq_resume)(struct irq_data *);
void (*irq_pm_shutdown)(struct irq_data *);
void (*irq_calc_mask)(struct irq_data *);
void (*irq_print_chip)(struct irq_data *, struct seq_file *);
int (*irq_request_resources)(struct irq_data *);
void (*irq_release_resources)(struct irq_data *);
void (*irq_compose_msi_msg)(struct irq_data *, struct msi_msg *);
void (*irq_write_msi_msg)(struct irq_data *, struct msi_msg *);
int (*irq_get_irqchip_state)(struct irq_data *, enum irqchip_irq_state, bool *);
int (*irq_set_irqchip_state)(struct irq_data *, enum irqchip_irq_state, bool);
int (*irq_set_vcpu_affinity)(struct irq_data *, void *);
void (*ipi_send_single)(struct irq_data *, unsigned int);
void (*ipi_send_mask)(struct irq_data *, const struct cpumask *);
int (*irq_nmi_setup)(struct irq_data *);
void (*irq_nmi_teardown)(struct irq_data *);
long unsigned int flags;
};
struct irqaction {
irq_handler_t handler;
void *dev_id;
void *percpu_dev_id;
struct irqaction *next;
irq_handler_t thread_fn;
struct task_struct *thread;
struct irqaction *secondary;
unsigned int irq;
unsigned int flags;
long unsigned int thread_flags;
long unsigned int thread_mask;
const char *name;
struct proc_dir_entry *dir;
long: 32;
long: 32;
long: 32;
};
struct irq_affinity_notify {
unsigned int irq;
struct kref kref;
struct work_struct work;
void (*notify)(struct irq_affinity_notify *, const cpumask_t *);
void (*release)(struct kref *);
};
struct irq_chip_regs {
long unsigned int enable;
long unsigned int disable;
long unsigned int mask;
long unsigned int ack;
long unsigned int eoi;
long unsigned int type;
long unsigned int polarity;
};
struct irq_chip_type {
struct irq_chip chip;
struct irq_chip_regs regs;
irq_flow_handler_t handler;
u32 type;
u32 mask_cache_priv;
u32 *mask_cache;
};
struct irq_chip_generic {
raw_spinlock_t lock;
void *reg_base;
u32 (*reg_readl)(void *);
void (*reg_writel)(u32, void *);
void (*suspend)(struct irq_chip_generic *);
void (*resume)(struct irq_chip_generic *);
unsigned int irq_base;
unsigned int irq_cnt;
u32 mask_cache;
u32 type_cache;
u32 polarity_cache;
u32 wake_enabled;
u32 wake_active;
unsigned int num_ct;
void *private;
long unsigned int installed;
long unsigned int unused;
struct irq_domain *domain;
struct list_head list;
struct irq_chip_type chip_types[0];
};
enum irq_gc_flags {
IRQ_GC_INIT_MASK_CACHE = 1,
IRQ_GC_INIT_NESTED_LOCK = 2,
IRQ_GC_MASK_CACHE_PER_TYPE = 4,
IRQ_GC_NO_MASK = 8,
IRQ_GC_BE_IO = 16,
};
struct irq_affinity_desc {
struct cpumask mask;
unsigned int is_managed: 1;
};
typedef void (*dr_release_t)(struct device *, void *);
typedef int (*dr_match_t)(struct device *, void *, void *);
struct irq_devres {
unsigned int irq;
void *dev_id;
};
struct irq_desc_devres {
unsigned int from;
unsigned int cnt;
};
struct irq_generic_chip_devres {
struct irq_chip_generic *gc;
u32 msk;
unsigned int clr;
unsigned int set;
};
enum pgtable_bits {
_PAGE_PRESENT_SHIFT = 0,
_PAGE_WRITE_SHIFT = 1,
_PAGE_ACCESSED_SHIFT = 2,
_PAGE_MODIFIED_SHIFT = 3,
_PAGE_NO_EXEC_SHIFT = 4,
_PAGE_NO_READ_SHIFT = 5,
_PAGE_GLOBAL_SHIFT = 6,
_PAGE_VALID_SHIFT = 7,
_PAGE_DIRTY_SHIFT = 8,
_CACHE_SHIFT = 9,
};
struct fwnode_operations;
struct fwnode_handle {
struct fwnode_handle *secondary;
const struct fwnode_operations *ops;
struct device *dev;
struct list_head suppliers;
struct list_head consumers;
u8 flags;
};
enum dev_dma_attr {
DEV_DMA_NOT_SUPPORTED = 0,
DEV_DMA_NON_COHERENT = 1,
DEV_DMA_COHERENT = 2,
};
struct fwnode_reference_args;
struct fwnode_endpoint;
struct fwnode_operations {
struct fwnode_handle * (*get)(struct fwnode_handle *);
void (*put)(struct fwnode_handle *);
bool (*device_is_available)(const struct fwnode_handle *);
const void * (*device_get_match_data)(const struct fwnode_handle *, const struct device *);
bool (*device_dma_supported)(const struct fwnode_handle *);
enum dev_dma_attr (*device_get_dma_attr)(const struct fwnode_handle *);
bool (*property_present)(const struct fwnode_handle *, const char *);
int (*property_read_int_array)(const struct fwnode_handle *, const char *, unsigned int, void *, size_t);
int (*property_read_string_array)(const struct fwnode_handle *, const char *, const char **, size_t);
const char * (*get_name)(const struct fwnode_handle *);
const char * (*get_name_prefix)(const struct fwnode_handle *);
struct fwnode_handle * (*get_parent)(const struct fwnode_handle *);
struct fwnode_handle * (*get_next_child_node)(const struct fwnode_handle *, struct fwnode_handle *);
struct fwnode_handle * (*get_named_child_node)(const struct fwnode_handle *, const char *);
int (*get_reference_args)(const struct fwnode_handle *, const char *, const char *, unsigned int, unsigned int, struct fwnode_reference_args *);
struct fwnode_handle * (*graph_get_next_endpoint)(const struct fwnode_handle *, struct fwnode_handle *);
struct fwnode_handle * (*graph_get_remote_endpoint)(const struct fwnode_handle *);
struct fwnode_handle * (*graph_get_port_parent)(struct fwnode_handle *);
int (*graph_parse_endpoint)(const struct fwnode_handle *, struct fwnode_endpoint *);
void * (*iomap)(struct fwnode_handle *, int);
int (*irq_get)(const struct fwnode_handle *, unsigned int);
int (*add_links)(struct fwnode_handle *);
};
struct fwnode_endpoint {
unsigned int port;
unsigned int id;
const struct fwnode_handle *local_fwnode;
};
struct fwnode_reference_args {
struct fwnode_handle *fwnode;
unsigned int nargs;
u64 args[8];
};
typedef u32 phandle;
struct property {
char *name;
int length;
void *value;
struct property *next;
struct bin_attribute attr;
};
struct device_node {
const char *name;
phandle phandle;
const char *full_name;
struct fwnode_handle fwnode;
struct property *properties;
struct property *deadprops;
struct device_node *parent;
struct device_node *child;
struct device_node *sibling;
struct kobject kobj;
long unsigned int _flags;
void *data;
};
enum dma_data_direction {
DMA_BIDIRECTIONAL = 0,
DMA_TO_DEVICE = 1,
DMA_FROM_DEVICE = 2,
DMA_NONE = 3,
};
struct scatterlist {
long unsigned int page_link;
unsigned int offset;
unsigned int length;
dma_addr_t dma_address;
};
struct sg_table {
struct scatterlist *sgl;
unsigned int nents;
unsigned int orig_nents;
};
struct dma_map_ops {
unsigned int flags;
void * (*alloc)(struct device *, size_t, dma_addr_t *, gfp_t, long unsigned int);
void (*free)(struct device *, size_t, void *, dma_addr_t, long unsigned int);
struct page * (*alloc_pages)(struct device *, size_t, dma_addr_t *, enum dma_data_direction, gfp_t);
void (*free_pages)(struct device *, size_t, struct page *, dma_addr_t, enum dma_data_direction);
struct sg_table * (*alloc_noncontiguous)(struct device *, size_t, enum dma_data_direction, gfp_t, long unsigned int);
void (*free_noncontiguous)(struct device *, size_t, struct sg_table *, enum dma_data_direction);
int (*mmap)(struct device *, struct vm_area_struct *, void *, dma_addr_t, size_t, long unsigned int);
int (*get_sgtable)(struct device *, struct sg_table *, void *, dma_addr_t, size_t, long unsigned int);
dma_addr_t (*map_page)(struct device *, struct page *, long unsigned int, size_t, enum dma_data_direction, long unsigned int);
void (*unmap_page)(struct device *, dma_addr_t, size_t, enum dma_data_direction, long unsigned int);
int (*map_sg)(struct device *, struct scatterlist *, int, enum dma_data_direction, long unsigned int);
void (*unmap_sg)(struct device *, struct scatterlist *, int, enum dma_data_direction, long unsigned int);
dma_addr_t (*map_resource)(struct device *, phys_addr_t, size_t, enum dma_data_direction, long unsigned int);
void (*unmap_resource)(struct device *, dma_addr_t, size_t, enum dma_data_direction, long unsigned int);
void (*sync_single_for_cpu)(struct device *, dma_addr_t, size_t, enum dma_data_direction);
void (*sync_single_for_device)(struct device *, dma_addr_t, size_t, enum dma_data_direction);
void (*sync_sg_for_cpu)(struct device *, struct scatterlist *, int, enum dma_data_direction);
void (*sync_sg_for_device)(struct device *, struct scatterlist *, int, enum dma_data_direction);
void (*cache_sync)(struct device *, void *, size_t, enum dma_data_direction);
int (*dma_supported)(struct device *, u64);
u64 (*get_required_mask)(struct device *);
size_t (*max_mapping_size)(struct device *);
size_t (*opt_mapping_size)();
long unsigned int (*get_merge_boundary)(struct device *);
};
struct dma_sgt_handle {
struct sg_table sgt;
struct page **pages;
};
struct dma_devres {
size_t size;
void *vaddr;
dma_addr_t dma_handle;
long unsigned int attrs;
};
typedef __kernel_timer_t timer_t;
typedef unsigned int slab_flags_t;
typedef void (*rcu_callback_t)(struct callback_head *);
struct __kernel_itimerspec {
struct __kernel_timespec it_interval;
struct __kernel_timespec it_value;
};
struct timezone {
int tz_minuteswest;
int tz_dsttime;
};
struct itimerspec64 {
struct timespec64 it_interval;
struct timespec64 it_value;
};
struct __kernel_timex_timeval {
__kernel_time64_t tv_sec;
long long int tv_usec;
};
struct __kernel_timex {
unsigned int modes;
long: 32;
long long int offset;
long long int freq;
long long int maxerror;
long long int esterror;
int status;
long: 32;
long long int constant;
long long int precision;
long long int tolerance;
struct __kernel_timex_timeval time;
long long int tick;
long long int ppsfreq;
long long int jitter;
int shift;
long: 32;
long long int stabil;
long long int jitcnt;
long long int calcnt;
long long int errcnt;
long long int stbcnt;
int tai;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct old_timeval32 {
old_time32_t tv_sec;
s32 tv_usec;
};
struct old_itimerspec32 {
struct old_timespec32 it_interval;
struct old_timespec32 it_value;
};
struct old_timex32 {
u32 modes;
s32 offset;
s32 freq;
s32 maxerror;
s32 esterror;
s32 status;
s32 constant;
s32 precision;
s32 tolerance;
struct old_timeval32 time;
s32 tick;
s32 ppsfreq;
s32 jitter;
s32 shift;
s32 stabil;
s32 jitcnt;
s32 calcnt;
s32 errcnt;
s32 stbcnt;
s32 tai;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum tk_offsets {
TK_OFFS_REAL = 0,
TK_OFFS_BOOT = 1,
TK_OFFS_TAI = 2,
TK_OFFS_MAX = 3,
};
enum hrtimer_mode {
HRTIMER_MODE_ABS = 0,
HRTIMER_MODE_REL = 1,
HRTIMER_MODE_PINNED = 2,
HRTIMER_MODE_SOFT = 4,
HRTIMER_MODE_HARD = 8,
HRTIMER_MODE_ABS_PINNED = 2,
HRTIMER_MODE_REL_PINNED = 3,
HRTIMER_MODE_ABS_SOFT = 4,
HRTIMER_MODE_REL_SOFT = 5,
HRTIMER_MODE_ABS_PINNED_SOFT = 6,
HRTIMER_MODE_REL_PINNED_SOFT = 7,
HRTIMER_MODE_ABS_HARD = 8,
HRTIMER_MODE_REL_HARD = 9,
HRTIMER_MODE_ABS_PINNED_HARD = 10,
HRTIMER_MODE_REL_PINNED_HARD = 11,
};
struct sigevent {
sigval_t sigev_value;
int sigev_signo;
int sigev_notify;
union {
int _pad[13];
int _tid;
struct {
void (*_function)(sigval_t);
void *_attribute;
} _sigev_thread;
} _sigev_un;
};
typedef struct sigevent sigevent_t;
enum alarmtimer_type {
ALARM_REALTIME = 0,
ALARM_BOOTTIME = 1,
ALARM_NUMTYPE = 2,
ALARM_REALTIME_FREEZER = 3,
ALARM_BOOTTIME_FREEZER = 4,
};
enum alarmtimer_restart {
ALARMTIMER_NORESTART = 0,
ALARMTIMER_RESTART = 1,
};
struct alarm {
struct timerqueue_node node;
struct hrtimer timer;
enum alarmtimer_restart (*function)(struct alarm *, ktime_t);
enum alarmtimer_type type;
int state;
void *data;
};
struct cpu_timer {
struct timerqueue_node node;
struct timerqueue_head *head;
struct pid *pid;
struct list_head elist;
int firing;
long: 32;
};
struct k_clock;
struct k_itimer {
struct list_head list;
struct hlist_node t_hash;
spinlock_t it_lock;
const struct k_clock *kclock;
clockid_t it_clock;
timer_t it_id;
int it_active;
long: 32;
s64 it_overrun;
s64 it_overrun_last;
int it_requeue_pending;
int it_sigev_notify;
ktime_t it_interval;
struct signal_struct *it_signal;
union {
struct pid *it_pid;
struct task_struct *it_process;
};
struct sigqueue *sigq;
long: 32;
union {
struct {
struct hrtimer timer;
} real;
struct cpu_timer cpu;
struct {
struct alarm alarmtimer;
} alarm;
} it;
struct callback_head rcu;
};
struct k_clock {
int (*clock_getres)(const clockid_t, struct timespec64 *);
int (*clock_set)(const clockid_t, const struct timespec64 *);
int (*clock_get_timespec)(const clockid_t, struct timespec64 *);
ktime_t (*clock_get_ktime)(const clockid_t);
int (*clock_adj)(const clockid_t, struct __kernel_timex *);
int (*timer_create)(struct k_itimer *);
int (*nsleep)(const clockid_t, int, const struct timespec64 *);
int (*timer_set)(struct k_itimer *, int, struct itimerspec64 *, struct itimerspec64 *);
int (*timer_del)(struct k_itimer *);
void (*timer_get)(struct k_itimer *, struct itimerspec64 *);
void (*timer_rearm)(struct k_itimer *);
s64 (*timer_forward)(struct k_itimer *, ktime_t);
ktime_t (*timer_remaining)(struct k_itimer *, ktime_t);
int (*timer_try_to_cancel)(struct k_itimer *);
void (*timer_arm)(struct k_itimer *, ktime_t, bool, bool);
void (*timer_wait_running)(struct k_itimer *);
};
struct timens_offsets {
struct timespec64 monotonic;
struct timespec64 boottime;
};
struct time_namespace {
struct user_namespace *user_ns;
struct ucounts *ucounts;
struct ns_common ns;
struct timens_offsets offsets;
struct page *vvar_page;
bool frozen_offsets;
};
typedef short int __s16;
typedef __s16 s16;
typedef __u16 __be16;
typedef __u32 __be32;
typedef __u32 __wsum;
struct rhash_head {
struct rhash_head *next;
};
struct rhashtable;
struct rhashtable_compare_arg {
struct rhashtable *ht;
const void *key;
};
typedef u32 (*rht_hashfn_t)(const void *, u32, u32);
typedef u32 (*rht_obj_hashfn_t)(const void *, u32, u32);
typedef int (*rht_obj_cmpfn_t)(struct rhashtable_compare_arg *, const void *);
struct rhashtable_params {
u16 nelem_hint;
u16 key_len;
u16 key_offset;
u16 head_offset;
unsigned int max_size;
u16 min_size;
bool automatic_shrinking;
rht_hashfn_t hashfn;
rht_obj_hashfn_t obj_hashfn;
rht_obj_cmpfn_t obj_cmpfn;
};
struct bucket_table;
struct rhashtable {
struct bucket_table *tbl;
unsigned int key_len;
unsigned int max_elems;
struct rhashtable_params p;
bool rhlist;
struct work_struct run_work;
struct mutex mutex;
spinlock_t lock;
atomic_t nelems;
};
struct seccomp_data {
int nr;
__u32 arch;
__u64 instruction_pointer;
__u64 args[6];
};
struct seccomp_notif_sizes {
__u16 seccomp_notif;
__u16 seccomp_notif_resp;
__u16 seccomp_data;
};
struct seccomp_notif {
__u64 id;
__u32 pid;
__u32 flags;
struct seccomp_data data;
};
struct seccomp_notif_resp {
__u64 id;
__s64 val;
__s32 error;
__u32 flags;
};
struct seccomp_notif_addfd {
__u64 id;
__u32 flags;
__u32 srcfd;
__u32 newfd;
__u32 newfd_flags;
};
struct action_cache {};
struct notification;
struct seccomp_filter {
refcount_t refs;
refcount_t users;
bool log;
bool wait_killable_recv;
struct action_cache cache;
struct seccomp_filter *prev;
struct bpf_prog *prog;
struct notification *notif;
struct mutex notify_lock;
wait_queue_head_t wqh;
};
struct static_key_false {
struct static_key key;
};
struct pipe_buffer;
struct pipe_inode_info {
struct mutex mutex;
wait_queue_head_t rd_wait;
wait_queue_head_t wr_wait;
unsigned int head;
unsigned int tail;
unsigned int max_usage;
unsigned int ring_size;
unsigned int nr_accounted;
unsigned int readers;
unsigned int writers;
unsigned int files;
unsigned int r_counter;
unsigned int w_counter;
bool poll_usage;
struct page *tmp_page;
struct fasync_struct *fasync_readers;
struct fasync_struct *fasync_writers;
struct pipe_buffer *bufs;
struct user_struct *user;
};
struct bpf_run_ctx {};
struct ctl_path {
const char *procname;
};
struct notifier_block;
typedef int (*notifier_fn_t)(struct notifier_block *, long unsigned int, void *);
struct notifier_block {
notifier_fn_t notifier_call;
struct notifier_block *next;
int priority;
};
struct blocking_notifier_head {
struct rw_semaphore rwsem;
struct notifier_block *head;
};
struct raw_notifier_head {
struct notifier_block *head;
};
struct page_pool_params {
unsigned int flags;
unsigned int order;
unsigned int pool_size;
int nid;
struct device *dev;
enum dma_data_direction dma_dir;
unsigned int max_len;
unsigned int offset;
void (*init_callback)(struct page *, void *);
void *init_arg;
};
struct pp_alloc_cache {
u32 count;
struct page *cache[128];
};
struct ptr_ring {
int producer;
spinlock_t producer_lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
int consumer_head;
int consumer_tail;
spinlock_t consumer_lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
int size;
int batch;
void **queue;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct page_pool {
struct page_pool_params p;
struct delayed_work release_dw;
void (*disconnect)(void *);
long unsigned int defer_start;
long unsigned int defer_warn;
u32 pages_state_hold_cnt;
unsigned int frag_offset;
struct page *frag_page;
long int frag_users;
u32 xdp_mem_id;
long: 32;
long: 32;
long: 32;
struct pp_alloc_cache alloc;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct ptr_ring ring;
atomic_t pages_state_release_cnt;
refcount_t user_cnt;
u64 destroy_cnt;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct semaphore {
raw_spinlock_t lock;
unsigned int count;
struct list_head wait_list;
};
struct ref_tracker_dir {};
struct prot_inuse;
struct netns_core {
struct ctl_table_header *sysctl_hdr;
int sysctl_somaxconn;
u8 sysctl_txrehash;
struct prot_inuse *prot_inuse;
};
struct ipstats_mib;
struct tcp_mib;
struct linux_mib;
struct udp_mib;
struct icmp_mib;
struct icmpmsg_mib;
struct icmpv6_mib;
struct icmpv6msg_mib;
struct netns_mib {
struct ipstats_mib *ip_statistics;
struct ipstats_mib *ipv6_statistics;
struct tcp_mib *tcp_statistics;
struct linux_mib *net_statistics;
struct udp_mib *udp_statistics;
struct udp_mib *udp_stats_in6;
struct udp_mib *udplite_statistics;
struct udp_mib *udplite_stats_in6;
struct icmp_mib *icmp_statistics;
struct icmpmsg_mib *icmpmsg_statistics;
struct icmpv6_mib *icmpv6_statistics;
struct icmpv6msg_mib *icmpv6msg_statistics;
struct proc_dir_entry *proc_net_devsnmp6;
};
struct netns_packet {
struct mutex sklist_lock;
struct hlist_head sklist;
};
struct unix_table {
spinlock_t *locks;
struct hlist_head *buckets;
};
struct netns_unix {
struct unix_table table;
int sysctl_max_dgram_qlen;
struct ctl_table_header *ctl;
};
struct netns_nexthop {
struct rb_root rb_root;
struct hlist_head *devhash;
unsigned int seq;
u32 last_id_allocated;
struct blocking_notifier_head notifier_chain;
};
struct inet_hashinfo;
struct inet_timewait_death_row {
refcount_t tw_refcount;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct inet_hashinfo *hashinfo;
int sysctl_max_tw_buckets;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct local_ports {
seqlock_t lock;
int range[2];
bool warned;
};
struct ping_group_range {
seqlock_t lock;
kgid_t range[2];
};
typedef struct {
u64 key[2];
} siphash_key_t;
struct ipv4_devconf;
struct ip_ra_chain;
struct fib_rules_ops;
struct fib_table;
struct inet_peer_base;
struct fqdir;
struct tcp_congestion_ops;
struct tcp_fastopen_context;
struct mr_table;
struct fib_notifier_ops;
struct netns_ipv4 {
struct inet_timewait_death_row tcp_death_row;
struct ctl_table_header *forw_hdr;
struct ctl_table_header *frags_hdr;
struct ctl_table_header *ipv4_hdr;
struct ctl_table_header *route_hdr;
struct ctl_table_header *xfrm4_hdr;
struct ipv4_devconf *devconf_all;
struct ipv4_devconf *devconf_dflt;
struct ip_ra_chain *ra_chain;
struct mutex ra_mutex;
struct fib_rules_ops *rules_ops;
struct fib_table *fib_main;
struct fib_table *fib_default;
unsigned int fib_rules_require_fldissect;
bool fib_has_custom_rules;
bool fib_has_custom_local_routes;
bool fib_offload_disabled;
atomic_t fib_num_tclassid_users;
struct hlist_head *fib_table_hash;
struct sock *fibnl;
struct sock *mc_autojoin_sk;
struct inet_peer_base *peers;
struct fqdir *fqdir;
u8 sysctl_icmp_echo_ignore_all;
u8 sysctl_icmp_echo_enable_probe;
u8 sysctl_icmp_echo_ignore_broadcasts;
u8 sysctl_icmp_ignore_bogus_error_responses;
u8 sysctl_icmp_errors_use_inbound_ifaddr;
int sysctl_icmp_ratelimit;
int sysctl_icmp_ratemask;
u32 ip_rt_min_pmtu;
int ip_rt_mtu_expires;
int ip_rt_min_advmss;
struct local_ports ip_local_ports;
u8 sysctl_tcp_ecn;
u8 sysctl_tcp_ecn_fallback;
u8 sysctl_ip_default_ttl;
u8 sysctl_ip_no_pmtu_disc;
u8 sysctl_ip_fwd_use_pmtu;
u8 sysctl_ip_fwd_update_priority;
u8 sysctl_ip_nonlocal_bind;
u8 sysctl_ip_autobind_reuse;
u8 sysctl_ip_dynaddr;
u8 sysctl_ip_early_demux;
u8 sysctl_raw_l3mdev_accept;
u8 sysctl_tcp_early_demux;
u8 sysctl_udp_early_demux;
u8 sysctl_nexthop_compat_mode;
u8 sysctl_fwmark_reflect;
u8 sysctl_tcp_fwmark_accept;
u8 sysctl_tcp_l3mdev_accept;
u8 sysctl_tcp_mtu_probing;
int sysctl_tcp_mtu_probe_floor;
int sysctl_tcp_base_mss;
int sysctl_tcp_min_snd_mss;
int sysctl_tcp_probe_threshold;
u32 sysctl_tcp_probe_interval;
int sysctl_tcp_keepalive_time;
int sysctl_tcp_keepalive_intvl;
u8 sysctl_tcp_keepalive_probes;
u8 sysctl_tcp_syn_retries;
u8 sysctl_tcp_synack_retries;
u8 sysctl_tcp_syncookies;
u8 sysctl_tcp_migrate_req;
u8 sysctl_tcp_comp_sack_nr;
int sysctl_tcp_reordering;
u8 sysctl_tcp_retries1;
u8 sysctl_tcp_retries2;
u8 sysctl_tcp_orphan_retries;
u8 sysctl_tcp_tw_reuse;
int sysctl_tcp_fin_timeout;
unsigned int sysctl_tcp_notsent_lowat;
u8 sysctl_tcp_sack;
u8 sysctl_tcp_window_scaling;
u8 sysctl_tcp_timestamps;
u8 sysctl_tcp_early_retrans;
u8 sysctl_tcp_recovery;
u8 sysctl_tcp_thin_linear_timeouts;
u8 sysctl_tcp_slow_start_after_idle;
u8 sysctl_tcp_retrans_collapse;
u8 sysctl_tcp_stdurg;
u8 sysctl_tcp_rfc1337;
u8 sysctl_tcp_abort_on_overflow;
u8 sysctl_tcp_fack;
int sysctl_tcp_max_reordering;
int sysctl_tcp_adv_win_scale;
u8 sysctl_tcp_dsack;
u8 sysctl_tcp_app_win;
u8 sysctl_tcp_frto;
u8 sysctl_tcp_nometrics_save;
u8 sysctl_tcp_no_ssthresh_metrics_save;
u8 sysctl_tcp_moderate_rcvbuf;
u8 sysctl_tcp_tso_win_divisor;
u8 sysctl_tcp_workaround_signed_windows;
int sysctl_tcp_limit_output_bytes;
int sysctl_tcp_challenge_ack_limit;
int sysctl_tcp_min_rtt_wlen;
u8 sysctl_tcp_min_tso_segs;
u8 sysctl_tcp_tso_rtt_log;
u8 sysctl_tcp_autocorking;
u8 sysctl_tcp_reflect_tos;
int sysctl_tcp_invalid_ratelimit;
int sysctl_tcp_pacing_ss_ratio;
int sysctl_tcp_pacing_ca_ratio;
int sysctl_tcp_wmem[3];
int sysctl_tcp_rmem[3];
unsigned int sysctl_tcp_child_ehash_entries;
long unsigned int sysctl_tcp_comp_sack_delay_ns;
long unsigned int sysctl_tcp_comp_sack_slack_ns;
int sysctl_max_syn_backlog;
int sysctl_tcp_fastopen;
const struct tcp_congestion_ops *tcp_congestion_control;
struct tcp_fastopen_context *tcp_fastopen_ctx;
unsigned int sysctl_tcp_fastopen_blackhole_timeout;
atomic_t tfo_active_disable_times;
long unsigned int tfo_active_disable_stamp;
u32 tcp_challenge_timestamp;
u32 tcp_challenge_count;
int sysctl_udp_wmem_min;
int sysctl_udp_rmem_min;
u8 sysctl_fib_notify_on_flag_change;
u8 sysctl_udp_l3mdev_accept;
u8 sysctl_igmp_llm_reports;
int sysctl_igmp_max_memberships;
int sysctl_igmp_max_msf;
int sysctl_igmp_qrv;
struct ping_group_range ping_group_range;
atomic_t dev_addr_genid;
long unsigned int *sysctl_local_reserved_ports;
int sysctl_ip_prot_sock;
struct mr_table *mrt;
u32 sysctl_fib_multipath_hash_fields;
u8 sysctl_fib_multipath_use_neigh;
u8 sysctl_fib_multipath_hash_policy;
struct fib_notifier_ops *notifier_ops;
unsigned int fib_seq;
struct fib_notifier_ops *ipmr_notifier_ops;
unsigned int ipmr_seq;
atomic_t rt_genid;
siphash_key_t ip_id_key;
long: 32;
long: 32;
};
struct dst_entry;
struct net_device;
struct sk_buff;
struct neighbour;
struct dst_ops {
short unsigned int family;
unsigned int gc_thresh;
int (*gc)(struct dst_ops *);
struct dst_entry * (*check)(struct dst_entry *, __u32);
unsigned int (*default_advmss)(const struct dst_entry *);
unsigned int (*mtu)(const struct dst_entry *);
u32 * (*cow_metrics)(struct dst_entry *, long unsigned int);
void (*destroy)(struct dst_entry *);
void (*ifdown)(struct dst_entry *, struct net_device *, int);
struct dst_entry * (*negative_advice)(struct dst_entry *);
void (*link_failure)(struct sk_buff *);
void (*update_pmtu)(struct dst_entry *, struct sock *, struct sk_buff *, u32, bool);
void (*redirect)(struct dst_entry *, struct sock *, struct sk_buff *);
int (*local_out)(struct net *, struct sock *, struct sk_buff *);
struct neighbour * (*neigh_lookup)(const struct dst_entry *, struct sk_buff *, const void *);
void (*confirm_neigh)(const struct dst_entry *, const void *);
struct kmem_cache *kmem_cachep;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct percpu_counter pcpuc_entries;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct netns_sysctl_ipv6 {
struct ctl_table_header *hdr;
struct ctl_table_header *route_hdr;
struct ctl_table_header *icmp_hdr;
struct ctl_table_header *frags_hdr;
struct ctl_table_header *xfrm6_hdr;
int flush_delay;
int ip6_rt_max_size;
int ip6_rt_gc_min_interval;
int ip6_rt_gc_timeout;
int ip6_rt_gc_interval;
int ip6_rt_gc_elasticity;
int ip6_rt_mtu_expires;
int ip6_rt_min_advmss;
u32 multipath_hash_fields;
u8 multipath_hash_policy;
u8 bindv6only;
u8 flowlabel_consistency;
u8 auto_flowlabels;
int icmpv6_time;
u8 icmpv6_echo_ignore_all;
u8 icmpv6_echo_ignore_multicast;
u8 icmpv6_echo_ignore_anycast;
long unsigned int icmpv6_ratemask[8];
long unsigned int *icmpv6_ratemask_ptr;
u8 anycast_src_echo_reply;
u8 ip_nonlocal_bind;
u8 fwmark_reflect;
u8 flowlabel_state_ranges;
int idgen_retries;
int idgen_delay;
int flowlabel_reflect;
int max_dst_opts_cnt;
int max_hbh_opts_cnt;
int max_dst_opts_len;
int max_hbh_opts_len;
int seg6_flowlabel;
u32 ioam6_id;
u64 ioam6_id_wide;
bool skip_notify_on_dev_down;
u8 fib_notify_on_flag_change;
long: 32;
};
struct ipv6_devconf;
struct fib6_info;
struct rt6_info;
struct rt6_statistics;
struct fib6_table;
struct seg6_pernet_data;
struct ioam6_pernet_data;
struct netns_ipv6 {
struct dst_ops ip6_dst_ops;
struct netns_sysctl_ipv6 sysctl;
struct ipv6_devconf *devconf_all;
struct ipv6_devconf *devconf_dflt;
struct inet_peer_base *peers;
struct fqdir *fqdir;
struct fib6_info *fib6_null_entry;
struct rt6_info *ip6_null_entry;
struct rt6_statistics *rt6_stats;
struct timer_list ip6_fib_timer;
struct hlist_head *fib_table_hash;
struct fib6_table *fib6_main_tbl;
struct list_head fib6_walkers;
rwlock_t fib6_walker_lock;
spinlock_t fib6_gc_lock;
atomic_t ip6_rt_gc_expire;
long unsigned int ip6_rt_last_gc;
unsigned char flowlabel_has_excl;
struct sock *ndisc_sk;
struct sock *tcp_sk;
struct sock *igmp_sk;
struct sock *mc_autojoin_sk;
struct hlist_head *inet6_addr_lst;
spinlock_t addrconf_hash_lock;
struct delayed_work addr_chk_work;
struct mr_table *mrt6;
atomic_t dev_addr_genid;
atomic_t fib6_sernum;
struct seg6_pernet_data *seg6_data;
struct fib_notifier_ops *notifier_ops;
struct fib_notifier_ops *ip6mr_notifier_ops;
unsigned int ipmr_seq;
struct {
struct hlist_head head;
spinlock_t lock;
u32 seq;
} ip6addrlbl_table;
struct ioam6_pernet_data *ioam6_data;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct sctp_mib;
struct netns_sctp {
struct sctp_mib *sctp_statistics;
struct proc_dir_entry *proc_net_sctp;
struct ctl_table_header *sysctl_header;
struct sock *ctl_sock;
struct sock *udp4_sock;
struct sock *udp6_sock;
int udp_port;
int encap_port;
struct list_head local_addr_list;
struct list_head addr_waitq;
struct timer_list addr_wq_timer;
struct list_head auto_asconf_splist;
spinlock_t addr_wq_lock;
spinlock_t local_addr_lock;
unsigned int rto_initial;
unsigned int rto_min;
unsigned int rto_max;
int rto_alpha;
int rto_beta;
int max_burst;
int cookie_preserve_enable;
char *sctp_hmac_alg;
unsigned int valid_cookie_life;
unsigned int sack_timeout;
unsigned int hb_interval;
unsigned int probe_interval;
int max_retrans_association;
int max_retrans_path;
int max_retrans_init;
int pf_retrans;
int ps_retrans;
int pf_enable;
int pf_expose;
int sndbuf_policy;
int rcvbuf_policy;
int default_auto_asconf;
int addip_enable;
int addip_noauth;
int prsctp_enable;
int reconf_enable;
int auth_enable;
int intl_enable;
int ecn_enable;
int scope_policy;
int rwnd_upd_shift;
long unsigned int max_autoclose;
};
struct nf_logger;
struct nf_hook_entries;
struct netns_nf {
struct proc_dir_entry *proc_netfilter;
const struct nf_logger *nf_loggers[11];
struct ctl_table_header *nf_log_dir_header;
struct nf_hook_entries *hooks_ipv4[5];
struct nf_hook_entries *hooks_ipv6[5];
struct nf_hook_entries *hooks_arp[3];
struct nf_hook_entries *hooks_bridge[5];
unsigned int defrag_ipv4_users;
unsigned int defrag_ipv6_users;
};
struct nf_generic_net {
unsigned int timeout;
};
struct nf_tcp_net {
unsigned int timeouts[14];
u8 tcp_loose;
u8 tcp_be_liberal;
u8 tcp_max_retrans;
u8 tcp_ignore_invalid_rst;
};
struct nf_udp_net {
unsigned int timeouts[2];
};
struct nf_icmp_net {
unsigned int timeout;
};
struct nf_dccp_net {
u8 dccp_loose;
unsigned int dccp_timeout[10];
};
struct nf_sctp_net {
unsigned int timeouts[10];
};
struct nf_gre_net {
struct list_head keymap_list;
unsigned int timeouts[2];
};
struct nf_ip_net {
struct nf_generic_net generic;
struct nf_tcp_net tcp;
struct nf_udp_net udp;
struct nf_icmp_net icmp;
struct nf_icmp_net icmpv6;
struct nf_dccp_net dccp;
struct nf_sctp_net sctp;
struct nf_gre_net gre;
};
struct ip_conntrack_stat;
struct nf_ct_event_notifier;
struct netns_ct {
u8 ctnetlink_has_listener;
bool ecache_dwork_pending;
u8 sysctl_log_invalid;
u8 sysctl_events;
u8 sysctl_acct;
u8 sysctl_tstamp;
u8 sysctl_checksum;
struct ip_conntrack_stat *stat;
struct nf_ct_event_notifier *nf_conntrack_event_cb;
struct nf_ip_net nf_ct_proto;
};
struct sk_buff_list {
struct sk_buff *next;
struct sk_buff *prev;
};
struct sk_buff_head {
union {
struct {
struct sk_buff *next;
struct sk_buff *prev;
};
struct sk_buff_list list;
};
__u32 qlen;
spinlock_t lock;
};
struct netns_bpf {
struct bpf_prog_array *run_array[2];
struct bpf_prog *progs[2];
struct list_head links[2];
};
struct xfrm_policy_hash {
struct hlist_head *table;
unsigned int hmask;
u8 dbits4;
u8 sbits4;
u8 dbits6;
u8 sbits6;
};
struct xfrm_policy_hthresh {
struct work_struct work;
seqlock_t lock;
u8 lbits4;
u8 rbits4;
u8 lbits6;
u8 rbits6;
};
struct netns_xfrm {
struct list_head state_all;
struct hlist_head *state_bydst;
struct hlist_head *state_bysrc;
struct hlist_head *state_byspi;
struct hlist_head *state_byseq;
unsigned int state_hmask;
unsigned int state_num;
struct work_struct state_hash_work;
struct list_head policy_all;
struct hlist_head *policy_byidx;
unsigned int policy_idx_hmask;
struct hlist_head policy_inexact[3];
struct xfrm_policy_hash policy_bydst[3];
unsigned int policy_count[6];
struct work_struct policy_hash_work;
struct xfrm_policy_hthresh policy_hthresh;
struct list_head inexact_bins;
struct sock *nlsk;
struct sock *nlsk_stash;
u32 sysctl_aevent_etime;
u32 sysctl_aevent_rseqth;
int sysctl_larval_drop;
u32 sysctl_acq_expires;
u8 policy_default[3];
struct ctl_table_header *sysctl_hdr;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct dst_ops xfrm4_dst_ops;
struct dst_ops xfrm6_dst_ops;
spinlock_t xfrm_state_lock;
seqcount_spinlock_t xfrm_state_hash_generation;
seqcount_spinlock_t xfrm_policy_hash_generation;
spinlock_t xfrm_policy_lock;
struct mutex xfrm_cfg_mutex;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct netns_ipvs;
struct uevent_sock;
struct net_generic;
struct net {
refcount_t passive;
spinlock_t rules_mod_lock;
atomic_t dev_unreg_count;
unsigned int dev_base_seq;
int ifindex;
spinlock_t nsid_lock;
atomic_t fnhe_genid;
struct list_head list;
struct list_head exit_list;
struct llist_node cleanup_list;
struct key_tag *key_domain;
struct user_namespace *user_ns;
struct ucounts *ucounts;
struct idr netns_ids;
struct ns_common ns;
struct ref_tracker_dir refcnt_tracker;
struct list_head dev_base_head;
struct proc_dir_entry *proc_net;
struct proc_dir_entry *proc_net_stat;
struct ctl_table_set sysctls;
struct sock *rtnl;
struct sock *genl_sock;
struct uevent_sock *uevent_sock;
struct hlist_head *dev_name_head;
struct hlist_head *dev_index_head;
struct raw_notifier_head netdev_chain;
u32 hash_mix;
struct net_device *loopback_dev;
struct list_head rules_ops;
struct netns_core core;
struct netns_mib mib;
struct netns_packet packet;
struct netns_unix unx;
struct netns_nexthop nexthop;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct netns_ipv4 ipv4;
struct netns_ipv6 ipv6;
struct netns_sctp sctp;
struct netns_nf nf;
struct netns_ct ct;
struct sk_buff_head wext_nlevents;
struct net_generic *gen;
struct netns_bpf bpf;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct netns_xfrm xfrm;
u64 net_cookie;
struct netns_ipvs *ipvs;
struct sock *diag_nlsk;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef short unsigned int __kernel_sa_family_t;
typedef __kernel_sa_family_t sa_family_t;
struct sockaddr {
sa_family_t sa_family;
char sa_data[14];
};
typedef unsigned char *sk_buff_data_t;
struct skb_ext;
struct sk_buff {
union {
struct {
struct sk_buff *next;
struct sk_buff *prev;
union {
struct net_device *dev;
long unsigned int dev_scratch;
};
};
struct rb_node rbnode;
struct list_head list;
struct llist_node ll_node;
};
union {
struct sock *sk;
int ip_defrag_offset;
};
union {
ktime_t tstamp;
u64 skb_mstamp_ns;
};
char cb[48];
union {
struct {
long unsigned int _skb_refdst;
void (*destructor)(struct sk_buff *);
};
struct list_head tcp_tsorted_anchor;
long unsigned int _sk_redir;
};
long unsigned int _nfct;
unsigned int len;
unsigned int data_len;
__u16 mac_len;
__u16 hdr_len;
__u16 queue_mapping;
__u8 __cloned_offset[0];
__u8 cloned: 1;
__u8 nohdr: 1;
__u8 fclone: 2;
__u8 peeked: 1;
__u8 head_frag: 1;
__u8 pfmemalloc: 1;
__u8 pp_recycle: 1;
__u8 active_extensions;
union {
struct {
__u8 __pkt_type_offset[0];
__u8 pkt_type: 3;
__u8 ignore_df: 1;
__u8 nf_trace: 1;
__u8 ip_summed: 2;
__u8 ooo_okay: 1;
__u8 l4_hash: 1;
__u8 sw_hash: 1;
__u8 wifi_acked_valid: 1;
__u8 wifi_acked: 1;
__u8 no_fcs: 1;
__u8 encapsulation: 1;
__u8 encap_hdr_csum: 1;
__u8 csum_valid: 1;
__u8 __pkt_vlan_present_offset[0];
__u8 vlan_present: 1;
__u8 csum_complete_sw: 1;
__u8 csum_level: 2;
__u8 dst_pending_confirm: 1;
__u8 mono_delivery_time: 1;
__u8 tc_skip_classify: 1;
__u8 tc_at_ingress: 1;
__u8 ndisc_nodetype: 2;
__u8 ipvs_property: 1;
__u8 inner_protocol_type: 1;
__u8 remcsum_offload: 1;
__u8 redirected: 1;
__u8 from_ingress: 1;
__u8 nf_skip_egress: 1;
__u8 slow_gro: 1;
__u8 csum_not_inet: 1;
__u8 scm_io_uring: 1;
__u16 tc_index;
union {
__wsum csum;
struct {
__u16 csum_start;
__u16 csum_offset;
};
};
__u32 priority;
int skb_iif;
__u32 hash;
__be16 vlan_proto;
__u16 vlan_tci;
union {
unsigned int napi_id;
unsigned int sender_cpu;
};
u16 alloc_cpu;
__u32 secmark;
union {
__u32 mark;
__u32 reserved_tailroom;
};
union {
__be16 inner_protocol;
__u8 inner_ipproto;
};
__u16 inner_transport_header;
__u16 inner_network_header;
__u16 inner_mac_header;
__be16 protocol;
__u16 transport_header;
__u16 network_header;
__u16 mac_header;
};
struct {
__u8 __pkt_type_offset[0];
__u8 pkt_type: 3;
__u8 ignore_df: 1;
__u8 nf_trace: 1;
__u8 ip_summed: 2;
__u8 ooo_okay: 1;
__u8 l4_hash: 1;
__u8 sw_hash: 1;
__u8 wifi_acked_valid: 1;
__u8 wifi_acked: 1;
__u8 no_fcs: 1;
__u8 encapsulation: 1;
__u8 encap_hdr_csum: 1;
__u8 csum_valid: 1;
__u8 __pkt_vlan_present_offset[0];
__u8 vlan_present: 1;
__u8 csum_complete_sw: 1;
__u8 csum_level: 2;
__u8 dst_pending_confirm: 1;
__u8 mono_delivery_time: 1;
__u8 tc_skip_classify: 1;
__u8 tc_at_ingress: 1;
__u8 ndisc_nodetype: 2;
__u8 ipvs_property: 1;
__u8 inner_protocol_type: 1;
__u8 remcsum_offload: 1;
__u8 redirected: 1;
__u8 from_ingress: 1;
__u8 nf_skip_egress: 1;
__u8 slow_gro: 1;
__u8 csum_not_inet: 1;
__u8 scm_io_uring: 1;
__u16 tc_index;
union {
__wsum csum;
struct {
__u16 csum_start;
__u16 csum_offset;
};
};
__u32 priority;
int skb_iif;
__u32 hash;
__be16 vlan_proto;
__u16 vlan_tci;
union {
unsigned int napi_id;
unsigned int sender_cpu;
};
u16 alloc_cpu;
__u32 secmark;
union {
__u32 mark;
__u32 reserved_tailroom;
};
union {
__be16 inner_protocol;
__u8 inner_ipproto;
};
__u16 inner_transport_header;
__u16 inner_network_header;
__u16 inner_mac_header;
__be16 protocol;
__u16 transport_header;
__u16 network_header;
__u16 mac_header;
} headers;
};
sk_buff_data_t tail;
sk_buff_data_t end;
unsigned char *head;
unsigned char *data;
unsigned int truesize;
refcount_t users;
struct skb_ext *extensions;
long: 32;
};
typedef struct {
unsigned int clock_rate;
unsigned int clock_type;
short unsigned int loopback;
} sync_serial_settings;
typedef struct {
unsigned int clock_rate;
unsigned int clock_type;
short unsigned int loopback;
unsigned int slot_map;
} te1_settings;
typedef struct {
short unsigned int encoding;
short unsigned int parity;
} raw_hdlc_proto;
typedef struct {
unsigned int t391;
unsigned int t392;
unsigned int n391;
unsigned int n392;
unsigned int n393;
short unsigned int lmi;
short unsigned int dce;
} fr_proto;
typedef struct {
unsigned int dlci;
} fr_proto_pvc;
typedef struct {
unsigned int dlci;
char master[16];
} fr_proto_pvc_info;
typedef struct {
unsigned int interval;
unsigned int timeout;
} cisco_proto;
typedef struct {
short unsigned int dce;
unsigned int modulo;
unsigned int window;
unsigned int t1;
unsigned int t2;
unsigned int n2;
} x25_hdlc_proto;
struct ifmap {
long unsigned int mem_start;
long unsigned int mem_end;
short unsigned int base_addr;
unsigned char irq;
unsigned char dma;
unsigned char port;
};
struct if_settings {
unsigned int type;
unsigned int size;
union {
raw_hdlc_proto *raw_hdlc;
cisco_proto *cisco;
fr_proto *fr;
fr_proto_pvc *fr_pvc;
fr_proto_pvc_info *fr_pvc_info;
x25_hdlc_proto *x25;
sync_serial_settings *sync;
te1_settings *te1;
} ifs_ifsu;
};
struct ifreq {
union {
char ifrn_name[16];
} ifr_ifrn;
union {
struct sockaddr ifru_addr;
struct sockaddr ifru_dstaddr;
struct sockaddr ifru_broadaddr;
struct sockaddr ifru_netmask;
struct sockaddr ifru_hwaddr;
short int ifru_flags;
int ifru_ivalue;
int ifru_mtu;
struct ifmap ifru_map;
char ifru_slave[16];
char ifru_newname[16];
void *ifru_data;
struct if_settings ifru_settings;
} ifr_ifru;
};
typedef struct poll_table_struct poll_table;
typedef struct {
u64 v;
} u64_stats_t;
enum bpf_prog_type {
BPF_PROG_TYPE_UNSPEC = 0,
BPF_PROG_TYPE_SOCKET_FILTER = 1,
BPF_PROG_TYPE_KPROBE = 2,
BPF_PROG_TYPE_SCHED_CLS = 3,
BPF_PROG_TYPE_SCHED_ACT = 4,
BPF_PROG_TYPE_TRACEPOINT = 5,
BPF_PROG_TYPE_XDP = 6,
BPF_PROG_TYPE_PERF_EVENT = 7,
BPF_PROG_TYPE_CGROUP_SKB = 8,
BPF_PROG_TYPE_CGROUP_SOCK = 9,
BPF_PROG_TYPE_LWT_IN = 10,
BPF_PROG_TYPE_LWT_OUT = 11,
BPF_PROG_TYPE_LWT_XMIT = 12,
BPF_PROG_TYPE_SOCK_OPS = 13,
BPF_PROG_TYPE_SK_SKB = 14,
BPF_PROG_TYPE_CGROUP_DEVICE = 15,
BPF_PROG_TYPE_SK_MSG = 16,
BPF_PROG_TYPE_RAW_TRACEPOINT = 17,
BPF_PROG_TYPE_CGROUP_SOCK_ADDR = 18,
BPF_PROG_TYPE_LWT_SEG6LOCAL = 19,
BPF_PROG_TYPE_LIRC_MODE2 = 20,
BPF_PROG_TYPE_SK_REUSEPORT = 21,
BPF_PROG_TYPE_FLOW_DISSECTOR = 22,
BPF_PROG_TYPE_CGROUP_SYSCTL = 23,
BPF_PROG_TYPE_RAW_TRACEPOINT_WRITABLE = 24,
BPF_PROG_TYPE_CGROUP_SOCKOPT = 25,
BPF_PROG_TYPE_TRACING = 26,
BPF_PROG_TYPE_STRUCT_OPS = 27,
BPF_PROG_TYPE_EXT = 28,
BPF_PROG_TYPE_LSM = 29,
BPF_PROG_TYPE_SK_LOOKUP = 30,
BPF_PROG_TYPE_SYSCALL = 31,
};
enum bpf_attach_type {
BPF_CGROUP_INET_INGRESS = 0,
BPF_CGROUP_INET_EGRESS = 1,
BPF_CGROUP_INET_SOCK_CREATE = 2,
BPF_CGROUP_SOCK_OPS = 3,
BPF_SK_SKB_STREAM_PARSER = 4,
BPF_SK_SKB_STREAM_VERDICT = 5,
BPF_CGROUP_DEVICE = 6,
BPF_SK_MSG_VERDICT = 7,
BPF_CGROUP_INET4_BIND = 8,
BPF_CGROUP_INET6_BIND = 9,
BPF_CGROUP_INET4_CONNECT = 10,
BPF_CGROUP_INET6_CONNECT = 11,
BPF_CGROUP_INET4_POST_BIND = 12,
BPF_CGROUP_INET6_POST_BIND = 13,
BPF_CGROUP_UDP4_SENDMSG = 14,
BPF_CGROUP_UDP6_SENDMSG = 15,
BPF_LIRC_MODE2 = 16,
BPF_FLOW_DISSECTOR = 17,
BPF_CGROUP_SYSCTL = 18,
BPF_CGROUP_UDP4_RECVMSG = 19,
BPF_CGROUP_UDP6_RECVMSG = 20,
BPF_CGROUP_GETSOCKOPT = 21,
BPF_CGROUP_SETSOCKOPT = 22,
BPF_TRACE_RAW_TP = 23,
BPF_TRACE_FENTRY = 24,
BPF_TRACE_FEXIT = 25,
BPF_MODIFY_RETURN = 26,
BPF_LSM_MAC = 27,
BPF_TRACE_ITER = 28,
BPF_CGROUP_INET4_GETPEERNAME = 29,
BPF_CGROUP_INET6_GETPEERNAME = 30,
BPF_CGROUP_INET4_GETSOCKNAME = 31,
BPF_CGROUP_INET6_GETSOCKNAME = 32,
BPF_XDP_DEVMAP = 33,
BPF_CGROUP_INET_SOCK_RELEASE = 34,
BPF_XDP_CPUMAP = 35,
BPF_SK_LOOKUP = 36,
BPF_XDP = 37,
BPF_SK_SKB_VERDICT = 38,
BPF_SK_REUSEPORT_SELECT = 39,
BPF_SK_REUSEPORT_SELECT_OR_MIGRATE = 40,
BPF_PERF_EVENT = 41,
BPF_TRACE_KPROBE_MULTI = 42,
BPF_LSM_CGROUP = 43,
__MAX_BPF_ATTACH_TYPE = 44,
};
struct sock_filter {
__u16 code;
__u8 jt;
__u8 jf;
__u32 k;
};
struct bpf_insn {
__u8 code;
__u8 dst_reg: 4;
__u8 src_reg: 4;
__s16 off;
__s32 imm;
};
struct bpf_prog_stats;
struct bpf_prog_aux;
struct sock_fprog_kern;
struct bpf_prog {
u16 pages;
u16 jited: 1;
u16 jit_requested: 1;
u16 gpl_compatible: 1;
u16 cb_access: 1;
u16 dst_needed: 1;
u16 blinding_requested: 1;
u16 blinded: 1;
u16 is_func: 1;
u16 kprobe_override: 1;
u16 has_callchain_buf: 1;
u16 enforce_expected_attach_type: 1;
u16 call_get_stack: 1;
u16 call_get_func_ip: 1;
u16 tstamp_type_access: 1;
enum bpf_prog_type type;
enum bpf_attach_type expected_attach_type;
u32 len;
u32 jited_len;
u8 tag[8];
struct bpf_prog_stats *stats;
int *active;
unsigned int (*bpf_func)(const void *, const struct bpf_insn *);
struct bpf_prog_aux *aux;
struct sock_fprog_kern *orig_prog;
union {
struct {
struct {} __empty_insns;
struct sock_filter insns[0];
};
struct {
struct {} __empty_insnsi;
struct bpf_insn insnsi[0];
};
};
};
struct bpf_cgroup_storage;
struct bpf_prog_array_item {
struct bpf_prog *prog;
long: 32;
union {
struct bpf_cgroup_storage *cgroup_storage[2];
u64 bpf_cookie;
};
};
struct bpf_prog_array {
struct callback_head rcu;
struct bpf_prog_array_item items[0];
};
enum bpf_cgroup_iter_order {
BPF_CGROUP_ITER_ORDER_UNSPEC = 0,
BPF_CGROUP_ITER_SELF_ONLY = 1,
BPF_CGROUP_ITER_DESCENDANTS_PRE = 2,
BPF_CGROUP_ITER_DESCENDANTS_POST = 3,
BPF_CGROUP_ITER_ANCESTORS_UP = 4,
};
enum bpf_map_type {
BPF_MAP_TYPE_UNSPEC = 0,
BPF_MAP_TYPE_HASH = 1,
BPF_MAP_TYPE_ARRAY = 2,
BPF_MAP_TYPE_PROG_ARRAY = 3,
BPF_MAP_TYPE_PERF_EVENT_ARRAY = 4,
BPF_MAP_TYPE_PERCPU_HASH = 5,
BPF_MAP_TYPE_PERCPU_ARRAY = 6,
BPF_MAP_TYPE_STACK_TRACE = 7,
BPF_MAP_TYPE_CGROUP_ARRAY = 8,
BPF_MAP_TYPE_LRU_HASH = 9,
BPF_MAP_TYPE_LRU_PERCPU_HASH = 10,
BPF_MAP_TYPE_LPM_TRIE = 11,
BPF_MAP_TYPE_ARRAY_OF_MAPS = 12,
BPF_MAP_TYPE_HASH_OF_MAPS = 13,
BPF_MAP_TYPE_DEVMAP = 14,
BPF_MAP_TYPE_SOCKMAP = 15,
BPF_MAP_TYPE_CPUMAP = 16,
BPF_MAP_TYPE_XSKMAP = 17,
BPF_MAP_TYPE_SOCKHASH = 18,
BPF_MAP_TYPE_CGROUP_STORAGE = 19,
BPF_MAP_TYPE_REUSEPORT_SOCKARRAY = 20,
BPF_MAP_TYPE_PERCPU_CGROUP_STORAGE = 21,
BPF_MAP_TYPE_QUEUE = 22,
BPF_MAP_TYPE_STACK = 23,
BPF_MAP_TYPE_SK_STORAGE = 24,
BPF_MAP_TYPE_DEVMAP_HASH = 25,
BPF_MAP_TYPE_STRUCT_OPS = 26,
BPF_MAP_TYPE_RINGBUF = 27,
BPF_MAP_TYPE_INODE_STORAGE = 28,
BPF_MAP_TYPE_TASK_STORAGE = 29,
BPF_MAP_TYPE_BLOOM_FILTER = 30,
BPF_MAP_TYPE_USER_RINGBUF = 31,
};
union bpf_attr {
struct {
__u32 map_type;
__u32 key_size;
__u32 value_size;
__u32 max_entries;
__u32 map_flags;
__u32 inner_map_fd;
__u32 numa_node;
char map_name[16];
__u32 map_ifindex;
__u32 btf_fd;
__u32 btf_key_type_id;
__u32 btf_value_type_id;
__u32 btf_vmlinux_value_type_id;
__u64 map_extra;
};
struct {
__u32 map_fd;
long: 32;
__u64 key;
union {
__u64 value;
__u64 next_key;
};
__u64 flags;
};
struct {
__u64 in_batch;
__u64 out_batch;
__u64 keys;
__u64 values;
__u32 count;
__u32 map_fd;
__u64 elem_flags;
__u64 flags;
} batch;
struct {
__u32 prog_type;
__u32 insn_cnt;
__u64 insns;
__u64 license;
__u32 log_level;
__u32 log_size;
__u64 log_buf;
__u32 kern_version;
__u32 prog_flags;
char prog_name[16];
__u32 prog_ifindex;
__u32 expected_attach_type;
__u32 prog_btf_fd;
__u32 func_info_rec_size;
__u64 func_info;
__u32 func_info_cnt;
__u32 line_info_rec_size;
__u64 line_info;
__u32 line_info_cnt;
__u32 attach_btf_id;
union {
__u32 attach_prog_fd;
__u32 attach_btf_obj_fd;
};
__u32 core_relo_cnt;
__u64 fd_array;
__u64 core_relos;
__u32 core_relo_rec_size;
long: 32;
};
struct {
__u64 pathname;
__u32 bpf_fd;
__u32 file_flags;
};
struct {
__u32 target_fd;
__u32 attach_bpf_fd;
__u32 attach_type;
__u32 attach_flags;
__u32 replace_bpf_fd;
};
struct {
__u32 prog_fd;
__u32 retval;
__u32 data_size_in;
__u32 data_size_out;
__u64 data_in;
__u64 data_out;
__u32 repeat;
__u32 duration;
__u32 ctx_size_in;
__u32 ctx_size_out;
__u64 ctx_in;
__u64 ctx_out;
__u32 flags;
__u32 cpu;
__u32 batch_size;
long: 32;
} test;
struct {
union {
__u32 start_id;
__u32 prog_id;
__u32 map_id;
__u32 btf_id;
__u32 link_id;
};
__u32 next_id;
__u32 open_flags;
};
struct {
__u32 bpf_fd;
__u32 info_len;
__u64 info;
} info;
struct {
__u32 target_fd;
__u32 attach_type;
__u32 query_flags;
__u32 attach_flags;
__u64 prog_ids;
__u32 prog_cnt;
long: 32;
__u64 prog_attach_flags;
} query;
struct {
__u64 name;
__u32 prog_fd;
long: 32;
} raw_tracepoint;
struct {
__u64 btf;
__u64 btf_log_buf;
__u32 btf_size;
__u32 btf_log_size;
__u32 btf_log_level;
long: 32;
};
struct {
__u32 pid;
__u32 fd;
__u32 flags;
__u32 buf_len;
__u64 buf;
__u32 prog_id;
__u32 fd_type;
__u64 probe_offset;
__u64 probe_addr;
} task_fd_query;
struct {
__u32 prog_fd;
union {
__u32 target_fd;
__u32 target_ifindex;
};
__u32 attach_type;
__u32 flags;
union {
__u32 target_btf_id;
struct {
__u64 iter_info;
__u32 iter_info_len;
long: 32;
};
struct {
__u64 bpf_cookie;
} perf_event;
struct {
__u32 flags;
__u32 cnt;
__u64 syms;
__u64 addrs;
__u64 cookies;
} kprobe_multi;
struct {
__u32 target_btf_id;
long: 32;
__u64 cookie;
} tracing;
};
} link_create;
struct {
__u32 link_fd;
__u32 new_prog_fd;
__u32 flags;
__u32 old_prog_fd;
} link_update;
struct {
__u32 link_fd;
} link_detach;
struct {
__u32 type;
} enable_stats;
struct {
__u32 link_fd;
__u32 flags;
} iter_create;
struct {
__u32 prog_fd;
__u32 map_fd;
__u32 flags;
} prog_bind_map;
};
struct bpf_func_info {
__u32 insn_off;
__u32 type_id;
};
struct bpf_line_info {
__u32 insn_off;
__u32 file_name_off;
__u32 line_off;
__u32 line_col;
};
struct sock_fprog {
short unsigned int len;
struct sock_filter *filter;
};
struct btf_type {
__u32 name_off;
__u32 info;
union {
__u32 size;
__u32 type;
};
};
typedef void (*btf_dtor_kfunc_t)(void *);
typedef u64 (*bpf_callback_t)(u64, u64, u64, u64, u64);
struct bpf_iter_aux_info;
typedef int (*bpf_iter_init_seq_priv_t)(void *, struct bpf_iter_aux_info *);
enum bpf_iter_task_type {
BPF_TASK_ITER_ALL = 0,
BPF_TASK_ITER_TID = 1,
BPF_TASK_ITER_TGID = 2,
};
struct bpf_map;
struct bpf_iter_aux_info {
struct bpf_map *map;
struct {
struct cgroup *start;
enum bpf_cgroup_iter_order order;
} cgroup;
struct {
enum bpf_iter_task_type type;
u32 pid;
} task;
};
typedef void (*bpf_iter_fini_seq_priv_t)(void *);
typedef unsigned int (*bpf_func_t)(const void *, const struct bpf_insn *);
struct bpf_iter_seq_info {
const struct seq_operations *seq_ops;
bpf_iter_init_seq_priv_t init_seq_private;
bpf_iter_fini_seq_priv_t fini_seq_private;
u32 seq_priv_size;
};
struct btf;
struct bpf_local_storage_map;
struct bpf_verifier_env;
struct bpf_func_state;
struct bpf_map_ops {
int (*map_alloc_check)(union bpf_attr *);
struct bpf_map * (*map_alloc)(union bpf_attr *);
void (*map_release)(struct bpf_map *, struct file *);
void (*map_free)(struct bpf_map *);
int (*map_get_next_key)(struct bpf_map *, void *, void *);
void (*map_release_uref)(struct bpf_map *);
void * (*map_lookup_elem_sys_only)(struct bpf_map *, void *);
int (*map_lookup_batch)(struct bpf_map *, const union bpf_attr *, union bpf_attr *);
int (*map_lookup_and_delete_elem)(struct bpf_map *, void *, void *, u64);
int (*map_lookup_and_delete_batch)(struct bpf_map *, const union bpf_attr *, union bpf_attr *);
int (*map_update_batch)(struct bpf_map *, const union bpf_attr *, union bpf_attr *);
int (*map_delete_batch)(struct bpf_map *, const union bpf_attr *, union bpf_attr *);
void * (*map_lookup_elem)(struct bpf_map *, void *);
int (*map_update_elem)(struct bpf_map *, void *, void *, u64);
int (*map_delete_elem)(struct bpf_map *, void *);
int (*map_push_elem)(struct bpf_map *, void *, u64);
int (*map_pop_elem)(struct bpf_map *, void *);
int (*map_peek_elem)(struct bpf_map *, void *);
void * (*map_lookup_percpu_elem)(struct bpf_map *, void *, u32);
void * (*map_fd_get_ptr)(struct bpf_map *, struct file *, int);
void (*map_fd_put_ptr)(void *);
int (*map_gen_lookup)(struct bpf_map *, struct bpf_insn *);
u32 (*map_fd_sys_lookup_elem)(void *);
void (*map_seq_show_elem)(struct bpf_map *, void *, struct seq_file *);
int (*map_check_btf)(const struct bpf_map *, const struct btf *, const struct btf_type *, const struct btf_type *);
int (*map_poke_track)(struct bpf_map *, struct bpf_prog_aux *);
void (*map_poke_untrack)(struct bpf_map *, struct bpf_prog_aux *);
void (*map_poke_run)(struct bpf_map *, u32, struct bpf_prog *, struct bpf_prog *);
int (*map_direct_value_addr)(const struct bpf_map *, u64 *, u32);
int (*map_direct_value_meta)(const struct bpf_map *, u64, u32 *);
int (*map_mmap)(struct bpf_map *, struct vm_area_struct *);
__poll_t (*map_poll)(struct bpf_map *, struct file *, struct poll_table_struct *);
int (*map_local_storage_charge)(struct bpf_local_storage_map *, void *, u32);
void (*map_local_storage_uncharge)(struct bpf_local_storage_map *, void *, u32);
struct bpf_local_storage ** (*map_owner_storage_ptr)(void *);
int (*map_redirect)(struct bpf_map *, u32, u64);
bool (*map_meta_equal)(const struct bpf_map *, const struct bpf_map *);
int (*map_set_for_each_callback_args)(struct bpf_verifier_env *, struct bpf_func_state *, struct bpf_func_state *);
int (*map_for_each_callback)(struct bpf_map *, bpf_callback_t, void *, u64);
int *map_btf_id;
const struct bpf_iter_seq_info *iter_seq_info;
};
struct bpf_map_value_off;
struct bpf_map_off_arr;
struct bpf_map {
const struct bpf_map_ops *ops;
struct bpf_map *inner_map_meta;
void *security;
enum bpf_map_type map_type;
u32 key_size;
u32 value_size;
u32 max_entries;
long: 32;
u64 map_extra;
u32 map_flags;
int spin_lock_off;
struct bpf_map_value_off *kptr_off_tab;
int timer_off;
u32 id;
int numa_node;
u32 btf_key_type_id;
u32 btf_value_type_id;
u32 btf_vmlinux_value_type_id;
struct btf *btf;
char name[16];
struct bpf_map_off_arr *off_arr;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
atomic64_t refcnt;
atomic64_t usercnt;
struct work_struct work;
struct mutex freeze_mutex;
atomic64_t writecnt;
struct {
spinlock_t lock;
enum bpf_prog_type type;
bool jited;
bool xdp_has_frags;
} owner;
bool bypass_spec_v1;
bool frozen;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct btf_header {
__u16 magic;
__u8 version;
__u8 flags;
__u32 hdr_len;
__u32 type_off;
__u32 type_len;
__u32 str_off;
__u32 str_len;
};
struct btf_kfunc_set_tab;
struct btf_id_dtor_kfunc_tab;
struct btf {
void *data;
struct btf_type **types;
u32 *resolved_ids;
u32 *resolved_sizes;
const char *strings;
void *nohdr_data;
struct btf_header hdr;
u32 nr_types;
u32 types_size;
u32 data_size;
refcount_t refcnt;
u32 id;
struct callback_head rcu;
struct btf_kfunc_set_tab *kfunc_set_tab;
struct btf_id_dtor_kfunc_tab *dtor_kfunc_tab;
struct btf *base_btf;
u32 start_id;
u32 start_str_off;
char name[60];
bool kernel_btf;
};
struct bpf_ksym {
long unsigned int start;
long unsigned int end;
char name[512];
struct list_head lnode;
struct latch_tree_node tnode;
bool prog;
};
struct bpf_ctx_arg_aux;
struct bpf_trampoline;
struct bpf_jit_poke_descriptor;
struct bpf_kfunc_desc_tab;
struct bpf_kfunc_btf_tab;
struct bpf_prog_ops;
struct btf_mod_pair;
struct bpf_prog_offload;
struct bpf_func_info_aux;
struct bpf_prog_aux {
atomic64_t refcnt;
u32 used_map_cnt;
u32 used_btf_cnt;
u32 max_ctx_offset;
u32 max_pkt_offset;
u32 max_tp_access;
u32 stack_depth;
u32 id;
u32 func_cnt;
u32 func_idx;
u32 attach_btf_id;
u32 ctx_arg_info_size;
u32 max_rdonly_access;
u32 max_rdwr_access;
struct btf *attach_btf;
const struct bpf_ctx_arg_aux *ctx_arg_info;
struct mutex dst_mutex;
struct bpf_prog *dst_prog;
struct bpf_trampoline *dst_trampoline;
enum bpf_prog_type saved_dst_prog_type;
enum bpf_attach_type saved_dst_attach_type;
bool verifier_zext;
bool offload_requested;
bool attach_btf_trace;
bool func_proto_unreliable;
bool sleepable;
bool tail_call_reachable;
bool xdp_has_frags;
const struct btf_type *attach_func_proto;
const char *attach_func_name;
struct bpf_prog **func;
void *jit_data;
struct bpf_jit_poke_descriptor *poke_tab;
struct bpf_kfunc_desc_tab *kfunc_tab;
struct bpf_kfunc_btf_tab *kfunc_btf_tab;
u32 size_poke_tab;
struct bpf_ksym ksym;
const struct bpf_prog_ops *ops;
struct bpf_map **used_maps;
struct mutex used_maps_mutex;
struct btf_mod_pair *used_btfs;
struct bpf_prog *prog;
struct user_struct *user;
long: 32;
u64 load_time;
u32 verified_insns;
int cgroup_atype;
struct bpf_map *cgroup_storage[2];
char name[16];
void *security;
struct bpf_prog_offload *offload;
struct btf *btf;
struct bpf_func_info *func_info;
struct bpf_func_info_aux *func_info_aux;
struct bpf_line_info *linfo;
void **jited_linfo;
u32 func_info_cnt;
u32 nr_linfo;
u32 linfo_idx;
u32 num_exentries;
struct exception_table_entry *extable;
union {
struct work_struct work;
struct callback_head rcu;
};
};
enum bpf_kptr_type {
BPF_KPTR_UNREF = 0,
BPF_KPTR_REF = 1,
};
struct bpf_map_value_off_desc {
u32 offset;
enum bpf_kptr_type type;
struct {
struct btf *btf;
struct module *module;
btf_dtor_kfunc_t dtor;
u32 btf_id;
} kptr;
};
struct bpf_map_value_off {
u32 nr_off;
struct bpf_map_value_off_desc off[0];
};
struct bpf_map_off_arr {
u32 cnt;
u32 field_off[10];
u8 field_sz[10];
};
struct bpf_offloaded_map;
struct bpf_map_dev_ops {
int (*map_get_next_key)(struct bpf_offloaded_map *, void *, void *);
int (*map_lookup_elem)(struct bpf_offloaded_map *, void *, void *);
int (*map_update_elem)(struct bpf_offloaded_map *, void *, void *, u64);
int (*map_delete_elem)(struct bpf_offloaded_map *, void *);
};
struct bpf_offloaded_map {
struct bpf_map map;
struct net_device *netdev;
const struct bpf_map_dev_ops *dev_ops;
void *dev_priv;
struct list_head offloads;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef u64 netdev_features_t;
struct net_device_stats {
long unsigned int rx_packets;
long unsigned int tx_packets;
long unsigned int rx_bytes;
long unsigned int tx_bytes;
long unsigned int rx_errors;
long unsigned int tx_errors;
long unsigned int rx_dropped;
long unsigned int tx_dropped;
long unsigned int multicast;
long unsigned int collisions;
long unsigned int rx_length_errors;
long unsigned int rx_over_errors;
long unsigned int rx_crc_errors;
long unsigned int rx_frame_errors;
long unsigned int rx_fifo_errors;
long unsigned int rx_missed_errors;
long unsigned int tx_aborted_errors;
long unsigned int tx_carrier_errors;
long unsigned int tx_fifo_errors;
long unsigned int tx_heartbeat_errors;
long unsigned int tx_window_errors;
long unsigned int rx_compressed;
long unsigned int tx_compressed;
};
struct netdev_hw_addr_list {
struct list_head list;
int count;
struct rb_root tree;
};
enum rx_handler_result {
RX_HANDLER_CONSUMED = 0,
RX_HANDLER_ANOTHER = 1,
RX_HANDLER_EXACT = 2,
RX_HANDLER_PASS = 3,
};
typedef enum rx_handler_result rx_handler_result_t;
typedef rx_handler_result_t rx_handler_func_t(struct sk_buff **);
typedef struct {
struct net *net;
} possible_net_t;
enum netdev_ml_priv_type {
ML_PRIV_NONE = 0,
ML_PRIV_CAN = 1,
};
struct pcpu_dstats;
struct garp_port;
struct netdev_tc_txq {
u16 count;
u16 offset;
};
struct sfp_bus;
struct udp_tunnel_nic;
struct bpf_xdp_link;
struct bpf_xdp_entity {
struct bpf_prog *prog;
struct bpf_xdp_link *link;
};
typedef struct {} netdevice_tracker;
struct netdev_name_node;
struct dev_ifalias;
struct net_device_ops;
struct net_device_core_stats;
struct iw_handler_def;
struct iw_public_data;
struct ethtool_ops;
struct l3mdev_ops;
struct ndisc_ops;
struct header_ops;
struct in_device;
struct inet6_dev;
struct vlan_info;
struct wireless_dev;
struct netdev_rx_queue;
struct mini_Qdisc;
struct netdev_queue;
struct cpu_rmap;
struct Qdisc;
struct xdp_dev_bulk_queue;
struct xps_dev_maps;
struct netpoll_info;
struct pcpu_lstats;
struct pcpu_sw_netstats;
struct rtnl_link_ops;
struct phy_device;
struct macsec_ops;
struct udp_tunnel_nic_info;
struct rtnl_hw_stats64;
struct net_device {
char name[16];
struct netdev_name_node *name_node;
struct dev_ifalias *ifalias;
long unsigned int mem_end;
long unsigned int mem_start;
long unsigned int base_addr;
long unsigned int state;
struct list_head dev_list;
struct list_head napi_list;
struct list_head unreg_list;
struct list_head close_list;
struct list_head ptype_all;
struct list_head ptype_specific;
struct {
struct list_head upper;
struct list_head lower;
} adj_list;
unsigned int flags;
long: 32;
long long unsigned int priv_flags;
const struct net_device_ops *netdev_ops;
int ifindex;
short unsigned int gflags;
short unsigned int hard_header_len;
unsigned int mtu;
short unsigned int needed_headroom;
short unsigned int needed_tailroom;
long: 32;
netdev_features_t features;
netdev_features_t hw_features;
netdev_features_t wanted_features;
netdev_features_t vlan_features;
netdev_features_t hw_enc_features;
netdev_features_t mpls_features;
netdev_features_t gso_partial_features;
unsigned int min_mtu;
unsigned int max_mtu;
short unsigned int type;
unsigned char min_header_len;
unsigned char name_assign_type;
int group;
struct net_device_stats stats;
struct net_device_core_stats *core_stats;
atomic_t carrier_up_count;
atomic_t carrier_down_count;
const struct iw_handler_def *wireless_handlers;
struct iw_public_data *wireless_data;
const struct ethtool_ops *ethtool_ops;
const struct l3mdev_ops *l3mdev_ops;
const struct ndisc_ops *ndisc_ops;
const struct header_ops *header_ops;
unsigned char operstate;
unsigned char link_mode;
unsigned char if_port;
unsigned char dma;
unsigned char perm_addr[32];
unsigned char addr_assign_type;
unsigned char addr_len;
unsigned char upper_level;
unsigned char lower_level;
short unsigned int neigh_priv_len;
short unsigned int dev_id;
short unsigned int dev_port;
short unsigned int padded;
spinlock_t addr_list_lock;
int irq;
struct netdev_hw_addr_list uc;
struct netdev_hw_addr_list mc;
struct netdev_hw_addr_list dev_addrs;
struct kset *queues_kset;
unsigned int promiscuity;
unsigned int allmulti;
bool uc_promisc;
struct in_device *ip_ptr;
struct inet6_dev *ip6_ptr;
struct vlan_info *vlan_info;
void *atalk_ptr;
struct wireless_dev *ieee80211_ptr;
const unsigned char *dev_addr;
struct netdev_rx_queue *_rx;
unsigned int num_rx_queues;
unsigned int real_num_rx_queues;
struct bpf_prog *xdp_prog;
long unsigned int gro_flush_timeout;
int napi_defer_hard_irqs;
unsigned int gro_max_size;
rx_handler_func_t *rx_handler;
void *rx_handler_data;
struct mini_Qdisc *miniq_ingress;
struct netdev_queue *ingress_queue;
struct nf_hook_entries *nf_hooks_ingress;
unsigned char broadcast[32];
struct cpu_rmap *rx_cpu_rmap;
struct hlist_node index_hlist;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct netdev_queue *_tx;
unsigned int num_tx_queues;
unsigned int real_num_tx_queues;
struct Qdisc *qdisc;
unsigned int tx_queue_len;
spinlock_t tx_global_lock;
struct xdp_dev_bulk_queue *xdp_bulkq;
struct xps_dev_maps *xps_maps[2];
struct mini_Qdisc *miniq_egress;
struct nf_hook_entries *nf_hooks_egress;
struct hlist_head qdisc_hash[16];
struct timer_list watchdog_timer;
int watchdog_timeo;
u32 proto_down_reason;
struct list_head todo_list;
int *pcpu_refcnt;
struct ref_tracker_dir refcnt_tracker;
struct list_head link_watch_list;
enum {
NETREG_UNINITIALIZED = 0,
NETREG_REGISTERED = 1,
NETREG_UNREGISTERING = 2,
NETREG_UNREGISTERED = 3,
NETREG_RELEASED = 4,
NETREG_DUMMY = 5,
} reg_state: 8;
bool dismantle;
enum {
RTNL_LINK_INITIALIZED = 0,
RTNL_LINK_INITIALIZING = 1,
} rtnl_link_state: 16;
bool needs_free_netdev;
void (*priv_destructor)(struct net_device *);
struct netpoll_info *npinfo;
possible_net_t nd_net;
void *ml_priv;
enum netdev_ml_priv_type ml_priv_type;
union {
struct pcpu_lstats *lstats;
struct pcpu_sw_netstats *tstats;
struct pcpu_dstats *dstats;
};
struct garp_port *garp_port;
struct device dev;
const struct attribute_group *sysfs_groups[4];
const struct attribute_group *sysfs_rx_queue_group;
const struct rtnl_link_ops *rtnl_link_ops;
unsigned int gso_max_size;
unsigned int tso_max_size;
u16 gso_max_segs;
u16 tso_max_segs;
s16 num_tc;
struct netdev_tc_txq tc_to_txq[16];
u8 prio_tc_map[16];
struct phy_device *phydev;
struct sfp_bus *sfp_bus;
struct lock_class_key *qdisc_tx_busylock;
bool proto_down;
unsigned int wol_enabled: 1;
unsigned int threaded: 1;
struct list_head net_notifier_list;
const struct macsec_ops *macsec_ops;
const struct udp_tunnel_nic_info *udp_tunnel_nic_info;
struct udp_tunnel_nic *udp_tunnel_nic;
struct bpf_xdp_entity xdp_state[3];
u8 dev_addr_shadow[32];
netdevice_tracker linkwatch_dev_tracker;
netdevice_tracker watchdog_dev_tracker;
netdevice_tracker dev_registered_tracker;
struct rtnl_hw_stats64 *offload_xstats_l3;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum bpf_reg_type {
NOT_INIT = 0,
SCALAR_VALUE = 1,
PTR_TO_CTX = 2,
CONST_PTR_TO_MAP = 3,
PTR_TO_MAP_VALUE = 4,
PTR_TO_MAP_KEY = 5,
PTR_TO_STACK = 6,
PTR_TO_PACKET_META = 7,
PTR_TO_PACKET = 8,
PTR_TO_PACKET_END = 9,
PTR_TO_FLOW_KEYS = 10,
PTR_TO_SOCKET = 11,
PTR_TO_SOCK_COMMON = 12,
PTR_TO_TCP_SOCK = 13,
PTR_TO_TP_BUFFER = 14,
PTR_TO_XDP_SOCK = 15,
PTR_TO_BTF_ID = 16,
PTR_TO_MEM = 17,
PTR_TO_BUF = 18,
PTR_TO_FUNC = 19,
PTR_TO_DYNPTR = 20,
__BPF_REG_TYPE_MAX = 21,
PTR_TO_MAP_VALUE_OR_NULL = 260,
PTR_TO_SOCKET_OR_NULL = 267,
PTR_TO_SOCK_COMMON_OR_NULL = 268,
PTR_TO_TCP_SOCK_OR_NULL = 269,
PTR_TO_BTF_ID_OR_NULL = 272,
__BPF_REG_TYPE_LIMIT = 524287,
};
struct bpf_prog_ops {
int (*test_run)(struct bpf_prog *, const union bpf_attr *, union bpf_attr *);
};
struct bpf_offload_dev;
struct bpf_prog_offload {
struct bpf_prog *prog;
struct net_device *netdev;
struct bpf_offload_dev *offdev;
void *dev_priv;
struct list_head offloads;
bool dev_state;
bool opt_failed;
void *jited_image;
u32 jited_len;
};
struct btf_func_model {
u8 ret_size;
u8 nr_args;
u8 arg_size[12];
u8 arg_flags[12];
};
struct bpf_tramp_image {
void *image;
struct bpf_ksym ksym;
struct percpu_ref pcref;
void *ip_after_call;
void *ip_epilogue;
union {
struct callback_head rcu;
struct work_struct work;
};
};
struct bpf_trampoline {
struct hlist_node hlist;
struct ftrace_ops *fops;
struct mutex mutex;
refcount_t refcnt;
u32 flags;
long: 32;
u64 key;
struct {
struct btf_func_model model;
void *addr;
bool ftrace_managed;
} func;
struct bpf_prog *extension_prog;
struct hlist_head progs_hlist[3];
int progs_cnt[3];
struct bpf_tramp_image *cur_image;
long: 32;
u64 selector;
struct module *mod;
long: 32;
};
struct bpf_func_info_aux {
u16 linkage;
bool unreliable;
};
struct bpf_jit_poke_descriptor {
void *tailcall_target;
void *tailcall_bypass;
void *bypass_addr;
void *aux;
union {
struct {
struct bpf_map *map;
u32 key;
} tail_call;
};
bool tailcall_target_stable;
u8 adj_off;
u16 reason;
u32 insn_idx;
};
struct bpf_ctx_arg_aux {
u32 offset;
enum bpf_reg_type reg_type;
u32 btf_id;
};
struct btf_mod_pair {
struct btf *btf;
struct module *module;
};
struct bpf_prog_stats {
u64_stats_t cnt;
u64_stats_t nsecs;
u64_stats_t misses;
struct u64_stats_sync syncp;
long: 32;
};
struct sock_fprog_kern {
u16 len;
struct sock_filter *filter;
};
struct in6_addr {
union {
__u8 u6_addr8[16];
__be16 u6_addr16[8];
__be32 u6_addr32[4];
} in6_u;
};
struct pipe_buf_operations;
struct pipe_buffer {
struct page *page;
unsigned int offset;
unsigned int len;
const struct pipe_buf_operations *ops;
unsigned int flags;
long unsigned int private;
};
struct pipe_buf_operations {
int (*confirm)(struct pipe_inode_info *, struct pipe_buffer *);
void (*release)(struct pipe_inode_info *, struct pipe_buffer *);
bool (*try_steal)(struct pipe_inode_info *, struct pipe_buffer *);
bool (*get)(struct pipe_inode_info *, struct pipe_buffer *);
};
struct ip_conntrack_stat {
unsigned int found;
unsigned int invalid;
unsigned int insert;
unsigned int insert_failed;
unsigned int clash_resolve;
unsigned int drop;
unsigned int early_drop;
unsigned int error;
unsigned int expect_new;
unsigned int expect_create;
unsigned int expect_delete;
unsigned int search_restart;
unsigned int chaintoolong;
};
struct skb_shared_hwtstamps {
union {
ktime_t hwtstamp;
void *netdev_data;
};
};
struct skb_ext {
refcount_t refcnt;
u8 offset[1];
u8 chunks;
long: 0;
char data[0];
};
struct dql {
unsigned int num_queued;
unsigned int adj_limit;
unsigned int last_obj_cnt;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
unsigned int limit;
unsigned int num_completed;
unsigned int prev_ovlimit;
unsigned int prev_num_queued;
unsigned int prev_last_obj_cnt;
unsigned int lowest_slack;
long unsigned int slack_start_time;
unsigned int max_limit;
unsigned int min_limit;
unsigned int slack_hold_time;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct ipstats_mib {
u64 mibs[37];
struct u64_stats_sync syncp;
long: 32;
};
struct icmp_mib {
long unsigned int mibs[28];
};
struct icmpmsg_mib {
atomic_long_t mibs[512];
};
struct icmpv6_mib {
long unsigned int mibs[6];
};
struct icmpv6msg_mib {
atomic_long_t mibs[512];
};
struct tcp_mib {
long unsigned int mibs[16];
};
struct udp_mib {
long unsigned int mibs[10];
};
struct linux_mib {
long unsigned int mibs[126];
};
struct inet_frags;
struct fqdir {
long int high_thresh;
long int low_thresh;
int timeout;
int max_dist;
struct inet_frags *f;
struct net *net;
bool dead;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct rhashtable rhashtable;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
atomic_long_t mem;
struct work_struct destroy_work;
struct llist_node free_list;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct inet_frag_queue;
struct inet_frags {
unsigned int qsize;
void (*constructor)(struct inet_frag_queue *, const void *);
void (*destructor)(struct inet_frag_queue *);
void (*frag_expire)(struct timer_list *);
struct kmem_cache *frags_cachep;
const char *frags_cache_name;
struct rhashtable_params rhash_params;
refcount_t refcnt;
struct completion completion;
};
struct frag_v4_compare_key {
__be32 saddr;
__be32 daddr;
u32 user;
u32 vif;
__be16 id;
u16 protocol;
};
struct frag_v6_compare_key {
struct in6_addr saddr;
struct in6_addr daddr;
u32 user;
__be32 id;
u32 iif;
};
struct inet_frag_queue {
struct rhash_head node;
union {
struct frag_v4_compare_key v4;
struct frag_v6_compare_key v6;
} key;
struct timer_list timer;
spinlock_t lock;
refcount_t refcnt;
struct rb_root rb_fragments;
struct sk_buff *fragments_tail;
struct sk_buff *last_run_head;
ktime_t stamp;
int len;
int meat;
u8 mono_delivery_time;
__u8 flags;
u16 max_size;
struct fqdir *fqdir;
struct callback_head rcu;
};
enum tcp_ca_event {
CA_EVENT_TX_START = 0,
CA_EVENT_CWND_RESTART = 1,
CA_EVENT_COMPLETE_CWR = 2,
CA_EVENT_LOSS = 3,
CA_EVENT_ECN_NO_CE = 4,
CA_EVENT_ECN_IS_CE = 5,
};
struct ack_sample;
struct rate_sample;
union tcp_cc_info;
struct tcp_congestion_ops {
u32 (*ssthresh)(struct sock *);
void (*cong_avoid)(struct sock *, u32, u32);
void (*set_state)(struct sock *, u8);
void (*cwnd_event)(struct sock *, enum tcp_ca_event);
void (*in_ack_event)(struct sock *, u32);
void (*pkts_acked)(struct sock *, const struct ack_sample *);
u32 (*min_tso_segs)(struct sock *);
void (*cong_control)(struct sock *, const struct rate_sample *);
u32 (*undo_cwnd)(struct sock *);
u32 (*sndbuf_expand)(struct sock *);
size_t (*get_info)(struct sock *, u32, int *, union tcp_cc_info *);
char name[16];
struct module *owner;
struct list_head list;
u32 key;
u32 flags;
void (*init)(struct sock *);
void (*release)(struct sock *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct xfrm_state;
struct lwtunnel_state;
struct dst_entry {
struct net_device *dev;
struct dst_ops *ops;
long unsigned int _metrics;
long unsigned int expires;
struct xfrm_state *xfrm;
int (*input)(struct sk_buff *);
int (*output)(struct net *, struct sock *, struct sk_buff *);
short unsigned int flags;
short int obsolete;
short unsigned int header_len;
short unsigned int trailer_len;
int __use;
long unsigned int lastuse;
struct lwtunnel_state *lwtstate;
struct callback_head callback_head;
short int error;
short int __pad;
__u32 tclassid;
atomic_t __refcnt;
netdevice_tracker dev_tracker;
};
struct hh_cache {
unsigned int hh_len;
seqlock_t hh_lock;
long unsigned int hh_data[32];
};
struct neigh_table;
struct neigh_parms;
struct neigh_ops;
struct neighbour {
struct neighbour *next;
struct neigh_table *tbl;
struct neigh_parms *parms;
long unsigned int confirmed;
long unsigned int updated;
rwlock_t lock;
refcount_t refcnt;
unsigned int arp_queue_len_bytes;
struct sk_buff_head arp_queue;
struct timer_list timer;
long unsigned int used;
atomic_t probes;
u8 nud_state;
u8 type;
u8 dead;
u8 protocol;
u32 flags;
seqlock_t ha_lock;
unsigned char ha[32];
struct hh_cache hh;
int (*output)(struct neighbour *, struct sk_buff *);
const struct neigh_ops *ops;
struct list_head gc_list;
struct list_head managed_list;
struct callback_head rcu;
struct net_device *dev;
netdevice_tracker dev_tracker;
u8 primary_key[0];
};
enum nf_log_type {
NF_LOG_TYPE_LOG = 0,
NF_LOG_TYPE_ULOG = 1,
NF_LOG_TYPE_MAX = 2,
};
typedef u8 u_int8_t;
struct nf_loginfo;
typedef void nf_logfn(struct net *, u_int8_t, unsigned int, const struct sk_buff *, const struct net_device *, const struct net_device *, const struct nf_loginfo *, const char *);
struct nf_logger {
char *name;
enum nf_log_type type;
nf_logfn *logfn;
struct module *me;
};
struct xdp_mem_info {
u32 type;
u32 id;
};
struct xdp_rxq_info {
struct net_device *dev;
u32 queue_index;
u32 reg_state;
struct xdp_mem_info mem;
unsigned int napi_id;
u32 frag_size;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct xdp_txq_info {
struct net_device *dev;
};
struct xdp_buff {
void *data;
void *data_end;
void *data_meta;
void *data_hard_start;
struct xdp_rxq_info *rxq;
struct xdp_txq_info *txq;
u32 frame_sz;
u32 flags;
};
struct xdp_frame {
void *data;
u16 len;
u16 headroom;
u32 metasize;
struct xdp_mem_info mem;
struct net_device *dev_rx;
u32 frame_sz;
u32 flags;
};
struct nlmsghdr {
__u32 nlmsg_len;
__u16 nlmsg_type;
__u16 nlmsg_flags;
__u32 nlmsg_seq;
__u32 nlmsg_pid;
};
struct nlattr {
__u16 nla_len;
__u16 nla_type;
};
struct nla_policy;
struct netlink_ext_ack {
const char *_msg;
const struct nlattr *bad_attr;
const struct nla_policy *policy;
const struct nlattr *miss_nest;
u16 miss_type;
u8 cookie[20];
u8 cookie_len;
};
struct netlink_range_validation;
struct netlink_range_validation_signed;
struct nla_policy {
u8 type;
u8 validation_type;
u16 len;
union {
u16 strict_start_type;
const u32 bitfield32_valid;
const u32 mask;
const char *reject_message;
const struct nla_policy *nested_policy;
struct netlink_range_validation *range;
struct netlink_range_validation_signed *range_signed;
struct {
s16 min;
s16 max;
};
int (*validate)(const struct nlattr *, struct netlink_ext_ack *);
};
};
struct netlink_callback {
struct sk_buff *skb;
const struct nlmsghdr *nlh;
int (*dump)(struct sk_buff *, struct netlink_callback *);
int (*done)(struct netlink_callback *);
void *data;
struct module *module;
struct netlink_ext_ack *extack;
u16 family;
u16 answer_flags;
u32 min_dump_alloc;
unsigned int prev_seq;
unsigned int seq;
bool strict_check;
union {
u8 ctx[48];
long int args[6];
};
};
struct ndmsg {
__u8 ndm_family;
__u8 ndm_pad1;
__u16 ndm_pad2;
__s32 ndm_ifindex;
__u16 ndm_state;
__u8 ndm_flags;
__u8 ndm_type;
};
struct rtnl_link_stats64 {
__u64 rx_packets;
__u64 tx_packets;
__u64 rx_bytes;
__u64 tx_bytes;
__u64 rx_errors;
__u64 tx_errors;
__u64 rx_dropped;
__u64 tx_dropped;
__u64 multicast;
__u64 collisions;
__u64 rx_length_errors;
__u64 rx_over_errors;
__u64 rx_crc_errors;
__u64 rx_frame_errors;
__u64 rx_fifo_errors;
__u64 rx_missed_errors;
__u64 tx_aborted_errors;
__u64 tx_carrier_errors;
__u64 tx_fifo_errors;
__u64 tx_heartbeat_errors;
__u64 tx_window_errors;
__u64 rx_compressed;
__u64 tx_compressed;
__u64 rx_nohandler;
__u64 rx_otherhost_dropped;
};
struct rtnl_hw_stats64 {
__u64 rx_packets;
__u64 tx_packets;
__u64 rx_bytes;
__u64 tx_bytes;
__u64 rx_errors;
__u64 tx_errors;
__u64 rx_dropped;
__u64 tx_dropped;
__u64 multicast;
};
struct ifla_vf_guid {
__u32 vf;
long: 32;
__u64 guid;
};
struct ifla_vf_stats {
__u64 rx_packets;
__u64 tx_packets;
__u64 rx_bytes;
__u64 tx_bytes;
__u64 broadcast;
__u64 multicast;
__u64 rx_dropped;
__u64 tx_dropped;
};
struct ifla_vf_info {
__u32 vf;
__u8 mac[32];
__u32 vlan;
__u32 qos;
__u32 spoofchk;
__u32 linkstate;
__u32 min_tx_rate;
__u32 max_tx_rate;
__u32 rss_query_en;
__u32 trusted;
__be16 vlan_proto;
};
struct tc_stats {
__u64 bytes;
__u32 packets;
__u32 drops;
__u32 overlimits;
__u32 bps;
__u32 pps;
__u32 qlen;
__u32 backlog;
long: 32;
};
struct tc_sizespec {
unsigned char cell_log;
unsigned char size_log;
short int cell_align;
int overhead;
unsigned int linklayer;
unsigned int mpu;
unsigned int mtu;
unsigned int tsize;
};
enum netdev_tx {
__NETDEV_TX_MIN = -2147483648,
NETDEV_TX_OK = 0,
NETDEV_TX_BUSY = 16,
};
typedef enum netdev_tx netdev_tx_t;
struct net_device_core_stats {
long unsigned int rx_dropped;
long unsigned int tx_dropped;
long unsigned int rx_nohandler;
long unsigned int rx_otherhost_dropped;
};
struct header_ops {
int (*create)(struct sk_buff *, struct net_device *, short unsigned int, const void *, const void *, unsigned int);
int (*parse)(const struct sk_buff *, unsigned char *);
int (*cache)(const struct neighbour *, struct hh_cache *, __be16);
void (*cache_update)(struct hh_cache *, const struct net_device *, const unsigned char *);
bool (*validate)(const char *, unsigned int);
__be16 (*parse_protocol)(const struct sk_buff *);
};
struct netdev_queue {
struct net_device *dev;
netdevice_tracker dev_tracker;
struct Qdisc *qdisc;
struct Qdisc *qdisc_sleeping;
struct kobject kobj;
long unsigned int tx_maxrate;
atomic_long_t trans_timeout;
struct net_device *sb_dev;
long: 32;
spinlock_t _xmit_lock;
int xmit_lock_owner;
long unsigned int trans_start;
long unsigned int state;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct dql dql;
};
struct qdisc_skb_head {
struct sk_buff *head;
struct sk_buff *tail;
__u32 qlen;
spinlock_t lock;
};
struct gnet_stats_basic_sync {
u64_stats_t bytes;
u64_stats_t packets;
struct u64_stats_sync syncp;
long: 32;
long: 32;
long: 32;
};
struct gnet_stats_queue {
__u32 qlen;
__u32 backlog;
__u32 drops;
__u32 requeues;
__u32 overlimits;
};
struct Qdisc_ops;
struct qdisc_size_table;
struct net_rate_estimator;
struct Qdisc {
int (*enqueue)(struct sk_buff *, struct Qdisc *, struct sk_buff **);
struct sk_buff * (*dequeue)(struct Qdisc *);
unsigned int flags;
u32 limit;
const struct Qdisc_ops *ops;
struct qdisc_size_table *stab;
struct hlist_node hash;
u32 handle;
u32 parent;
struct netdev_queue *dev_queue;
struct net_rate_estimator *rate_est;
struct gnet_stats_basic_sync *cpu_bstats;
struct gnet_stats_queue *cpu_qstats;
int pad;
refcount_t refcnt;
struct sk_buff_head gso_skb;
struct qdisc_skb_head q;
struct gnet_stats_basic_sync bstats;
struct gnet_stats_queue qstats;
long unsigned int state;
long unsigned int state2;
struct Qdisc *next_sched;
struct sk_buff_head skb_bad_txq;
long: 32;
long: 32;
long: 32;
long: 32;
spinlock_t busylock;
spinlock_t seqlock;
struct callback_head rcu;
netdevice_tracker dev_tracker;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long int privdata[0];
};
struct rps_map {
unsigned int len;
struct callback_head rcu;
u16 cpus[0];
};
struct rps_dev_flow {
u16 cpu;
u16 filter;
unsigned int last_qtail;
};
struct rps_dev_flow_table {
unsigned int mask;
struct callback_head rcu;
struct rps_dev_flow flows[0];
};
struct netdev_rx_queue {
struct xdp_rxq_info xdp_rxq;
struct rps_map *rps_map;
struct rps_dev_flow_table *rps_flow_table;
struct kobject kobj;
struct net_device *dev;
netdevice_tracker dev_tracker;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct xps_map {
unsigned int len;
unsigned int alloc_len;
struct callback_head rcu;
u16 queues[0];
};
struct xps_dev_maps {
struct callback_head rcu;
unsigned int nr_ids;
s16 num_tc;
struct xps_map *attr_map[0];
};
struct netdev_phys_item_id {
unsigned char id[32];
unsigned char id_len;
};
enum net_device_path_type {
DEV_PATH_ETHERNET = 0,
DEV_PATH_VLAN = 1,
DEV_PATH_BRIDGE = 2,
DEV_PATH_PPPOE = 3,
DEV_PATH_DSA = 4,
DEV_PATH_MTK_WDMA = 5,
};
struct net_device_path {
enum net_device_path_type type;
const struct net_device *dev;
union {
struct {
u16 id;
__be16 proto;
u8 h_dest[6];
} encap;
struct {
enum {
DEV_PATH_BR_VLAN_KEEP = 0,
DEV_PATH_BR_VLAN_TAG = 1,
DEV_PATH_BR_VLAN_UNTAG = 2,
DEV_PATH_BR_VLAN_UNTAG_HW = 3,
} vlan_mode;
u16 vlan_id;
__be16 vlan_proto;
} bridge;
struct {
int port;
u16 proto;
} dsa;
struct {
u8 wdma_idx;
u8 queue;
u16 wcid;
u8 bss;
} mtk_wdma;
};
};
struct net_device_path_ctx {
const struct net_device *dev;
u8 daddr[6];
int num_vlans;
struct {
u16 id;
__be16 proto;
} vlan[2];
};
enum tc_setup_type {
TC_QUERY_CAPS = 0,
TC_SETUP_QDISC_MQPRIO = 1,
TC_SETUP_CLSU32 = 2,
TC_SETUP_CLSFLOWER = 3,
TC_SETUP_CLSMATCHALL = 4,
TC_SETUP_CLSBPF = 5,
TC_SETUP_BLOCK = 6,
TC_SETUP_QDISC_CBS = 7,
TC_SETUP_QDISC_RED = 8,
TC_SETUP_QDISC_PRIO = 9,
TC_SETUP_QDISC_MQ = 10,
TC_SETUP_QDISC_ETF = 11,
TC_SETUP_ROOT_QDISC = 12,
TC_SETUP_QDISC_GRED = 13,
TC_SETUP_QDISC_TAPRIO = 14,
TC_SETUP_FT = 15,
TC_SETUP_QDISC_ETS = 16,
TC_SETUP_QDISC_TBF = 17,
TC_SETUP_QDISC_FIFO = 18,
TC_SETUP_QDISC_HTB = 19,
TC_SETUP_ACT = 20,
};
enum bpf_netdev_command {
XDP_SETUP_PROG = 0,
XDP_SETUP_PROG_HW = 1,
BPF_OFFLOAD_MAP_ALLOC = 2,
BPF_OFFLOAD_MAP_FREE = 3,
XDP_SETUP_XSK_POOL = 4,
};
struct xsk_buff_pool;
struct netdev_bpf {
enum bpf_netdev_command command;
union {
struct {
u32 flags;
struct bpf_prog *prog;
struct netlink_ext_ack *extack;
};
struct {
struct bpf_offloaded_map *offmap;
};
struct {
struct xsk_buff_pool *pool;
u16 queue_id;
} xsk;
};
};
struct dev_ifalias {
struct callback_head rcuhead;
char ifalias[0];
};
struct devlink_port;
struct ip_tunnel_parm;
struct net_device_ops {
int (*ndo_init)(struct net_device *);
void (*ndo_uninit)(struct net_device *);
int (*ndo_open)(struct net_device *);
int (*ndo_stop)(struct net_device *);
netdev_tx_t (*ndo_start_xmit)(struct sk_buff *, struct net_device *);
netdev_features_t (*ndo_features_check)(struct sk_buff *, struct net_device *, netdev_features_t);
u16 (*ndo_select_queue)(struct net_device *, struct sk_buff *, struct net_device *);
void (*ndo_change_rx_flags)(struct net_device *, int);
void (*ndo_set_rx_mode)(struct net_device *);
int (*ndo_set_mac_address)(struct net_device *, void *);
int (*ndo_validate_addr)(struct net_device *);
int (*ndo_do_ioctl)(struct net_device *, struct ifreq *, int);
int (*ndo_eth_ioctl)(struct net_device *, struct ifreq *, int);
int (*ndo_siocbond)(struct net_device *, struct ifreq *, int);
int (*ndo_siocwandev)(struct net_device *, struct if_settings *);
int (*ndo_siocdevprivate)(struct net_device *, struct ifreq *, void *, int);
int (*ndo_set_config)(struct net_device *, struct ifmap *);
int (*ndo_change_mtu)(struct net_device *, int);
int (*ndo_neigh_setup)(struct net_device *, struct neigh_parms *);
void (*ndo_tx_timeout)(struct net_device *, unsigned int);
void (*ndo_get_stats64)(struct net_device *, struct rtnl_link_stats64 *);
bool (*ndo_has_offload_stats)(const struct net_device *, int);
int (*ndo_get_offload_stats)(int, const struct net_device *, void *);
struct net_device_stats * (*ndo_get_stats)(struct net_device *);
int (*ndo_vlan_rx_add_vid)(struct net_device *, __be16, u16);
int (*ndo_vlan_rx_kill_vid)(struct net_device *, __be16, u16);
void (*ndo_poll_controller)(struct net_device *);
int (*ndo_netpoll_setup)(struct net_device *, struct netpoll_info *);
void (*ndo_netpoll_cleanup)(struct net_device *);
int (*ndo_set_vf_mac)(struct net_device *, int, u8 *);
int (*ndo_set_vf_vlan)(struct net_device *, int, u16, u8, __be16);
int (*ndo_set_vf_rate)(struct net_device *, int, int, int);
int (*ndo_set_vf_spoofchk)(struct net_device *, int, bool);
int (*ndo_set_vf_trust)(struct net_device *, int, bool);
int (*ndo_get_vf_config)(struct net_device *, int, struct ifla_vf_info *);
int (*ndo_set_vf_link_state)(struct net_device *, int, int);
int (*ndo_get_vf_stats)(struct net_device *, int, struct ifla_vf_stats *);
int (*ndo_set_vf_port)(struct net_device *, int, struct nlattr **);
int (*ndo_get_vf_port)(struct net_device *, int, struct sk_buff *);
int (*ndo_get_vf_guid)(struct net_device *, int, struct ifla_vf_guid *, struct ifla_vf_guid *);
int (*ndo_set_vf_guid)(struct net_device *, int, u64, int);
int (*ndo_set_vf_rss_query_en)(struct net_device *, int, bool);
int (*ndo_setup_tc)(struct net_device *, enum tc_setup_type, void *);
int (*ndo_rx_flow_steer)(struct net_device *, const struct sk_buff *, u16, u32);
int (*ndo_add_slave)(struct net_device *, struct net_device *, struct netlink_ext_ack *);
int (*ndo_del_slave)(struct net_device *, struct net_device *);
struct net_device * (*ndo_get_xmit_slave)(struct net_device *, struct sk_buff *, bool);
struct net_device * (*ndo_sk_get_lower_dev)(struct net_device *, struct sock *);
netdev_features_t (*ndo_fix_features)(struct net_device *, netdev_features_t);
int (*ndo_set_features)(struct net_device *, netdev_features_t);
int (*ndo_neigh_construct)(struct net_device *, struct neighbour *);
void (*ndo_neigh_destroy)(struct net_device *, struct neighbour *);
int (*ndo_fdb_add)(struct ndmsg *, struct nlattr **, struct net_device *, const unsigned char *, u16, u16, struct netlink_ext_ack *);
int (*ndo_fdb_del)(struct ndmsg *, struct nlattr **, struct net_device *, const unsigned char *, u16, struct netlink_ext_ack *);
int (*ndo_fdb_del_bulk)(struct ndmsg *, struct nlattr **, struct net_device *, u16, struct netlink_ext_ack *);
int (*ndo_fdb_dump)(struct sk_buff *, struct netlink_callback *, struct net_device *, struct net_device *, int *);
int (*ndo_fdb_get)(struct sk_buff *, struct nlattr **, struct net_device *, const unsigned char *, u16, u32, u32, struct netlink_ext_ack *);
int (*ndo_bridge_setlink)(struct net_device *, struct nlmsghdr *, u16, struct netlink_ext_ack *);
int (*ndo_bridge_getlink)(struct sk_buff *, u32, u32, struct net_device *, u32, int);
int (*ndo_bridge_dellink)(struct net_device *, struct nlmsghdr *, u16);
int (*ndo_change_carrier)(struct net_device *, bool);
int (*ndo_get_phys_port_id)(struct net_device *, struct netdev_phys_item_id *);
int (*ndo_get_port_parent_id)(struct net_device *, struct netdev_phys_item_id *);
int (*ndo_get_phys_port_name)(struct net_device *, char *, size_t);
void * (*ndo_dfwd_add_station)(struct net_device *, struct net_device *);
void (*ndo_dfwd_del_station)(struct net_device *, void *);
int (*ndo_set_tx_maxrate)(struct net_device *, int, u32);
int (*ndo_get_iflink)(const struct net_device *);
int (*ndo_fill_metadata_dst)(struct net_device *, struct sk_buff *);
void (*ndo_set_rx_headroom)(struct net_device *, int);
int (*ndo_bpf)(struct net_device *, struct netdev_bpf *);
int (*ndo_xdp_xmit)(struct net_device *, int, struct xdp_frame **, u32);
struct net_device * (*ndo_xdp_get_xmit_slave)(struct net_device *, struct xdp_buff *);
int (*ndo_xsk_wakeup)(struct net_device *, u32, u32);
struct devlink_port * (*ndo_get_devlink_port)(struct net_device *);
int (*ndo_tunnel_ctl)(struct net_device *, struct ip_tunnel_parm *, int);
struct net_device * (*ndo_get_peer_dev)(struct net_device *);
int (*ndo_fill_forward_path)(struct net_device_path_ctx *, struct net_device_path *);
ktime_t (*ndo_get_tstamp)(struct net_device *, const struct skb_shared_hwtstamps *, bool);
};
struct pcpu_lstats {
u64_stats_t packets;
u64_stats_t bytes;
struct u64_stats_sync syncp;
long: 32;
long: 32;
long: 32;
};
struct pcpu_sw_netstats {
u64_stats_t rx_packets;
u64_stats_t rx_bytes;
u64_stats_t tx_packets;
u64_stats_t tx_bytes;
struct u64_stats_sync syncp;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct iw_request_info;
union iwreq_data;
typedef int (*iw_handler)(struct net_device *, struct iw_request_info *, union iwreq_data *, char *);
struct iw_priv_args;
struct iw_statistics;
struct iw_handler_def {
const iw_handler *standard;
__u16 num_standard;
__u16 num_private;
__u16 num_private_args;
const iw_handler *private;
const struct iw_priv_args *private_args;
struct iw_statistics * (*get_wireless_stats)(struct net_device *);
};
enum ethtool_phys_id_state {
ETHTOOL_ID_INACTIVE = 0,
ETHTOOL_ID_ACTIVE = 1,
ETHTOOL_ID_ON = 2,
ETHTOOL_ID_OFF = 3,
};
struct ethtool_drvinfo;
struct ethtool_regs;
struct ethtool_wolinfo;
struct ethtool_link_ext_state_info;
struct ethtool_eeprom;
struct ethtool_coalesce;
struct kernel_ethtool_coalesce;
struct ethtool_ringparam;
struct kernel_ethtool_ringparam;
struct ethtool_pause_stats;
struct ethtool_pauseparam;
struct ethtool_test;
struct ethtool_stats;
struct ethtool_rxnfc;
struct ethtool_flash;
struct ethtool_channels;
struct ethtool_dump;
struct ethtool_ts_info;
struct ethtool_modinfo;
struct ethtool_eee;
struct ethtool_tunable;
struct ethtool_link_ksettings;
struct ethtool_fec_stats;
struct ethtool_fecparam;
struct ethtool_module_eeprom;
struct ethtool_eth_phy_stats;
struct ethtool_eth_mac_stats;
struct ethtool_eth_ctrl_stats;
struct ethtool_rmon_stats;
struct ethtool_rmon_hist_range;
struct ethtool_module_power_mode_params;
struct ethtool_ops {
u32 cap_link_lanes_supported: 1;
u32 supported_coalesce_params;
u32 supported_ring_params;
void (*get_drvinfo)(struct net_device *, struct ethtool_drvinfo *);
int (*get_regs_len)(struct net_device *);
void (*get_regs)(struct net_device *, struct ethtool_regs *, void *);
void (*get_wol)(struct net_device *, struct ethtool_wolinfo *);
int (*set_wol)(struct net_device *, struct ethtool_wolinfo *);
u32 (*get_msglevel)(struct net_device *);
void (*set_msglevel)(struct net_device *, u32);
int (*nway_reset)(struct net_device *);
u32 (*get_link)(struct net_device *);
int (*get_link_ext_state)(struct net_device *, struct ethtool_link_ext_state_info *);
int (*get_eeprom_len)(struct net_device *);
int (*get_eeprom)(struct net_device *, struct ethtool_eeprom *, u8 *);
int (*set_eeprom)(struct net_device *, struct ethtool_eeprom *, u8 *);
int (*get_coalesce)(struct net_device *, struct ethtool_coalesce *, struct kernel_ethtool_coalesce *, struct netlink_ext_ack *);
int (*set_coalesce)(struct net_device *, struct ethtool_coalesce *, struct kernel_ethtool_coalesce *, struct netlink_ext_ack *);
void (*get_ringparam)(struct net_device *, struct ethtool_ringparam *, struct kernel_ethtool_ringparam *, struct netlink_ext_ack *);
int (*set_ringparam)(struct net_device *, struct ethtool_ringparam *, struct kernel_ethtool_ringparam *, struct netlink_ext_ack *);
void (*get_pause_stats)(struct net_device *, struct ethtool_pause_stats *);
void (*get_pauseparam)(struct net_device *, struct ethtool_pauseparam *);
int (*set_pauseparam)(struct net_device *, struct ethtool_pauseparam *);
void (*self_test)(struct net_device *, struct ethtool_test *, u64 *);
void (*get_strings)(struct net_device *, u32, u8 *);
int (*set_phys_id)(struct net_device *, enum ethtool_phys_id_state);
void (*get_ethtool_stats)(struct net_device *, struct ethtool_stats *, u64 *);
int (*begin)(struct net_device *);
void (*complete)(struct net_device *);
u32 (*get_priv_flags)(struct net_device *);
int (*set_priv_flags)(struct net_device *, u32);
int (*get_sset_count)(struct net_device *, int);
int (*get_rxnfc)(struct net_device *, struct ethtool_rxnfc *, u32 *);
int (*set_rxnfc)(struct net_device *, struct ethtool_rxnfc *);
int (*flash_device)(struct net_device *, struct ethtool_flash *);
int (*reset)(struct net_device *, u32 *);
u32 (*get_rxfh_key_size)(struct net_device *);
u32 (*get_rxfh_indir_size)(struct net_device *);
int (*get_rxfh)(struct net_device *, u32 *, u8 *, u8 *);
int (*set_rxfh)(struct net_device *, const u32 *, const u8 *, const u8);
int (*get_rxfh_context)(struct net_device *, u32 *, u8 *, u8 *, u32);
int (*set_rxfh_context)(struct net_device *, const u32 *, const u8 *, const u8, u32 *, bool);
void (*get_channels)(struct net_device *, struct ethtool_channels *);
int (*set_channels)(struct net_device *, struct ethtool_channels *);
int (*get_dump_flag)(struct net_device *, struct ethtool_dump *);
int (*get_dump_data)(struct net_device *, struct ethtool_dump *, void *);
int (*set_dump)(struct net_device *, struct ethtool_dump *);
int (*get_ts_info)(struct net_device *, struct ethtool_ts_info *);
int (*get_module_info)(struct net_device *, struct ethtool_modinfo *);
int (*get_module_eeprom)(struct net_device *, struct ethtool_eeprom *, u8 *);
int (*get_eee)(struct net_device *, struct ethtool_eee *);
int (*set_eee)(struct net_device *, struct ethtool_eee *);
int (*get_tunable)(struct net_device *, const struct ethtool_tunable *, void *);
int (*set_tunable)(struct net_device *, const struct ethtool_tunable *, const void *);
int (*get_per_queue_coalesce)(struct net_device *, u32, struct ethtool_coalesce *);
int (*set_per_queue_coalesce)(struct net_device *, u32, struct ethtool_coalesce *);
int (*get_link_ksettings)(struct net_device *, struct ethtool_link_ksettings *);
int (*set_link_ksettings)(struct net_device *, const struct ethtool_link_ksettings *);
void (*get_fec_stats)(struct net_device *, struct ethtool_fec_stats *);
int (*get_fecparam)(struct net_device *, struct ethtool_fecparam *);
int (*set_fecparam)(struct net_device *, struct ethtool_fecparam *);
void (*get_ethtool_phy_stats)(struct net_device *, struct ethtool_stats *, u64 *);
int (*get_phy_tunable)(struct net_device *, const struct ethtool_tunable *, void *);
int (*set_phy_tunable)(struct net_device *, const struct ethtool_tunable *, const void *);
int (*get_module_eeprom_by_page)(struct net_device *, const struct ethtool_module_eeprom *, struct netlink_ext_ack *);
void (*get_eth_phy_stats)(struct net_device *, struct ethtool_eth_phy_stats *);
void (*get_eth_mac_stats)(struct net_device *, struct ethtool_eth_mac_stats *);
void (*get_eth_ctrl_stats)(struct net_device *, struct ethtool_eth_ctrl_stats *);
void (*get_rmon_stats)(struct net_device *, struct ethtool_rmon_stats *, const struct ethtool_rmon_hist_range **);
int (*get_module_power_mode)(struct net_device *, struct ethtool_module_power_mode_params *, struct netlink_ext_ack *);
int (*set_module_power_mode)(struct net_device *, const struct ethtool_module_power_mode_params *, struct netlink_ext_ack *);
};
struct flowi6;
struct l3mdev_ops {
u32 (*l3mdev_fib_table)(const struct net_device *);
struct sk_buff * (*l3mdev_l3_rcv)(struct net_device *, struct sk_buff *, u16);
struct sk_buff * (*l3mdev_l3_out)(struct net_device *, struct sock *, struct sk_buff *, u16);
struct dst_entry * (*l3mdev_link_scope_lookup)(const struct net_device *, struct flowi6 *);
};
struct nd_opt_hdr;
struct ndisc_options;
struct prefix_info;
struct ndisc_ops {
int (*is_useropt)(u8);
int (*parse_options)(const struct net_device *, struct nd_opt_hdr *, struct ndisc_options *);
void (*update)(const struct net_device *, struct neighbour *, u32, u8, const struct ndisc_options *);
int (*opt_addr_space)(const struct net_device *, u8, struct neighbour *, u8 *, u8 **);
void (*fill_addr_option)(const struct net_device *, struct sk_buff *, u8, const u8 *);
void (*prefix_rcv_add_addr)(struct net *, struct net_device *, const struct prefix_info *, struct inet6_dev *, struct in6_addr *, int, u32, bool, bool, __u32, u32, bool);
};
struct tcf_proto;
struct tcf_block;
struct mini_Qdisc {
struct tcf_proto *filter_list;
struct tcf_block *block;
struct gnet_stats_basic_sync *cpu_bstats;
struct gnet_stats_queue *cpu_qstats;
long unsigned int rcu_state;
};
struct rtnl_link_ops {
struct list_head list;
const char *kind;
size_t priv_size;
struct net_device * (*alloc)(struct nlattr **, const char *, unsigned char, unsigned int, unsigned int);
void (*setup)(struct net_device *);
bool netns_refund;
unsigned int maxtype;
const struct nla_policy *policy;
int (*validate)(struct nlattr **, struct nlattr **, struct netlink_ext_ack *);
int (*newlink)(struct net *, struct net_device *, struct nlattr **, struct nlattr **, struct netlink_ext_ack *);
int (*changelink)(struct net_device *, struct nlattr **, struct nlattr **, struct netlink_ext_ack *);
void (*dellink)(struct net_device *, struct list_head *);
size_t (*get_size)(const struct net_device *);
int (*fill_info)(struct sk_buff *, const struct net_device *);
size_t (*get_xstats_size)(const struct net_device *);
int (*fill_xstats)(struct sk_buff *, const struct net_device *);
unsigned int (*get_num_tx_queues)();
unsigned int (*get_num_rx_queues)();
unsigned int slave_maxtype;
const struct nla_policy *slave_policy;
int (*slave_changelink)(struct net_device *, struct net_device *, struct nlattr **, struct nlattr **, struct netlink_ext_ack *);
size_t (*get_slave_size)(const struct net_device *, const struct net_device *);
int (*fill_slave_info)(struct sk_buff *, const struct net_device *, const struct net_device *);
struct net * (*get_link_net)(const struct net_device *);
size_t (*get_linkxstats_size)(const struct net_device *, int);
int (*fill_linkxstats)(struct sk_buff *, const struct net_device *, int *, int);
};
struct macsec_context;
struct macsec_ops {
int (*mdo_dev_open)(struct macsec_context *);
int (*mdo_dev_stop)(struct macsec_context *);
int (*mdo_add_secy)(struct macsec_context *);
int (*mdo_upd_secy)(struct macsec_context *);
int (*mdo_del_secy)(struct macsec_context *);
int (*mdo_add_rxsc)(struct macsec_context *);
int (*mdo_upd_rxsc)(struct macsec_context *);
int (*mdo_del_rxsc)(struct macsec_context *);
int (*mdo_add_rxsa)(struct macsec_context *);
int (*mdo_upd_rxsa)(struct macsec_context *);
int (*mdo_del_rxsa)(struct macsec_context *);
int (*mdo_add_txsa)(struct macsec_context *);
int (*mdo_upd_txsa)(struct macsec_context *);
int (*mdo_del_txsa)(struct macsec_context *);
int (*mdo_get_dev_stats)(struct macsec_context *);
int (*mdo_get_tx_sc_stats)(struct macsec_context *);
int (*mdo_get_tx_sa_stats)(struct macsec_context *);
int (*mdo_get_rx_sc_stats)(struct macsec_context *);
int (*mdo_get_rx_sa_stats)(struct macsec_context *);
};
struct udp_tunnel_nic_table_info {
unsigned int n_entries;
unsigned int tunnel_types;
};
struct udp_tunnel_info;
struct udp_tunnel_nic_shared;
struct udp_tunnel_nic_info {
int (*set_port)(struct net_device *, unsigned int, unsigned int, struct udp_tunnel_info *);
int (*unset_port)(struct net_device *, unsigned int, unsigned int, struct udp_tunnel_info *);
int (*sync_table)(struct net_device *, unsigned int);
struct udp_tunnel_nic_shared *shared;
unsigned int flags;
struct udp_tunnel_nic_table_info tables[4];
};
struct tcmsg {
unsigned char tcm_family;
unsigned char tcm__pad1;
short unsigned int tcm__pad2;
int tcm_ifindex;
__u32 tcm_handle;
__u32 tcm_parent;
__u32 tcm_info;
};
struct gnet_dump {
spinlock_t *lock;
struct sk_buff *skb;
struct nlattr *tail;
int compat_tc_stats;
int compat_xstats;
int padattr;
void *xstats;
int xstats_len;
struct tc_stats tc_stats;
};
struct netlink_range_validation {
u64 min;
u64 max;
};
struct netlink_range_validation_signed {
s64 min;
s64 max;
};
enum flow_action_hw_stats_bit {
FLOW_ACTION_HW_STATS_IMMEDIATE_BIT = 0,
FLOW_ACTION_HW_STATS_DELAYED_BIT = 1,
FLOW_ACTION_HW_STATS_DISABLED_BIT = 2,
FLOW_ACTION_HW_STATS_NUM_BITS = 3,
};
struct flow_block {
struct list_head cb_list;
};
typedef int flow_setup_cb_t(enum tc_setup_type, void *, void *);
struct qdisc_size_table {
struct callback_head rcu;
struct list_head list;
struct tc_sizespec szopts;
int refcnt;
u16 data[0];
};
struct Qdisc_class_ops;
struct Qdisc_ops {
struct Qdisc_ops *next;
const struct Qdisc_class_ops *cl_ops;
char id[16];
int priv_size;
unsigned int static_flags;
int (*enqueue)(struct sk_buff *, struct Qdisc *, struct sk_buff **);
struct sk_buff * (*dequeue)(struct Qdisc *);
struct sk_buff * (*peek)(struct Qdisc *);
int (*init)(struct Qdisc *, struct nlattr *, struct netlink_ext_ack *);
void (*reset)(struct Qdisc *);
void (*destroy)(struct Qdisc *);
int (*change)(struct Qdisc *, struct nlattr *, struct netlink_ext_ack *);
void (*attach)(struct Qdisc *);
int (*change_tx_queue_len)(struct Qdisc *, unsigned int);
void (*change_real_num_tx)(struct Qdisc *, unsigned int);
int (*dump)(struct Qdisc *, struct sk_buff *);
int (*dump_stats)(struct Qdisc *, struct gnet_dump *);
void (*ingress_block_set)(struct Qdisc *, u32);
void (*egress_block_set)(struct Qdisc *, u32);
u32 (*ingress_block_get)(struct Qdisc *);
u32 (*egress_block_get)(struct Qdisc *);
struct module *owner;
};
struct qdisc_walker;
struct Qdisc_class_ops {
unsigned int flags;
struct netdev_queue * (*select_queue)(struct Qdisc *, struct tcmsg *);
int (*graft)(struct Qdisc *, long unsigned int, struct Qdisc *, struct Qdisc **, struct netlink_ext_ack *);
struct Qdisc * (*leaf)(struct Qdisc *, long unsigned int);
void (*qlen_notify)(struct Qdisc *, long unsigned int);
long unsigned int (*find)(struct Qdisc *, u32);
int (*change)(struct Qdisc *, u32, u32, struct nlattr **, long unsigned int *, struct netlink_ext_ack *);
int (*delete)(struct Qdisc *, long unsigned int, struct netlink_ext_ack *);
void (*walk)(struct Qdisc *, struct qdisc_walker *);
struct tcf_block * (*tcf_block)(struct Qdisc *, long unsigned int, struct netlink_ext_ack *);
long unsigned int (*bind_tcf)(struct Qdisc *, long unsigned int, u32);
void (*unbind_tcf)(struct Qdisc *, long unsigned int);
int (*dump)(struct Qdisc *, long unsigned int, struct sk_buff *, struct tcmsg *);
int (*dump_stats)(struct Qdisc *, long unsigned int, struct gnet_dump *);
};
struct tcf_chain;
struct tcf_block {
struct mutex lock;
struct list_head chain_list;
u32 index;
u32 classid;
refcount_t refcnt;
struct net *net;
struct Qdisc *q;
struct rw_semaphore cb_lock;
struct flow_block flow_block;
struct list_head owner_list;
bool keep_dst;
atomic_t offloadcnt;
unsigned int nooffloaddevcnt;
unsigned int lockeddevcnt;
struct {
struct tcf_chain *chain;
struct list_head filter_chain_list;
} chain0;
struct callback_head rcu;
struct hlist_head proto_destroy_ht[128];
struct mutex proto_destroy_lock;
};
struct tcf_result;
struct tcf_proto_ops;
struct tcf_proto {
struct tcf_proto *next;
void *root;
int (*classify)(struct sk_buff *, const struct tcf_proto *, struct tcf_result *);
__be16 protocol;
u32 prio;
void *data;
const struct tcf_proto_ops *ops;
struct tcf_chain *chain;
spinlock_t lock;
bool deleting;
refcount_t refcnt;
struct callback_head rcu;
struct hlist_node destroy_ht_node;
};
struct tcf_result {
union {
struct {
long unsigned int class;
u32 classid;
};
const struct tcf_proto *goto_tp;
};
};
struct tcf_walker;
struct tcf_proto_ops {
struct list_head head;
char kind[16];
int (*classify)(struct sk_buff *, const struct tcf_proto *, struct tcf_result *);
int (*init)(struct tcf_proto *);
void (*destroy)(struct tcf_proto *, bool, struct netlink_ext_ack *);
void * (*get)(struct tcf_proto *, u32);
void (*put)(struct tcf_proto *, void *);
int (*change)(struct net *, struct sk_buff *, struct tcf_proto *, long unsigned int, u32, struct nlattr **, void **, u32, struct netlink_ext_ack *);
int (*delete)(struct tcf_proto *, void *, bool *, bool, struct netlink_ext_ack *);
bool (*delete_empty)(struct tcf_proto *);
void (*walk)(struct tcf_proto *, struct tcf_walker *, bool);
int (*reoffload)(struct tcf_proto *, bool, flow_setup_cb_t *, void *, struct netlink_ext_ack *);
void (*hw_add)(struct tcf_proto *, void *);
void (*hw_del)(struct tcf_proto *, void *);
void (*bind_class)(void *, u32, long unsigned int, void *, long unsigned int);
void * (*tmplt_create)(struct net *, struct tcf_chain *, struct nlattr **, struct netlink_ext_ack *);
void (*tmplt_destroy)(void *);
int (*dump)(struct net *, struct tcf_proto *, void *, struct sk_buff *, struct tcmsg *, bool);
int (*terse_dump)(struct net *, struct tcf_proto *, void *, struct sk_buff *, struct tcmsg *, bool);
int (*tmplt_dump)(struct sk_buff *, struct net *, void *);
struct module *owner;
int flags;
};
struct tcf_chain {
struct mutex filter_chain_lock;
struct tcf_proto *filter_chain;
struct list_head list;
struct tcf_block *block;
u32 index;
unsigned int refcnt;
unsigned int action_refcnt;
bool explicitly_created;
bool flushing;
const struct tcf_proto_ops *tmplt_ops;
void *tmplt_priv;
struct callback_head rcu;
};
typedef unsigned int (*bpf_dispatcher_fn)(const void *, const struct bpf_insn *, unsigned int (*)(const void *, const struct bpf_insn *));
typedef int (*bpf_aux_classic_check_t)(struct sock_filter *, unsigned int);
enum notify_state {
SECCOMP_NOTIFY_INIT = 0,
SECCOMP_NOTIFY_SENT = 1,
SECCOMP_NOTIFY_REPLIED = 2,
};
struct seccomp_knotif {
struct task_struct *task;
long: 32;
u64 id;
const struct seccomp_data *data;
enum notify_state state;
int error;
long int val;
u32 flags;
struct completion ready;
struct list_head list;
struct list_head addfd;
long: 32;
};
struct seccomp_kaddfd {
struct file *file;
int fd;
unsigned int flags;
__u32 ioctl_flags;
union {
bool setfd;
int ret;
};
struct completion completion;
struct list_head list;
};
struct notification {
struct semaphore request;
u64 next_id;
struct list_head notifications;
};
struct seccomp_log_name {
u32 log;
const char *name;
};
enum ctx_state {
CONTEXT_DISABLED = -1,
CONTEXT_KERNEL = 0,
CONTEXT_IDLE = 1,
CONTEXT_USER = 2,
CONTEXT_GUEST = 3,
CONTEXT_MAX = 4,
};
struct context_tracking {
atomic_t state;
long int dynticks_nesting;
long int dynticks_nmi_nesting;
};
struct cacheline_padding {
char x[0];
};
struct anon_vma {
struct anon_vma *root;
struct rw_semaphore rwsem;
atomic_t refcount;
long unsigned int num_children;
long unsigned int num_active_vmas;
struct anon_vma *parent;
struct rb_root_cached rb_root;
};
enum pageflags {
PG_locked = 0,
PG_referenced = 1,
PG_uptodate = 2,
PG_dirty = 3,
PG_lru = 4,
PG_active = 5,
PG_workingset = 6,
PG_waiters = 7,
PG_error = 8,
PG_slab = 9,
PG_owner_priv_1 = 10,
PG_arch_1 = 11,
PG_reserved = 12,
PG_private = 13,
PG_private_2 = 14,
PG_writeback = 15,
PG_head = 16,
PG_mappedtodisk = 17,
PG_reclaim = 18,
PG_swapbacked = 19,
PG_unevictable = 20,
PG_mlocked = 21,
__NR_PAGEFLAGS = 22,
PG_readahead = 18,
PG_anon_exclusive = 17,
PG_checked = 10,
PG_swapcache = 10,
PG_fscache = 14,
PG_pinned = 10,
PG_savepinned = 3,
PG_foreign = 10,
PG_xen_remapped = 10,
PG_slob_free = 13,
PG_double_map = 6,
PG_isolated = 18,
PG_reported = 2,
};
struct free_area {
struct list_head free_list[4];
long unsigned int nr_free;
};
struct lruvec {
struct list_head lists[5];
spinlock_t lru_lock;
long unsigned int anon_cost;
long unsigned int file_cost;
atomic_long_t nonresident_age;
long unsigned int refaults[2];
long unsigned int flags;
};
struct per_cpu_pages {
spinlock_t lock;
int count;
int high;
int batch;
short int free_factor;
struct list_head lists[12];
long: 32;
long: 32;
long: 32;
};
struct per_cpu_zonestat {
s8 vm_stat_diff[10];
s8 stat_threshold;
};
struct per_cpu_nodestat {
s8 stat_threshold;
s8 vm_node_stat_diff[41];
};
enum zone_type {
ZONE_DMA = 0,
ZONE_NORMAL = 1,
ZONE_MOVABLE = 2,
__MAX_NR_ZONES = 3,
};
struct pglist_data;
struct zone {
long unsigned int _watermark[4];
long unsigned int watermark_boost;
long unsigned int nr_reserved_highatomic;
long int lowmem_reserve[3];
struct pglist_data *zone_pgdat;
struct per_cpu_pages *per_cpu_pageset;
struct per_cpu_zonestat *per_cpu_zonestats;
int pageset_high;
int pageset_batch;
long unsigned int *pageblock_flags;
long unsigned int zone_start_pfn;
atomic_long_t managed_pages;
long unsigned int spanned_pages;
long unsigned int present_pages;
const char *name;
int initialized;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct cacheline_padding _pad1_;
struct free_area free_area[11];
long unsigned int flags;
spinlock_t lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct cacheline_padding _pad2_;
long unsigned int percpu_drift_mark;
long unsigned int compact_cached_free_pfn;
long unsigned int compact_cached_migrate_pfn[2];
long unsigned int compact_init_migrate_pfn;
long unsigned int compact_init_free_pfn;
unsigned int compact_considered;
unsigned int compact_defer_shift;
int compact_order_failed;
bool compact_blockskip_flush;
bool contiguous;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct cacheline_padding _pad3_;
atomic_long_t vm_stat[10];
atomic_long_t vm_numa_event[0];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct zoneref {
struct zone *zone;
int zone_idx;
};
struct zonelist {
struct zoneref _zonerefs[4];
};
struct pglist_data {
struct zone node_zones[3];
struct zonelist node_zonelists[1];
int nr_zones;
struct page *node_mem_map;
long unsigned int node_start_pfn;
long unsigned int node_present_pages;
long unsigned int node_spanned_pages;
int node_id;
wait_queue_head_t kswapd_wait;
wait_queue_head_t pfmemalloc_wait;
wait_queue_head_t reclaim_wait[4];
atomic_t nr_writeback_throttled;
long unsigned int nr_reclaim_start;
struct task_struct *kswapd;
int kswapd_order;
enum zone_type kswapd_highest_zoneidx;
int kswapd_failures;
int kcompactd_max_order;
enum zone_type kcompactd_highest_zoneidx;
wait_queue_head_t kcompactd_wait;
struct task_struct *kcompactd;
bool proactive_compact_trigger;
long unsigned int totalreserve_pages;
long: 32;
long: 32;
struct cacheline_padding _pad1_;
struct lruvec __lruvec;
long unsigned int flags;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct cacheline_padding _pad2_;
struct per_cpu_nodestat *per_cpu_nodestats;
atomic_long_t vm_stat[41];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct reclaim_state {
long unsigned int reclaimed_slab;
};
struct fprop_local_percpu {
struct percpu_counter events;
unsigned int period;
raw_spinlock_t lock;
};
enum wb_reason {
WB_REASON_BACKGROUND = 0,
WB_REASON_VMSCAN = 1,
WB_REASON_SYNC = 2,
WB_REASON_PERIODIC = 3,
WB_REASON_LAPTOP_TIMER = 4,
WB_REASON_FS_FREE_SPACE = 5,
WB_REASON_FORKER_THREAD = 6,
WB_REASON_FOREIGN_FLUSH = 7,
WB_REASON_MAX = 8,
};
struct bdi_writeback {
struct backing_dev_info *bdi;
long unsigned int state;
long unsigned int last_old_flush;
struct list_head b_dirty;
struct list_head b_io;
struct list_head b_more_io;
struct list_head b_dirty_time;
spinlock_t list_lock;
atomic_t writeback_inodes;
long: 32;
struct percpu_counter stat[4];
long unsigned int bw_time_stamp;
long unsigned int dirtied_stamp;
long unsigned int written_stamp;
long unsigned int write_bandwidth;
long unsigned int avg_write_bandwidth;
long unsigned int dirty_ratelimit;
long unsigned int balanced_dirty_ratelimit;
long: 32;
struct fprop_local_percpu completions;
int dirty_exceeded;
enum wb_reason start_all_reason;
spinlock_t work_lock;
struct list_head work_list;
struct delayed_work dwork;
struct delayed_work bw_dwork;
long unsigned int dirty_sleep;
struct list_head bdi_node;
};
struct backing_dev_info {
u64 id;
struct rb_node rb_node;
struct list_head bdi_list;
long unsigned int ra_pages;
long unsigned int io_pages;
struct kref refcnt;
unsigned int capabilities;
unsigned int min_ratio;
unsigned int max_ratio;
unsigned int max_prop_frac;
atomic_long_t tot_write_bandwidth;
long: 32;
struct bdi_writeback wb;
struct list_head wb_list;
wait_queue_head_t wb_waitq;
struct device *dev;
char dev_name[64];
struct device *owner;
struct timer_list laptop_mode_wb_timer;
struct dentry *debug_dir;
long: 32;
};
struct compact_control;
struct capture_control {
struct compact_control *cc;
struct page *page;
};
enum migrate_reason {
MR_COMPACTION = 0,
MR_MEMORY_FAILURE = 1,
MR_MEMORY_HOTPLUG = 2,
MR_SYSCALL = 3,
MR_MEMPOLICY_MBIND = 4,
MR_NUMA_MISPLACED = 5,
MR_CONTIG_RANGE = 6,
MR_LONGTERM_PIN = 7,
MR_DEMOTION = 8,
MR_TYPES = 9,
};
enum writeback_sync_modes {
WB_SYNC_NONE = 0,
WB_SYNC_ALL = 1,
};
struct swap_iocb;
struct writeback_control {
long int nr_to_write;
long int pages_skipped;
loff_t range_start;
loff_t range_end;
enum writeback_sync_modes sync_mode;
unsigned int for_kupdate: 1;
unsigned int for_background: 1;
unsigned int tagged_writepages: 1;
unsigned int for_reclaim: 1;
unsigned int range_cyclic: 1;
unsigned int for_sync: 1;
unsigned int unpinned_fscache_wb: 1;
unsigned int no_cgroup_owner: 1;
unsigned int punt_to_cgroup: 1;
struct swap_iocb **swap_plug;
long: 32;
};
struct swap_cluster_info {
spinlock_t lock;
unsigned int data: 24;
unsigned int flags: 8;
};
struct swap_cluster_list {
struct swap_cluster_info head;
struct swap_cluster_info tail;
};
struct percpu_cluster;
struct swap_info_struct {
struct percpu_ref users;
long unsigned int flags;
short int prio;
struct plist_node list;
signed char type;
unsigned int max;
unsigned char *swap_map;
struct swap_cluster_info *cluster_info;
struct swap_cluster_list free_clusters;
unsigned int lowest_bit;
unsigned int highest_bit;
unsigned int pages;
unsigned int inuse_pages;
unsigned int cluster_next;
unsigned int cluster_nr;
unsigned int *cluster_next_cpu;
struct percpu_cluster *percpu_cluster;
struct rb_root swap_extent_root;
struct block_device *bdev;
struct file *swap_file;
unsigned int old_block_size;
struct completion comp;
spinlock_t lock;
spinlock_t cont_lock;
struct work_struct discard_work;
struct swap_cluster_list discard_clusters;
struct plist_node avail_lists[0];
};
struct disk_stats;
struct gendisk;
struct request_queue;
struct partition_meta_info;
struct block_device {
sector_t bd_start_sect;
sector_t bd_nr_sectors;
struct disk_stats *bd_stats;
long unsigned int bd_stamp;
bool bd_read_only;
dev_t bd_dev;
atomic_t bd_openers;
struct inode *bd_inode;
struct super_block *bd_super;
void *bd_claiming;
struct device bd_device;
void *bd_holder;
int bd_holders;
bool bd_write_holder;
struct kobject *bd_holder_dir;
u8 bd_partno;
spinlock_t bd_size_lock;
struct gendisk *bd_disk;
struct request_queue *bd_queue;
int bd_fsfreeze_count;
struct mutex bd_fsfreeze_mutex;
struct super_block *bd_fsfreeze_sb;
struct partition_meta_info *bd_meta_info;
long: 32;
};
enum wb_stat_item {
WB_RECLAIMABLE = 0,
WB_WRITEBACK = 1,
WB_DIRTIED = 2,
WB_WRITTEN = 3,
NR_WB_STAT_ITEMS = 4,
};
typedef __u32 blk_opf_t;
struct percpu_cluster {
struct swap_cluster_info index;
unsigned int next;
};
struct compact_control {
struct list_head freepages;
struct list_head migratepages;
unsigned int nr_freepages;
unsigned int nr_migratepages;
long unsigned int free_pfn;
long unsigned int migrate_pfn;
long unsigned int fast_start_pfn;
struct zone *zone;
long unsigned int total_migrate_scanned;
long unsigned int total_free_scanned;
short unsigned int fast_search_fail;
short int search_order;
const gfp_t gfp_mask;
int order;
int migratetype;
const unsigned int alloc_flags;
const int highest_zoneidx;
enum migrate_mode mode;
bool ignore_skip_hint;
bool no_set_skip_hint;
bool ignore_block_suitable;
bool direct_compaction;
bool proactive_compaction;
bool whole_zone;
bool contended;
bool rescan;
bool alloc_contig;
};
struct pcpu_group_info {
int nr_units;
long unsigned int base_offset;
unsigned int *cpu_map;
};
struct pcpu_alloc_info {
size_t static_size;
size_t reserved_size;
size_t dyn_size;
size_t unit_size;
size_t atom_size;
size_t alloc_size;
size_t __ai_size;
int nr_groups;
struct pcpu_group_info groups[0];
};
typedef int pcpu_fc_cpu_to_node_fn_t(int);
typedef int pcpu_fc_cpu_distance_fn_t(unsigned int, unsigned int);
typedef struct {
long unsigned int bits[1];
} nodemask_t;
enum {
WORK_STRUCT_PENDING_BIT = 0LL,
WORK_STRUCT_INACTIVE_BIT = 1LL,
WORK_STRUCT_PWQ_BIT = 2LL,
WORK_STRUCT_LINKED_BIT = 3LL,
WORK_STRUCT_COLOR_SHIFT = 4LL,
WORK_STRUCT_COLOR_BITS = 4LL,
WORK_STRUCT_PENDING = 1LL,
WORK_STRUCT_INACTIVE = 2LL,
WORK_STRUCT_PWQ = 4LL,
WORK_STRUCT_LINKED = 8LL,
WORK_STRUCT_STATIC = 0LL,
WORK_NR_COLORS = 16LL,
WORK_CPU_UNBOUND = 8LL,
WORK_STRUCT_FLAG_BITS = 8LL,
WORK_OFFQ_FLAG_BASE = 4LL,
__WORK_OFFQ_CANCELING = 4LL,
WORK_OFFQ_CANCELING = 16LL,
WORK_OFFQ_FLAG_BITS = 1LL,
WORK_OFFQ_POOL_SHIFT = 5LL,
WORK_OFFQ_LEFT = 27LL,
WORK_OFFQ_POOL_BITS = 27LL,
WORK_OFFQ_POOL_NONE = 134217727LL,
WORK_STRUCT_FLAG_MASK = 255LL,
WORK_STRUCT_WQ_DATA_MASK = -256LL,
WORK_STRUCT_NO_POOL = 4294967264LL,
WORK_BUSY_PENDING = 1LL,
WORK_BUSY_RUNNING = 2LL,
WORKER_DESC_LEN = 24LL,
};
struct trace_print_flags {
long unsigned int mask;
const char *name;
};
enum fixed_addresses {
FIX_CMAP_BEGIN = 0,
FIX_CMAP_END = 16,
__end_of_fixed_addresses = 17,
};
struct vm_struct {
struct vm_struct *next;
void *addr;
long unsigned int size;
long unsigned int flags;
struct page **pages;
unsigned int nr_pages;
phys_addr_t phys_addr;
const void *caller;
};
enum compact_priority {
COMPACT_PRIO_SYNC_FULL = 0,
MIN_COMPACT_PRIORITY = 0,
COMPACT_PRIO_SYNC_LIGHT = 1,
MIN_COMPACT_COSTLY_PRIORITY = 1,
DEF_COMPACT_PRIORITY = 1,
COMPACT_PRIO_ASYNC = 2,
INIT_COMPACT_PRIORITY = 2,
};
enum compact_result {
COMPACT_NOT_SUITABLE_ZONE = 0,
COMPACT_SKIPPED = 1,
COMPACT_DEFERRED = 2,
COMPACT_NO_SUITABLE_PAGE = 3,
COMPACT_CONTINUE = 4,
COMPACT_COMPLETE = 5,
COMPACT_PARTIAL_SKIPPED = 6,
COMPACT_CONTENDED = 7,
COMPACT_SUCCESS = 8,
};
struct ring_buffer_event {
u32 type_len: 5;
u32 time_delta: 27;
u32 array[0];
};
struct trace_buffer;
struct trace_event_file;
struct trace_event_buffer {
struct trace_buffer *buffer;
struct ring_buffer_event *event;
struct trace_event_file *trace_file;
void *entry;
unsigned int trace_ctx;
struct pt_regs *regs;
};
struct trace_subsystem_dir;
struct trace_event_file {
struct list_head list;
struct trace_event_call *event_call;
struct event_filter *filter;
struct dentry *dir;
struct trace_array *tr;
struct trace_subsystem_dir *system;
struct list_head triggers;
long unsigned int flags;
atomic_t sm_ref;
atomic_t tm_ref;
};
enum {
EVENT_FILE_FL_ENABLED = 1,
EVENT_FILE_FL_RECORDED_CMD = 2,
EVENT_FILE_FL_RECORDED_TGID = 4,
EVENT_FILE_FL_FILTERED = 8,
EVENT_FILE_FL_NO_SET_FILTER = 16,
EVENT_FILE_FL_SOFT_MODE = 32,
EVENT_FILE_FL_SOFT_DISABLED = 64,
EVENT_FILE_FL_TRIGGER_MODE = 128,
EVENT_FILE_FL_TRIGGER_COND = 256,
EVENT_FILE_FL_PID_FILTER = 512,
EVENT_FILE_FL_WAS_ENABLED = 1024,
};
enum {
FILTER_OTHER = 0,
FILTER_STATIC_STRING = 1,
FILTER_DYN_STRING = 2,
FILTER_RDYN_STRING = 3,
FILTER_PTR_STRING = 4,
FILTER_TRACE_FN = 5,
FILTER_COMM = 6,
FILTER_CPU = 7,
};
struct trace_event_raw_percpu_alloc_percpu {
struct trace_entry ent;
long unsigned int call_site;
bool reserved;
bool is_atomic;
size_t size;
size_t align;
void *base_addr;
int off;
void *ptr;
size_t bytes_alloc;
long unsigned int gfp_flags;
char __data[0];
};
struct trace_event_raw_percpu_free_percpu {
struct trace_entry ent;
void *base_addr;
int off;
void *ptr;
char __data[0];
};
struct trace_event_raw_percpu_alloc_percpu_fail {
struct trace_entry ent;
bool reserved;
bool is_atomic;
size_t size;
size_t align;
char __data[0];
};
struct trace_event_raw_percpu_create_chunk {
struct trace_entry ent;
void *base_addr;
char __data[0];
};
struct trace_event_raw_percpu_destroy_chunk {
struct trace_entry ent;
void *base_addr;
char __data[0];
};
struct trace_event_data_offsets_percpu_alloc_percpu {};
struct trace_event_data_offsets_percpu_free_percpu {};
struct trace_event_data_offsets_percpu_alloc_percpu_fail {};
struct trace_event_data_offsets_percpu_create_chunk {};
struct trace_event_data_offsets_percpu_destroy_chunk {};
typedef void (*btf_trace_percpu_alloc_percpu)(void *, long unsigned int, bool, bool, size_t, size_t, void *, int, void *, size_t, gfp_t);
typedef void (*btf_trace_percpu_free_percpu)(void *, void *, int, void *);
typedef void (*btf_trace_percpu_alloc_percpu_fail)(void *, bool, bool, size_t, size_t);
typedef void (*btf_trace_percpu_create_chunk)(void *, void *);
typedef void (*btf_trace_percpu_destroy_chunk)(void *, void *);
struct pcpu_block_md {
int scan_hint;
int scan_hint_start;
int contig_hint;
int contig_hint_start;
int left_free;
int right_free;
int first_free;
int nr_bits;
};
struct pcpu_chunk {
struct list_head list;
int free_bytes;
struct pcpu_block_md chunk_md;
void *base_addr;
long unsigned int *alloc_map;
long unsigned int *bound_map;
struct pcpu_block_md *md_blocks;
void *data;
bool immutable;
bool isolated;
int start_offset;
int end_offset;
int nr_pages;
int nr_populated;
int nr_empty_pop_pages;
long unsigned int populated[0];
};
struct obj_cgroup;
typedef struct {
int val[2];
} __kernel_fsid_t;
typedef long unsigned int vm_flags_t;
typedef unsigned int xa_mark_t;
struct xa_node {
unsigned char shift;
unsigned char offset;
unsigned char count;
unsigned char nr_values;
struct xa_node *parent;
struct xarray *array;
union {
struct list_head private_list;
struct callback_head callback_head;
};
void *slots[64];
union {
long unsigned int tags[6];
long unsigned int marks[6];
};
};
typedef void (*xa_update_node_t)(struct xa_node *);
struct xa_state {
struct xarray *xa;
long unsigned int xa_index;
unsigned char xa_shift;
unsigned char xa_sibs;
unsigned char xa_offset;
unsigned char xa_pad;
struct xa_node *xa_node;
struct xa_node *xa_alloc;
xa_update_node_t xa_update;
struct list_lru *xa_lru;
};
enum {
XA_CHECK_SCHED = 4096,
};
struct kstatfs {
long int f_type;
long int f_bsize;
u64 f_blocks;
u64 f_bfree;
u64 f_bavail;
u64 f_files;
u64 f_ffree;
__kernel_fsid_t f_fsid;
long int f_namelen;
long int f_frsize;
long int f_flags;
long int f_spare[4];
long: 32;
};
struct fc_log;
struct p_log {
const char *prefix;
struct fc_log *log;
};
enum fs_context_purpose {
FS_CONTEXT_FOR_MOUNT = 0,
FS_CONTEXT_FOR_SUBMOUNT = 1,
FS_CONTEXT_FOR_RECONFIGURE = 2,
};
enum fs_context_phase {
FS_CONTEXT_CREATE_PARAMS = 0,
FS_CONTEXT_CREATING = 1,
FS_CONTEXT_AWAITING_MOUNT = 2,
FS_CONTEXT_AWAITING_RECONF = 3,
FS_CONTEXT_RECONF_PARAMS = 4,
FS_CONTEXT_RECONFIGURING = 5,
FS_CONTEXT_FAILED = 6,
};
struct fs_context_operations;
struct fs_context {
const struct fs_context_operations *ops;
struct mutex uapi_mutex;
struct file_system_type *fs_type;
void *fs_private;
void *sget_key;
struct dentry *root;
struct user_namespace *user_ns;
struct net *net_ns;
const struct cred *cred;
struct p_log log;
const char *source;
void *security;
void *s_fs_info;
unsigned int sb_flags;
unsigned int sb_flags_mask;
unsigned int s_iflags;
unsigned int lsm_flags;
enum fs_context_purpose purpose: 8;
enum fs_context_phase phase: 8;
bool need_free: 1;
bool global: 1;
bool oldapi: 1;
};
struct audit_names;
struct filename {
const char *name;
const char *uptr;
int refcnt;
struct audit_names *aname;
const char iname[0];
};
enum {
HUGETLB_SHMFS_INODE = 1,
HUGETLB_ANONHUGE_INODE = 2,
};
struct shared_policy {};
struct simple_xattrs {
struct list_head head;
spinlock_t lock;
};
enum fs_value_type {
fs_value_is_undefined = 0,
fs_value_is_flag = 1,
fs_value_is_string = 2,
fs_value_is_blob = 3,
fs_value_is_filename = 4,
fs_value_is_file = 5,
};
struct fs_parameter {
const char *key;
enum fs_value_type type: 8;
union {
char *string;
void *blob;
struct filename *name;
struct file *file;
};
size_t size;
int dirfd;
};
struct fc_log {
refcount_t usage;
u8 head;
u8 tail;
u8 need_free;
struct module *owner;
char *buffer[8];
};
struct fs_context_operations {
void (*free)(struct fs_context *);
int (*dup)(struct fs_context *, struct fs_context *);
int (*parse_param)(struct fs_context *, struct fs_parameter *);
int (*parse_monolithic)(struct fs_context *, void *);
int (*get_tree)(struct fs_context *);
int (*reconfigure)(struct fs_context *);
};
struct fs_parse_result {
bool negated;
long: 32;
union {
bool boolean;
int int_32;
unsigned int uint_32;
u64 uint_64;
};
};
struct shmem_inode_info {
spinlock_t lock;
unsigned int seals;
long unsigned int flags;
long unsigned int alloced;
long unsigned int swapped;
long unsigned int fallocend;
struct list_head shrinklist;
struct list_head swaplist;
struct shared_policy policy;
struct simple_xattrs xattrs;
atomic_t stop_eviction;
struct timespec64 i_crtime;
unsigned int fsflags;
long: 32;
struct inode vfs_inode;
};
typedef __kernel_ulong_t ino_t;
struct wait_bit_queue_entry {
struct wait_bit_key key;
struct wait_queue_entry wq_entry;
};
enum xa_lock_type {
XA_LOCK_IRQ = 1,
XA_LOCK_BH = 2,
};
enum lru_status {
LRU_REMOVED = 0,
LRU_REMOVED_RETRY = 1,
LRU_ROTATE = 2,
LRU_SKIP = 3,
LRU_RETRY = 4,
};
typedef enum lru_status (*list_lru_walk_cb)(struct list_head *, struct list_lru_one *, spinlock_t *, void *);
struct inodes_stat_t {
long int nr_inodes;
long int nr_unused;
long int dummy[5];
};
typedef int __kernel_rwf_t;
enum rw_hint {
WRITE_LIFE_NOT_SET = 0,
WRITE_LIFE_NONE = 1,
WRITE_LIFE_SHORT = 2,
WRITE_LIFE_MEDIUM = 3,
WRITE_LIFE_LONG = 4,
WRITE_LIFE_EXTREME = 5,
};
struct posix_acl_entry {
short int e_tag;
short unsigned int e_perm;
union {
kuid_t e_uid;
kgid_t e_gid;
};
};
struct posix_acl {
refcount_t a_refcount;
struct callback_head a_rcu;
unsigned int a_count;
struct posix_acl_entry a_entries[0];
};
typedef struct fsnotify_mark_connector *fsnotify_connp_t;
struct fsnotify_mark_connector {
spinlock_t lock;
short unsigned int type;
short unsigned int flags;
__kernel_fsid_t fsid;
union {
fsnotify_connp_t *obj;
struct fsnotify_mark_connector *destroy_next;
};
struct hlist_head list;
};
enum inode_i_mutex_lock_class {
I_MUTEX_NORMAL = 0,
I_MUTEX_PARENT = 1,
I_MUTEX_CHILD = 2,
I_MUTEX_XATTR = 3,
I_MUTEX_NONDIR2 = 4,
I_MUTEX_PARENT2 = 5,
};
enum file_time_flags {
S_ATIME = 1,
S_MTIME = 2,
S_CTIME = 4,
S_VERSION = 8,
};
struct vm_event_state {
long unsigned int event[66];
};
enum fsnotify_iter_type {
FSNOTIFY_ITER_TYPE_INODE = 0,
FSNOTIFY_ITER_TYPE_VFSMOUNT = 1,
FSNOTIFY_ITER_TYPE_SB = 2,
FSNOTIFY_ITER_TYPE_PARENT = 3,
FSNOTIFY_ITER_TYPE_INODE2 = 4,
FSNOTIFY_ITER_TYPE_COUNT = 5,
};
struct fs_struct {
int users;
spinlock_t lock;
seqcount_spinlock_t seq;
int umask;
int in_exec;
struct path root;
struct path pwd;
};
struct mount;
struct mnt_namespace {
struct ns_common ns;
struct mount *root;
struct list_head list;
spinlock_t ns_lock;
struct user_namespace *user_ns;
struct ucounts *ucounts;
u64 seq;
wait_queue_head_t poll;
long: 32;
u64 event;
unsigned int mounts;
unsigned int pending_mounts;
};
struct fsnotify_group;
struct fsnotify_iter_info;
struct fsnotify_mark;
struct fsnotify_event;
struct fsnotify_ops {
int (*handle_event)(struct fsnotify_group *, u32, const void *, int, struct inode *, const struct qstr *, u32, struct fsnotify_iter_info *);
int (*handle_inode_event)(struct fsnotify_mark *, u32, struct inode *, struct inode *, const struct qstr *, u32);
void (*free_group_priv)(struct fsnotify_group *);
void (*freeing_mark)(struct fsnotify_mark *, struct fsnotify_group *);
void (*free_event)(struct fsnotify_group *, struct fsnotify_event *);
void (*free_mark)(struct fsnotify_mark *);
};
struct inotify_group_private_data {
spinlock_t idr_lock;
struct idr idr;
struct ucounts *ucounts;
};
struct fsnotify_group {
const struct fsnotify_ops *ops;
refcount_t refcnt;
spinlock_t notification_lock;
struct list_head notification_list;
wait_queue_head_t notification_waitq;
unsigned int q_len;
unsigned int max_events;
unsigned int priority;
bool shutdown;
int flags;
unsigned int owner_flags;
struct mutex mark_mutex;
atomic_t user_waits;
struct list_head marks_list;
struct fasync_struct *fsn_fa;
struct fsnotify_event *overflow_event;
struct mem_cgroup *memcg;
union {
void *private;
struct inotify_group_private_data inotify_data;
};
};
struct fsnotify_iter_info {
struct fsnotify_mark *marks[5];
struct fsnotify_group *current_group;
unsigned int report_mask;
int srcu_idx;
};
struct fsnotify_mark {
__u32 mask;
refcount_t refcnt;
struct fsnotify_group *group;
struct list_head g_list;
spinlock_t lock;
struct hlist_node obj_list;
struct fsnotify_mark_connector *connector;
__u32 ignore_mask;
unsigned int flags;
};
struct fsnotify_event {
struct list_head list;
};
enum fsnotify_obj_type {
FSNOTIFY_OBJ_TYPE_ANY = -1,
FSNOTIFY_OBJ_TYPE_INODE = 0,
FSNOTIFY_OBJ_TYPE_VFSMOUNT = 1,
FSNOTIFY_OBJ_TYPE_SB = 2,
FSNOTIFY_OBJ_TYPE_COUNT = 3,
FSNOTIFY_OBJ_TYPE_DETACHED = 3,
};
struct mnt_pcp;
struct mountpoint;
struct mount {
struct hlist_node mnt_hash;
struct mount *mnt_parent;
struct dentry *mnt_mountpoint;
struct vfsmount mnt;
union {
struct callback_head mnt_rcu;
struct llist_node mnt_llist;
};
struct mnt_pcp *mnt_pcp;
struct list_head mnt_mounts;
struct list_head mnt_child;
struct list_head mnt_instance;
const char *mnt_devname;
struct list_head mnt_list;
struct list_head mnt_expire;
struct list_head mnt_share;
struct list_head mnt_slave_list;
struct list_head mnt_slave;
struct mount *mnt_master;
struct mnt_namespace *mnt_ns;
struct mountpoint *mnt_mp;
union {
struct hlist_node mnt_mp_list;
struct hlist_node mnt_umount;
};
struct list_head mnt_umounting;
struct fsnotify_mark_connector *mnt_fsnotify_marks;
__u32 mnt_fsnotify_mask;
int mnt_id;
int mnt_group_id;
int mnt_expiry_mark;
struct hlist_head mnt_pins;
struct hlist_head mnt_stuck_children;
};
struct mnt_pcp {
int mnt_count;
int mnt_writers;
};
struct mountpoint {
struct hlist_node m_hash;
struct dentry *m_dentry;
struct hlist_head m_list;
int m_count;
};
struct bio;
struct bio_list {
struct bio *head;
struct bio *tail;
};
struct request;
struct blk_plug {
struct request *mq_list;
struct request *cached_rq;
short unsigned int nr_ios;
short unsigned int rq_count;
bool multiple_queues;
bool has_elevator;
bool nowait;
struct list_head cb_list;
};
enum blk_bounce {
BLK_BOUNCE_NONE = 0,
BLK_BOUNCE_HIGH = 1,
};
enum blk_zoned_model {
BLK_ZONED_NONE = 0,
BLK_ZONED_HA = 1,
BLK_ZONED_HM = 2,
};
struct queue_limits {
enum blk_bounce bounce;
long unsigned int seg_boundary_mask;
long unsigned int virt_boundary_mask;
unsigned int max_hw_sectors;
unsigned int max_dev_sectors;
unsigned int chunk_sectors;
unsigned int max_sectors;
unsigned int max_segment_size;
unsigned int physical_block_size;
unsigned int logical_block_size;
unsigned int alignment_offset;
unsigned int io_min;
unsigned int io_opt;
unsigned int max_discard_sectors;
unsigned int max_hw_discard_sectors;
unsigned int max_secure_erase_sectors;
unsigned int max_write_zeroes_sectors;
unsigned int max_zone_append_sectors;
unsigned int discard_granularity;
unsigned int discard_alignment;
unsigned int zone_write_granularity;
short unsigned int max_segments;
short unsigned int max_integrity_segments;
short unsigned int max_discard_segments;
unsigned char misaligned;
unsigned char discard_misaligned;
unsigned char raid_partial_stripes_expensive;
enum blk_zoned_model zoned;
unsigned int dma_alignment;
};
struct elevator_queue;
struct blk_queue_stats;
struct rq_qos;
struct blk_mq_ops;
struct blk_mq_ctx;
struct blk_stat_callback;
struct blk_rq_stat;
struct blk_mq_tags;
struct blk_trace;
struct blk_flush_queue;
struct blk_mq_tag_set;
struct request_queue {
struct request *last_merge;
struct elevator_queue *elevator;
struct percpu_ref q_usage_counter;
struct blk_queue_stats *stats;
struct rq_qos *rq_qos;
const struct blk_mq_ops *mq_ops;
struct blk_mq_ctx *queue_ctx;
unsigned int queue_depth;
struct xarray hctx_table;
unsigned int nr_hw_queues;
void *queuedata;
long unsigned int queue_flags;
atomic_t pm_only;
int id;
spinlock_t queue_lock;
struct gendisk *disk;
struct kobject kobj;
struct kobject *mq_kobj;
long unsigned int nr_requests;
unsigned int dma_pad_mask;
unsigned int rq_timeout;
int poll_nsec;
struct blk_stat_callback *poll_cb;
struct blk_rq_stat *poll_stat;
struct timer_list timeout;
struct work_struct timeout_work;
atomic_t nr_active_requests_shared_tags;
struct blk_mq_tags *sched_shared_tags;
struct list_head icq_list;
struct queue_limits limits;
unsigned int required_elevator_features;
int node;
struct blk_trace *blk_trace;
struct blk_flush_queue *fq;
struct list_head requeue_list;
spinlock_t requeue_lock;
struct delayed_work requeue_work;
struct mutex sysfs_lock;
struct mutex sysfs_dir_lock;
struct list_head unused_hctx_list;
spinlock_t unused_hctx_lock;
int mq_freeze_depth;
struct callback_head callback_head;
wait_queue_head_t mq_freeze_wq;
struct mutex mq_freeze_lock;
int quiesce_depth;
struct blk_mq_tag_set *tag_set;
struct list_head tag_set_list;
struct dentry *debugfs_dir;
struct dentry *sched_debugfs_dir;
struct dentry *rqos_debugfs_dir;
struct mutex debugfs_mutex;
bool mq_sysfs_init_done;
struct srcu_struct srcu[0];
};
struct io_comp_batch {
struct request *req_list;
bool need_ts;
void (*complete)(struct io_comp_batch *);
};
typedef u8 blk_status_t;
struct bvec_iter {
sector_t bi_sector;
unsigned int bi_size;
unsigned int bi_idx;
unsigned int bi_bvec_done;
};
typedef unsigned int blk_qc_t;
typedef void bio_end_io_t(struct bio *);
struct bio_set;
struct bio {
struct bio *bi_next;
struct block_device *bi_bdev;
blk_opf_t bi_opf;
short unsigned int bi_flags;
short unsigned int bi_ioprio;
blk_status_t bi_status;
atomic_t __bi_remaining;
struct bvec_iter bi_iter;
blk_qc_t bi_cookie;
bio_end_io_t *bi_end_io;
void *bi_private;
union {};
short unsigned int bi_vcnt;
short unsigned int bi_max_vecs;
atomic_t __bi_cnt;
struct bio_vec *bi_io_vec;
struct bio_set *bi_pool;
struct bio_vec bi_inline_vecs[0];
};
typedef void *mempool_alloc_t(gfp_t, void *);
typedef void mempool_free_t(void *, void *);
struct mempool_s {
spinlock_t lock;
int min_nr;
int curr_nr;
void **elements;
void *pool_data;
mempool_alloc_t *alloc;
mempool_free_t *free;
wait_queue_head_t wait;
};
typedef struct mempool_s mempool_t;
struct bio_alloc_cache;
struct bio_set {
struct kmem_cache *bio_slab;
unsigned int front_pad;
struct bio_alloc_cache *cache;
mempool_t bio_pool;
mempool_t bvec_pool;
unsigned int back_pad;
spinlock_t rescue_lock;
struct bio_list rescue_list;
struct work_struct rescue_work;
struct workqueue_struct *rescue_workqueue;
struct hlist_node cpuhp_dead;
};
struct block_device_operations;
struct timer_rand_state;
struct disk_events;
struct cdrom_device_info;
struct badblocks;
struct blk_independent_access_ranges;
struct gendisk {
int major;
int first_minor;
int minors;
char disk_name[32];
short unsigned int events;
short unsigned int event_flags;
struct xarray part_tbl;
struct block_device *part0;
const struct block_device_operations *fops;
struct request_queue *queue;
void *private_data;
struct bio_set bio_split;
int flags;
long unsigned int state;
struct mutex open_mutex;
unsigned int open_partitions;
struct backing_dev_info *bdi;
struct kobject *slave_dir;
struct list_head slave_bdevs;
struct timer_rand_state *random;
atomic_t sync_io;
struct disk_events *ev;
struct cdrom_device_info *cdi;
int node_id;
struct badblocks *bb;
struct lockdep_map lockdep_map;
u64 diskseq;
struct blk_independent_access_ranges *ia_ranges;
long: 32;
};
struct partition_meta_info {
char uuid[37];
u8 volname[64];
};
enum {
BIO_NO_PAGE_REF = 0,
BIO_CLONED = 1,
BIO_BOUNCED = 2,
BIO_QUIET = 3,
BIO_CHAIN = 4,
BIO_REFFED = 5,
BIO_BPS_THROTTLED = 6,
BIO_TRACE_COMPLETION = 7,
BIO_CGROUP_ACCT = 8,
BIO_QOS_THROTTLED = 9,
BIO_QOS_MERGED = 10,
BIO_REMAPPED = 11,
BIO_ZONE_WRITE_LOCKED = 12,
BIO_FLAG_LAST = 13,
};
enum req_op {
REQ_OP_READ = 0,
REQ_OP_WRITE = 1,
REQ_OP_FLUSH = 2,
REQ_OP_DISCARD = 3,
REQ_OP_SECURE_ERASE = 5,
REQ_OP_WRITE_ZEROES = 9,
REQ_OP_ZONE_OPEN = 10,
REQ_OP_ZONE_CLOSE = 11,
REQ_OP_ZONE_FINISH = 12,
REQ_OP_ZONE_APPEND = 13,
REQ_OP_ZONE_RESET = 15,
REQ_OP_ZONE_RESET_ALL = 17,
REQ_OP_DRV_IN = 34,
REQ_OP_DRV_OUT = 35,
REQ_OP_LAST = 36,
};
enum req_flag_bits {
__REQ_FAILFAST_DEV = 8,
__REQ_FAILFAST_TRANSPORT = 9,
__REQ_FAILFAST_DRIVER = 10,
__REQ_SYNC = 11,
__REQ_META = 12,
__REQ_PRIO = 13,
__REQ_NOMERGE = 14,
__REQ_IDLE = 15,
__REQ_INTEGRITY = 16,
__REQ_FUA = 17,
__REQ_PREFLUSH = 18,
__REQ_RAHEAD = 19,
__REQ_BACKGROUND = 20,
__REQ_NOWAIT = 21,
__REQ_CGROUP_PUNT = 22,
__REQ_POLLED = 23,
__REQ_ALLOC_CACHE = 24,
__REQ_SWAP = 25,
__REQ_DRV = 26,
__REQ_NOUNMAP = 27,
__REQ_NR_BITS = 28,
};
struct blk_rq_stat {
u64 mean;
u64 min;
u64 max;
u32 nr_samples;
long: 32;
u64 batch;
};
enum iter_type {
ITER_IOVEC = 0,
ITER_KVEC = 1,
ITER_BVEC = 2,
ITER_PIPE = 3,
ITER_XARRAY = 4,
ITER_DISCARD = 5,
ITER_UBUF = 6,
};
struct blk_zone {
__u64 start;
__u64 len;
__u64 wp;
__u8 type;
__u8 cond;
__u8 non_seq;
__u8 reset;
__u8 resv[4];
__u64 capacity;
__u8 reserved[24];
};
typedef int (*report_zones_cb)(struct blk_zone *, unsigned int, void *);
enum blk_unique_id {
BLK_UID_T10 = 1,
BLK_UID_EUI64 = 2,
BLK_UID_NAA = 3,
};
struct hd_geometry;
struct pr_ops;
struct block_device_operations {
void (*submit_bio)(struct bio *);
int (*poll_bio)(struct bio *, struct io_comp_batch *, unsigned int);
int (*open)(struct block_device *, fmode_t);
void (*release)(struct gendisk *, fmode_t);
int (*rw_page)(struct block_device *, sector_t, struct page *, enum req_op);
int (*ioctl)(struct block_device *, fmode_t, unsigned int, long unsigned int);
int (*compat_ioctl)(struct block_device *, fmode_t, unsigned int, long unsigned int);
unsigned int (*check_events)(struct gendisk *, unsigned int);
void (*unlock_native_capacity)(struct gendisk *);
int (*getgeo)(struct block_device *, struct hd_geometry *);
int (*set_read_only)(struct block_device *, bool);
void (*free_disk)(struct gendisk *);
void (*swap_slot_free_notify)(struct block_device *, long unsigned int);
int (*report_zones)(struct gendisk *, sector_t, unsigned int, report_zones_cb, void *);
char * (*devnode)(struct gendisk *, umode_t *);
int (*get_unique_id)(struct gendisk *, u8 *, enum blk_unique_id);
struct module *owner;
const struct pr_ops *pr_ops;
int (*alternative_gpt_sector)(struct gendisk *, sector_t *);
};
struct blk_independent_access_range {
struct kobject kobj;
long: 32;
sector_t sector;
sector_t nr_sectors;
};
struct blk_independent_access_ranges {
struct kobject kobj;
bool sysfs_registered;
unsigned int nr_ia_ranges;
long: 32;
struct blk_independent_access_range ia_range[0];
};
enum blk_eh_timer_return {
BLK_EH_DONE = 0,
BLK_EH_RESET_TIMER = 1,
};
struct blk_mq_hw_ctx;
struct blk_mq_queue_data;
struct blk_mq_ops {
blk_status_t (*queue_rq)(struct blk_mq_hw_ctx *, const struct blk_mq_queue_data *);
void (*commit_rqs)(struct blk_mq_hw_ctx *);
void (*queue_rqs)(struct request **);
int (*get_budget)(struct request_queue *);
void (*put_budget)(struct request_queue *, int);
void (*set_rq_budget_token)(struct request *, int);
int (*get_rq_budget_token)(struct request *);
enum blk_eh_timer_return (*timeout)(struct request *);
int (*poll)(struct blk_mq_hw_ctx *, struct io_comp_batch *);
void (*complete)(struct request *);
int (*init_hctx)(struct blk_mq_hw_ctx *, void *, unsigned int);
void (*exit_hctx)(struct blk_mq_hw_ctx *, unsigned int);
int (*init_request)(struct blk_mq_tag_set *, struct request *, unsigned int, unsigned int);
void (*exit_request)(struct blk_mq_tag_set *, struct request *, unsigned int);
void (*cleanup_rq)(struct request *);
bool (*busy)(struct request_queue *);
void (*map_queues)(struct blk_mq_tag_set *);
void (*show_rq)(struct seq_file *, struct request *);
};
enum pr_type {
PR_WRITE_EXCLUSIVE = 1,
PR_EXCLUSIVE_ACCESS = 2,
PR_WRITE_EXCLUSIVE_REG_ONLY = 3,
PR_EXCLUSIVE_ACCESS_REG_ONLY = 4,
PR_WRITE_EXCLUSIVE_ALL_REGS = 5,
PR_EXCLUSIVE_ACCESS_ALL_REGS = 6,
};
struct pr_ops {
int (*pr_register)(struct block_device *, u64, u64, u32);
int (*pr_reserve)(struct block_device *, u64, enum pr_type, u32);
int (*pr_release)(struct block_device *, u64, enum pr_type);
int (*pr_preempt)(struct block_device *, u64, u64, enum pr_type, bool);
int (*pr_clear)(struct block_device *, u64);
};
struct dax_device;
struct iomap_page_ops;
struct iomap {
u64 addr;
loff_t offset;
u64 length;
u16 type;
u16 flags;
struct block_device *bdev;
struct dax_device *dax_dev;
void *inline_data;
void *private;
const struct iomap_page_ops *page_ops;
};
struct iomap_page_ops {
int (*page_prepare)(struct inode *, loff_t, unsigned int);
void (*page_done)(struct inode *, loff_t, unsigned int, struct page *);
};
struct iomap_ops {
int (*iomap_begin)(struct inode *, loff_t, loff_t, unsigned int, struct iomap *, struct iomap *);
int (*iomap_end)(struct inode *, loff_t, loff_t, ssize_t, unsigned int, struct iomap *);
};
struct iomap_iter {
struct inode *inode;
long: 32;
loff_t pos;
u64 len;
s64 processed;
unsigned int flags;
long: 32;
struct iomap iomap;
struct iomap srcmap;
void *private;
long: 32;
};
struct iomap_dio_ops {
int (*end_io)(struct kiocb *, ssize_t, int, unsigned int);
void (*submit_io)(const struct iomap_iter *, struct bio *, loff_t);
struct bio_set *bio_set;
};
struct iomap_dio {
struct kiocb *iocb;
const struct iomap_dio_ops *dops;
loff_t i_size;
loff_t size;
atomic_t ref;
unsigned int flags;
int error;
size_t done_before;
bool wait_for_completion;
union {
struct {
struct iov_iter *iter;
struct task_struct *waiter;
struct bio *poll_bio;
} submit;
struct {
struct work_struct work;
} aio;
};
long: 32;
};
typedef u32 nlink_t;
struct llist_head {
struct llist_node *first;
};
struct linux_binprm;
struct coredump_params;
struct linux_binfmt {
struct list_head lh;
struct module *module;
int (*load_binary)(struct linux_binprm *);
int (*load_shlib)(struct file *);
int (*core_dump)(struct coredump_params *);
long unsigned int min_coredump;
};
struct ld_semaphore {
atomic_long_t count;
raw_spinlock_t wait_lock;
unsigned int wait_readers;
struct list_head read_wait;
struct list_head write_wait;
};
typedef unsigned int tcflag_t;
typedef unsigned char cc_t;
typedef unsigned int speed_t;
struct ktermios {
tcflag_t c_iflag;
tcflag_t c_oflag;
tcflag_t c_cflag;
tcflag_t c_lflag;
cc_t c_line;
cc_t c_cc[23];
speed_t c_ispeed;
speed_t c_ospeed;
};
struct winsize {
short unsigned int ws_row;
short unsigned int ws_col;
short unsigned int ws_xpixel;
short unsigned int ws_ypixel;
};
struct tty_driver;
struct tty_operations;
struct tty_ldisc;
struct tty_port;
struct tty_struct {
struct kref kref;
struct device *dev;
struct tty_driver *driver;
const struct tty_operations *ops;
int index;
struct ld_semaphore ldisc_sem;
struct tty_ldisc *ldisc;
struct mutex atomic_write_lock;
struct mutex legacy_mutex;
struct mutex throttle_mutex;
struct rw_semaphore termios_rwsem;
struct mutex winsize_mutex;
struct ktermios termios;
struct ktermios termios_locked;
char name[64];
long unsigned int flags;
int count;
struct winsize winsize;
struct {
spinlock_t lock;
bool stopped;
bool tco_stopped;
long unsigned int unused[0];
} flow;
struct {
spinlock_t lock;
struct pid *pgrp;
struct pid *session;
unsigned char pktstatus;
bool packet;
long unsigned int unused[0];
} ctrl;
int hw_stopped;
unsigned int receive_room;
int flow_change;
struct tty_struct *link;
struct fasync_struct *fasync;
wait_queue_head_t write_wait;
wait_queue_head_t read_wait;
struct work_struct hangup_work;
void *disc_data;
void *driver_data;
spinlock_t files_lock;
struct list_head tty_files;
int closing;
unsigned char *write_buf;
int write_cnt;
struct work_struct SAK_work;
struct tty_port *port;
};
struct proc_ops {
unsigned int proc_flags;
int (*proc_open)(struct inode *, struct file *);
ssize_t (*proc_read)(struct file *, char *, size_t, loff_t *);
ssize_t (*proc_read_iter)(struct kiocb *, struct iov_iter *);
ssize_t (*proc_write)(struct file *, const char *, size_t, loff_t *);
loff_t (*proc_lseek)(struct file *, loff_t, int);
int (*proc_release)(struct inode *, struct file *);
__poll_t (*proc_poll)(struct file *, struct poll_table_struct *);
long int (*proc_ioctl)(struct file *, unsigned int, long unsigned int);
int (*proc_mmap)(struct file *, struct vm_area_struct *);
long unsigned int (*proc_get_unmapped_area)(struct file *, long unsigned int, long unsigned int, long unsigned int, long unsigned int);
};
typedef int (*proc_write_t)(struct file *, char *, size_t);
struct tty_buffer {
union {
struct tty_buffer *next;
struct llist_node free;
};
int used;
int size;
int commit;
int lookahead;
int read;
int flags;
long unsigned int data[0];
};
struct tty_bufhead {
struct tty_buffer *head;
struct work_struct work;
struct mutex lock;
atomic_t priority;
struct tty_buffer sentinel;
struct llist_head free;
atomic_t mem_used;
int mem_limit;
struct tty_buffer *tail;
};
struct serial_icounter_struct;
struct serial_struct;
struct tty_operations {
struct tty_struct * (*lookup)(struct tty_driver *, struct file *, int);
int (*install)(struct tty_driver *, struct tty_struct *);
void (*remove)(struct tty_driver *, struct tty_struct *);
int (*open)(struct tty_struct *, struct file *);
void (*close)(struct tty_struct *, struct file *);
void (*shutdown)(struct tty_struct *);
void (*cleanup)(struct tty_struct *);
int (*write)(struct tty_struct *, const unsigned char *, int);
int (*put_char)(struct tty_struct *, unsigned char);
void (*flush_chars)(struct tty_struct *);
unsigned int (*write_room)(struct tty_struct *);
unsigned int (*chars_in_buffer)(struct tty_struct *);
int (*ioctl)(struct tty_struct *, unsigned int, long unsigned int);
long int (*compat_ioctl)(struct tty_struct *, unsigned int, long unsigned int);
void (*set_termios)(struct tty_struct *, const struct ktermios *);
void (*throttle)(struct tty_struct *);
void (*unthrottle)(struct tty_struct *);
void (*stop)(struct tty_struct *);
void (*start)(struct tty_struct *);
void (*hangup)(struct tty_struct *);
int (*break_ctl)(struct tty_struct *, int);
void (*flush_buffer)(struct tty_struct *);
void (*set_ldisc)(struct tty_struct *);
void (*wait_until_sent)(struct tty_struct *, int);
void (*send_xchar)(struct tty_struct *, char);
int (*tiocmget)(struct tty_struct *);
int (*tiocmset)(struct tty_struct *, unsigned int, unsigned int);
int (*resize)(struct tty_struct *, struct winsize *);
int (*get_icount)(struct tty_struct *, struct serial_icounter_struct *);
int (*get_serial)(struct tty_struct *, struct serial_struct *);
int (*set_serial)(struct tty_struct *, struct serial_struct *);
void (*show_fdinfo)(struct tty_struct *, struct seq_file *);
int (*proc_show)(struct seq_file *, void *);
};
struct tty_driver {
struct kref kref;
struct cdev **cdevs;
struct module *owner;
const char *driver_name;
const char *name;
int name_base;
int major;
int minor_start;
unsigned int num;
short int type;
short int subtype;
struct ktermios init_termios;
long unsigned int flags;
struct proc_dir_entry *proc_entry;
struct tty_driver *other;
struct tty_struct **ttys;
struct tty_port **ports;
struct ktermios **termios;
void *driver_state;
const struct tty_operations *ops;
struct list_head tty_drivers;
};
struct proc_dir_entry {
atomic_t in_use;
refcount_t refcnt;
struct list_head pde_openers;
spinlock_t pde_unload_lock;
struct completion *pde_unload_completion;
const struct inode_operations *proc_iops;
union {
const struct proc_ops *proc_ops;
const struct file_operations *proc_dir_ops;
};
const struct dentry_operations *proc_dops;
union {
const struct seq_operations *seq_ops;
int (*single_show)(struct seq_file *, void *);
};
proc_write_t write;
void *data;
unsigned int state_size;
unsigned int low_ino;
nlink_t nlink;
kuid_t uid;
kgid_t gid;
long: 32;
loff_t size;
struct proc_dir_entry *parent;
struct rb_root subdir;
struct rb_node subdir_node;
char *name;
umode_t mode;
u8 flags;
u8 namelen;
char inline_name[0];
long: 32;
};
struct __kfifo {
unsigned int in;
unsigned int out;
unsigned int mask;
unsigned int esize;
void *data;
};
struct tty_port_operations;
struct tty_port_client_operations;
struct tty_port {
struct tty_bufhead buf;
struct tty_struct *tty;
struct tty_struct *itty;
const struct tty_port_operations *ops;
const struct tty_port_client_operations *client_ops;
spinlock_t lock;
int blocked_open;
int count;
wait_queue_head_t open_wait;
wait_queue_head_t delta_msr_wait;
long unsigned int flags;
long unsigned int iflags;
unsigned char console: 1;
struct mutex mutex;
struct mutex buf_mutex;
unsigned char *xmit_buf;
struct {
union {
struct __kfifo kfifo;
unsigned char *type;
const unsigned char *const_type;
char (*rectype)[0];
unsigned char *ptr;
const unsigned char *ptr_const;
};
unsigned char buf[0];
} xmit_fifo;
unsigned int close_delay;
unsigned int closing_wait;
int drain_delay;
struct kref kref;
void *client_data;
};
struct tty_ldisc_ops {
char *name;
int num;
int (*open)(struct tty_struct *);
void (*close)(struct tty_struct *);
void (*flush_buffer)(struct tty_struct *);
ssize_t (*read)(struct tty_struct *, struct file *, unsigned char *, size_t, void **, long unsigned int);
ssize_t (*write)(struct tty_struct *, struct file *, const unsigned char *, size_t);
int (*ioctl)(struct tty_struct *, unsigned int, long unsigned int);
int (*compat_ioctl)(struct tty_struct *, unsigned int, long unsigned int);
void (*set_termios)(struct tty_struct *, const struct ktermios *);
__poll_t (*poll)(struct tty_struct *, struct file *, struct poll_table_struct *);
void (*hangup)(struct tty_struct *);
void (*receive_buf)(struct tty_struct *, const unsigned char *, const char *, int);
void (*write_wakeup)(struct tty_struct *);
void (*dcd_change)(struct tty_struct *, unsigned int);
int (*receive_buf2)(struct tty_struct *, const unsigned char *, const char *, int);
void (*lookahead_buf)(struct tty_struct *, const unsigned char *, const unsigned char *, unsigned int);
struct module *owner;
};
struct tty_ldisc {
struct tty_ldisc_ops *ops;
struct tty_struct *tty;
};
struct tty_port_operations {
int (*carrier_raised)(struct tty_port *);
void (*dtr_rts)(struct tty_port *, int);
void (*shutdown)(struct tty_port *);
int (*activate)(struct tty_port *, struct tty_struct *);
void (*destruct)(struct tty_port *);
};
struct tty_port_client_operations {
int (*receive_buf)(struct tty_port *, const unsigned char *, const unsigned char *, size_t);
void (*lookahead_buf)(struct tty_port *, const unsigned char *, const unsigned char *, unsigned int);
void (*write_wakeup)(struct tty_port *);
};
struct linux_binprm {
struct vm_area_struct *vma;
long unsigned int vma_pages;
struct mm_struct *mm;
long unsigned int p;
long unsigned int argmin;
unsigned int have_execfd: 1;
unsigned int execfd_creds: 1;
unsigned int secureexec: 1;
unsigned int point_of_no_return: 1;
struct file *executable;
struct file *interpreter;
struct file *file;
struct cred *cred;
int unsafe;
unsigned int per_clear;
int argc;
int envc;
const char *filename;
const char *interp;
const char *fdpath;
unsigned int interp_flags;
int execfd;
long unsigned int loader;
long unsigned int exec;
struct rlimit rlim_stack;
char buf[256];
};
typedef unsigned int __kernel_uid_t;
typedef unsigned int __kernel_gid_t;
struct __kernel_old_timeval {
__kernel_long_t tv_sec;
__kernel_long_t tv_usec;
};
typedef struct pglist_data pg_data_t;
struct nsset {
unsigned int flags;
struct nsproxy *nsproxy;
struct fs_struct *fs;
const struct cred *cred;
};
typedef __u32 Elf32_Off;
struct elf32_hdr {
unsigned char e_ident[16];
Elf32_Half e_type;
Elf32_Half e_machine;
Elf32_Word e_version;
Elf32_Addr e_entry;
Elf32_Off e_phoff;
Elf32_Off e_shoff;
Elf32_Word e_flags;
Elf32_Half e_ehsize;
Elf32_Half e_phentsize;
Elf32_Half e_phnum;
Elf32_Half e_shentsize;
Elf32_Half e_shnum;
Elf32_Half e_shstrndx;
};
struct elf32_phdr {
Elf32_Word p_type;
Elf32_Off p_offset;
Elf32_Addr p_vaddr;
Elf32_Addr p_paddr;
Elf32_Word p_filesz;
Elf32_Word p_memsz;
Elf32_Word p_flags;
Elf32_Word p_align;
};
struct elf32_note {
Elf32_Word n_namesz;
Elf32_Word n_descsz;
Elf32_Word n_type;
};
typedef long unsigned int elf_greg_t;
typedef elf_greg_t elf_gregset_t[45];
struct elf_siginfo {
int si_signo;
int si_code;
int si_errno;
};
struct elf_prstatus_common {
struct elf_siginfo pr_info;
short int pr_cursig;
long unsigned int pr_sigpend;
long unsigned int pr_sighold;
pid_t pr_pid;
pid_t pr_ppid;
pid_t pr_pgrp;
pid_t pr_sid;
struct __kernel_old_timeval pr_utime;
struct __kernel_old_timeval pr_stime;
struct __kernel_old_timeval pr_cutime;
struct __kernel_old_timeval pr_cstime;
};
struct elf_prstatus {
struct elf_prstatus_common common;
elf_gregset_t pr_reg;
int pr_fpvalid;
};
struct elf_prpsinfo {
char pr_state;
char pr_sname;
char pr_zomb;
char pr_nice;
long unsigned int pr_flag;
__kernel_uid_t pr_uid;
__kernel_gid_t pr_gid;
pid_t pr_pid;
pid_t pr_ppid;
pid_t pr_pgrp;
pid_t pr_sid;
char pr_fname[16];
char pr_psargs[80];
};
enum kcore_type {
KCORE_TEXT = 0,
KCORE_VMALLOC = 1,
KCORE_RAM = 2,
KCORE_VMEMMAP = 3,
KCORE_USER = 4,
};
struct kcore_list {
struct list_head list;
long unsigned int addr;
size_t size;
int type;
};
enum lockdown_reason {
LOCKDOWN_NONE = 0,
LOCKDOWN_MODULE_SIGNATURE = 1,
LOCKDOWN_DEV_MEM = 2,
LOCKDOWN_EFI_TEST = 3,
LOCKDOWN_KEXEC = 4,
LOCKDOWN_HIBERNATION = 5,
LOCKDOWN_PCI_ACCESS = 6,
LOCKDOWN_IOPORT = 7,
LOCKDOWN_MSR = 8,
LOCKDOWN_ACPI_TABLES = 9,
LOCKDOWN_DEVICE_TREE = 10,
LOCKDOWN_PCMCIA_CIS = 11,
LOCKDOWN_TIOCSSERIAL = 12,
LOCKDOWN_MODULE_PARAMETERS = 13,
LOCKDOWN_MMIOTRACE = 14,
LOCKDOWN_DEBUGFS = 15,
LOCKDOWN_XMON_WR = 16,
LOCKDOWN_BPF_WRITE_USER = 17,
LOCKDOWN_DBG_WRITE_KERNEL = 18,
LOCKDOWN_RTAS_ERROR_INJECTION = 19,
LOCKDOWN_INTEGRITY_MAX = 20,
LOCKDOWN_KCORE = 21,
LOCKDOWN_KPROBES = 22,
LOCKDOWN_BPF_READ_KERNEL = 23,
LOCKDOWN_DBG_READ_KERNEL = 24,
LOCKDOWN_PERF = 25,
LOCKDOWN_TRACEFS = 26,
LOCKDOWN_XMON_RW = 27,
LOCKDOWN_XFRM_SECRET = 28,
LOCKDOWN_CONFIDENTIALITY_MAX = 29,
};
typedef __u16 __le16;
typedef __u32 __le32;
typedef __u64 __le64;
typedef void (*swap_func_t)(void *, void *, int);
typedef int (*cmp_func_t)(const void *, const void *);
struct buffer_head;
typedef void bh_end_io_t(struct buffer_head *, int);
struct buffer_head {
long unsigned int b_state;
struct buffer_head *b_this_page;
struct page *b_page;
long: 32;
sector_t b_blocknr;
size_t b_size;
char *b_data;
struct block_device *b_bdev;
bh_end_io_t *b_end_io;
void *b_private;
struct list_head b_assoc_buffers;
struct address_space *b_assoc_map;
atomic_t b_count;
spinlock_t b_uptodate_lock;
};
struct fiemap_extent;
struct fiemap_extent_info {
unsigned int fi_flags;
unsigned int fi_extents_mapped;
unsigned int fi_extents_max;
struct fiemap_extent *fi_extents_start;
};
typedef unsigned int tid_t;
struct transaction_chp_stats_s {
long unsigned int cs_chp_time;
__u32 cs_forced_to_close;
__u32 cs_written;
__u32 cs_dropped;
};
struct journal_s;
typedef struct journal_s journal_t;
struct journal_head;
struct transaction_s;
typedef struct transaction_s transaction_t;
struct transaction_s {
journal_t *t_journal;
tid_t t_tid;
enum {
T_RUNNING = 0,
T_LOCKED = 1,
T_SWITCH = 2,
T_FLUSH = 3,
T_COMMIT = 4,
T_COMMIT_DFLUSH = 5,
T_COMMIT_JFLUSH = 6,
T_COMMIT_CALLBACK = 7,
T_FINISHED = 8,
} t_state;
long unsigned int t_log_start;
int t_nr_buffers;
struct journal_head *t_reserved_list;
struct journal_head *t_buffers;
struct journal_head *t_forget;
struct journal_head *t_checkpoint_list;
struct journal_head *t_checkpoint_io_list;
struct journal_head *t_shadow_list;
struct list_head t_inode_list;
spinlock_t t_handle_lock;
long unsigned int t_max_wait;
long unsigned int t_start;
long unsigned int t_requested;
struct transaction_chp_stats_s t_chp_stats;
atomic_t t_updates;
atomic_t t_outstanding_credits;
atomic_t t_outstanding_revokes;
atomic_t t_handle_count;
transaction_t *t_cpnext;
transaction_t *t_cpprev;
long unsigned int t_expires;
ktime_t t_start_time;
unsigned int t_synchronous_commit: 1;
int t_need_data_flush;
struct list_head t_private_list;
};
struct jbd2_buffer_trigger_type;
struct journal_head {
struct buffer_head *b_bh;
spinlock_t b_state_lock;
int b_jcount;
unsigned int b_jlist;
unsigned int b_modified;
char *b_frozen_data;
char *b_committed_data;
transaction_t *b_transaction;
transaction_t *b_next_transaction;
struct journal_head *b_tnext;
struct journal_head *b_tprev;
transaction_t *b_cp_transaction;
struct journal_head *b_cpnext;
struct journal_head *b_cpprev;
struct jbd2_buffer_trigger_type *b_triggers;
struct jbd2_buffer_trigger_type *b_frozen_triggers;
};
struct jbd2_buffer_trigger_type {
void (*t_frozen)(struct jbd2_buffer_trigger_type *, struct buffer_head *, void *, size_t);
void (*t_abort)(struct jbd2_buffer_trigger_type *, struct buffer_head *);
};
struct crypto_alg;
struct crypto_tfm {
u32 crt_flags;
int node;
void (*exit)(struct crypto_tfm *);
struct crypto_alg *__crt_alg;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__crt_ctx[0];
};
struct cipher_alg {
unsigned int cia_min_keysize;
unsigned int cia_max_keysize;
int (*cia_setkey)(struct crypto_tfm *, const u8 *, unsigned int);
void (*cia_encrypt)(struct crypto_tfm *, u8 *, const u8 *);
void (*cia_decrypt)(struct crypto_tfm *, u8 *, const u8 *);
};
struct compress_alg {
int (*coa_compress)(struct crypto_tfm *, const u8 *, unsigned int, u8 *, unsigned int *);
int (*coa_decompress)(struct crypto_tfm *, const u8 *, unsigned int, u8 *, unsigned int *);
};
struct crypto_type;
struct crypto_alg {
struct list_head cra_list;
struct list_head cra_users;
u32 cra_flags;
unsigned int cra_blocksize;
unsigned int cra_ctxsize;
unsigned int cra_alignmask;
int cra_priority;
refcount_t cra_refcnt;
char cra_name[128];
char cra_driver_name[128];
const struct crypto_type *cra_type;
union {
struct cipher_alg cipher;
struct compress_alg compress;
} cra_u;
int (*cra_init)(struct crypto_tfm *);
void (*cra_exit)(struct crypto_tfm *);
void (*cra_destroy)(struct crypto_alg *);
struct module *cra_module;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct crypto_instance;
struct crypto_type {
unsigned int (*ctxsize)(struct crypto_alg *, u32, u32);
unsigned int (*extsize)(struct crypto_alg *);
int (*init)(struct crypto_tfm *, u32, u32);
int (*init_tfm)(struct crypto_tfm *);
void (*show)(struct seq_file *, struct crypto_alg *);
int (*report)(struct sk_buff *, struct crypto_alg *);
void (*free)(struct crypto_instance *);
unsigned int type;
unsigned int maskclear;
unsigned int maskset;
unsigned int tfmsize;
};
struct crypto_shash {
unsigned int descsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_tfm base;
};
struct transaction_run_stats_s {
long unsigned int rs_wait;
long unsigned int rs_request_delay;
long unsigned int rs_running;
long unsigned int rs_locked;
long unsigned int rs_flushing;
long unsigned int rs_logging;
__u32 rs_handle_count;
__u32 rs_blocks;
__u32 rs_blocks_logged;
};
struct transaction_stats_s {
long unsigned int ts_tid;
long unsigned int ts_requested;
struct transaction_run_stats_s run;
};
enum passtype {
PASS_SCAN = 0,
PASS_REVOKE = 1,
PASS_REPLAY = 2,
};
struct journal_superblock_s;
typedef struct journal_superblock_s journal_superblock_t;
struct jbd2_revoke_table_s;
struct jbd2_inode;
struct journal_s {
long unsigned int j_flags;
long unsigned int j_atomic_flags;
int j_errno;
struct mutex j_abort_mutex;
struct buffer_head *j_sb_buffer;
journal_superblock_t *j_superblock;
int j_format_version;
rwlock_t j_state_lock;
int j_barrier_count;
struct mutex j_barrier;
transaction_t *j_running_transaction;
transaction_t *j_committing_transaction;
transaction_t *j_checkpoint_transactions;
wait_queue_head_t j_wait_transaction_locked;
wait_queue_head_t j_wait_done_commit;
wait_queue_head_t j_wait_commit;
wait_queue_head_t j_wait_updates;
wait_queue_head_t j_wait_reserved;
wait_queue_head_t j_fc_wait;
struct mutex j_checkpoint_mutex;
struct buffer_head *j_chkpt_bhs[64];
struct shrinker j_shrinker;
struct percpu_counter j_checkpoint_jh_count;
transaction_t *j_shrink_transaction;
long unsigned int j_head;
long unsigned int j_tail;
long unsigned int j_free;
long unsigned int j_first;
long unsigned int j_last;
long unsigned int j_fc_first;
long unsigned int j_fc_off;
long unsigned int j_fc_last;
struct block_device *j_dev;
int j_blocksize;
long: 32;
long long unsigned int j_blk_offset;
char j_devname[56];
struct block_device *j_fs_dev;
unsigned int j_total_len;
atomic_t j_reserved_credits;
spinlock_t j_list_lock;
struct inode *j_inode;
tid_t j_tail_sequence;
tid_t j_transaction_sequence;
tid_t j_commit_sequence;
tid_t j_commit_request;
__u8 j_uuid[16];
struct task_struct *j_task;
int j_max_transaction_buffers;
int j_revoke_records_per_block;
long unsigned int j_commit_interval;
struct timer_list j_commit_timer;
spinlock_t j_revoke_lock;
struct jbd2_revoke_table_s *j_revoke;
struct jbd2_revoke_table_s *j_revoke_table[2];
struct buffer_head **j_wbuf;
struct buffer_head **j_fc_wbuf;
int j_wbufsize;
int j_fc_wbufsize;
pid_t j_last_sync_writer;
long: 32;
u64 j_average_commit_time;
u32 j_min_batch_time;
u32 j_max_batch_time;
void (*j_commit_callback)(journal_t *, transaction_t *);
int (*j_submit_inode_data_buffers)(struct jbd2_inode *);
int (*j_finish_inode_data_buffers)(struct jbd2_inode *);
spinlock_t j_history_lock;
struct proc_dir_entry *j_proc_entry;
struct transaction_stats_s j_stats;
unsigned int j_failed_commit;
void *j_private;
struct crypto_shash *j_chksum_driver;
__u32 j_csum_seed;
void (*j_fc_cleanup_callback)(struct journal_s *, int, tid_t);
int (*j_fc_replay_callback)(struct journal_s *, struct buffer_head *, enum passtype, int, tid_t);
};
struct journal_header_s {
__be32 h_magic;
__be32 h_blocktype;
__be32 h_sequence;
};
typedef struct journal_header_s journal_header_t;
struct journal_superblock_s {
journal_header_t s_header;
__be32 s_blocksize;
__be32 s_maxlen;
__be32 s_first;
__be32 s_sequence;
__be32 s_start;
__be32 s_errno;
__be32 s_feature_compat;
__be32 s_feature_incompat;
__be32 s_feature_ro_compat;
__u8 s_uuid[16];
__be32 s_nr_users;
__be32 s_dynsuper;
__be32 s_max_transaction;
__be32 s_max_trans_data;
__u8 s_checksum_type;
__u8 s_padding2[3];
__be32 s_num_fc_blks;
__u32 s_padding[41];
__be32 s_checksum;
__u8 s_users[768];
};
struct jbd2_inode {
transaction_t *i_transaction;
transaction_t *i_next_transaction;
struct list_head i_list;
struct inode *i_vfs_inode;
long unsigned int i_flags;
loff_t i_dirty_start;
loff_t i_dirty_end;
};
struct bgl_lock {
spinlock_t lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct blockgroup_lock {
struct bgl_lock locks[32];
};
struct fiemap_extent {
__u64 fe_logical;
__u64 fe_physical;
__u64 fe_length;
__u64 fe_reserved64[2];
__u32 fe_flags;
__u32 fe_reserved[3];
};
struct fscrypt_dummy_policy {};
typedef int ext4_grpblk_t;
typedef long long unsigned int ext4_fsblk_t;
typedef __u32 ext4_lblk_t;
typedef unsigned int ext4_group_t;
struct ext4_system_blocks {
struct rb_root root;
struct callback_head rcu;
};
struct ext4_group_desc {
__le32 bg_block_bitmap_lo;
__le32 bg_inode_bitmap_lo;
__le32 bg_inode_table_lo;
__le16 bg_free_blocks_count_lo;
__le16 bg_free_inodes_count_lo;
__le16 bg_used_dirs_count_lo;
__le16 bg_flags;
__le32 bg_exclude_bitmap_lo;
__le16 bg_block_bitmap_csum_lo;
__le16 bg_inode_bitmap_csum_lo;
__le16 bg_itable_unused_lo;
__le16 bg_checksum;
__le32 bg_block_bitmap_hi;
__le32 bg_inode_bitmap_hi;
__le32 bg_inode_table_hi;
__le16 bg_free_blocks_count_hi;
__le16 bg_free_inodes_count_hi;
__le16 bg_used_dirs_count_hi;
__le16 bg_itable_unused_hi;
__le32 bg_exclude_bitmap_hi;
__le16 bg_block_bitmap_csum_hi;
__le16 bg_inode_bitmap_csum_hi;
__u32 bg_reserved;
};
struct flex_groups {
atomic64_t free_clusters;
atomic_t free_inodes;
atomic_t used_dirs;
};
struct ext4_es_stats {
long unsigned int es_stats_shrunk;
long: 32;
struct percpu_counter es_stats_cache_hits;
struct percpu_counter es_stats_cache_misses;
u64 es_stats_scan_time;
u64 es_stats_max_scan_time;
struct percpu_counter es_stats_all_cnt;
struct percpu_counter es_stats_shk_cnt;
};
struct ext4_fc_stats {
unsigned int fc_ineligible_reason_count[9];
long unsigned int fc_num_commits;
long unsigned int fc_ineligible_commits;
long unsigned int fc_failed_commits;
long unsigned int fc_skipped_commits;
long unsigned int fc_numblks;
u64 s_fc_avg_commit_time;
};
struct ext4_fc_alloc_region {
ext4_lblk_t lblk;
long: 32;
ext4_fsblk_t pblk;
int ino;
int len;
};
struct ext4_fc_replay_state {
int fc_replay_num_tags;
int fc_replay_expected_off;
int fc_current_pass;
int fc_cur_tag;
int fc_crc;
struct ext4_fc_alloc_region *fc_regions;
int fc_regions_size;
int fc_regions_used;
int fc_regions_valid;
int *fc_modified_inodes;
int fc_modified_inodes_used;
int fc_modified_inodes_size;
};
struct ext4_super_block {
__le32 s_inodes_count;
__le32 s_blocks_count_lo;
__le32 s_r_blocks_count_lo;
__le32 s_free_blocks_count_lo;
__le32 s_free_inodes_count;
__le32 s_first_data_block;
__le32 s_log_block_size;
__le32 s_log_cluster_size;
__le32 s_blocks_per_group;
__le32 s_clusters_per_group;
__le32 s_inodes_per_group;
__le32 s_mtime;
__le32 s_wtime;
__le16 s_mnt_count;
__le16 s_max_mnt_count;
__le16 s_magic;
__le16 s_state;
__le16 s_errors;
__le16 s_minor_rev_level;
__le32 s_lastcheck;
__le32 s_checkinterval;
__le32 s_creator_os;
__le32 s_rev_level;
__le16 s_def_resuid;
__le16 s_def_resgid;
__le32 s_first_ino;
__le16 s_inode_size;
__le16 s_block_group_nr;
__le32 s_feature_compat;
__le32 s_feature_incompat;
__le32 s_feature_ro_compat;
__u8 s_uuid[16];
char s_volume_name[16];
char s_last_mounted[64];
__le32 s_algorithm_usage_bitmap;
__u8 s_prealloc_blocks;
__u8 s_prealloc_dir_blocks;
__le16 s_reserved_gdt_blocks;
__u8 s_journal_uuid[16];
__le32 s_journal_inum;
__le32 s_journal_dev;
__le32 s_last_orphan;
__le32 s_hash_seed[4];
__u8 s_def_hash_version;
__u8 s_jnl_backup_type;
__le16 s_desc_size;
__le32 s_default_mount_opts;
__le32 s_first_meta_bg;
__le32 s_mkfs_time;
__le32 s_jnl_blocks[17];
__le32 s_blocks_count_hi;
__le32 s_r_blocks_count_hi;
__le32 s_free_blocks_count_hi;
__le16 s_min_extra_isize;
__le16 s_want_extra_isize;
__le32 s_flags;
__le16 s_raid_stride;
__le16 s_mmp_update_interval;
__le64 s_mmp_block;
__le32 s_raid_stripe_width;
__u8 s_log_groups_per_flex;
__u8 s_checksum_type;
__u8 s_encryption_level;
__u8 s_reserved_pad;
__le64 s_kbytes_written;
__le32 s_snapshot_inum;
__le32 s_snapshot_id;
__le64 s_snapshot_r_blocks_count;
__le32 s_snapshot_list;
__le32 s_error_count;
__le32 s_first_error_time;
__le32 s_first_error_ino;
__le64 s_first_error_block;
__u8 s_first_error_func[32];
__le32 s_first_error_line;
__le32 s_last_error_time;
__le32 s_last_error_ino;
__le32 s_last_error_line;
__le64 s_last_error_block;
__u8 s_last_error_func[32];
__u8 s_mount_opts[64];
__le32 s_usr_quota_inum;
__le32 s_grp_quota_inum;
__le32 s_overhead_clusters;
__le32 s_backup_bgs[2];
__u8 s_encrypt_algos[4];
__u8 s_encrypt_pw_salt[16];
__le32 s_lpf_ino;
__le32 s_prj_quota_inum;
__le32 s_checksum_seed;
__u8 s_wtime_hi;
__u8 s_mtime_hi;
__u8 s_mkfs_time_hi;
__u8 s_lastcheck_hi;
__u8 s_first_error_time_hi;
__u8 s_last_error_time_hi;
__u8 s_first_error_errcode;
__u8 s_last_error_errcode;
__le16 s_encoding;
__le16 s_encoding_flags;
__le32 s_orphan_file_inum;
__le32 s_reserved[94];
__le32 s_checksum;
};
struct ext4_journal_trigger {
struct jbd2_buffer_trigger_type tr_triggers;
struct super_block *sb;
};
struct ext4_orphan_block {
atomic_t ob_free_entries;
struct buffer_head *ob_bh;
};
struct ext4_orphan_info {
int of_blocks;
__u32 of_csum_seed;
struct ext4_orphan_block *of_binfo;
};
struct ext4_group_info;
struct ext4_locality_group;
struct ext4_li_request;
struct mb_cache;
struct ext4_sb_info {
long unsigned int s_desc_size;
long unsigned int s_inodes_per_block;
long unsigned int s_blocks_per_group;
long unsigned int s_clusters_per_group;
long unsigned int s_inodes_per_group;
long unsigned int s_itb_per_group;
long unsigned int s_gdb_count;
long unsigned int s_desc_per_block;
ext4_group_t s_groups_count;
ext4_group_t s_blockfile_groups;
long unsigned int s_overhead;
unsigned int s_cluster_ratio;
unsigned int s_cluster_bits;
long: 32;
loff_t s_bitmap_maxbytes;
struct buffer_head *s_sbh;
struct ext4_super_block *s_es;
struct buffer_head **s_group_desc;
unsigned int s_mount_opt;
unsigned int s_mount_opt2;
long unsigned int s_mount_flags;
unsigned int s_def_mount_opt;
long: 32;
ext4_fsblk_t s_sb_block;
atomic64_t s_resv_clusters;
kuid_t s_resuid;
kgid_t s_resgid;
short unsigned int s_mount_state;
short unsigned int s_pad;
int s_addr_per_block_bits;
int s_desc_per_block_bits;
int s_inode_size;
int s_first_ino;
unsigned int s_inode_readahead_blks;
unsigned int s_inode_goal;
u32 s_hash_seed[4];
int s_def_hash_version;
int s_hash_unsigned;
long: 32;
struct percpu_counter s_freeclusters_counter;
struct percpu_counter s_freeinodes_counter;
struct percpu_counter s_dirs_counter;
struct percpu_counter s_dirtyclusters_counter;
struct percpu_counter s_sra_exceeded_retry_limit;
struct blockgroup_lock *s_blockgroup_lock;
struct proc_dir_entry *s_proc;
struct kobject s_kobj;
struct completion s_kobj_unregister;
struct super_block *s_sb;
struct buffer_head *s_mmp_bh;
struct journal_s *s_journal;
long unsigned int s_ext4_flags;
struct mutex s_orphan_lock;
struct list_head s_orphan;
struct ext4_orphan_info s_orphan_info;
long unsigned int s_commit_interval;
u32 s_max_batch_time;
u32 s_min_batch_time;
struct block_device *s_journal_bdev;
char *s_qf_names[3];
int s_jquota_fmt;
unsigned int s_want_extra_isize;
struct ext4_system_blocks *s_system_blks;
struct ext4_group_info ***s_group_info;
struct inode *s_buddy_cache;
spinlock_t s_md_lock;
short unsigned int *s_mb_offsets;
unsigned int *s_mb_maxs;
unsigned int s_group_info_size;
unsigned int s_mb_free_pending;
struct list_head s_freed_data_list;
struct list_head s_discard_list;
struct work_struct s_discard_work;
atomic_t s_retry_alloc_pending;
struct list_head *s_mb_avg_fragment_size;
rwlock_t *s_mb_avg_fragment_size_locks;
struct list_head *s_mb_largest_free_orders;
rwlock_t *s_mb_largest_free_orders_locks;
long unsigned int s_stripe;
unsigned int s_mb_max_linear_groups;
unsigned int s_mb_stream_request;
unsigned int s_mb_max_to_scan;
unsigned int s_mb_min_to_scan;
unsigned int s_mb_stats;
unsigned int s_mb_order2_reqs;
unsigned int s_mb_group_prealloc;
unsigned int s_mb_max_inode_prealloc;
unsigned int s_max_dir_size_kb;
long unsigned int s_mb_last_group;
long unsigned int s_mb_last_start;
unsigned int s_mb_prefetch;
unsigned int s_mb_prefetch_limit;
atomic_t s_bal_reqs;
atomic_t s_bal_success;
atomic_t s_bal_allocated;
atomic_t s_bal_ex_scanned;
atomic_t s_bal_groups_scanned;
atomic_t s_bal_goals;
atomic_t s_bal_breaks;
atomic_t s_bal_2orders;
atomic_t s_bal_cr0_bad_suggestions;
atomic_t s_bal_cr1_bad_suggestions;
atomic64_t s_bal_cX_groups_considered[4];
atomic64_t s_bal_cX_hits[4];
atomic64_t s_bal_cX_failed[4];
atomic_t s_mb_buddies_generated;
long: 32;
atomic64_t s_mb_generation_time;
atomic_t s_mb_lost_chunks;
atomic_t s_mb_preallocated;
atomic_t s_mb_discarded;
atomic_t s_lock_busy;
struct ext4_locality_group *s_locality_groups;
long unsigned int s_sectors_written_start;
u64 s_kbytes_written;
unsigned int s_extent_max_zeroout_kb;
unsigned int s_log_groups_per_flex;
struct flex_groups **s_flex_groups;
ext4_group_t s_flex_groups_allocated;
struct workqueue_struct *rsv_conversion_wq;
struct timer_list s_err_report;
struct ext4_li_request *s_li_request;
unsigned int s_li_wait_mult;
struct task_struct *s_mmp_tsk;
long unsigned int s_last_trim_minblks;
struct crypto_shash *s_chksum_driver;
__u32 s_csum_seed;
struct shrinker s_es_shrinker;
struct list_head s_es_list;
long int s_es_nr_inode;
long: 32;
struct ext4_es_stats s_es_stats;
struct mb_cache *s_ea_block_cache;
struct mb_cache *s_ea_inode_cache;
long: 32;
long: 32;
long: 32;
long: 32;
spinlock_t s_es_lock;
struct ext4_journal_trigger s_journal_triggers[1];
struct ratelimit_state s_err_ratelimit_state;
struct ratelimit_state s_warning_ratelimit_state;
struct ratelimit_state s_msg_ratelimit_state;
atomic_t s_warning_count;
atomic_t s_msg_count;
struct fscrypt_dummy_policy s_dummy_enc_policy;
struct percpu_rw_semaphore s_writepages_rwsem;
struct dax_device *s_daxdev;
long: 32;
u64 s_dax_part_off;
errseq_t s_bdev_wb_err;
spinlock_t s_bdev_wb_lock;
spinlock_t s_error_lock;
int s_add_error_count;
int s_first_error_code;
__u32 s_first_error_line;
__u32 s_first_error_ino;
long: 32;
__u64 s_first_error_block;
const char *s_first_error_func;
long: 32;
time64_t s_first_error_time;
int s_last_error_code;
__u32 s_last_error_line;
__u32 s_last_error_ino;
long: 32;
__u64 s_last_error_block;
const char *s_last_error_func;
long: 32;
time64_t s_last_error_time;
struct work_struct s_error_work;
atomic_t s_fc_subtid;
struct list_head s_fc_q[2];
struct list_head s_fc_dentry_q[2];
unsigned int s_fc_bytes;
spinlock_t s_fc_lock;
struct buffer_head *s_fc_bh;
struct ext4_fc_stats s_fc_stats;
tid_t s_fc_ineligible_tid;
struct ext4_fc_replay_state s_fc_replay_state;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct ext4_group_info {
long unsigned int bb_state;
struct rb_root bb_free_root;
ext4_grpblk_t bb_first_free;
ext4_grpblk_t bb_free;
ext4_grpblk_t bb_fragments;
int bb_avg_fragment_size_order;
ext4_grpblk_t bb_largest_free_order;
ext4_group_t bb_group;
struct list_head bb_prealloc_list;
struct rw_semaphore alloc_sem;
struct list_head bb_avg_fragment_size_node;
struct list_head bb_largest_free_order_node;
ext4_grpblk_t bb_counters[0];
};
struct ext4_locality_group {
struct mutex lg_mutex;
struct list_head lg_prealloc_list[10];
spinlock_t lg_prealloc_lock;
};
enum ext4_li_mode {
EXT4_LI_MODE_PREFETCH_BBITMAP = 0,
EXT4_LI_MODE_ITABLE = 1,
};
struct ext4_li_request {
struct super_block *lr_super;
enum ext4_li_mode lr_mode;
ext4_group_t lr_first_not_zeroed;
ext4_group_t lr_next_group;
struct list_head lr_request;
long unsigned int lr_next_sched;
long unsigned int lr_timeout;
};
struct fsmap {
__u32 fmr_device;
__u32 fmr_flags;
__u64 fmr_physical;
__u64 fmr_owner;
__u64 fmr_offset;
__u64 fmr_length;
__u64 fmr_reserved[3];
};
struct ext4_fsmap {
struct list_head fmr_list;
dev_t fmr_device;
uint32_t fmr_flags;
uint64_t fmr_physical;
uint64_t fmr_owner;
uint64_t fmr_length;
};
struct ext4_fsmap_head {
uint32_t fmh_iflags;
uint32_t fmh_oflags;
unsigned int fmh_count;
unsigned int fmh_entries;
struct ext4_fsmap fmh_keys[2];
};
typedef int (*ext4_fsmap_format_t)(struct ext4_fsmap *, void *);
typedef int (*ext4_mballoc_query_range_fn)(struct super_block *, ext4_group_t, ext4_grpblk_t, ext4_grpblk_t, void *);
typedef int (*list_cmp_func_t)(void *, const struct list_head *, const struct list_head *);
struct ext4_getfsmap_info {
struct ext4_fsmap_head *gfi_head;
ext4_fsmap_format_t gfi_formatter;
void *gfi_format_arg;
long: 32;
ext4_fsblk_t gfi_next_fsblk;
u32 gfi_dev;
ext4_group_t gfi_agno;
struct ext4_fsmap gfi_low;
struct ext4_fsmap gfi_high;
struct ext4_fsmap gfi_lastfree;
struct list_head gfi_meta_list;
bool gfi_last;
long: 32;
};
struct ext4_getfsmap_dev {
int (*gfd_fn)(struct super_block *, struct ext4_fsmap *, struct ext4_getfsmap_info *);
u32 gfd_dev;
};
struct disk_stats {
u64 nsecs[4];
long unsigned int sectors[4];
long unsigned int ios[4];
long unsigned int merges[4];
long unsigned int io_ticks;
local_t in_flight[2];
long: 32;
};
enum stat_group {
STAT_READ = 0,
STAT_WRITE = 1,
STAT_DISCARD = 2,
STAT_FLUSH = 3,
NR_STAT_GROUPS = 4,
};
enum {
attr_noop = 0,
attr_delayed_allocation_blocks = 1,
attr_session_write_kbytes = 2,
attr_lifetime_write_kbytes = 3,
attr_reserved_clusters = 4,
attr_sra_exceeded_retry_limit = 5,
attr_inode_readahead = 6,
attr_trigger_test_error = 7,
attr_first_error_time = 8,
attr_last_error_time = 9,
attr_feature = 10,
attr_pointer_ui = 11,
attr_pointer_ul = 12,
attr_pointer_u64 = 13,
attr_pointer_u8 = 14,
attr_pointer_string = 15,
attr_pointer_atomic = 16,
attr_journal_task = 17,
};
enum {
ptr_explicit = 0,
ptr_ext4_sb_info_offset = 1,
ptr_ext4_super_block_offset = 2,
};
struct ext4_attr {
struct attribute attr;
short int attr_id;
short int attr_ptr;
short unsigned int attr_size;
union {
int offset;
void *explicit_ptr;
} u;
};
typedef __u64 __be64;
enum bh_state_bits {
BH_Uptodate = 0,
BH_Dirty = 1,
BH_Lock = 2,
BH_Req = 3,
BH_Mapped = 4,
BH_New = 5,
BH_Async_Read = 6,
BH_Async_Write = 7,
BH_Delay = 8,
BH_Boundary = 9,
BH_Write_EIO = 10,
BH_Unwritten = 11,
BH_Quiet = 12,
BH_Meta = 13,
BH_Prio = 14,
BH_Defer_Completion = 15,
BH_PrivateStart = 16,
};
struct jbd2_journal_handle;
typedef struct jbd2_journal_handle handle_t;
struct jbd2_journal_handle {
union {
transaction_t *h_transaction;
journal_t *h_journal;
};
handle_t *h_rsv_handle;
int h_total_credits;
int h_revoke_credits;
int h_revoke_credits_requested;
int h_ref;
int h_err;
unsigned int h_sync: 1;
unsigned int h_jdata: 1;
unsigned int h_reserved: 1;
unsigned int h_aborted: 1;
unsigned int h_type: 8;
unsigned int h_line_no: 16;
long unsigned int h_start_jiffies;
unsigned int h_requested_credits;
unsigned int saved_alloc_context;
};
struct jbd2_journal_revoke_header_s {
journal_header_t r_header;
__be32 r_count;
};
typedef struct jbd2_journal_revoke_header_s jbd2_journal_revoke_header_t;
enum jbd_state_bits {
BH_JBD = 16,
BH_JWrite = 17,
BH_Freed = 18,
BH_Revoked = 19,
BH_RevokeValid = 20,
BH_JBDDirty = 21,
BH_JournalHead = 22,
BH_Shadow = 23,
BH_Verified = 24,
BH_JBDPrivateStart = 25,
};
struct jbd2_revoke_table_s {
int hash_size;
int hash_shift;
struct list_head *hash_table;
};
struct jbd2_revoke_record_s {
struct list_head hash;
tid_t sequence;
long: 32;
long long unsigned int blocknr;
};
typedef __u64 __addrpair;
typedef __u32 __portpair;
struct hlist_nulls_node {
struct hlist_nulls_node *next;
struct hlist_nulls_node **pprev;
};
struct proto;
struct sock_common {
union {
__addrpair skc_addrpair;
struct {
__be32 skc_daddr;
__be32 skc_rcv_saddr;
};
};
union {
unsigned int skc_hash;
__u16 skc_u16hashes[2];
};
union {
__portpair skc_portpair;
struct {
__be16 skc_dport;
__u16 skc_num;
};
};
short unsigned int skc_family;
volatile unsigned char skc_state;
unsigned char skc_reuse: 4;
unsigned char skc_reuseport: 1;
unsigned char skc_ipv6only: 1;
unsigned char skc_net_refcnt: 1;
int skc_bound_dev_if;
union {
struct hlist_node skc_bind_node;
struct hlist_node skc_portaddr_node;
};
struct proto *skc_prot;
possible_net_t skc_net;
struct in6_addr skc_v6_daddr;
struct in6_addr skc_v6_rcv_saddr;
atomic64_t skc_cookie;
union {
long unsigned int skc_flags;
struct sock *skc_listener;
struct inet_timewait_death_row *skc_tw_dr;
};
int skc_dontcopy_begin[0];
union {
struct hlist_node skc_node;
struct hlist_nulls_node skc_nulls_node;
};
short unsigned int skc_tx_queue_mapping;
short unsigned int skc_rx_queue_mapping;
union {
int skc_incoming_cpu;
u32 skc_rcv_wnd;
u32 skc_tw_rcv_nxt;
};
refcount_t skc_refcnt;
int skc_dontcopy_end[0];
union {
u32 skc_rxhash;
u32 skc_window_clamp;
u32 skc_tw_snd_nxt;
};
long: 32;
};
typedef struct {
spinlock_t slock;
int owned;
wait_queue_head_t wq;
} socket_lock_t;
struct sock_cgroup_data {};
typedef struct {} netns_tracker;
struct sk_filter;
struct socket_wq;
struct xfrm_policy;
struct socket;
struct sock_reuseport;
struct sock {
struct sock_common __sk_common;
struct dst_entry *sk_rx_dst;
int sk_rx_dst_ifindex;
u32 sk_rx_dst_cookie;
socket_lock_t sk_lock;
atomic_t sk_drops;
int sk_rcvlowat;
struct sk_buff_head sk_error_queue;
struct sk_buff_head sk_receive_queue;
struct {
atomic_t rmem_alloc;
int len;
struct sk_buff *head;
struct sk_buff *tail;
} sk_backlog;
int sk_forward_alloc;
u32 sk_reserved_mem;
unsigned int sk_ll_usec;
unsigned int sk_napi_id;
int sk_rcvbuf;
struct sk_filter *sk_filter;
union {
struct socket_wq *sk_wq;
struct socket_wq *sk_wq_raw;
};
struct xfrm_policy *sk_policy[2];
struct dst_entry *sk_dst_cache;
atomic_t sk_omem_alloc;
int sk_sndbuf;
int sk_wmem_queued;
refcount_t sk_wmem_alloc;
long unsigned int sk_tsq_flags;
union {
struct sk_buff *sk_send_head;
struct rb_root tcp_rtx_queue;
};
struct sk_buff_head sk_write_queue;
__s32 sk_peek_off;
int sk_write_pending;
__u32 sk_dst_pending_confirm;
u32 sk_pacing_status;
long int sk_sndtimeo;
struct timer_list sk_timer;
__u32 sk_priority;
__u32 sk_mark;
long unsigned int sk_pacing_rate;
long unsigned int sk_max_pacing_rate;
struct page_frag sk_frag;
netdev_features_t sk_route_caps;
int sk_gso_type;
unsigned int sk_gso_max_size;
gfp_t sk_allocation;
__u32 sk_txhash;
u8 sk_gso_disabled: 1;
u8 sk_kern_sock: 1;
u8 sk_no_check_tx: 1;
u8 sk_no_check_rx: 1;
u8 sk_userlocks: 4;
u8 sk_pacing_shift;
u16 sk_type;
u16 sk_protocol;
u16 sk_gso_max_segs;
long unsigned int sk_lingertime;
struct proto *sk_prot_creator;
rwlock_t sk_callback_lock;
int sk_err;
int sk_err_soft;
u32 sk_ack_backlog;
u32 sk_max_ack_backlog;
kuid_t sk_uid;
u8 sk_txrehash;
u8 sk_prefer_busy_poll;
u16 sk_busy_poll_budget;
spinlock_t sk_peer_lock;
int sk_bind_phc;
struct pid *sk_peer_pid;
const struct cred *sk_peer_cred;
long int sk_rcvtimeo;
long: 32;
ktime_t sk_stamp;
seqlock_t sk_stamp_seq;
u16 sk_tsflags;
u8 sk_shutdown;
atomic_t sk_tskey;
atomic_t sk_zckey;
u8 sk_clockid;
u8 sk_txtime_deadline_mode: 1;
u8 sk_txtime_report_errors: 1;
u8 sk_txtime_unused: 6;
struct socket *sk_socket;
void *sk_user_data;
void *sk_security;
struct sock_cgroup_data sk_cgrp_data;
struct mem_cgroup *sk_memcg;
void (*sk_state_change)(struct sock *);
void (*sk_data_ready)(struct sock *);
void (*sk_write_space)(struct sock *);
void (*sk_error_report)(struct sock *);
int (*sk_backlog_rcv)(struct sock *, struct sk_buff *);
void (*sk_destruct)(struct sock *);
struct sock_reuseport *sk_reuseport_cb;
struct bpf_local_storage *sk_bpf_storage;
struct callback_head sk_rcu;
netns_tracker ns_tracker;
struct hlist_node sk_bind2_node;
};
enum kobject_action {
KOBJ_ADD = 0,
KOBJ_REMOVE = 1,
KOBJ_CHANGE = 2,
KOBJ_MOVE = 3,
KOBJ_ONLINE = 4,
KOBJ_OFFLINE = 5,
KOBJ_BIND = 6,
KOBJ_UNBIND = 7,
};
struct kobj_attribute {
struct attribute attr;
ssize_t (*show)(struct kobject *, struct kobj_attribute *, char *);
ssize_t (*store)(struct kobject *, struct kobj_attribute *, const char *, size_t);
};
struct ubuf_info;
struct msghdr {
void *msg_name;
int msg_namelen;
int msg_inq;
long: 32;
struct iov_iter msg_iter;
union {
void *msg_control;
void *msg_control_user;
};
bool msg_control_is_user: 1;
bool msg_get_inq: 1;
unsigned int msg_flags;
__kernel_size_t msg_controllen;
struct kiocb *msg_iocb;
struct ubuf_info *msg_ubuf;
int (*sg_from_iter)(struct sock *, struct sk_buff *, struct iov_iter *, size_t);
long: 32;
};
struct ubuf_info {
void (*callback)(struct sk_buff *, struct ubuf_info *, bool);
refcount_t refcnt;
u8 flags;
};
struct flowi_tunnel {
__be64 tun_id;
};
struct flowi_common {
int flowic_oif;
int flowic_iif;
int flowic_l3mdev;
__u32 flowic_mark;
__u8 flowic_tos;
__u8 flowic_scope;
__u8 flowic_proto;
__u8 flowic_flags;
__u32 flowic_secid;
kuid_t flowic_uid;
long: 32;
struct flowi_tunnel flowic_tun_key;
__u32 flowic_multipath_hash;
long: 32;
};
union flowi_uli {
struct {
__be16 dport;
__be16 sport;
} ports;
struct {
__u8 type;
__u8 code;
} icmpt;
__be32 gre_key;
struct {
__u8 type;
} mht;
};
struct flowi4 {
struct flowi_common __fl_common;
__be32 saddr;
__be32 daddr;
union flowi_uli uli;
long: 32;
};
struct flowi6 {
struct flowi_common __fl_common;
struct in6_addr daddr;
struct in6_addr saddr;
__be32 flowlabel;
union flowi_uli uli;
__u32 mp_hash;
long: 32;
};
struct flowi {
union {
struct flowi_common __fl_common;
struct flowi4 ip4;
struct flowi6 ip6;
} u;
};
struct prot_inuse {
int all;
int val[64];
};
struct icmpv6_mib_device {
atomic_long_t mibs[6];
};
struct icmpv6msg_mib_device {
atomic_long_t mibs[512];
};
struct fib_rule;
struct fib_lookup_arg;
struct fib_rule_hdr;
struct fib_rules_ops {
int family;
struct list_head list;
int rule_size;
int addr_size;
int unresolved_rules;
int nr_goto_rules;
unsigned int fib_rules_seq;
int (*action)(struct fib_rule *, struct flowi *, int, struct fib_lookup_arg *);
bool (*suppress)(struct fib_rule *, int, struct fib_lookup_arg *);
int (*match)(struct fib_rule *, struct flowi *, int);
int (*configure)(struct fib_rule *, struct sk_buff *, struct fib_rule_hdr *, struct nlattr **, struct netlink_ext_ack *);
int (*delete)(struct fib_rule *);
int (*compare)(struct fib_rule *, struct fib_rule_hdr *, struct nlattr **);
int (*fill)(struct fib_rule *, struct sk_buff *, struct fib_rule_hdr *);
size_t (*nlmsg_payload)(struct fib_rule *);
void (*flush_cache)(struct fib_rules_ops *);
int nlgroup;
struct list_head rules_list;
struct module *owner;
struct net *fro_net;
struct callback_head rcu;
};
struct fib_notifier_ops {
int family;
struct list_head list;
unsigned int (*fib_seq_read)(struct net *);
int (*fib_dump)(struct net *, struct notifier_block *, struct netlink_ext_ack *);
struct module *owner;
struct callback_head rcu;
};
struct ipv6_stable_secret {
bool initialized;
struct in6_addr secret;
};
struct ipv6_devconf {
__s32 forwarding;
__s32 hop_limit;
__s32 mtu6;
__s32 accept_ra;
__s32 accept_redirects;
__s32 autoconf;
__s32 dad_transmits;
__s32 rtr_solicits;
__s32 rtr_solicit_interval;
__s32 rtr_solicit_max_interval;
__s32 rtr_solicit_delay;
__s32 force_mld_version;
__s32 mldv1_unsolicited_report_interval;
__s32 mldv2_unsolicited_report_interval;
__s32 use_tempaddr;
__s32 temp_valid_lft;
__s32 temp_prefered_lft;
__s32 regen_max_retry;
__s32 max_desync_factor;
__s32 max_addresses;
__s32 accept_ra_defrtr;
__u32 ra_defrtr_metric;
__s32 accept_ra_min_hop_limit;
__s32 accept_ra_pinfo;
__s32 ignore_routes_with_linkdown;
__s32 accept_ra_rtr_pref;
__s32 rtr_probe_interval;
__s32 accept_ra_rt_info_min_plen;
__s32 accept_ra_rt_info_max_plen;
__s32 proxy_ndp;
__s32 accept_source_route;
__s32 accept_ra_from_local;
__s32 optimistic_dad;
__s32 use_optimistic;
atomic_t mc_forwarding;
__s32 disable_ipv6;
__s32 drop_unicast_in_l2_multicast;
__s32 accept_dad;
__s32 force_tllao;
__s32 ndisc_notify;
__s32 suppress_frag_ndisc;
__s32 accept_ra_mtu;
__s32 drop_unsolicited_na;
__s32 accept_untracked_na;
struct ipv6_stable_secret stable_secret;
__s32 use_oif_addrs_only;
__s32 keep_addr_on_down;
__s32 seg6_enabled;
__u32 enhanced_dad;
__u32 addr_gen_mode;
__s32 disable_policy;
__s32 ndisc_tclass;
__s32 rpl_seg_enabled;
__u32 ioam6_id;
__u32 ioam6_id_wide;
__u8 ioam6_enabled;
__u8 ndisc_evict_nocarrier;
struct ctl_table_header *sysctl_header;
};
enum {
IPPROTO_IP = 0,
IPPROTO_ICMP = 1,
IPPROTO_IGMP = 2,
IPPROTO_IPIP = 4,
IPPROTO_TCP = 6,
IPPROTO_EGP = 8,
IPPROTO_PUP = 12,
IPPROTO_UDP = 17,
IPPROTO_IDP = 22,
IPPROTO_TP = 29,
IPPROTO_DCCP = 33,
IPPROTO_IPV6 = 41,
IPPROTO_RSVP = 46,
IPPROTO_GRE = 47,
IPPROTO_ESP = 50,
IPPROTO_AH = 51,
IPPROTO_MTP = 92,
IPPROTO_BEETPH = 94,
IPPROTO_ENCAP = 98,
IPPROTO_PIM = 103,
IPPROTO_COMP = 108,
IPPROTO_L2TP = 115,
IPPROTO_SCTP = 132,
IPPROTO_UDPLITE = 136,
IPPROTO_MPLS = 137,
IPPROTO_ETHERNET = 143,
IPPROTO_RAW = 255,
IPPROTO_MPTCP = 262,
IPPROTO_MAX = 263,
};
typedef struct {
union {
void *kernel;
void *user;
};
bool is_kernel: 1;
} sockptr_t;
typedef enum {
SS_FREE = 0,
SS_UNCONNECTED = 1,
SS_CONNECTING = 2,
SS_CONNECTED = 3,
SS_DISCONNECTING = 4,
} socket_state;
struct socket_wq {
wait_queue_head_t wait;
struct fasync_struct *fasync_list;
long unsigned int flags;
struct callback_head rcu;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct proto_ops;
struct socket {
socket_state state;
short int type;
long unsigned int flags;
struct file *file;
struct sock *sk;
const struct proto_ops *ops;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct socket_wq wq;
};
typedef struct {
size_t written;
size_t count;
union {
char *buf;
void *data;
} arg;
int error;
} read_descriptor_t;
typedef int (*sk_read_actor_t)(read_descriptor_t *, struct sk_buff *, unsigned int, size_t);
typedef int (*skb_read_actor_t)(struct sock *, struct sk_buff *);
struct proto_ops {
int family;
struct module *owner;
int (*release)(struct socket *);
int (*bind)(struct socket *, struct sockaddr *, int);
int (*connect)(struct socket *, struct sockaddr *, int, int);
int (*socketpair)(struct socket *, struct socket *);
int (*accept)(struct socket *, struct socket *, int, bool);
int (*getname)(struct socket *, struct sockaddr *, int);
__poll_t (*poll)(struct file *, struct socket *, struct poll_table_struct *);
int (*ioctl)(struct socket *, unsigned int, long unsigned int);
int (*gettstamp)(struct socket *, void *, bool, bool);
int (*listen)(struct socket *, int);
int (*shutdown)(struct socket *, int);
int (*setsockopt)(struct socket *, int, int, sockptr_t, unsigned int);
int (*getsockopt)(struct socket *, int, int, char *, int *);
void (*show_fdinfo)(struct seq_file *, struct socket *);
int (*sendmsg)(struct socket *, struct msghdr *, size_t);
int (*recvmsg)(struct socket *, struct msghdr *, size_t, int);
int (*mmap)(struct file *, struct socket *, struct vm_area_struct *);
ssize_t (*sendpage)(struct socket *, struct page *, int, size_t, int);
ssize_t (*splice_read)(struct socket *, loff_t *, struct pipe_inode_info *, size_t, unsigned int);
int (*set_peek_off)(struct sock *, int);
int (*peek_len)(struct socket *);
int (*read_sock)(struct sock *, read_descriptor_t *, sk_read_actor_t);
int (*read_skb)(struct sock *, skb_read_actor_t);
int (*sendpage_locked)(struct sock *, struct page *, int, size_t, int);
int (*sendmsg_locked)(struct sock *, struct msghdr *, size_t);
int (*set_rcvlowat)(struct sock *, int);
};
struct net_generic {
union {
struct {
unsigned int len;
struct callback_head rcu;
} s;
struct {
struct {} __empty_ptr;
void *ptr[0];
};
};
};
struct new_utsname {
char sysname[65];
char nodename[65];
char release[65];
char version[65];
char machine[65];
char domainname[65];
};
struct uts_namespace {
struct new_utsname name;
struct user_namespace *user_ns;
struct ucounts *ucounts;
struct ns_common ns;
};
enum {
NAPI_STATE_SCHED = 0,
NAPI_STATE_MISSED = 1,
NAPI_STATE_DISABLE = 2,
NAPI_STATE_NPSVC = 3,
NAPI_STATE_LISTED = 4,
NAPI_STATE_NO_BUSY_POLL = 5,
NAPI_STATE_IN_BUSY_POLL = 6,
NAPI_STATE_PREFER_BUSY_POLL = 7,
NAPI_STATE_THREADED = 8,
NAPI_STATE_SCHED_THREADED = 9,
};
enum xps_map_type {
XPS_CPUS = 0,
XPS_RXQS = 1,
XPS_MAPS_MAX = 2,
};
enum bpf_xdp_mode {
XDP_MODE_SKB = 0,
XDP_MODE_DRV = 1,
XDP_MODE_HW = 2,
__MAX_XDP_MODE = 3,
};
struct neigh_parms {
possible_net_t net;
struct net_device *dev;
netdevice_tracker dev_tracker;
struct list_head list;
int (*neigh_setup)(struct neighbour *);
struct neigh_table *tbl;
void *sysctl_table;
int dead;
refcount_t refcnt;
struct callback_head callback_head;
int reachable_time;
u32 qlen;
int data[14];
long unsigned int data_state[1];
};
struct ipv6_devstat {
struct proc_dir_entry *proc_dir_entry;
struct ipstats_mib *ipv6;
struct icmpv6_mib_device *icmpv6dev;
struct icmpv6msg_mib_device *icmpv6msgdev;
};
struct ifmcaddr6;
struct ifacaddr6;
struct inet6_dev {
struct net_device *dev;
netdevice_tracker dev_tracker;
struct list_head addr_list;
struct ifmcaddr6 *mc_list;
struct ifmcaddr6 *mc_tomb;
unsigned char mc_qrv;
unsigned char mc_gq_running;
unsigned char mc_ifc_count;
unsigned char mc_dad_count;
long unsigned int mc_v1_seen;
long unsigned int mc_qi;
long unsigned int mc_qri;
long unsigned int mc_maxdelay;
struct delayed_work mc_gq_work;
struct delayed_work mc_ifc_work;
struct delayed_work mc_dad_work;
struct delayed_work mc_query_work;
struct delayed_work mc_report_work;
struct sk_buff_head mc_query_queue;
struct sk_buff_head mc_report_queue;
spinlock_t mc_query_lock;
spinlock_t mc_report_lock;
struct mutex mc_lock;
struct ifacaddr6 *ac_list;
rwlock_t lock;
refcount_t refcnt;
__u32 if_flags;
int dead;
u32 desync_factor;
struct list_head tempaddr_list;
struct in6_addr token;
struct neigh_parms *nd_parms;
struct ipv6_devconf cnf;
struct ipv6_devstat stats;
struct timer_list rs_timer;
__s32 rs_interval;
__u8 rs_probes;
long unsigned int tstamp;
struct callback_head rcu;
unsigned int ra_mtu;
};
enum {
NETIF_MSG_DRV_BIT = 0,
NETIF_MSG_PROBE_BIT = 1,
NETIF_MSG_LINK_BIT = 2,
NETIF_MSG_TIMER_BIT = 3,
NETIF_MSG_IFDOWN_BIT = 4,
NETIF_MSG_IFUP_BIT = 5,
NETIF_MSG_RX_ERR_BIT = 6,
NETIF_MSG_TX_ERR_BIT = 7,
NETIF_MSG_TX_QUEUED_BIT = 8,
NETIF_MSG_INTR_BIT = 9,
NETIF_MSG_TX_DONE_BIT = 10,
NETIF_MSG_RX_STATUS_BIT = 11,
NETIF_MSG_PKTDATA_BIT = 12,
NETIF_MSG_HW_BIT = 13,
NETIF_MSG_WOL_BIT = 14,
NETIF_MSG_CLASS_COUNT = 15,
};
enum rpc_display_format_t {
RPC_DISPLAY_ADDR = 0,
RPC_DISPLAY_PORT = 1,
RPC_DISPLAY_PROTO = 2,
RPC_DISPLAY_HEX_ADDR = 3,
RPC_DISPLAY_HEX_PORT = 4,
RPC_DISPLAY_NETID = 5,
RPC_DISPLAY_MAX = 6,
};
struct rpc_pipe_msg {
struct list_head list;
void *data;
size_t len;
size_t copied;
int errno;
};
struct rpc_pipe_ops {
ssize_t (*upcall)(struct file *, struct rpc_pipe_msg *, char *, size_t);
ssize_t (*downcall)(struct file *, const char *, size_t);
void (*release_pipe)(struct inode *);
int (*open_pipe)(struct inode *);
void (*destroy_msg)(struct rpc_pipe_msg *);
};
struct rpc_pipe {
struct list_head pipe;
struct list_head in_upcall;
struct list_head in_downcall;
int pipelen;
int nreaders;
int nwriters;
int flags;
struct delayed_work queue_timeout;
const struct rpc_pipe_ops *ops;
spinlock_t lock;
struct dentry *dentry;
};
enum {
RTAX_UNSPEC = 0,
RTAX_LOCK = 1,
RTAX_MTU = 2,
RTAX_WINDOW = 3,
RTAX_RTT = 4,
RTAX_RTTVAR = 5,
RTAX_SSTHRESH = 6,
RTAX_CWND = 7,
RTAX_ADVMSS = 8,
RTAX_REORDERING = 9,
RTAX_HOPLIMIT = 10,
RTAX_INITCWND = 11,
RTAX_FEATURES = 12,
RTAX_RTO_MIN = 13,
RTAX_INITRWND = 14,
RTAX_QUICKACK = 15,
RTAX_CC_ALGO = 16,
RTAX_FASTOPEN_NO_COOKIE = 17,
__RTAX_MAX = 18,
};
enum {
NEIGH_VAR_MCAST_PROBES = 0,
NEIGH_VAR_UCAST_PROBES = 1,
NEIGH_VAR_APP_PROBES = 2,
NEIGH_VAR_MCAST_REPROBES = 3,
NEIGH_VAR_RETRANS_TIME = 4,
NEIGH_VAR_BASE_REACHABLE_TIME = 5,
NEIGH_VAR_DELAY_PROBE_TIME = 6,
NEIGH_VAR_INTERVAL_PROBE_TIME_MS = 7,
NEIGH_VAR_GC_STALETIME = 8,
NEIGH_VAR_QUEUE_LEN_BYTES = 9,
NEIGH_VAR_PROXY_QLEN = 10,
NEIGH_VAR_ANYCAST_DELAY = 11,
NEIGH_VAR_PROXY_DELAY = 12,
NEIGH_VAR_LOCKTIME = 13,
NEIGH_VAR_QUEUE_LEN = 14,
NEIGH_VAR_RETRANS_TIME_MS = 15,
NEIGH_VAR_BASE_REACHABLE_TIME_MS = 16,
NEIGH_VAR_GC_INTERVAL = 17,
NEIGH_VAR_GC_THRESH1 = 18,
NEIGH_VAR_GC_THRESH2 = 19,
NEIGH_VAR_GC_THRESH3 = 20,
NEIGH_VAR_MAX = 21,
};
struct pneigh_entry;
struct neigh_statistics;
struct neigh_hash_table;
struct neigh_table {
int family;
unsigned int entry_size;
unsigned int key_len;
__be16 protocol;
__u32 (*hash)(const void *, const struct net_device *, __u32 *);
bool (*key_eq)(const struct neighbour *, const void *);
int (*constructor)(struct neighbour *);
int (*pconstructor)(struct pneigh_entry *);
void (*pdestructor)(struct pneigh_entry *);
void (*proxy_redo)(struct sk_buff *);
int (*is_multicast)(const void *);
bool (*allow_add)(const struct net_device *, struct netlink_ext_ack *);
char *id;
struct neigh_parms parms;
struct list_head parms_list;
int gc_interval;
int gc_thresh1;
int gc_thresh2;
int gc_thresh3;
long unsigned int last_flush;
struct delayed_work gc_work;
struct delayed_work managed_work;
struct timer_list proxy_timer;
struct sk_buff_head proxy_queue;
atomic_t entries;
atomic_t gc_entries;
struct list_head gc_list;
struct list_head managed_list;
rwlock_t lock;
long unsigned int last_rand;
struct neigh_statistics *stats;
struct neigh_hash_table *nht;
struct pneigh_entry **phash_buckets;
};
struct neigh_statistics {
long unsigned int allocs;
long unsigned int destroys;
long unsigned int hash_grows;
long unsigned int res_failed;
long unsigned int lookups;
long unsigned int hits;
long unsigned int rcv_probes_mcast;
long unsigned int rcv_probes_ucast;
long unsigned int periodic_gc_runs;
long unsigned int forced_gc_runs;
long unsigned int unres_discards;
long unsigned int table_fulls;
};
struct neigh_ops {
int family;
void (*solicit)(struct neighbour *, struct sk_buff *);
void (*error_report)(struct neighbour *, struct sk_buff *);
int (*output)(struct neighbour *, struct sk_buff *);
int (*connected_output)(struct neighbour *, struct sk_buff *);
};
struct pneigh_entry {
struct pneigh_entry *next;
possible_net_t net;
struct net_device *dev;
netdevice_tracker dev_tracker;
u32 flags;
u8 protocol;
u8 key[0];
};
struct neigh_hash_table {
struct neighbour **hash_buckets;
unsigned int hash_shift;
__u32 hash_rnd[4];
struct callback_head rcu;
};
enum {
TCP_ESTABLISHED = 1,
TCP_SYN_SENT = 2,
TCP_SYN_RECV = 3,
TCP_FIN_WAIT1 = 4,
TCP_FIN_WAIT2 = 5,
TCP_TIME_WAIT = 6,
TCP_CLOSE = 7,
TCP_CLOSE_WAIT = 8,
TCP_LAST_ACK = 9,
TCP_LISTEN = 10,
TCP_CLOSING = 11,
TCP_NEW_SYN_RECV = 12,
TCP_MAX_STATES = 13,
};
struct fib_rule_hdr {
__u8 family;
__u8 dst_len;
__u8 src_len;
__u8 tos;
__u8 table;
__u8 res1;
__u8 res2;
__u8 action;
__u32 flags;
};
struct fib_rule_port_range {
__u16 start;
__u16 end;
};
struct fib_kuid_range {
kuid_t start;
kuid_t end;
};
struct fib_rule {
struct list_head list;
int iifindex;
int oifindex;
u32 mark;
u32 mark_mask;
u32 flags;
u32 table;
u8 action;
u8 l3mdev;
u8 proto;
u8 ip_proto;
u32 target;
__be64 tun_id;
struct fib_rule *ctarget;
struct net *fr_net;
refcount_t refcnt;
u32 pref;
int suppress_ifgroup;
int suppress_prefixlen;
char iifname[16];
char oifname[16];
struct fib_kuid_range uid_range;
struct fib_rule_port_range sport_range;
struct fib_rule_port_range dport_range;
struct callback_head rcu;
};
struct fib_lookup_arg {
void *lookup_ptr;
const void *lookup_data;
void *result;
struct fib_rule *rule;
u32 table;
int flags;
};
struct smc_hashinfo;
struct sk_psock;
struct request_sock_ops;
struct timewait_sock_ops;
struct udp_table;
struct raw_hashinfo;
struct proto {
void (*close)(struct sock *, long int);
int (*pre_connect)(struct sock *, struct sockaddr *, int);
int (*connect)(struct sock *, struct sockaddr *, int);
int (*disconnect)(struct sock *, int);
struct sock * (*accept)(struct sock *, int, int *, bool);
int (*ioctl)(struct sock *, int, long unsigned int);
int (*init)(struct sock *);
void (*destroy)(struct sock *);
void (*shutdown)(struct sock *, int);
int (*setsockopt)(struct sock *, int, int, sockptr_t, unsigned int);
int (*getsockopt)(struct sock *, int, int, char *, int *);
void (*keepalive)(struct sock *, int);
int (*sendmsg)(struct sock *, struct msghdr *, size_t);
int (*recvmsg)(struct sock *, struct msghdr *, size_t, int, int *);
int (*sendpage)(struct sock *, struct page *, int, size_t, int);
int (*bind)(struct sock *, struct sockaddr *, int);
int (*bind_add)(struct sock *, struct sockaddr *, int);
int (*backlog_rcv)(struct sock *, struct sk_buff *);
bool (*bpf_bypass_getsockopt)(int, int);
void (*release_cb)(struct sock *);
int (*hash)(struct sock *);
void (*unhash)(struct sock *);
void (*rehash)(struct sock *);
int (*get_port)(struct sock *, short unsigned int);
void (*put_port)(struct sock *);
int (*psock_update_sk_prot)(struct sock *, struct sk_psock *, bool);
unsigned int inuse_idx;
bool (*stream_memory_free)(const struct sock *, int);
bool (*sock_is_readable)(struct sock *);
void (*enter_memory_pressure)(struct sock *);
void (*leave_memory_pressure)(struct sock *);
atomic_long_t *memory_allocated;
int *per_cpu_fw_alloc;
struct percpu_counter *sockets_allocated;
long unsigned int *memory_pressure;
long int *sysctl_mem;
int *sysctl_wmem;
int *sysctl_rmem;
u32 sysctl_wmem_offset;
u32 sysctl_rmem_offset;
int max_header;
bool no_autobind;
struct kmem_cache *slab;
unsigned int obj_size;
slab_flags_t slab_flags;
unsigned int useroffset;
unsigned int usersize;
unsigned int *orphan_count;
struct request_sock_ops *rsk_prot;
struct timewait_sock_ops *twsk_prot;
union {
struct inet_hashinfo *hashinfo;
struct udp_table *udp_table;
struct raw_hashinfo *raw_hash;
struct smc_hashinfo *smc_hash;
} h;
struct module *owner;
char name[32];
struct list_head node;
int (*diag_destroy)(struct sock *, int);
};
struct request_sock;
struct request_sock_ops {
int family;
unsigned int obj_size;
struct kmem_cache *slab;
char *slab_name;
int (*rtx_syn_ack)(const struct sock *, struct request_sock *);
void (*send_ack)(const struct sock *, struct sk_buff *, struct request_sock *);
void (*send_reset)(const struct sock *, struct sk_buff *);
void (*destructor)(struct request_sock *);
void (*syn_ack_timeout)(const struct request_sock *);
};
struct timewait_sock_ops {
struct kmem_cache *twsk_slab;
char *twsk_slab_name;
unsigned int twsk_obj_size;
int (*twsk_unique)(struct sock *, struct sock *, void *);
void (*twsk_destructor)(struct sock *);
};
struct saved_syn;
struct request_sock {
struct sock_common __req_common;
struct request_sock *dl_next;
u16 mss;
u8 num_retrans;
u8 syncookie: 1;
u8 num_timeout: 7;
u32 ts_recent;
struct timer_list rsk_timer;
const struct request_sock_ops *rsk_ops;
struct sock *sk;
struct saved_syn *saved_syn;
u32 secid;
u32 peer_secid;
u32 timeout;
};
struct saved_syn {
u32 mac_hdrlen;
u32 network_hdrlen;
u32 tcp_hdrlen;
u8 data[0];
};
enum tsq_enum {
TSQ_THROTTLED = 0,
TSQ_QUEUED = 1,
TCP_TSQ_DEFERRED = 2,
TCP_WRITE_TIMER_DEFERRED = 3,
TCP_DELACK_TIMER_DEFERRED = 4,
TCP_MTU_REDUCED_DEFERRED = 5,
};
struct ip6_sf_list {
struct ip6_sf_list *sf_next;
struct in6_addr sf_addr;
long unsigned int sf_count[2];
unsigned char sf_gsresp;
unsigned char sf_oldin;
unsigned char sf_crcount;
struct callback_head rcu;
};
struct ifmcaddr6 {
struct in6_addr mca_addr;
struct inet6_dev *idev;
struct ifmcaddr6 *next;
struct ip6_sf_list *mca_sources;
struct ip6_sf_list *mca_tomb;
unsigned int mca_sfmode;
unsigned char mca_crcount;
long unsigned int mca_sfcount[2];
struct delayed_work mca_work;
unsigned int mca_flags;
int mca_users;
refcount_t mca_refcnt;
long unsigned int mca_cstamp;
long unsigned int mca_tstamp;
struct callback_head rcu;
};
struct ifacaddr6 {
struct in6_addr aca_addr;
struct fib6_info *aca_rt;
struct ifacaddr6 *aca_next;
struct hlist_node aca_addr_lst;
int aca_users;
refcount_t aca_refcnt;
long unsigned int aca_cstamp;
long unsigned int aca_tstamp;
struct callback_head rcu;
};
enum nfs_opnum4 {
OP_ACCESS = 3,
OP_CLOSE = 4,
OP_COMMIT = 5,
OP_CREATE = 6,
OP_DELEGPURGE = 7,
OP_DELEGRETURN = 8,
OP_GETATTR = 9,
OP_GETFH = 10,
OP_LINK = 11,
OP_LOCK = 12,
OP_LOCKT = 13,
OP_LOCKU = 14,
OP_LOOKUP = 15,
OP_LOOKUPP = 16,
OP_NVERIFY = 17,
OP_OPEN = 18,
OP_OPENATTR = 19,
OP_OPEN_CONFIRM = 20,
OP_OPEN_DOWNGRADE = 21,
OP_PUTFH = 22,
OP_PUTPUBFH = 23,
OP_PUTROOTFH = 24,
OP_READ = 25,
OP_READDIR = 26,
OP_READLINK = 27,
OP_REMOVE = 28,
OP_RENAME = 29,
OP_RENEW = 30,
OP_RESTOREFH = 31,
OP_SAVEFH = 32,
OP_SECINFO = 33,
OP_SETATTR = 34,
OP_SETCLIENTID = 35,
OP_SETCLIENTID_CONFIRM = 36,
OP_VERIFY = 37,
OP_WRITE = 38,
OP_RELEASE_LOCKOWNER = 39,
OP_BACKCHANNEL_CTL = 40,
OP_BIND_CONN_TO_SESSION = 41,
OP_EXCHANGE_ID = 42,
OP_CREATE_SESSION = 43,
OP_DESTROY_SESSION = 44,
OP_FREE_STATEID = 45,
OP_GET_DIR_DELEGATION = 46,
OP_GETDEVICEINFO = 47,
OP_GETDEVICELIST = 48,
OP_LAYOUTCOMMIT = 49,
OP_LAYOUTGET = 50,
OP_LAYOUTRETURN = 51,
OP_SECINFO_NO_NAME = 52,
OP_SEQUENCE = 53,
OP_SET_SSV = 54,
OP_TEST_STATEID = 55,
OP_WANT_DELEGATION = 56,
OP_DESTROY_CLIENTID = 57,
OP_RECLAIM_COMPLETE = 58,
OP_ALLOCATE = 59,
OP_COPY = 60,
OP_COPY_NOTIFY = 61,
OP_DEALLOCATE = 62,
OP_IO_ADVISE = 63,
OP_LAYOUTERROR = 64,
OP_LAYOUTSTATS = 65,
OP_OFFLOAD_CANCEL = 66,
OP_OFFLOAD_STATUS = 67,
OP_READ_PLUS = 68,
OP_SEEK = 69,
OP_WRITE_SAME = 70,
OP_CLONE = 71,
OP_GETXATTR = 72,
OP_SETXATTR = 73,
OP_LISTXATTRS = 74,
OP_REMOVEXATTR = 75,
OP_ILLEGAL = 10044,
};
struct bl_dev_msg {
int32_t status;
uint32_t major;
uint32_t minor;
};
struct cache_detail;
struct nfs_netns_client;
struct nfs_net {
struct cache_detail *nfs_dns_resolve;
struct rpc_pipe *bl_device_pipe;
struct bl_dev_msg bl_mount_reply;
wait_queue_head_t bl_wq;
struct mutex bl_mutex;
struct list_head nfs_client_list;
struct list_head nfs_volume_list;
struct nfs_netns_client *nfs_client;
spinlock_t nfs_client_lock;
ktime_t boot_time;
struct proc_dir_entry *proc_nfsfs;
long: 32;
};
struct nfs_netns_client {
struct kobject kobject;
struct net *net;
const char *identifier;
};
struct __kernel_sockaddr_storage {
union {
struct {
__kernel_sa_family_t ss_family;
char __data[126];
};
void *__align;
};
};
struct xdr_netobj {
unsigned int len;
u8 *data;
};
struct xdr_buf {
struct kvec head[1];
struct kvec tail[1];
struct bio_vec *bvec;
struct page **pages;
unsigned int page_base;
unsigned int page_len;
unsigned int flags;
unsigned int buflen;
unsigned int len;
};
struct rpc_rqst;
struct xdr_stream {
__be32 *p;
struct xdr_buf *buf;
__be32 *end;
struct kvec *iov;
struct kvec scratch;
struct page **page_ptr;
unsigned int nwords;
struct rpc_rqst *rqst;
};
struct cache_head {
struct hlist_node cache_list;
time64_t expiry_time;
time64_t last_refresh;
struct kref ref;
long unsigned int flags;
};
struct cache_detail {
struct module *owner;
int hash_size;
struct hlist_head *hash_table;
spinlock_t hash_lock;
char *name;
void (*cache_put)(struct kref *);
int (*cache_upcall)(struct cache_detail *, struct cache_head *);
void (*cache_request)(struct cache_detail *, struct cache_head *, char **, int *);
int (*cache_parse)(struct cache_detail *, char *, int);
int (*cache_show)(struct seq_file *, struct cache_detail *, struct cache_head *);
void (*warn_no_listener)(struct cache_detail *, int);
struct cache_head * (*alloc)();
void (*flush)();
int (*match)(struct cache_head *, struct cache_head *);
void (*init)(struct cache_head *, struct cache_head *);
void (*update)(struct cache_head *, struct cache_head *);
time64_t flush_time;
struct list_head others;
time64_t nextcheck;
int entries;
struct list_head queue;
atomic_t writers;
time64_t last_close;
time64_t last_warn;
union {
struct proc_dir_entry *procfs;
struct dentry *pipefs;
};
struct net *net;
};
struct cache_deferred_req;
struct cache_req {
struct cache_deferred_req * (*defer)(struct cache_req *);
long unsigned int thread_wait;
};
struct cache_deferred_req {
struct hlist_node hash;
struct list_head recent;
struct cache_head *item;
void *owner;
void (*revisit)(struct cache_deferred_req *, int);
};
struct gss_api_mech;
struct gss_ctx {
struct gss_api_mech *mech_type;
void *internal_ctx_id;
unsigned int slack;
unsigned int align;
};
struct rpcsec_gss_oid {
unsigned int len;
u8 data[32];
};
struct gss_api_ops;
struct pf_desc;
struct gss_api_mech {
struct list_head gm_list;
struct module *gm_owner;
struct rpcsec_gss_oid gm_oid;
char *gm_name;
const struct gss_api_ops *gm_ops;
int gm_pf_num;
struct pf_desc *gm_pfs;
const char *gm_upcall_enctypes;
};
struct auth_domain;
struct pf_desc {
u32 pseudoflavor;
u32 qop;
u32 service;
char *name;
char *auth_domain_name;
struct auth_domain *domain;
bool datatouch;
};
struct auth_ops;
struct auth_domain {
struct kref ref;
struct hlist_node hash;
char *name;
struct auth_ops *flavour;
struct callback_head callback_head;
};
struct gss_api_ops {
int (*gss_import_sec_context)(const void *, size_t, struct gss_ctx *, time64_t *, gfp_t);
u32 (*gss_get_mic)(struct gss_ctx *, struct xdr_buf *, struct xdr_netobj *);
u32 (*gss_verify_mic)(struct gss_ctx *, struct xdr_buf *, struct xdr_netobj *);
u32 (*gss_wrap)(struct gss_ctx *, int, struct xdr_buf *, struct page **);
u32 (*gss_unwrap)(struct gss_ctx *, int, int, struct xdr_buf *);
void (*gss_delete_sec_context)(void *);
};
struct svc_cred {
kuid_t cr_uid;
kgid_t cr_gid;
struct group_info *cr_group_info;
u32 cr_flavor;
char *cr_raw_principal;
char *cr_principal;
char *cr_targ_princ;
struct gss_api_mech *cr_gss_mech;
};
struct svc_rqst;
struct auth_ops {
char *name;
struct module *owner;
int flavour;
int (*accept)(struct svc_rqst *);
int (*release)(struct svc_rqst *);
void (*domain_release)(struct auth_domain *);
int (*set_client)(struct svc_rqst *);
};
struct pagevec {
unsigned char nr;
bool percpu_pvec_drained;
struct page *pages[15];
};
struct svc_xprt;
struct svc_serv;
struct svc_pool;
struct svc_procedure;
struct svc_deferred_req;
struct svc_cacherep;
struct svc_rqst {
struct list_head rq_all;
struct callback_head rq_rcu_head;
struct svc_xprt *rq_xprt;
struct __kernel_sockaddr_storage rq_addr;
size_t rq_addrlen;
struct __kernel_sockaddr_storage rq_daddr;
size_t rq_daddrlen;
struct svc_serv *rq_server;
struct svc_pool *rq_pool;
const struct svc_procedure *rq_procinfo;
struct auth_ops *rq_authop;
struct svc_cred rq_cred;
void *rq_xprt_ctxt;
struct svc_deferred_req *rq_deferred;
struct xdr_buf rq_arg;
struct xdr_stream rq_arg_stream;
struct xdr_stream rq_res_stream;
struct page *rq_scratch_page;
struct xdr_buf rq_res;
struct page *rq_pages[68];
struct page **rq_respages;
struct page **rq_next_page;
struct page **rq_page_end;
struct pagevec rq_pvec;
struct kvec rq_vec[67];
struct bio_vec rq_bvec[67];
__be32 rq_xid;
u32 rq_prog;
u32 rq_vers;
u32 rq_proc;
u32 rq_prot;
int rq_cachetype;
long unsigned int rq_flags;
long: 32;
ktime_t rq_qtime;
void *rq_argp;
void *rq_resp;
void *rq_auth_data;
__be32 rq_auth_stat;
int rq_auth_slack;
int rq_reserved;
ktime_t rq_stime;
struct cache_req rq_chandle;
struct auth_domain *rq_client;
struct auth_domain *rq_gssclient;
struct svc_cacherep *rq_cacherep;
struct task_struct *rq_task;
spinlock_t rq_lock;
struct net *rq_bc_net;
void **rq_lease_breaker;
long: 32;
};
struct svc_pool_stats {
atomic_long_t packets;
long unsigned int sockets_queued;
atomic_long_t threads_woken;
atomic_long_t threads_timedout;
};
struct svc_pool {
unsigned int sp_id;
spinlock_t sp_lock;
struct list_head sp_sockets;
unsigned int sp_nrthreads;
struct list_head sp_all_threads;
struct svc_pool_stats sp_stats;
long unsigned int sp_flags;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct svc_program;
struct svc_stat;
struct svc_serv {
struct svc_program *sv_program;
struct svc_stat *sv_stats;
spinlock_t sv_lock;
struct kref sv_refcnt;
unsigned int sv_nrthreads;
unsigned int sv_maxconn;
unsigned int sv_max_payload;
unsigned int sv_max_mesg;
unsigned int sv_xdrsize;
struct list_head sv_permsocks;
struct list_head sv_tempsocks;
int sv_tmpcnt;
struct timer_list sv_temptimer;
char *sv_name;
unsigned int sv_nrpools;
struct svc_pool *sv_pools;
int (*sv_threadfn)(void *);
};
struct svc_version;
struct svc_process_info;
struct svc_program {
struct svc_program *pg_next;
u32 pg_prog;
unsigned int pg_lovers;
unsigned int pg_hivers;
unsigned int pg_nvers;
const struct svc_version **pg_vers;
char *pg_name;
char *pg_class;
struct svc_stat *pg_stats;
int (*pg_authenticate)(struct svc_rqst *);
__be32 (*pg_init_request)(struct svc_rqst *, const struct svc_program *, struct svc_process_info *);
int (*pg_rpcbind_set)(struct net *, const struct svc_program *, u32, int, short unsigned int, short unsigned int);
};
struct svc_xprt_class;
struct svc_xprt_ops;
struct rpc_xprt;
struct rpc_xprt_switch;
struct svc_xprt {
struct svc_xprt_class *xpt_class;
const struct svc_xprt_ops *xpt_ops;
struct kref xpt_ref;
struct list_head xpt_list;
struct list_head xpt_ready;
long unsigned int xpt_flags;
struct svc_serv *xpt_server;
atomic_t xpt_reserved;
atomic_t xpt_nr_rqsts;
struct mutex xpt_mutex;
spinlock_t xpt_lock;
void *xpt_auth_cache;
struct list_head xpt_deferred;
struct __kernel_sockaddr_storage xpt_local;
size_t xpt_locallen;
struct __kernel_sockaddr_storage xpt_remote;
size_t xpt_remotelen;
char xpt_remotebuf[58];
struct list_head xpt_users;
struct net *xpt_net;
netns_tracker ns_tracker;
const struct cred *xpt_cred;
struct rpc_xprt *xpt_bc_xprt;
struct rpc_xprt_switch *xpt_bc_xps;
};
struct svc_procedure {
__be32 (*pc_func)(struct svc_rqst *);
bool (*pc_decode)(struct svc_rqst *, struct xdr_stream *);
bool (*pc_encode)(struct svc_rqst *, struct xdr_stream *);
void (*pc_release)(struct svc_rqst *);
unsigned int pc_argsize;
unsigned int pc_argzero;
unsigned int pc_ressize;
unsigned int pc_cachetype;
unsigned int pc_xdrressize;
const char *pc_name;
};
struct svc_deferred_req {
u32 prot;
struct svc_xprt *xprt;
struct __kernel_sockaddr_storage addr;
size_t addrlen;
struct __kernel_sockaddr_storage daddr;
size_t daddrlen;
void *xprt_ctxt;
struct cache_deferred_req handle;
int argslen;
__be32 args[0];
};
struct svc_process_info {
union {
int (*dispatch)(struct svc_rqst *, __be32 *);
struct {
unsigned int lovers;
unsigned int hivers;
} mismatch;
};
};
struct svc_version {
u32 vs_vers;
u32 vs_nproc;
const struct svc_procedure *vs_proc;
unsigned int *vs_count;
u32 vs_xdrsize;
bool vs_hidden;
bool vs_rpcb_optnl;
bool vs_need_cong_ctrl;
int (*vs_dispatch)(struct svc_rqst *, __be32 *);
};
struct svc_xprt_ops {
struct svc_xprt * (*xpo_create)(struct svc_serv *, struct net *, struct sockaddr *, int, int);
struct svc_xprt * (*xpo_accept)(struct svc_xprt *);
int (*xpo_has_wspace)(struct svc_xprt *);
int (*xpo_recvfrom)(struct svc_rqst *);
int (*xpo_sendto)(struct svc_rqst *);
int (*xpo_result_payload)(struct svc_rqst *, unsigned int, unsigned int);
void (*xpo_release_rqst)(struct svc_rqst *);
void (*xpo_detach)(struct svc_xprt *);
void (*xpo_free)(struct svc_xprt *);
void (*xpo_secure_port)(struct svc_rqst *);
void (*xpo_kill_temp_xprt)(struct svc_xprt *);
void (*xpo_start_tls)(struct svc_xprt *);
};
struct svc_xprt_class {
const char *xcl_name;
struct module *xcl_owner;
const struct svc_xprt_ops *xcl_ops;
struct list_head xcl_list;
u32 xcl_max_payload;
int xcl_ident;
};
struct nfsd4_fs_location {
char *hosts;
char *path;
};
struct nfsd4_fs_locations {
uint32_t locations_count;
struct nfsd4_fs_location *locations;
int migrated;
};
struct exp_flavor_info {
u32 pseudoflavor;
u32 flags;
};
struct export_stats {
time64_t start_time;
struct percpu_counter counter[3];
};
struct nfsd4_deviceid_map;
struct svc_export {
struct cache_head h;
struct auth_domain *ex_client;
int ex_flags;
struct path ex_path;
kuid_t ex_anon_uid;
kgid_t ex_anon_gid;
int ex_fsid;
unsigned char *ex_uuid;
struct nfsd4_fs_locations ex_fslocs;
uint32_t ex_nflavors;
struct exp_flavor_info ex_flavors[8];
u32 ex_layout_types;
struct nfsd4_deviceid_map *ex_devid_map;
struct cache_detail *cd;
struct callback_head ex_rcu;
long: 32;
struct export_stats ex_stats;
};
typedef u32 rpc_authflavor_t;
struct nlm_host;
struct nlm_lockowner {
struct list_head list;
refcount_t count;
struct nlm_host *host;
fl_owner_t owner;
uint32_t pid;
};
struct rpc_task;
struct rpc_cred;
struct rpc_rqst {
struct rpc_xprt *rq_xprt;
struct xdr_buf rq_snd_buf;
struct xdr_buf rq_rcv_buf;
struct rpc_task *rq_task;
struct rpc_cred *rq_cred;
__be32 rq_xid;
int rq_cong;
u32 rq_seqno;
int rq_enc_pages_num;
struct page **rq_enc_pages;
void (*rq_release_snd_buf)(struct rpc_rqst *);
union {
struct list_head rq_list;
struct rb_node rq_recv;
};
struct list_head rq_xmit;
struct list_head rq_xmit2;
void *rq_buffer;
size_t rq_callsize;
void *rq_rbuffer;
size_t rq_rcvsize;
size_t rq_xmit_bytes_sent;
size_t rq_reply_bytes_recvd;
struct xdr_buf rq_private_buf;
long unsigned int rq_majortimeo;
long unsigned int rq_minortimeo;
long unsigned int rq_timeout;
ktime_t rq_rtt;
unsigned int rq_retries;
unsigned int rq_connect_cookie;
atomic_t rq_pin;
u32 rq_bytes_sent;
ktime_t rq_xtime;
int rq_ntrans;
long: 32;
};
typedef void (*kxdreproc_t)(struct rpc_rqst *, struct xdr_stream *, const void *);
typedef int (*kxdrdproc_t)(struct rpc_rqst *, struct xdr_stream *, void *);
struct rpc_procinfo;
struct rpc_message {
const struct rpc_procinfo *rpc_proc;
void *rpc_argp;
void *rpc_resp;
const struct cred *rpc_cred;
};
struct rpc_procinfo {
u32 p_proc;
kxdreproc_t p_encode;
kxdrdproc_t p_decode;
unsigned int p_arglen;
unsigned int p_replen;
unsigned int p_timer;
u32 p_statidx;
const char *p_name;
};
struct rpc_wait {
struct list_head list;
struct list_head links;
struct list_head timer_list;
};
struct rpc_wait_queue;
struct rpc_call_ops;
struct rpc_clnt;
struct rpc_task {
atomic_t tk_count;
int tk_status;
struct list_head tk_task;
void (*tk_callback)(struct rpc_task *);
void (*tk_action)(struct rpc_task *);
long unsigned int tk_timeout;
long unsigned int tk_runstate;
struct rpc_wait_queue *tk_waitqueue;
union {
struct work_struct tk_work;
struct rpc_wait tk_wait;
} u;
struct rpc_message tk_msg;
void *tk_calldata;
const struct rpc_call_ops *tk_ops;
struct rpc_clnt *tk_client;
struct rpc_xprt *tk_xprt;
struct rpc_cred *tk_op_cred;
struct rpc_rqst *tk_rqstp;
struct workqueue_struct *tk_workqueue;
ktime_t tk_start;
pid_t tk_owner;
int tk_rpc_status;
short unsigned int tk_flags;
short unsigned int tk_timeouts;
short unsigned int tk_pid;
unsigned char tk_priority: 2;
unsigned char tk_garb_retry: 2;
unsigned char tk_cred_retry: 2;
unsigned char tk_rebind_retry: 2;
};
struct rpc_timer {
struct list_head list;
long unsigned int expires;
struct delayed_work dwork;
};
struct rpc_wait_queue {
spinlock_t lock;
struct list_head tasks[4];
unsigned char maxpriority;
unsigned char priority;
unsigned char nr;
short unsigned int qlen;
struct rpc_timer timer_list;
const char *name;
};
struct rpc_call_ops {
void (*rpc_call_prepare)(struct rpc_task *, void *);
void (*rpc_call_done)(struct rpc_task *, void *);
void (*rpc_count_stats)(struct rpc_task *, void *);
void (*rpc_release)(void *);
};
struct rpc_pipe_dir_head {
struct list_head pdh_entries;
struct dentry *pdh_dentry;
};
struct rpc_rtt {
long unsigned int timeo;
long unsigned int srtt[5];
long unsigned int sdrtt[5];
int ntimeouts[5];
};
struct rpc_timeout {
long unsigned int to_initval;
long unsigned int to_maxval;
long unsigned int to_increment;
unsigned int to_retries;
unsigned char to_exponential;
};
struct rpc_xprt_iter_ops;
struct rpc_xprt_iter {
struct rpc_xprt_switch *xpi_xpswitch;
struct rpc_xprt *xpi_cursor;
const struct rpc_xprt_iter_ops *xpi_ops;
};
struct rpc_auth;
struct rpc_stat;
struct rpc_iostats;
struct rpc_program;
struct rpc_sysfs_client;
struct rpc_clnt {
refcount_t cl_count;
unsigned int cl_clid;
struct list_head cl_clients;
struct list_head cl_tasks;
atomic_t cl_pid;
spinlock_t cl_lock;
struct rpc_xprt *cl_xprt;
const struct rpc_procinfo *cl_procinfo;
u32 cl_prog;
u32 cl_vers;
u32 cl_maxproc;
struct rpc_auth *cl_auth;
struct rpc_stat *cl_stats;
struct rpc_iostats *cl_metrics;
unsigned int cl_softrtry: 1;
unsigned int cl_softerr: 1;
unsigned int cl_discrtry: 1;
unsigned int cl_noretranstimeo: 1;
unsigned int cl_autobind: 1;
unsigned int cl_chatty: 1;
struct rpc_rtt *cl_rtt;
const struct rpc_timeout *cl_timeout;
atomic_t cl_swapper;
int cl_nodelen;
char cl_nodename[65];
struct rpc_pipe_dir_head cl_pipedir_objects;
struct rpc_clnt *cl_parent;
struct rpc_rtt cl_rtt_default;
struct rpc_timeout cl_timeout_default;
const struct rpc_program *cl_program;
const char *cl_principal;
struct rpc_sysfs_client *cl_sysfs;
union {
struct rpc_xprt_iter cl_xpi;
struct work_struct cl_work;
};
const struct cred *cl_cred;
unsigned int cl_max_connect;
};
struct rpc_xprt_ops;
struct xprt_class;
struct rpc_sysfs_xprt;
struct rpc_xprt {
struct kref kref;
const struct rpc_xprt_ops *ops;
unsigned int id;
const struct rpc_timeout *timeout;
struct __kernel_sockaddr_storage addr;
size_t addrlen;
int prot;
long unsigned int cong;
long unsigned int cwnd;
size_t max_payload;
struct rpc_wait_queue binding;
struct rpc_wait_queue sending;
struct rpc_wait_queue pending;
struct rpc_wait_queue backlog;
struct list_head free;
unsigned int max_reqs;
unsigned int min_reqs;
unsigned int num_reqs;
long unsigned int state;
unsigned char resvport: 1;
unsigned char reuseport: 1;
atomic_t swapper;
unsigned int bind_index;
struct list_head xprt_switch;
long unsigned int bind_timeout;
long unsigned int reestablish_timeout;
unsigned int connect_cookie;
struct work_struct task_cleanup;
struct timer_list timer;
long unsigned int last_used;
long unsigned int idle_timeout;
long unsigned int connect_timeout;
long unsigned int max_reconnect_timeout;
atomic_long_t queuelen;
spinlock_t transport_lock;
spinlock_t reserve_lock;
spinlock_t queue_lock;
u32 xid;
struct rpc_task *snd_task;
struct list_head xmit_queue;
atomic_long_t xmit_queuelen;
struct svc_xprt *bc_xprt;
struct rb_root recv_queue;
long: 32;
struct {
long unsigned int bind_count;
long unsigned int connect_count;
long unsigned int connect_start;
long unsigned int connect_time;
long unsigned int sends;
long unsigned int recvs;
long unsigned int bad_xids;
long unsigned int max_slots;
long long unsigned int req_u;
long long unsigned int bklog_u;
long long unsigned int sending_u;
long long unsigned int pending_u;
} stat;
struct net *xprt_net;
netns_tracker ns_tracker;
const char *servername;
const char *address_strings[6];
struct callback_head rcu;
const struct xprt_class *xprt_class;
struct rpc_sysfs_xprt *xprt_sysfs;
bool main;
long: 32;
};
struct rpc_credops;
struct rpc_cred {
struct hlist_node cr_hash;
struct list_head cr_lru;
struct callback_head cr_rcu;
struct rpc_auth *cr_auth;
const struct rpc_credops *cr_ops;
long unsigned int cr_expire;
long unsigned int cr_flags;
refcount_t cr_count;
const struct cred *cr_cred;
};
struct rpc_xprt_ops {
void (*set_buffer_size)(struct rpc_xprt *, size_t, size_t);
int (*reserve_xprt)(struct rpc_xprt *, struct rpc_task *);
void (*release_xprt)(struct rpc_xprt *, struct rpc_task *);
void (*alloc_slot)(struct rpc_xprt *, struct rpc_task *);
void (*free_slot)(struct rpc_xprt *, struct rpc_rqst *);
void (*rpcbind)(struct rpc_task *);
void (*set_port)(struct rpc_xprt *, short unsigned int);
void (*connect)(struct rpc_xprt *, struct rpc_task *);
int (*get_srcaddr)(struct rpc_xprt *, char *, size_t);
short unsigned int (*get_srcport)(struct rpc_xprt *);
int (*buf_alloc)(struct rpc_task *);
void (*buf_free)(struct rpc_task *);
int (*prepare_request)(struct rpc_rqst *, struct xdr_buf *);
int (*send_request)(struct rpc_rqst *);
void (*wait_for_reply_request)(struct rpc_task *);
void (*timer)(struct rpc_xprt *, struct rpc_task *);
void (*release_request)(struct rpc_task *);
void (*close)(struct rpc_xprt *);
void (*destroy)(struct rpc_xprt *);
void (*set_connect_timeout)(struct rpc_xprt *, long unsigned int, long unsigned int);
void (*print_stats)(struct rpc_xprt *, struct seq_file *);
int (*enable_swap)(struct rpc_xprt *);
void (*disable_swap)(struct rpc_xprt *);
void (*inject_disconnect)(struct rpc_xprt *);
int (*bc_setup)(struct rpc_xprt *, unsigned int);
size_t (*bc_maxpayload)(struct rpc_xprt *);
unsigned int (*bc_num_slots)(struct rpc_xprt *);
void (*bc_free_rqst)(struct rpc_rqst *);
void (*bc_destroy)(struct rpc_xprt *, unsigned int);
};
struct xprt_create;
struct xprt_class {
struct list_head list;
int ident;
struct rpc_xprt * (*setup)(struct xprt_create *);
struct module *owner;
char name[32];
const char *netid[0];
};
struct xprt_create {
int ident;
struct net *net;
struct sockaddr *srcaddr;
struct sockaddr *dstaddr;
size_t addrlen;
const char *servername;
struct svc_xprt *bc_xprt;
struct rpc_xprt_switch *bc_xps;
unsigned int flags;
};
struct rpc_sysfs_xprt_switch;
struct rpc_xprt_switch {
spinlock_t xps_lock;
struct kref xps_kref;
unsigned int xps_id;
unsigned int xps_nxprts;
unsigned int xps_nactive;
unsigned int xps_nunique_destaddr_xprts;
atomic_long_t xps_queuelen;
struct list_head xps_xprt_list;
struct net *xps_net;
const struct rpc_xprt_iter_ops *xps_iter_ops;
struct rpc_sysfs_xprt_switch *xps_sysfs;
struct callback_head xps_rcu;
};
struct auth_cred {
const struct cred *cred;
const char *principal;
};
struct rpc_authops;
struct rpc_cred_cache;
struct rpc_auth {
unsigned int au_cslack;
unsigned int au_rslack;
unsigned int au_verfsize;
unsigned int au_ralign;
long unsigned int au_flags;
const struct rpc_authops *au_ops;
rpc_authflavor_t au_flavor;
refcount_t au_count;
struct rpc_cred_cache *au_credcache;
};
struct rpc_credops {
const char *cr_name;
int (*cr_init)(struct rpc_auth *, struct rpc_cred *);
void (*crdestroy)(struct rpc_cred *);
int (*crmatch)(struct auth_cred *, struct rpc_cred *, int);
int (*crmarshal)(struct rpc_task *, struct xdr_stream *);
int (*crrefresh)(struct rpc_task *);
int (*crvalidate)(struct rpc_task *, struct xdr_stream *);
int (*crwrap_req)(struct rpc_task *, struct xdr_stream *);
int (*crunwrap_resp)(struct rpc_task *, struct xdr_stream *);
int (*crkey_timeout)(struct rpc_cred *);
char * (*crstringify_acceptor)(struct rpc_cred *);
bool (*crneed_reencode)(struct rpc_task *);
};
struct rpc_auth_create_args;
struct rpcsec_gss_info;
struct rpc_authops {
struct module *owner;
rpc_authflavor_t au_flavor;
char *au_name;
struct rpc_auth * (*create)(const struct rpc_auth_create_args *, struct rpc_clnt *);
void (*destroy)(struct rpc_auth *);
int (*hash_cred)(struct auth_cred *, unsigned int);
struct rpc_cred * (*lookup_cred)(struct rpc_auth *, struct auth_cred *, int);
struct rpc_cred * (*crcreate)(struct rpc_auth *, struct auth_cred *, int, gfp_t);
rpc_authflavor_t (*info2flavor)(struct rpcsec_gss_info *);
int (*flavor2info)(rpc_authflavor_t, struct rpcsec_gss_info *);
int (*key_timeout)(struct rpc_auth *, struct rpc_cred *);
};
struct rpc_auth_create_args {
rpc_authflavor_t pseudoflavor;
const char *target_name;
};
struct rpcsec_gss_info {
struct rpcsec_gss_oid oid;
u32 qop;
u32 service;
};
struct rpc_stat {
const struct rpc_program *program;
unsigned int netcnt;
unsigned int netudpcnt;
unsigned int nettcpcnt;
unsigned int nettcpconn;
unsigned int netreconn;
unsigned int rpccnt;
unsigned int rpcretrans;
unsigned int rpcauthrefresh;
unsigned int rpcgarbage;
};
struct rpc_version;
struct rpc_program {
const char *name;
u32 number;
unsigned int nrvers;
const struct rpc_version **version;
struct rpc_stat *stats;
const char *pipe_dir_name;
};
struct svc_stat {
struct svc_program *program;
unsigned int netcnt;
unsigned int netudpcnt;
unsigned int nettcpcnt;
unsigned int nettcpconn;
unsigned int rpccnt;
unsigned int rpcbadfmt;
unsigned int rpcbadauth;
unsigned int rpcbadclnt;
};
struct rpc_xprt_iter_ops {
void (*xpi_rewind)(struct rpc_xprt_iter *);
struct rpc_xprt * (*xpi_xprt)(struct rpc_xprt_iter *);
struct rpc_xprt * (*xpi_next)(struct rpc_xprt_iter *);
};
struct rpc_version {
u32 number;
unsigned int nrprocs;
const struct rpc_procinfo *procs;
unsigned int *counts;
};
enum {
NLM_LCK_GRANTED = 0,
NLM_LCK_DENIED = 1,
NLM_LCK_DENIED_NOLOCKS = 2,
NLM_LCK_BLOCKED = 3,
NLM_LCK_DENIED_GRACE_PERIOD = 4,
NLM_DEADLCK = 5,
NLM_ROFS = 6,
NLM_STALE_FH = 7,
NLM_FBIG = 8,
NLM_FAILED = 9,
};
struct nfs_fh {
short unsigned int size;
unsigned char data[128];
};
struct nsm_private {
unsigned char data[16];
};
struct nlm_lock {
char *caller;
unsigned int len;
struct nfs_fh fh;
struct xdr_netobj oh;
u32 svid;
u64 lock_start;
u64 lock_len;
struct file_lock fl;
};
struct nlm_cookie {
unsigned char data[32];
unsigned int len;
};
struct nlm_args {
struct nlm_cookie cookie;
long: 32;
struct nlm_lock lock;
u32 block;
u32 reclaim;
u32 state;
u32 monitor;
u32 fsm_access;
u32 fsm_mode;
};
struct nlm_res {
struct nlm_cookie cookie;
__be32 status;
struct nlm_lock lock;
};
struct nlmclnt_operations {
void (*nlmclnt_alloc_call)(void *);
bool (*nlmclnt_unlock_prepare)(struct rpc_task *, void *);
void (*nlmclnt_release_call)(void *);
};
struct nsm_handle;
struct nlm_host {
struct hlist_node h_hash;
struct __kernel_sockaddr_storage h_addr;
size_t h_addrlen;
struct __kernel_sockaddr_storage h_srcaddr;
size_t h_srcaddrlen;
struct rpc_clnt *h_rpcclnt;
char *h_name;
u32 h_version;
short unsigned int h_proto;
short unsigned int h_reclaiming: 1;
short unsigned int h_server: 1;
short unsigned int h_noresvport: 1;
short unsigned int h_inuse: 1;
wait_queue_head_t h_gracewait;
struct rw_semaphore h_rwsem;
u32 h_state;
u32 h_nsmstate;
u32 h_pidcount;
refcount_t h_count;
struct mutex h_mutex;
long unsigned int h_nextrebind;
long unsigned int h_expires;
struct list_head h_lockowners;
spinlock_t h_lock;
struct list_head h_granted;
struct list_head h_reclaim;
struct nsm_handle *h_nsmhandle;
char *h_addrbuf;
struct net *net;
const struct cred *h_cred;
char nodename[65];
const struct nlmclnt_operations *h_nlmclnt_ops;
};
struct nsm_handle {
struct list_head sm_link;
refcount_t sm_count;
char *sm_mon_name;
char *sm_name;
struct __kernel_sockaddr_storage sm_addr;
size_t sm_addrlen;
unsigned int sm_monitored: 1;
unsigned int sm_sticky: 1;
struct nsm_private sm_priv;
char sm_addrbuf[51];
};
struct nlm_block;
struct nlm_rqst {
refcount_t a_count;
unsigned int a_flags;
struct nlm_host *a_host;
long: 32;
struct nlm_args a_args;
struct nlm_res a_res;
struct nlm_block *a_block;
unsigned int a_retries;
u8 a_owner[74];
void *a_callback_data;
};
struct nlm_file;
struct nlm_block {
struct kref b_count;
struct list_head b_list;
struct list_head b_flist;
struct nlm_rqst *b_call;
struct svc_serv *b_daemon;
struct nlm_host *b_host;
long unsigned int b_when;
unsigned int b_id;
unsigned char b_granted;
struct nlm_file *b_file;
struct cache_req *b_cache_req;
struct cache_deferred_req *b_deferred_req;
unsigned int b_flags;
};
struct nlm_share;
struct nlm_file {
struct hlist_node f_list;
struct nfs_fh f_handle;
struct file *f_file[2];
struct nlm_share *f_shares;
struct list_head f_blocks;
unsigned int f_locks;
unsigned int f_count;
struct mutex f_mutex;
};
typedef int (*nlm_host_match_fn_t)(void *, struct nlm_host *);
struct fid {
union {
struct {
u32 ino;
u32 gen;
u32 parent_ino;
u32 parent_gen;
} i32;
struct {
u32 block;
u16 partref;
u16 parent_partref;
u32 generation;
u32 parent_block;
u32 parent_generation;
} udf;
__u32 raw[0];
};
};
enum key_need_perm {
KEY_NEED_UNSPECIFIED = 0,
KEY_NEED_VIEW = 1,
KEY_NEED_READ = 2,
KEY_NEED_WRITE = 3,
KEY_NEED_SEARCH = 4,
KEY_NEED_LINK = 5,
KEY_NEED_SETATTR = 6,
KEY_NEED_UNLINK = 7,
KEY_SYSADMIN_OVERRIDE = 8,
KEY_AUTHTOKEN_OVERRIDE = 9,
KEY_DEFER_PERM_CHECK = 10,
};
struct __key_reference_with_attributes;
typedef struct __key_reference_with_attributes *key_ref_t;
enum key_state {
KEY_IS_UNINSTANTIATED = 0,
KEY_IS_POSITIVE = 1,
};
struct key_user {
struct rb_node node;
struct mutex cons_lock;
spinlock_t lock;
refcount_t usage;
atomic_t nkeys;
atomic_t nikeys;
kuid_t uid;
int qnkeys;
int qnbytes;
};
enum hash_algo {
HASH_ALGO_MD4 = 0,
HASH_ALGO_MD5 = 1,
HASH_ALGO_SHA1 = 2,
HASH_ALGO_RIPE_MD_160 = 3,
HASH_ALGO_SHA256 = 4,
HASH_ALGO_SHA384 = 5,
HASH_ALGO_SHA512 = 6,
HASH_ALGO_SHA224 = 7,
HASH_ALGO_RIPE_MD_128 = 8,
HASH_ALGO_RIPE_MD_256 = 9,
HASH_ALGO_RIPE_MD_320 = 10,
HASH_ALGO_WP_256 = 11,
HASH_ALGO_WP_384 = 12,
HASH_ALGO_WP_512 = 13,
HASH_ALGO_TGR_128 = 14,
HASH_ALGO_TGR_160 = 15,
HASH_ALGO_TGR_192 = 16,
HASH_ALGO_SM3_256 = 17,
HASH_ALGO_STREEBOG_256 = 18,
HASH_ALGO_STREEBOG_512 = 19,
HASH_ALGO__LAST = 20,
};
struct key_preparsed_payload {
const char *orig_description;
char *description;
union key_payload payload;
const void *data;
size_t datalen;
size_t quotalen;
long: 32;
time64_t expiry;
};
struct key_match_data {
bool (*cmp)(const struct key *, const struct key_match_data *);
const void *raw_data;
void *preparsed;
unsigned int lookup_type;
};
enum kernel_pkey_operation {
kernel_pkey_encrypt = 0,
kernel_pkey_decrypt = 1,
kernel_pkey_sign = 2,
kernel_pkey_verify = 3,
};
struct kernel_pkey_params {
struct key *key;
const char *encoding;
const char *hash_algo;
char *info;
__u32 in_len;
union {
__u32 out_len;
__u32 in2_len;
};
enum kernel_pkey_operation op: 8;
};
struct kernel_pkey_query {
__u32 supported_ops;
__u32 key_size;
__u16 max_data_size;
__u16 max_sig_size;
__u16 max_enc_size;
__u16 max_dec_size;
};
enum key_notification_subtype {
NOTIFY_KEY_INSTANTIATED = 0,
NOTIFY_KEY_UPDATED = 1,
NOTIFY_KEY_LINKED = 2,
NOTIFY_KEY_UNLINKED = 3,
NOTIFY_KEY_CLEARED = 4,
NOTIFY_KEY_REVOKED = 5,
NOTIFY_KEY_INVALIDATED = 6,
NOTIFY_KEY_SETATTR = 7,
};
struct lsm_blob_sizes {
int lbs_cred;
int lbs_file;
int lbs_inode;
int lbs_superblock;
int lbs_ipc;
int lbs_msg_msg;
int lbs_task;
};
enum lsm_order {
LSM_ORDER_FIRST = -1,
LSM_ORDER_MUTABLE = 0,
};
struct lsm_info {
const char *name;
enum lsm_order order;
long unsigned int flags;
int *enabled;
int (*init)();
struct lsm_blob_sizes *blobs;
};
enum integrity_status {
INTEGRITY_PASS = 0,
INTEGRITY_PASS_IMMUTABLE = 1,
INTEGRITY_FAIL = 2,
INTEGRITY_FAIL_IMMUTABLE = 3,
INTEGRITY_NOLABEL = 4,
INTEGRITY_NOXATTRS = 5,
INTEGRITY_UNKNOWN = 6,
};
struct ima_digest_data {
u8 algo;
u8 length;
union {
struct {
u8 unused;
u8 type;
} sha1;
struct {
u8 type;
u8 algo;
} ng;
u8 data[2];
} xattr;
u8 digest[0];
};
struct integrity_iint_cache {
struct rb_node rb_node;
struct mutex mutex;
struct inode *inode;
u64 version;
long unsigned int flags;
long unsigned int measured_pcrs;
long unsigned int atomic_flags;
enum integrity_status ima_file_status: 4;
enum integrity_status ima_mmap_status: 4;
enum integrity_status ima_bprm_status: 4;
enum integrity_status ima_read_status: 4;
enum integrity_status ima_creds_status: 4;
enum integrity_status evm_status: 4;
struct ima_digest_data *ima_hash;
long: 32;
};
struct crypto_async_request;
typedef void (*crypto_completion_t)(struct crypto_async_request *, int);
struct crypto_async_request {
struct list_head list;
crypto_completion_t complete;
void *data;
struct crypto_tfm *tfm;
u32 flags;
};
struct crypto_template;
struct crypto_spawn;
struct crypto_instance {
struct crypto_alg alg;
struct crypto_template *tmpl;
union {
struct hlist_node list;
struct crypto_spawn *spawns;
};
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__ctx[0];
};
struct crypto_spawn {
struct list_head list;
struct crypto_alg *alg;
union {
struct crypto_instance *inst;
struct crypto_spawn *next;
};
const struct crypto_type *frontend;
u32 mask;
bool dead;
bool registered;
};
struct rtattr;
struct crypto_template {
struct list_head list;
struct hlist_head instances;
struct module *module;
int (*create)(struct crypto_template *, struct rtattr **);
char name[128];
};
enum crypto_attr_type_t {
CRYPTOCFGA_UNSPEC = 0,
CRYPTOCFGA_PRIORITY_VAL = 1,
CRYPTOCFGA_REPORT_LARVAL = 2,
CRYPTOCFGA_REPORT_HASH = 3,
CRYPTOCFGA_REPORT_BLKCIPHER = 4,
CRYPTOCFGA_REPORT_AEAD = 5,
CRYPTOCFGA_REPORT_COMPRESS = 6,
CRYPTOCFGA_REPORT_RNG = 7,
CRYPTOCFGA_REPORT_CIPHER = 8,
CRYPTOCFGA_REPORT_AKCIPHER = 9,
CRYPTOCFGA_REPORT_KPP = 10,
CRYPTOCFGA_REPORT_ACOMP = 11,
CRYPTOCFGA_STAT_LARVAL = 12,
CRYPTOCFGA_STAT_HASH = 13,
CRYPTOCFGA_STAT_BLKCIPHER = 14,
CRYPTOCFGA_STAT_AEAD = 15,
CRYPTOCFGA_STAT_COMPRESS = 16,
CRYPTOCFGA_STAT_RNG = 17,
CRYPTOCFGA_STAT_CIPHER = 18,
CRYPTOCFGA_STAT_AKCIPHER = 19,
CRYPTOCFGA_STAT_KPP = 20,
CRYPTOCFGA_STAT_ACOMP = 21,
__CRYPTOCFGA_MAX = 22,
};
struct crypto_report_akcipher {
char type[64];
};
struct akcipher_request {
struct crypto_async_request base;
struct scatterlist *src;
struct scatterlist *dst;
unsigned int src_len;
unsigned int dst_len;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__ctx[0];
};
struct crypto_akcipher {
struct crypto_tfm base;
};
struct akcipher_alg {
int (*sign)(struct akcipher_request *);
int (*verify)(struct akcipher_request *);
int (*encrypt)(struct akcipher_request *);
int (*decrypt)(struct akcipher_request *);
int (*set_pub_key)(struct crypto_akcipher *, const void *, unsigned int);
int (*set_priv_key)(struct crypto_akcipher *, const void *, unsigned int);
unsigned int (*max_size)(struct crypto_akcipher *);
int (*init)(struct crypto_akcipher *);
void (*exit)(struct crypto_akcipher *);
unsigned int reqsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct akcipher_instance {
void (*free)(struct akcipher_instance *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
union {
struct {
char head[128];
struct crypto_instance base;
} s;
struct akcipher_alg alg;
};
};
struct crypto_akcipher_spawn {
struct crypto_spawn base;
};
typedef void (*exitcall_t)();
enum asymmetric_payload_bits {
asym_crypto = 0,
asym_subtype = 1,
asym_key_ids = 2,
asym_auth = 3,
};
struct asymmetric_key_id {
short unsigned int len;
unsigned char data[0];
};
struct asymmetric_key_ids {
void *id[3];
};
struct public_key_signature;
struct asymmetric_key_subtype {
struct module *owner;
const char *name;
short unsigned int name_len;
void (*describe)(const struct key *, struct seq_file *);
void (*destroy)(void *, void *);
int (*query)(const struct kernel_pkey_params *, struct kernel_pkey_query *);
int (*eds_op)(struct kernel_pkey_params *, const void *, void *);
int (*verify_signature)(const struct key *, const struct public_key_signature *);
};
struct public_key_signature {
struct asymmetric_key_id *auth_ids[3];
u8 *s;
u8 *digest;
u32 s_size;
u32 digest_size;
const char *pkey_algo;
const char *hash_algo;
const char *encoding;
const void *data;
unsigned int data_size;
};
struct asymmetric_key_parser {
struct list_head link;
struct module *owner;
const char *name;
int (*parse)(struct key_preparsed_payload *);
};
typedef void (*smp_call_func_t)(void *);
struct __call_single_data {
struct __call_single_node node;
smp_call_func_t func;
void *info;
};
struct io_cq {
struct request_queue *q;
struct io_context *ioc;
union {
struct list_head q_node;
struct kmem_cache *__rcu_icq_cache;
};
union {
struct hlist_node ioc_node;
struct callback_head __rcu_head;
};
unsigned int flags;
};
struct ida {
struct xarray xa;
};
typedef __u32 blk_mq_req_flags_t;
struct sbitmap_word {
long unsigned int word;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long unsigned int cleared;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct sbitmap {
unsigned int depth;
unsigned int shift;
unsigned int map_nr;
bool round_robin;
struct sbitmap_word *map;
unsigned int *alloc_hint;
};
struct sbq_wait_state {
atomic_t wait_cnt;
wait_queue_head_t wait;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct sbitmap_queue {
struct sbitmap sb;
unsigned int wake_batch;
atomic_t wake_index;
struct sbq_wait_state *ws;
atomic_t ws_active;
unsigned int min_shallow_depth;
};
typedef __u32 req_flags_t;
enum mq_rq_state {
MQ_RQ_IDLE = 0,
MQ_RQ_IN_FLIGHT = 1,
MQ_RQ_COMPLETE = 2,
};
enum rq_end_io_ret {
RQ_END_IO_NONE = 0,
RQ_END_IO_FREE = 1,
};
typedef enum rq_end_io_ret rq_end_io_fn(struct request *, blk_status_t);
struct request {
struct request_queue *q;
struct blk_mq_ctx *mq_ctx;
struct blk_mq_hw_ctx *mq_hctx;
blk_opf_t cmd_flags;
req_flags_t rq_flags;
int tag;
int internal_tag;
unsigned int timeout;
unsigned int __data_len;
long: 32;
sector_t __sector;
struct bio *bio;
struct bio *biotail;
union {
struct list_head queuelist;
struct request *rq_next;
};
struct block_device *part;
long: 32;
u64 start_time_ns;
u64 io_start_time_ns;
short unsigned int stats_sectors;
short unsigned int nr_phys_segments;
short unsigned int write_hint;
short unsigned int ioprio;
enum mq_rq_state state;
atomic_t ref;
long unsigned int deadline;
union {
struct hlist_node hash;
struct llist_node ipi_list;
};
union {
struct rb_node rb_node;
struct bio_vec special_vec;
void *completion_data;
};
union {
struct {
struct io_cq *icq;
void *priv[2];
} elv;
struct {
unsigned int seq;
struct list_head list;
rq_end_io_fn *saved_end_io;
} flush;
};
union {
struct __call_single_data csd;
u64 fifo_time;
};
rq_end_io_fn *end_io;
void *end_io_data;
};
struct elevator_type;
struct elevator_queue {
struct elevator_type *type;
void *elevator_data;
struct kobject kobj;
struct mutex sysfs_lock;
unsigned int registered: 1;
struct hlist_head hash[64];
};
enum rq_qos_id {
RQ_QOS_WBT = 0,
RQ_QOS_LATENCY = 1,
RQ_QOS_COST = 2,
};
struct rq_qos_ops;
struct rq_qos {
struct rq_qos_ops *ops;
struct request_queue *q;
enum rq_qos_id id;
struct rq_qos *next;
struct dentry *debugfs_dir;
};
struct blk_mq_ctxs;
struct blk_mq_ctx {
struct {
spinlock_t lock;
struct list_head rq_lists[3];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
unsigned int cpu;
short unsigned int index_hw[3];
struct blk_mq_hw_ctx *hctxs[3];
struct request_queue *queue;
struct blk_mq_ctxs *ctxs;
struct kobject kobj;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct blk_stat_callback {
struct list_head list;
struct timer_list timer;
struct blk_rq_stat *cpu_stat;
int (*bucket_fn)(const struct request *);
unsigned int buckets;
struct blk_rq_stat *stat;
void (*timer_fn)(struct blk_stat_callback *);
void *data;
struct callback_head rcu;
};
struct blk_mq_tags {
unsigned int nr_tags;
unsigned int nr_reserved_tags;
atomic_t active_queues;
struct sbitmap_queue bitmap_tags;
struct sbitmap_queue breserved_tags;
struct request **rqs;
struct request **static_rqs;
struct list_head page_list;
spinlock_t lock;
};
struct rchan;
struct blk_trace {
int trace_state;
struct rchan *rchan;
long unsigned int *sequence;
unsigned char *msg_data;
u16 act_mask;
long: 32;
u64 start_lba;
u64 end_lba;
u32 pid;
u32 dev;
struct dentry *dir;
struct list_head running_list;
atomic_t dropped;
};
struct blk_flush_queue {
unsigned int flush_pending_idx: 1;
unsigned int flush_running_idx: 1;
blk_status_t rq_status;
long unsigned int flush_pending_since;
struct list_head flush_queue[2];
struct list_head flush_data_in_flight;
struct request *flush_rq;
spinlock_t mq_flush_lock;
};
struct blk_mq_queue_map {
unsigned int *mq_map;
unsigned int nr_queues;
unsigned int queue_offset;
};
struct blk_mq_tag_set {
struct blk_mq_queue_map map[3];
unsigned int nr_maps;
const struct blk_mq_ops *ops;
unsigned int nr_hw_queues;
unsigned int queue_depth;
unsigned int reserved_tags;
unsigned int cmd_size;
int numa_node;
unsigned int timeout;
unsigned int flags;
void *driver_data;
struct blk_mq_tags **tags;
struct blk_mq_tags *shared_tags;
struct mutex tag_list_lock;
struct list_head tag_list;
};
struct blk_mq_hw_ctx {
struct {
spinlock_t lock;
struct list_head dispatch;
long unsigned int state;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct delayed_work run_work;
cpumask_var_t cpumask;
int next_cpu;
int next_cpu_batch;
long unsigned int flags;
void *sched_data;
struct request_queue *queue;
struct blk_flush_queue *fq;
void *driver_data;
struct sbitmap ctx_map;
struct blk_mq_ctx *dispatch_from;
unsigned int dispatch_busy;
short unsigned int type;
short unsigned int nr_ctx;
struct blk_mq_ctx **ctxs;
spinlock_t dispatch_wait_lock;
wait_queue_entry_t dispatch_wait;
atomic_t wait_index;
struct blk_mq_tags *tags;
struct blk_mq_tags *sched_tags;
long unsigned int queued;
long unsigned int run;
unsigned int numa_node;
unsigned int queue_num;
atomic_t nr_active;
struct hlist_node cpuhp_online;
struct hlist_node cpuhp_dead;
struct kobject kobj;
struct dentry *debugfs_dir;
struct dentry *sched_debugfs_dir;
struct list_head hctx_list;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum hctx_type {
HCTX_TYPE_DEFAULT = 0,
HCTX_TYPE_READ = 1,
HCTX_TYPE_POLL = 2,
HCTX_MAX_TYPES = 3,
};
struct blk_mq_queue_data {
struct request *rq;
bool last;
};
struct rchan_buf {
void *start;
void *data;
size_t offset;
size_t subbufs_produced;
size_t subbufs_consumed;
struct rchan *chan;
wait_queue_head_t read_wait;
struct irq_work wakeup_work;
struct dentry *dentry;
struct kref kref;
struct page **page_array;
unsigned int page_count;
unsigned int finalized;
size_t *padding;
size_t prev_padding;
size_t bytes_consumed;
size_t early_bytes;
unsigned int cpu;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct rchan_callbacks;
struct rchan {
u32 version;
size_t subbuf_size;
size_t n_subbufs;
size_t alloc_size;
const struct rchan_callbacks *cb;
struct kref kref;
void *private_data;
size_t last_toobig;
struct rchan_buf **buf;
int is_global;
struct list_head list;
struct dentry *parent;
int has_base_filename;
char base_filename[255];
};
struct rchan_callbacks {
int (*subbuf_start)(struct rchan_buf *, void *, void *, size_t);
struct dentry * (*create_buf_file)(const char *, struct dentry *, umode_t, struct rchan_buf *, int *);
int (*remove_buf_file)(struct dentry *);
};
enum blktrace_act {
__BLK_TA_QUEUE = 1,
__BLK_TA_BACKMERGE = 2,
__BLK_TA_FRONTMERGE = 3,
__BLK_TA_GETRQ = 4,
__BLK_TA_SLEEPRQ = 5,
__BLK_TA_REQUEUE = 6,
__BLK_TA_ISSUE = 7,
__BLK_TA_COMPLETE = 8,
__BLK_TA_PLUG = 9,
__BLK_TA_UNPLUG_IO = 10,
__BLK_TA_UNPLUG_TIMER = 11,
__BLK_TA_INSERT = 12,
__BLK_TA_SPLIT = 13,
__BLK_TA_BOUNCE = 14,
__BLK_TA_REMAP = 15,
__BLK_TA_ABORT = 16,
__BLK_TA_DRV_DATA = 17,
__BLK_TA_CGROUP = 256,
};
struct blk_mq_ctxs {
struct kobject kobj;
struct blk_mq_ctx *queue_ctx;
};
struct blk_mq_alloc_data {
struct request_queue *q;
blk_mq_req_flags_t flags;
unsigned int shallow_depth;
blk_opf_t cmd_flags;
req_flags_t rq_flags;
unsigned int nr_tags;
struct request **cached_rq;
struct blk_mq_ctx *ctx;
struct blk_mq_hw_ctx *hctx;
};
struct blk_mq_debugfs_attr {
const char *name;
umode_t mode;
int (*show)(void *, struct seq_file *);
ssize_t (*write)(void *, const char *, size_t, loff_t *);
const struct seq_operations *seq_ops;
};
enum elv_merge {
ELEVATOR_NO_MERGE = 0,
ELEVATOR_FRONT_MERGE = 1,
ELEVATOR_BACK_MERGE = 2,
ELEVATOR_DISCARD_MERGE = 3,
};
struct elevator_mq_ops {
int (*init_sched)(struct request_queue *, struct elevator_type *);
void (*exit_sched)(struct elevator_queue *);
int (*init_hctx)(struct blk_mq_hw_ctx *, unsigned int);
void (*exit_hctx)(struct blk_mq_hw_ctx *, unsigned int);
void (*depth_updated)(struct blk_mq_hw_ctx *);
bool (*allow_merge)(struct request_queue *, struct request *, struct bio *);
bool (*bio_merge)(struct request_queue *, struct bio *, unsigned int);
int (*request_merge)(struct request_queue *, struct request **, struct bio *);
void (*request_merged)(struct request_queue *, struct request *, enum elv_merge);
void (*requests_merged)(struct request_queue *, struct request *, struct request *);
void (*limit_depth)(blk_opf_t, struct blk_mq_alloc_data *);
void (*prepare_request)(struct request *);
void (*finish_request)(struct request *);
void (*insert_requests)(struct blk_mq_hw_ctx *, struct list_head *, bool);
struct request * (*dispatch_request)(struct blk_mq_hw_ctx *);
bool (*has_work)(struct blk_mq_hw_ctx *);
void (*completed_request)(struct request *, u64);
void (*requeue_request)(struct request *);
struct request * (*former_request)(struct request_queue *, struct request *);
struct request * (*next_request)(struct request_queue *, struct request *);
void (*init_icq)(struct io_cq *);
void (*exit_icq)(struct io_cq *);
};
struct elv_fs_entry;
struct elevator_type {
struct kmem_cache *icq_cache;
struct elevator_mq_ops ops;
size_t icq_size;
size_t icq_align;
struct elv_fs_entry *elevator_attrs;
const char *elevator_name;
const char *elevator_alias;
const unsigned int elevator_features;
struct module *elevator_owner;
const struct blk_mq_debugfs_attr *queue_debugfs_attrs;
const struct blk_mq_debugfs_attr *hctx_debugfs_attrs;
char icq_cache_name[22];
struct list_head list;
};
struct elv_fs_entry {
struct attribute attr;
ssize_t (*show)(struct elevator_queue *, char *);
ssize_t (*store)(struct elevator_queue *, const char *, size_t);
};
struct rq_qos_ops {
void (*throttle)(struct rq_qos *, struct bio *);
void (*track)(struct rq_qos *, struct request *, struct bio *);
void (*merge)(struct rq_qos *, struct request *, struct bio *);
void (*issue)(struct rq_qos *, struct request *);
void (*requeue)(struct rq_qos *, struct request *);
void (*done)(struct rq_qos *, struct request *);
void (*done_bio)(struct rq_qos *, struct bio *);
void (*cleanup)(struct rq_qos *, struct bio *);
void (*queue_depth_changed)(struct rq_qos *);
void (*exit)(struct rq_qos *);
const struct blk_mq_debugfs_attr *debugfs_attrs;
};
enum {
WBT_RWQ_BG = 0,
WBT_RWQ_KSWAPD = 1,
WBT_RWQ_DISCARD = 2,
WBT_NUM_RWQ = 3,
};
enum blkg_rwstat_type {
BLKG_RWSTAT_READ = 0,
BLKG_RWSTAT_WRITE = 1,
BLKG_RWSTAT_SYNC = 2,
BLKG_RWSTAT_ASYNC = 3,
BLKG_RWSTAT_DISCARD = 4,
BLKG_RWSTAT_NR = 5,
BLKG_RWSTAT_TOTAL = 5,
};
enum {
LIMIT_LOW = 0,
LIMIT_MAX = 1,
LIMIT_CNT = 2,
};
struct queue_sysfs_entry {
struct attribute attr;
ssize_t (*show)(struct request_queue *, char *);
ssize_t (*store)(struct request_queue *, const char *, size_t);
};
struct pci_device_id {
__u32 vendor;
__u32 device;
__u32 subvendor;
__u32 subdevice;
__u32 class;
__u32 class_mask;
kernel_ulong_t driver_data;
__u32 override_only;
};
struct pci_bus;
struct hotplug_slot;
struct pci_slot {
struct pci_bus *bus;
struct list_head list;
struct hotplug_slot *hotplug;
unsigned char number;
struct kobject kobj;
};
typedef short unsigned int pci_bus_flags_t;
struct pci_dev;
struct pci_ops;
struct pci_bus {
struct list_head node;
struct pci_bus *parent;
struct list_head children;
struct list_head devices;
struct pci_dev *self;
struct list_head slots;
struct resource *resource[4];
struct list_head resources;
struct resource busn_res;
struct pci_ops *ops;
void *sysdata;
struct proc_dir_entry *procdir;
unsigned char number;
unsigned char primary;
unsigned char max_bus_speed;
unsigned char cur_bus_speed;
char name[48];
short unsigned int bridge_ctl;
pci_bus_flags_t bus_flags;
struct device *bridge;
struct device dev;
struct bin_attribute *legacy_io;
struct bin_attribute *legacy_mem;
unsigned int is_added: 1;
unsigned int unsafe_warn: 1;
long: 32;
};
enum {
PCI_STD_RESOURCES = 0,
PCI_STD_RESOURCE_END = 5,
PCI_ROM_RESOURCE = 6,
PCI_BRIDGE_RESOURCES = 7,
PCI_BRIDGE_RESOURCE_END = 10,
PCI_NUM_RESOURCES = 11,
DEVICE_COUNT_RESOURCE = 11,
};
typedef int pci_power_t;
typedef unsigned int pci_channel_state_t;
typedef unsigned int pcie_reset_state_t;
typedef short unsigned int pci_dev_flags_t;
struct pci_vpd {
struct mutex lock;
unsigned int len;
u8 cap;
};
struct pci_driver;
struct pcie_link_state;
struct pci_dev {
struct list_head bus_list;
struct pci_bus *bus;
struct pci_bus *subordinate;
void *sysdata;
struct proc_dir_entry *procent;
struct pci_slot *slot;
unsigned int devfn;
short unsigned int vendor;
short unsigned int device;
short unsigned int subsystem_vendor;
short unsigned int subsystem_device;
unsigned int class;
u8 revision;
u8 hdr_type;
u32 devcap;
u8 pcie_cap;
u8 msi_cap;
u8 msix_cap;
u8 pcie_mpss: 3;
u8 rom_base_reg;
u8 pin;
u16 pcie_flags_reg;
long unsigned int *dma_alias_mask;
struct pci_driver *driver;
long: 32;
u64 dma_mask;
struct device_dma_parameters dma_parms;
pci_power_t current_state;
unsigned int imm_ready: 1;
u8 pm_cap;
unsigned int pme_support: 5;
unsigned int pme_poll: 1;
unsigned int d1_support: 1;
unsigned int d2_support: 1;
unsigned int no_d1d2: 1;
unsigned int no_d3cold: 1;
unsigned int bridge_d3: 1;
unsigned int d3cold_allowed: 1;
unsigned int mmio_always_on: 1;
unsigned int wakeup_prepared: 1;
unsigned int skip_bus_pm: 1;
unsigned int ignore_hotplug: 1;
unsigned int hotplug_user_indicators: 1;
unsigned int clear_retrain_link: 1;
unsigned int d3hot_delay;
unsigned int d3cold_delay;
struct pcie_link_state *link_state;
unsigned int ltr_path: 1;
u16 l1ss;
unsigned int pasid_no_tlp: 1;
unsigned int eetlp_prefix_path: 1;
pci_channel_state_t error_state;
struct device dev;
int cfg_size;
unsigned int irq;
struct resource resource[11];
bool match_driver;
unsigned int transparent: 1;
unsigned int io_window: 1;
unsigned int pref_window: 1;
unsigned int pref_64_window: 1;
unsigned int multifunction: 1;
unsigned int is_busmaster: 1;
unsigned int no_msi: 1;
unsigned int no_64bit_msi: 1;
unsigned int block_cfg_access: 1;
unsigned int broken_parity_status: 1;
unsigned int irq_reroute_variant: 2;
unsigned int msi_enabled: 1;
unsigned int msix_enabled: 1;
unsigned int ari_enabled: 1;
unsigned int ats_enabled: 1;
unsigned int pasid_enabled: 1;
unsigned int pri_enabled: 1;
unsigned int is_managed: 1;
unsigned int is_msi_managed: 1;
unsigned int needs_freset: 1;
unsigned int state_saved: 1;
unsigned int is_physfn: 1;
unsigned int is_virtfn: 1;
unsigned int is_hotplug_bridge: 1;
unsigned int shpc_managed: 1;
unsigned int is_thunderbolt: 1;
unsigned int untrusted: 1;
unsigned int external_facing: 1;
unsigned int broken_intx_masking: 1;
unsigned int io_window_1k: 1;
unsigned int irq_managed: 1;
unsigned int non_compliant_bars: 1;
unsigned int is_probed: 1;
unsigned int link_active_reporting: 1;
unsigned int no_vf_scan: 1;
unsigned int no_command_memory: 1;
unsigned int rom_bar_overlap: 1;
pci_dev_flags_t dev_flags;
atomic_t enable_cnt;
u32 saved_config_space[16];
struct hlist_head saved_cap_space;
int rom_attr_enabled;
struct bin_attribute *res_attr[11];
struct bin_attribute *res_attr_wc[11];
struct pci_vpd vpd;
u16 acs_cap;
phys_addr_t rom;
size_t romlen;
const char *driver_override;
long unsigned int priv_flags;
u8 reset_methods[7];
};
struct pci_dynids {
spinlock_t lock;
struct list_head list;
};
struct pci_error_handlers;
struct pci_driver {
struct list_head node;
const char *name;
const struct pci_device_id *id_table;
int (*probe)(struct pci_dev *, const struct pci_device_id *);
void (*remove)(struct pci_dev *);
int (*suspend)(struct pci_dev *, pm_message_t);
int (*resume)(struct pci_dev *);
void (*shutdown)(struct pci_dev *);
int (*sriov_configure)(struct pci_dev *, int);
int (*sriov_set_msix_vec_count)(struct pci_dev *, int);
u32 (*sriov_get_vf_total_msix)(struct pci_dev *);
const struct pci_error_handlers *err_handler;
const struct attribute_group **groups;
const struct attribute_group **dev_groups;
struct device_driver driver;
struct pci_dynids dynids;
bool driver_managed_dma;
};
struct pci_ops {
int (*add_bus)(struct pci_bus *);
void (*remove_bus)(struct pci_bus *);
void * (*map_bus)(struct pci_bus *, unsigned int, int);
int (*read)(struct pci_bus *, unsigned int, int, int, u32 *);
int (*write)(struct pci_bus *, unsigned int, int, int, u32);
};
typedef unsigned int pci_ers_result_t;
struct pci_error_handlers {
pci_ers_result_t (*error_detected)(struct pci_dev *, pci_channel_state_t);
pci_ers_result_t (*mmio_enabled)(struct pci_dev *);
pci_ers_result_t (*slot_reset)(struct pci_dev *);
void (*reset_prepare)(struct pci_dev *);
void (*reset_done)(struct pci_dev *);
void (*resume)(struct pci_dev *);
};
struct io_ring_ctx;
struct io_wq;
struct io_uring_task {
int cached_refs;
const struct io_ring_ctx *last;
struct io_wq *io_wq;
struct file *registered_rings[16];
struct xarray xa;
struct wait_queue_head wait;
atomic_t in_idle;
atomic_t inflight_tracked;
long: 32;
struct percpu_counter inflight;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct {
struct llist_head task_list;
struct callback_head task_work;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
};
enum {
__PERCPU_REF_ATOMIC = 1,
__PERCPU_REF_DEAD = 2,
__PERCPU_REF_ATOMIC_DEAD = 3,
__PERCPU_REF_FLAG_BITS = 2,
};
struct io_uring_cmd {
struct file *file;
const void *cmd;
union {
void (*task_work_cb)(struct io_uring_cmd *);
void *cookie;
};
u32 cmd_op;
u32 flags;
u8 pdu[32];
};
struct io_uring_sqe {
__u8 opcode;
__u8 flags;
__u16 ioprio;
__s32 fd;
union {
__u64 off;
__u64 addr2;
struct {
__u32 cmd_op;
__u32 __pad1;
};
};
union {
__u64 addr;
__u64 splice_off_in;
};
__u32 len;
union {
__kernel_rwf_t rw_flags;
__u32 fsync_flags;
__u16 poll_events;
__u32 poll32_events;
__u32 sync_range_flags;
__u32 msg_flags;
__u32 timeout_flags;
__u32 accept_flags;
__u32 cancel_flags;
__u32 open_flags;
__u32 statx_flags;
__u32 fadvise_advice;
__u32 splice_flags;
__u32 rename_flags;
__u32 unlink_flags;
__u32 hardlink_flags;
__u32 xattr_flags;
__u32 msg_ring_flags;
__u32 uring_cmd_flags;
};
__u64 user_data;
union {
__u16 buf_index;
__u16 buf_group;
};
__u16 personality;
union {
__s32 splice_fd_in;
__u32 file_index;
struct {
__u16 addr_len;
__u16 __pad3[1];
};
};
union {
struct {
__u64 addr3;
__u64 __pad2[1];
};
__u8 cmd[0];
};
};
struct io_uring_cqe {
__u64 user_data;
__s32 res;
__u32 flags;
__u64 big_cqe[0];
};
enum task_work_notify_mode {
TWA_NONE = 0,
TWA_RESUME = 1,
TWA_SIGNAL = 2,
TWA_SIGNAL_NO_IPI = 3,
};
struct io_wq_work_node {
struct io_wq_work_node *next;
};
struct io_wq_work_list {
struct io_wq_work_node *first;
struct io_wq_work_node *last;
};
struct io_wq_work {
struct io_wq_work_node list;
unsigned int flags;
int cancel_seq;
};
struct io_fixed_file {
long unsigned int file_ptr;
};
struct io_file_table {
struct io_fixed_file *files;
long unsigned int *bitmap;
unsigned int alloc_hint;
};
struct io_hash_bucket {
spinlock_t lock;
struct hlist_head list;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct io_hash_table {
struct io_hash_bucket *hbs;
unsigned int hash_bits;
};
struct io_kiocb;
struct io_submit_link {
struct io_kiocb *head;
struct io_kiocb *last;
};
struct io_submit_state {
struct io_wq_work_node free_list;
struct io_wq_work_list compl_reqs;
struct io_submit_link link;
bool plug_started;
bool need_plug;
short unsigned int submit_nr;
struct blk_plug plug;
};
struct io_alloc_cache {
struct hlist_head list;
unsigned int nr_cached;
};
struct io_restriction {
long unsigned int register_op[1];
long unsigned int sqe_op[2];
u8 sqe_flags_allowed;
u8 sqe_flags_required;
bool registered;
};
struct io_rings;
struct io_rsrc_node;
struct io_mapped_ubuf;
struct io_buffer_list;
struct io_sq_data;
struct io_ev_fd;
struct io_rsrc_data;
struct io_wq_hash;
struct io_ring_ctx {
struct {
struct percpu_ref refs;
struct io_rings *rings;
unsigned int flags;
enum task_work_notify_mode notify_method;
unsigned int compat: 1;
unsigned int drain_next: 1;
unsigned int restricted: 1;
unsigned int off_timeout_used: 1;
unsigned int drain_active: 1;
unsigned int drain_disabled: 1;
unsigned int has_evfd: 1;
unsigned int syscall_iopoll: 1;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct {
struct mutex uring_lock;
u32 *sq_array;
struct io_uring_sqe *sq_sqes;
unsigned int cached_sq_head;
unsigned int sq_entries;
struct io_rsrc_node *rsrc_node;
int rsrc_cached_refs;
atomic_t cancel_seq;
struct io_file_table file_table;
unsigned int nr_user_files;
unsigned int nr_user_bufs;
struct io_mapped_ubuf **user_bufs;
struct io_submit_state submit_state;
struct io_buffer_list *io_bl;
struct xarray io_bl_xa;
struct list_head io_buffers_cache;
struct io_hash_table cancel_table_locked;
struct list_head cq_overflow_list;
struct io_alloc_cache apoll_cache;
struct io_alloc_cache netmsg_cache;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct io_wq_work_list locked_free_list;
unsigned int locked_free_nr;
const struct cred *sq_creds;
struct io_sq_data *sq_data;
struct wait_queue_head sqo_sq_wait;
struct list_head sqd_list;
long unsigned int check_cq;
unsigned int file_alloc_start;
unsigned int file_alloc_end;
struct xarray personalities;
u32 pers_next;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct {
struct io_uring_cqe *cqe_cached;
struct io_uring_cqe *cqe_sentinel;
unsigned int cached_cq_tail;
unsigned int cq_entries;
struct io_ev_fd *io_ev_fd;
struct wait_queue_head cq_wait;
unsigned int cq_extra;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct {
spinlock_t completion_lock;
struct io_wq_work_list iopoll_list;
struct io_hash_table cancel_table;
bool poll_multi_queue;
struct llist_head work_llist;
struct list_head io_buffers_comp;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct {
spinlock_t timeout_lock;
atomic_t cq_timeouts;
struct list_head timeout_list;
struct list_head ltimeout_list;
unsigned int cq_last_tm_flush;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct io_restriction restrictions;
struct task_struct *submitter_task;
struct io_rsrc_node *rsrc_backup_node;
struct io_mapped_ubuf *dummy_ubuf;
struct io_rsrc_data *file_data;
struct io_rsrc_data *buf_data;
struct delayed_work rsrc_put_work;
struct llist_head rsrc_put_llist;
struct list_head rsrc_ref_list;
spinlock_t rsrc_ref_lock;
struct list_head io_buffers_pages;
struct socket *ring_sock;
struct io_wq_hash *hash_map;
struct user_struct *user;
struct mm_struct *mm_account;
struct llist_head fallback_llist;
struct delayed_work fallback_work;
struct work_struct exit_work;
struct list_head tctx_list;
struct completion ref_comp;
u32 iowq_limits[2];
bool iowq_limits_set;
struct list_head defer_list;
unsigned int sq_thread_idle;
unsigned int evfd_last_cq_tail;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct io_uring {
u32 head;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
u32 tail;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct io_rings {
struct io_uring sq;
struct io_uring cq;
u32 sq_ring_mask;
u32 cq_ring_mask;
u32 sq_ring_entries;
u32 cq_ring_entries;
u32 sq_dropped;
atomic_t sq_flags;
u32 cq_flags;
u32 cq_overflow;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct io_uring_cqe cqes[0];
};
struct io_cmd_data {
struct file *file;
__u8 data[56];
};
struct io_cqe {
__u64 user_data;
__s32 res;
union {
__u32 flags;
int fd;
};
};
typedef void (*io_req_tw_func_t)(struct io_kiocb *, bool *);
struct io_task_work {
struct llist_node node;
io_req_tw_func_t func;
};
struct io_buffer;
struct async_poll;
struct io_kiocb {
union {
struct file *file;
struct io_cmd_data cmd;
};
u8 opcode;
u8 iopoll_completed;
u16 buf_index;
unsigned int flags;
long: 32;
struct io_cqe cqe;
struct io_ring_ctx *ctx;
struct task_struct *task;
struct io_rsrc_node *rsrc_node;
union {
struct io_mapped_ubuf *imu;
struct io_buffer *kbuf;
struct io_buffer_list *buf_list;
};
union {
struct io_wq_work_node comp_list;
__poll_t apoll_events;
};
atomic_t refs;
atomic_t poll_refs;
struct io_task_work io_task_work;
long: 32;
union {
struct hlist_node hash_node;
struct {
u64 extra1;
u64 extra2;
};
};
struct async_poll *apoll;
void *async_data;
struct io_kiocb *link;
const struct cred *creds;
struct io_wq_work work;
long: 32;
};
struct eventfd_ctx;
struct io_ev_fd {
struct eventfd_ctx *cq_ev_fd;
unsigned int eventfd_async: 1;
struct callback_head rcu;
atomic_t refs;
atomic_t ops;
};
struct io_rsrc_node {
struct percpu_ref refs;
struct list_head node;
struct list_head rsrc_list;
struct io_rsrc_data *rsrc_data;
struct llist_node llist;
bool done;
};
struct io_mapped_ubuf {
u64 ubuf;
u64 ubuf_end;
unsigned int nr_bvecs;
long unsigned int acct_pages;
struct bio_vec bvec[0];
};
struct io_sq_data {
refcount_t refs;
atomic_t park_pending;
struct mutex lock;
struct list_head ctx_list;
struct task_struct *thread;
struct wait_queue_head wait;
unsigned int sq_thread_idle;
int sq_cpu;
pid_t task_pid;
pid_t task_tgid;
long unsigned int state;
struct completion exited;
};
struct io_rsrc_put;
typedef void rsrc_put_fn(struct io_ring_ctx *, struct io_rsrc_put *);
struct io_rsrc_data {
struct io_ring_ctx *ctx;
u64 **tags;
unsigned int nr;
rsrc_put_fn *do_put;
atomic_t refs;
struct completion done;
bool quiesce;
};
struct io_wq_hash {
refcount_t refs;
long unsigned int map;
struct wait_queue_head wait;
};
struct io_overflow_cqe {
struct list_head list;
struct io_uring_cqe cqe;
};
struct io_rsrc_put {
struct list_head list;
u64 tag;
union {
void *rsrc;
struct file *file;
struct io_mapped_ubuf *buf;
};
long: 32;
};
enum blake2s_lengths {
BLAKE2S_BLOCK_SIZE = 64,
BLAKE2S_HASH_SIZE = 32,
BLAKE2S_KEY_SIZE = 32,
BLAKE2S_128_HASH_SIZE = 16,
BLAKE2S_160_HASH_SIZE = 20,
BLAKE2S_224_HASH_SIZE = 28,
BLAKE2S_256_HASH_SIZE = 32,
};
struct blake2s_state {
u32 h[8];
u32 t[2];
u32 f[2];
u8 buf[64];
unsigned int buflen;
unsigned int outlen;
};
enum blake2s_iv {
BLAKE2S_IV0 = 1779033703,
BLAKE2S_IV1 = 3144134277,
BLAKE2S_IV2 = 1013904242,
BLAKE2S_IV3 = 2773480762,
BLAKE2S_IV4 = 1359893119,
BLAKE2S_IV5 = 2600822924,
BLAKE2S_IV6 = 528734635,
BLAKE2S_IV7 = 1541459225,
};
typedef enum {
ZSTD_error_no_error = 0,
ZSTD_error_GENERIC = 1,
ZSTD_error_prefix_unknown = 10,
ZSTD_error_version_unsupported = 12,
ZSTD_error_frameParameter_unsupported = 14,
ZSTD_error_frameParameter_windowTooLarge = 16,
ZSTD_error_corruption_detected = 20,
ZSTD_error_checksum_wrong = 22,
ZSTD_error_dictionary_corrupted = 30,
ZSTD_error_dictionary_wrong = 32,
ZSTD_error_dictionaryCreation_failed = 34,
ZSTD_error_parameter_unsupported = 40,
ZSTD_error_parameter_outOfBound = 42,
ZSTD_error_tableLog_tooLarge = 44,
ZSTD_error_maxSymbolValue_tooLarge = 46,
ZSTD_error_maxSymbolValue_tooSmall = 48,
ZSTD_error_stage_wrong = 60,
ZSTD_error_init_missing = 62,
ZSTD_error_memory_allocation = 64,
ZSTD_error_workSpace_tooSmall = 66,
ZSTD_error_dstSize_tooSmall = 70,
ZSTD_error_srcSize_wrong = 72,
ZSTD_error_dstBuffer_null = 74,
ZSTD_error_frameIndex_tooLarge = 100,
ZSTD_error_seekableIO = 102,
ZSTD_error_dstBuffer_wrong = 104,
ZSTD_error_srcBuffer_wrong = 105,
ZSTD_error_maxCode = 120,
} ZSTD_ErrorCode;
typedef ZSTD_ErrorCode ERR_enum;
typedef u8 uint8_t;
struct module_version_attribute {
struct module_attribute mattr;
const char *module_name;
const char *version;
};
enum xz_mode {
XZ_SINGLE = 0,
XZ_PREALLOC = 1,
XZ_DYNALLOC = 2,
};
enum xz_ret {
XZ_OK = 0,
XZ_STREAM_END = 1,
XZ_UNSUPPORTED_CHECK = 2,
XZ_MEM_ERROR = 3,
XZ_MEMLIMIT_ERROR = 4,
XZ_FORMAT_ERROR = 5,
XZ_OPTIONS_ERROR = 6,
XZ_DATA_ERROR = 7,
XZ_BUF_ERROR = 8,
};
struct xz_buf {
const uint8_t *in;
size_t in_pos;
size_t in_size;
uint8_t *out;
size_t out_pos;
size_t out_size;
};
typedef long unsigned int mpi_limb_t;
struct gcry_mpi {
int alloced;
int nlimbs;
int nbits;
int sign;
unsigned int flags;
mpi_limb_t *d;
};
typedef struct gcry_mpi *MPI;
typedef mpi_limb_t *mpi_ptr_t;
typedef int mpi_size_t;
enum OID {
OID_id_dsa_with_sha1 = 0,
OID_id_dsa = 1,
OID_id_ecPublicKey = 2,
OID_id_prime192v1 = 3,
OID_id_prime256v1 = 4,
OID_id_ecdsa_with_sha1 = 5,
OID_id_ecdsa_with_sha224 = 6,
OID_id_ecdsa_with_sha256 = 7,
OID_id_ecdsa_with_sha384 = 8,
OID_id_ecdsa_with_sha512 = 9,
OID_rsaEncryption = 10,
OID_md2WithRSAEncryption = 11,
OID_md3WithRSAEncryption = 12,
OID_md4WithRSAEncryption = 13,
OID_sha1WithRSAEncryption = 14,
OID_sha256WithRSAEncryption = 15,
OID_sha384WithRSAEncryption = 16,
OID_sha512WithRSAEncryption = 17,
OID_sha224WithRSAEncryption = 18,
OID_data = 19,
OID_signed_data = 20,
OID_email_address = 21,
OID_contentType = 22,
OID_messageDigest = 23,
OID_signingTime = 24,
OID_smimeCapabilites = 25,
OID_smimeAuthenticatedAttrs = 26,
OID_md2 = 27,
OID_md4 = 28,
OID_md5 = 29,
OID_mskrb5 = 30,
OID_krb5 = 31,
OID_krb5u2u = 32,
OID_msIndirectData = 33,
OID_msStatementType = 34,
OID_msSpOpusInfo = 35,
OID_msPeImageDataObjId = 36,
OID_msIndividualSPKeyPurpose = 37,
OID_msOutlookExpress = 38,
OID_ntlmssp = 39,
OID_spnego = 40,
OID_IAKerb = 41,
OID_PKU2U = 42,
OID_Scram = 43,
OID_certAuthInfoAccess = 44,
OID_sha1 = 45,
OID_id_ansip384r1 = 46,
OID_sha256 = 47,
OID_sha384 = 48,
OID_sha512 = 49,
OID_sha224 = 50,
OID_commonName = 51,
OID_surname = 52,
OID_countryName = 53,
OID_locality = 54,
OID_stateOrProvinceName = 55,
OID_organizationName = 56,
OID_organizationUnitName = 57,
OID_title = 58,
OID_description = 59,
OID_name = 60,
OID_givenName = 61,
OID_initials = 62,
OID_generationalQualifier = 63,
OID_subjectKeyIdentifier = 64,
OID_keyUsage = 65,
OID_subjectAltName = 66,
OID_issuerAltName = 67,
OID_basicConstraints = 68,
OID_crlDistributionPoints = 69,
OID_certPolicies = 70,
OID_authorityKeyIdentifier = 71,
OID_extKeyUsage = 72,
OID_NetlogonMechanism = 73,
OID_appleLocalKdcSupported = 74,
OID_gostCPSignA = 75,
OID_gostCPSignB = 76,
OID_gostCPSignC = 77,
OID_gost2012PKey256 = 78,
OID_gost2012PKey512 = 79,
OID_gost2012Digest256 = 80,
OID_gost2012Digest512 = 81,
OID_gost2012Signature256 = 82,
OID_gost2012Signature512 = 83,
OID_gostTC26Sign256A = 84,
OID_gostTC26Sign256B = 85,
OID_gostTC26Sign256C = 86,
OID_gostTC26Sign256D = 87,
OID_gostTC26Sign512A = 88,
OID_gostTC26Sign512B = 89,
OID_gostTC26Sign512C = 90,
OID_sm2 = 91,
OID_sm3 = 92,
OID_SM2_with_SM3 = 93,
OID_sm3WithRSAEncryption = 94,
OID_TPMLoadableKey = 95,
OID_TPMImportableKey = 96,
OID_TPMSealedData = 97,
OID__NR = 98,
};
enum asn1_tag {
ASN1_EOC = 0,
ASN1_BOOL = 1,
ASN1_INT = 2,
ASN1_BTS = 3,
ASN1_OTS = 4,
ASN1_NULL = 5,
ASN1_OID = 6,
ASN1_ODE = 7,
ASN1_EXT = 8,
ASN1_REAL = 9,
ASN1_ENUM = 10,
ASN1_EPDV = 11,
ASN1_UTF8STR = 12,
ASN1_RELOID = 13,
ASN1_SEQ = 16,
ASN1_SET = 17,
ASN1_NUMSTR = 18,
ASN1_PRNSTR = 19,
ASN1_TEXSTR = 20,
ASN1_VIDSTR = 21,
ASN1_IA5STR = 22,
ASN1_UNITIM = 23,
ASN1_GENTIM = 24,
ASN1_GRASTR = 25,
ASN1_VISSTR = 26,
ASN1_GENSTR = 27,
ASN1_UNISTR = 28,
ASN1_CHRSTR = 29,
ASN1_BMPSTR = 30,
ASN1_LONG_TAG = 31,
};
struct driver_attribute {
struct attribute attr;
ssize_t (*show)(struct device_driver *, char *);
ssize_t (*store)(struct device_driver *, const char *, size_t);
};
struct iommu_group {};
enum hk_type {
HK_TYPE_TIMER = 0,
HK_TYPE_RCU = 1,
HK_TYPE_MISC = 2,
HK_TYPE_SCHED = 3,
HK_TYPE_TICK = 4,
HK_TYPE_DOMAIN = 5,
HK_TYPE_WQ = 6,
HK_TYPE_MANAGED_IRQ = 7,
HK_TYPE_KTHREAD = 8,
HK_TYPE_MAX = 9,
};
struct pci_dynid {
struct list_head node;
struct pci_device_id id;
};
struct drv_dev_and_id {
struct pci_driver *drv;
struct pci_dev *dev;
const struct pci_device_id *id;
};
struct acpi_device;
struct clk_hw;
struct clk_rate_request {
long unsigned int rate;
long unsigned int min_rate;
long unsigned int max_rate;
long unsigned int best_parent_rate;
struct clk_hw *best_parent_hw;
};
struct clk_core;
struct clk;
struct clk_init_data;
struct clk_hw {
struct clk_core *core;
struct clk *clk;
const struct clk_init_data *init;
};
struct clk_duty {
unsigned int num;
unsigned int den;
};
struct clk_ops {
int (*prepare)(struct clk_hw *);
void (*unprepare)(struct clk_hw *);
int (*is_prepared)(struct clk_hw *);
void (*unprepare_unused)(struct clk_hw *);
int (*enable)(struct clk_hw *);
void (*disable)(struct clk_hw *);
int (*is_enabled)(struct clk_hw *);
void (*disable_unused)(struct clk_hw *);
int (*save_context)(struct clk_hw *);
void (*restore_context)(struct clk_hw *);
long unsigned int (*recalc_rate)(struct clk_hw *, long unsigned int);
long int (*round_rate)(struct clk_hw *, long unsigned int, long unsigned int *);
int (*determine_rate)(struct clk_hw *, struct clk_rate_request *);
int (*set_parent)(struct clk_hw *, u8);
u8 (*get_parent)(struct clk_hw *);
int (*set_rate)(struct clk_hw *, long unsigned int, long unsigned int);
int (*set_rate_and_parent)(struct clk_hw *, long unsigned int, long unsigned int, u8);
long unsigned int (*recalc_accuracy)(struct clk_hw *, long unsigned int);
int (*get_phase)(struct clk_hw *);
int (*set_phase)(struct clk_hw *, int);
int (*get_duty_cycle)(struct clk_hw *, struct clk_duty *);
int (*set_duty_cycle)(struct clk_hw *, struct clk_duty *);
int (*init)(struct clk_hw *);
void (*terminate)(struct clk_hw *);
void (*debug_init)(struct clk_hw *, struct dentry *);
};
struct clk_parent_data {
const struct clk_hw *hw;
const char *fw_name;
const char *name;
int index;
};
struct clk_init_data {
const char *name;
const struct clk_ops *ops;
const char * const *parent_names;
const struct clk_parent_data *parent_data;
const struct clk_hw **parent_hws;
u8 num_parents;
long unsigned int flags;
};
struct clk_multiplier {
struct clk_hw hw;
void *reg;
u8 shift;
u8 width;
u8 flags;
spinlock_t *lock;
};
struct termios {
tcflag_t c_iflag;
tcflag_t c_oflag;
tcflag_t c_cflag;
tcflag_t c_lflag;
cc_t c_line;
cc_t c_cc[23];
};
struct termios2 {
tcflag_t c_iflag;
tcflag_t c_oflag;
tcflag_t c_cflag;
tcflag_t c_lflag;
cc_t c_line;
cc_t c_cc[23];
speed_t c_ispeed;
speed_t c_ospeed;
};
struct sgttyb {
char sg_ispeed;
char sg_ospeed;
char sg_erase;
char sg_kill;
int sg_flags;
};
struct ltchars {
char t_suspc;
char t_dsuspc;
char t_rprntc;
char t_flushc;
char t_werasc;
char t_lnextc;
};
struct termio {
short unsigned int c_iflag;
short unsigned int c_oflag;
short unsigned int c_cflag;
short unsigned int c_lflag;
char c_line;
unsigned char c_cc[23];
};
struct platform_device_id {
char name[20];
kernel_ulong_t driver_data;
};
struct of_phandle_args {
struct device_node *np;
int args_count;
uint32_t args[16];
};
struct pdev_archdata {};
struct mfd_cell;
struct platform_device {
const char *name;
int id;
bool id_auto;
long: 32;
struct device dev;
u64 platform_dma_mask;
struct device_dma_parameters dma_parms;
u32 num_resources;
struct resource *resource;
const struct platform_device_id *id_entry;
const char *driver_override;
struct mfd_cell *mfd_cell;
struct pdev_archdata archdata;
};
struct platform_driver {
int (*probe)(struct platform_device *);
int (*remove)(struct platform_device *);
void (*shutdown)(struct platform_device *);
int (*suspend)(struct platform_device *, pm_message_t);
int (*resume)(struct platform_device *);
struct device_driver driver;
const struct platform_device_id *id_table;
bool prevent_deferred_probe;
bool driver_managed_dma;
};
struct syscon_platform_data {
const char *label;
};
enum regcache_type {
REGCACHE_NONE = 0,
REGCACHE_RBTREE = 1,
REGCACHE_COMPRESSED = 2,
REGCACHE_FLAT = 3,
};
struct reg_default {
unsigned int reg;
unsigned int def;
};
enum regmap_endian {
REGMAP_ENDIAN_DEFAULT = 0,
REGMAP_ENDIAN_BIG = 1,
REGMAP_ENDIAN_LITTLE = 2,
REGMAP_ENDIAN_NATIVE = 3,
};
struct regmap_range {
unsigned int range_min;
unsigned int range_max;
};
struct regmap_access_table {
const struct regmap_range *yes_ranges;
unsigned int n_yes_ranges;
const struct regmap_range *no_ranges;
unsigned int n_no_ranges;
};
typedef void (*regmap_lock)(void *);
typedef void (*regmap_unlock)(void *);
struct regmap_range_cfg;
struct regmap_config {
const char *name;
int reg_bits;
int reg_stride;
int reg_downshift;
unsigned int reg_base;
int pad_bits;
int val_bits;
bool (*writeable_reg)(struct device *, unsigned int);
bool (*readable_reg)(struct device *, unsigned int);
bool (*volatile_reg)(struct device *, unsigned int);
bool (*precious_reg)(struct device *, unsigned int);
bool (*writeable_noinc_reg)(struct device *, unsigned int);
bool (*readable_noinc_reg)(struct device *, unsigned int);
bool disable_locking;
regmap_lock lock;
regmap_unlock unlock;
void *lock_arg;
int (*reg_read)(void *, unsigned int, unsigned int *);
int (*reg_write)(void *, unsigned int, unsigned int);
int (*reg_update_bits)(void *, unsigned int, unsigned int, unsigned int);
int (*read)(void *, const void *, size_t, void *, size_t);
int (*write)(void *, const void *, size_t);
size_t max_raw_read;
size_t max_raw_write;
bool fast_io;
bool io_port;
unsigned int max_register;
const struct regmap_access_table *wr_table;
const struct regmap_access_table *rd_table;
const struct regmap_access_table *volatile_table;
const struct regmap_access_table *precious_table;
const struct regmap_access_table *wr_noinc_table;
const struct regmap_access_table *rd_noinc_table;
const struct reg_default *reg_defaults;
unsigned int num_reg_defaults;
enum regcache_type cache_type;
const void *reg_defaults_raw;
unsigned int num_reg_defaults_raw;
long unsigned int read_flag_mask;
long unsigned int write_flag_mask;
bool zero_flag_mask;
bool use_single_read;
bool use_single_write;
bool use_relaxed_mmio;
bool can_multi_write;
enum regmap_endian reg_format_endian;
enum regmap_endian val_format_endian;
const struct regmap_range_cfg *ranges;
unsigned int num_ranges;
bool use_hwlock;
bool use_raw_spinlock;
unsigned int hwlock_id;
unsigned int hwlock_mode;
bool can_sleep;
};
struct regmap_range_cfg {
const char *name;
unsigned int range_min;
unsigned int range_max;
unsigned int selector_reg;
unsigned int selector_mask;
int selector_shift;
unsigned int window_start;
unsigned int window_len;
};
struct regmap;
struct syscon {
struct device_node *np;
struct regmap *regmap;
struct list_head list;
};
struct sg_io_v4 {
__s32 guard;
__u32 protocol;
__u32 subprotocol;
__u32 request_len;
__u64 request;
__u64 request_tag;
__u32 request_attr;
__u32 request_priority;
__u32 request_extra;
__u32 max_response_len;
__u64 response;
__u32 dout_iovec_count;
__u32 dout_xfer_len;
__u32 din_iovec_count;
__u32 din_xfer_len;
__u64 dout_xferp;
__u64 din_xferp;
__u32 timeout;
__u32 flags;
__u64 usr_ptr;
__u32 spare_in;
__u32 driver_status;
__u32 transport_status;
__u32 device_status;
__u32 retry_delay;
__u32 info;
__u32 duration;
__u32 response_len;
__s32 din_resid;
__s32 dout_resid;
__u64 generated_tag;
__u32 spare_out;
__u32 padding;
};
typedef int bsg_sg_io_fn(struct request_queue *, struct sg_io_v4 *, fmode_t, unsigned int);
struct execute_work {
struct work_struct work;
};
enum sam_status {
SAM_STAT_GOOD = 0,
SAM_STAT_CHECK_CONDITION = 2,
SAM_STAT_CONDITION_MET = 4,
SAM_STAT_BUSY = 8,
SAM_STAT_INTERMEDIATE = 16,
SAM_STAT_INTERMEDIATE_CONDITION_MET = 20,
SAM_STAT_RESERVATION_CONFLICT = 24,
SAM_STAT_COMMAND_TERMINATED = 34,
SAM_STAT_TASK_SET_FULL = 40,
SAM_STAT_ACA_ACTIVE = 48,
SAM_STAT_TASK_ABORTED = 64,
};
struct rq_map_data {
struct page **pages;
long unsigned int offset;
short unsigned int page_order;
short unsigned int nr_entries;
bool null_mapped;
bool from_user;
};
typedef __u64 blist_flags_t;
enum scsi_device_state {
SDEV_CREATED = 1,
SDEV_RUNNING = 2,
SDEV_CANCEL = 3,
SDEV_DEL = 4,
SDEV_QUIESCE = 5,
SDEV_OFFLINE = 6,
SDEV_TRANSPORT_OFFLINE = 7,
SDEV_BLOCK = 8,
SDEV_CREATED_BLOCK = 9,
};
struct scsi_vpd {
struct callback_head rcu;
int len;
unsigned char data[0];
};
struct Scsi_Host;
struct scsi_target;
struct scsi_device_handler;
struct bsg_device;
struct scsi_device {
struct Scsi_Host *host;
struct request_queue *request_queue;
struct list_head siblings;
struct list_head same_target_siblings;
struct sbitmap budget_map;
atomic_t device_blocked;
atomic_t restarts;
spinlock_t list_lock;
struct list_head starved_entry;
short unsigned int queue_depth;
short unsigned int max_queue_depth;
short unsigned int last_queue_full_depth;
short unsigned int last_queue_full_count;
long unsigned int last_queue_full_time;
long unsigned int queue_ramp_up_period;
long unsigned int last_queue_ramp_up;
unsigned int id;
unsigned int channel;
u64 lun;
unsigned int manufacturer;
unsigned int sector_size;
void *hostdata;
unsigned char type;
char scsi_level;
char inq_periph_qual;
struct mutex inquiry_mutex;
unsigned char inquiry_len;
unsigned char *inquiry;
const char *vendor;
const char *model;
const char *rev;
struct scsi_vpd *vpd_pg0;
struct scsi_vpd *vpd_pg83;
struct scsi_vpd *vpd_pg80;
struct scsi_vpd *vpd_pg89;
struct scsi_vpd *vpd_pgb0;
struct scsi_vpd *vpd_pgb1;
struct scsi_vpd *vpd_pgb2;
struct scsi_target *sdev_target;
long: 32;
blist_flags_t sdev_bflags;
unsigned int eh_timeout;
unsigned int removable: 1;
unsigned int changed: 1;
unsigned int busy: 1;
unsigned int lockable: 1;
unsigned int locked: 1;
unsigned int borken: 1;
unsigned int disconnect: 1;
unsigned int soft_reset: 1;
unsigned int sdtr: 1;
unsigned int wdtr: 1;
unsigned int ppr: 1;
unsigned int tagged_supported: 1;
unsigned int simple_tags: 1;
unsigned int was_reset: 1;
unsigned int expecting_cc_ua: 1;
unsigned int use_10_for_rw: 1;
unsigned int use_10_for_ms: 1;
unsigned int set_dbd_for_ms: 1;
unsigned int no_report_opcodes: 1;
unsigned int no_write_same: 1;
unsigned int use_16_for_rw: 1;
unsigned int skip_ms_page_8: 1;
unsigned int skip_ms_page_3f: 1;
unsigned int skip_vpd_pages: 1;
unsigned int try_vpd_pages: 1;
unsigned int use_192_bytes_for_3f: 1;
unsigned int no_start_on_add: 1;
unsigned int allow_restart: 1;
unsigned int manage_start_stop: 1;
unsigned int start_stop_pwr_cond: 1;
unsigned int no_uld_attach: 1;
unsigned int select_no_atn: 1;
unsigned int fix_capacity: 1;
unsigned int guess_capacity: 1;
unsigned int retry_hwerror: 1;
unsigned int last_sector_bug: 1;
unsigned int no_read_disc_info: 1;
unsigned int no_read_capacity_16: 1;
unsigned int try_rc_10_first: 1;
unsigned int security_supported: 1;
unsigned int is_visible: 1;
unsigned int wce_default_on: 1;
unsigned int no_dif: 1;
unsigned int broken_fua: 1;
unsigned int lun_in_cdb: 1;
unsigned int unmap_limit_for_ws: 1;
unsigned int rpm_autosuspend: 1;
unsigned int ignore_media_change: 1;
unsigned int silence_suspend: 1;
unsigned int queue_stopped;
bool offline_already;
atomic_t disk_events_disable_depth;
long unsigned int supported_events[1];
long unsigned int pending_events[1];
struct list_head event_list;
struct work_struct event_work;
unsigned int max_device_blocked;
atomic_t iorequest_cnt;
atomic_t iodone_cnt;
atomic_t ioerr_cnt;
atomic_t iotmo_cnt;
long: 32;
struct device sdev_gendev;
struct device sdev_dev;
struct execute_work ew;
struct work_struct requeue_work;
struct scsi_device_handler *handler;
void *handler_data;
size_t dma_drain_len;
void *dma_drain_buf;
unsigned int sg_timeout;
unsigned int sg_reserved_size;
struct bsg_device *bsg_dev;
unsigned char access_state;
struct mutex state_mutex;
enum scsi_device_state sdev_state;
struct task_struct *quiesced_by;
long unsigned int sdev_data[0];
};
enum scsi_target_state {
STARGET_CREATED = 1,
STARGET_RUNNING = 2,
STARGET_REMOVE = 3,
STARGET_CREATED_REMOVE = 4,
STARGET_DEL = 5,
};
struct scsi_target {
struct scsi_device *starget_sdev_user;
struct list_head siblings;
struct list_head devices;
long: 32;
struct device dev;
struct kref reap_ref;
unsigned int channel;
unsigned int id;
unsigned int create: 1;
unsigned int single_lun: 1;
unsigned int pdt_1f_for_no_lun: 1;
unsigned int no_report_luns: 1;
unsigned int expecting_lun_change: 1;
atomic_t target_busy;
atomic_t target_blocked;
unsigned int can_queue;
unsigned int max_target_blocked;
char scsi_level;
enum scsi_target_state state;
void *hostdata;
long unsigned int starget_data[0];
long: 32;
};
struct scsi_data_buffer {
struct sg_table table;
unsigned int length;
};
enum scsi_cmnd_submitter {
SUBMITTED_BY_BLOCK_LAYER = 0,
SUBMITTED_BY_SCSI_ERROR_HANDLER = 1,
SUBMITTED_BY_SCSI_RESET_IOCTL = 2,
} __attribute__((mode(byte)));
struct scsi_cmnd {
struct scsi_device *device;
struct list_head eh_entry;
struct delayed_work abort_work;
struct callback_head rcu;
int eh_eflags;
int budget_token;
long unsigned int jiffies_at_alloc;
int retries;
int allowed;
unsigned char prot_op;
unsigned char prot_type;
unsigned char prot_flags;
enum scsi_cmnd_submitter submitter;
short unsigned int cmd_len;
enum dma_data_direction sc_data_direction;
unsigned char cmnd[32];
struct scsi_data_buffer sdb;
struct scsi_data_buffer *prot_sdb;
unsigned int underflow;
unsigned int transfersize;
unsigned int resid_len;
unsigned int sense_len;
unsigned char *sense_buffer;
int flags;
long unsigned int state;
unsigned int extra_len;
unsigned char *host_scribble;
int result;
};
typedef unsigned char u_char;
typedef unsigned int u_int;
typedef long unsigned int u_long;
struct mtd_ecc_stats {
__u32 corrected;
__u32 failed;
__u32 badblocks;
__u32 bbtblocks;
};
struct mtd_debug_info {
struct dentry *dfs_dir;
};
struct mtd_part {
struct list_head node;
u64 offset;
u64 size;
u32 flags;
long: 32;
};
struct mtd_master {
struct mutex partitions_lock;
struct mutex chrdev_lock;
unsigned int suspended: 1;
};
struct mtd_ooblayout_ops;
struct mtd_pairing_scheme;
struct mtd_erase_region_info;
struct erase_info;
struct mtd_oob_ops;
struct otp_info;
struct nvmem_device;
struct mtd_info {
u_char type;
uint32_t flags;
uint64_t size;
uint32_t erasesize;
uint32_t writesize;
uint32_t writebufsize;
uint32_t oobsize;
uint32_t oobavail;
unsigned int erasesize_shift;
unsigned int writesize_shift;
unsigned int erasesize_mask;
unsigned int writesize_mask;
unsigned int bitflip_threshold;
const char *name;
int index;
const struct mtd_ooblayout_ops *ooblayout;
const struct mtd_pairing_scheme *pairing;
unsigned int ecc_step_size;
unsigned int ecc_strength;
int numeraseregions;
struct mtd_erase_region_info *eraseregions;
int (*_erase)(struct mtd_info *, struct erase_info *);
int (*_point)(struct mtd_info *, loff_t, size_t, size_t *, void **, resource_size_t *);
int (*_unpoint)(struct mtd_info *, loff_t, size_t);
int (*_read)(struct mtd_info *, loff_t, size_t, size_t *, u_char *);
int (*_write)(struct mtd_info *, loff_t, size_t, size_t *, const u_char *);
int (*_panic_write)(struct mtd_info *, loff_t, size_t, size_t *, const u_char *);
int (*_read_oob)(struct mtd_info *, loff_t, struct mtd_oob_ops *);
int (*_write_oob)(struct mtd_info *, loff_t, struct mtd_oob_ops *);
int (*_get_fact_prot_info)(struct mtd_info *, size_t, size_t *, struct otp_info *);
int (*_read_fact_prot_reg)(struct mtd_info *, loff_t, size_t, size_t *, u_char *);
int (*_get_user_prot_info)(struct mtd_info *, size_t, size_t *, struct otp_info *);
int (*_read_user_prot_reg)(struct mtd_info *, loff_t, size_t, size_t *, u_char *);
int (*_write_user_prot_reg)(struct mtd_info *, loff_t, size_t, size_t *, const u_char *);
int (*_lock_user_prot_reg)(struct mtd_info *, loff_t, size_t);
int (*_erase_user_prot_reg)(struct mtd_info *, loff_t, size_t);
int (*_writev)(struct mtd_info *, const struct kvec *, long unsigned int, loff_t, size_t *);
void (*_sync)(struct mtd_info *);
int (*_lock)(struct mtd_info *, loff_t, uint64_t);
int (*_unlock)(struct mtd_info *, loff_t, uint64_t);
int (*_is_locked)(struct mtd_info *, loff_t, uint64_t);
int (*_block_isreserved)(struct mtd_info *, loff_t);
int (*_block_isbad)(struct mtd_info *, loff_t);
int (*_block_markbad)(struct mtd_info *, loff_t);
int (*_max_bad_blocks)(struct mtd_info *, loff_t, size_t);
int (*_suspend)(struct mtd_info *);
void (*_resume)(struct mtd_info *);
void (*_reboot)(struct mtd_info *);
int (*_get_device)(struct mtd_info *);
void (*_put_device)(struct mtd_info *);
bool oops_panic_write;
struct notifier_block reboot_notifier;
struct mtd_ecc_stats ecc_stats;
int subpage_sft;
void *priv;
struct module *owner;
struct device dev;
int usecount;
struct mtd_debug_info dbg;
struct nvmem_device *nvmem;
struct nvmem_device *otp_user_nvmem;
struct nvmem_device *otp_factory_nvmem;
struct mtd_info *parent;
struct list_head partitions;
struct mtd_part part;
struct mtd_master master;
long: 32;
};
struct blkpg_ioctl_arg {
int op;
int flags;
int datalen;
void *data;
};
struct blkpg_partition {
long long int start;
long long int length;
int pno;
char devname[64];
char volname[64];
long: 32;
};
struct erase_info_user {
__u32 start;
__u32 length;
};
struct erase_info_user64 {
__u64 start;
__u64 length;
};
struct mtd_oob_buf {
__u32 start;
__u32 length;
unsigned char *ptr;
};
struct mtd_oob_buf64 {
__u64 start;
__u32 pad;
__u32 length;
__u64 usr_ptr;
};
enum {
MTD_OPS_PLACE_OOB = 0,
MTD_OPS_AUTO_OOB = 1,
MTD_OPS_RAW = 2,
};
struct mtd_write_req {
__u64 start;
__u64 len;
__u64 ooblen;
__u64 usr_data;
__u64 usr_oob;
__u8 mode;
__u8 padding[7];
};
struct mtd_read_req_ecc_stats {
__u32 uncorrectable_errors;
__u32 corrected_bitflips;
__u32 max_bitflips;
};
struct mtd_read_req {
__u64 start;
__u64 len;
__u64 ooblen;
__u64 usr_data;
__u64 usr_oob;
__u8 mode;
__u8 padding[7];
struct mtd_read_req_ecc_stats ecc_stats;
long: 32;
};
struct mtd_info_user {
__u8 type;
__u32 flags;
__u32 size;
__u32 erasesize;
__u32 writesize;
__u32 oobsize;
__u64 padding;
};
struct region_info_user {
__u32 offset;
__u32 erasesize;
__u32 numblocks;
__u32 regionindex;
};
struct otp_info {
__u32 start;
__u32 length;
__u32 locked;
};
struct nand_oobinfo {
__u32 useecc;
__u32 eccbytes;
__u32 oobfree[16];
__u32 eccpos[32];
};
struct nand_oobfree {
__u32 offset;
__u32 length;
};
struct nand_ecclayout_user {
__u32 eccbytes;
__u32 eccpos[64];
__u32 oobavail;
struct nand_oobfree oobfree[8];
};
enum mtd_file_modes {
MTD_FILE_MODE_NORMAL = 0,
MTD_FILE_MODE_OTP_FACTORY = 1,
MTD_FILE_MODE_OTP_USER = 2,
MTD_FILE_MODE_RAW = 3,
};
struct erase_info {
uint64_t addr;
uint64_t len;
uint64_t fail_addr;
};
struct mtd_erase_region_info {
uint64_t offset;
uint32_t erasesize;
uint32_t numblocks;
long unsigned int *lockmap;
long: 32;
};
struct mtd_req_stats {
unsigned int uncorrectable_errors;
unsigned int corrected_bitflips;
unsigned int max_bitflips;
};
struct mtd_oob_ops {
unsigned int mode;
size_t len;
size_t retlen;
size_t ooblen;
size_t oobretlen;
uint32_t ooboffs;
uint8_t *datbuf;
uint8_t *oobbuf;
struct mtd_req_stats *stats;
};
struct mtd_oob_region {
u32 offset;
u32 length;
};
struct mtd_ooblayout_ops {
int (*ecc)(struct mtd_info *, int, struct mtd_oob_region *);
int (*free)(struct mtd_info *, int, struct mtd_oob_region *);
};
struct mtd_pairing_info {
int pair;
int group;
};
struct mtd_pairing_scheme {
int ngroups;
int (*get_info)(struct mtd_info *, int, struct mtd_pairing_info *);
int (*get_wunit)(struct mtd_info *, const struct mtd_pairing_info *);
};
struct mtd_chip_driver;
struct map_info {
const char *name;
long unsigned int size;
resource_size_t phys;
void *virt;
void *cached;
int swap;
int bankwidth;
void (*inval_cache)(struct map_info *, long unsigned int, ssize_t);
void (*set_vpp)(struct map_info *, int);
long unsigned int pfow_base;
long unsigned int map_priv_1;
long unsigned int map_priv_2;
struct device_node *device_node;
void *fldrv_priv;
struct mtd_chip_driver *fldrv;
};
struct mtd_chip_driver {
struct mtd_info * (*probe)(struct map_info *);
void (*destroy)(struct mtd_info *);
struct module *module;
char *name;
struct list_head list;
};
struct mtd_file_info {
struct mtd_info *mtd;
enum mtd_file_modes mode;
};
struct ethtool_wolinfo {
__u32 cmd;
__u32 supported;
__u32 wolopts;
__u8 sopass[6];
};
struct ethtool_tunable {
__u32 cmd;
__u32 id;
__u32 type_id;
__u32 len;
void *data[0];
};
struct ethtool_eeprom {
__u32 cmd;
__u32 magic;
__u32 offset;
__u32 len;
__u8 data[0];
};
struct ethtool_modinfo {
__u32 cmd;
__u32 type;
__u32 eeprom_len;
__u32 reserved[8];
};
struct ethtool_stats {
__u32 cmd;
__u32 n_stats;
__u64 data[0];
};
struct ethtool_ts_info {
__u32 cmd;
__u32 so_timestamping;
__s32 phc_index;
__u32 tx_types;
__u32 tx_reserved[3];
__u32 rx_filters;
__u32 rx_reserved[3];
};
enum ethtool_link_mode_bit_indices {
ETHTOOL_LINK_MODE_10baseT_Half_BIT = 0,
ETHTOOL_LINK_MODE_10baseT_Full_BIT = 1,
ETHTOOL_LINK_MODE_100baseT_Half_BIT = 2,
ETHTOOL_LINK_MODE_100baseT_Full_BIT = 3,
ETHTOOL_LINK_MODE_1000baseT_Half_BIT = 4,
ETHTOOL_LINK_MODE_1000baseT_Full_BIT = 5,
ETHTOOL_LINK_MODE_Autoneg_BIT = 6,
ETHTOOL_LINK_MODE_TP_BIT = 7,
ETHTOOL_LINK_MODE_AUI_BIT = 8,
ETHTOOL_LINK_MODE_MII_BIT = 9,
ETHTOOL_LINK_MODE_FIBRE_BIT = 10,
ETHTOOL_LINK_MODE_BNC_BIT = 11,
ETHTOOL_LINK_MODE_10000baseT_Full_BIT = 12,
ETHTOOL_LINK_MODE_Pause_BIT = 13,
ETHTOOL_LINK_MODE_Asym_Pause_BIT = 14,
ETHTOOL_LINK_MODE_2500baseX_Full_BIT = 15,
ETHTOOL_LINK_MODE_Backplane_BIT = 16,
ETHTOOL_LINK_MODE_1000baseKX_Full_BIT = 17,
ETHTOOL_LINK_MODE_10000baseKX4_Full_BIT = 18,
ETHTOOL_LINK_MODE_10000baseKR_Full_BIT = 19,
ETHTOOL_LINK_MODE_10000baseR_FEC_BIT = 20,
ETHTOOL_LINK_MODE_20000baseMLD2_Full_BIT = 21,
ETHTOOL_LINK_MODE_20000baseKR2_Full_BIT = 22,
ETHTOOL_LINK_MODE_40000baseKR4_Full_BIT = 23,
ETHTOOL_LINK_MODE_40000baseCR4_Full_BIT = 24,
ETHTOOL_LINK_MODE_40000baseSR4_Full_BIT = 25,
ETHTOOL_LINK_MODE_40000baseLR4_Full_BIT = 26,
ETHTOOL_LINK_MODE_56000baseKR4_Full_BIT = 27,
ETHTOOL_LINK_MODE_56000baseCR4_Full_BIT = 28,
ETHTOOL_LINK_MODE_56000baseSR4_Full_BIT = 29,
ETHTOOL_LINK_MODE_56000baseLR4_Full_BIT = 30,
ETHTOOL_LINK_MODE_25000baseCR_Full_BIT = 31,
ETHTOOL_LINK_MODE_25000baseKR_Full_BIT = 32,
ETHTOOL_LINK_MODE_25000baseSR_Full_BIT = 33,
ETHTOOL_LINK_MODE_50000baseCR2_Full_BIT = 34,
ETHTOOL_LINK_MODE_50000baseKR2_Full_BIT = 35,
ETHTOOL_LINK_MODE_100000baseKR4_Full_BIT = 36,
ETHTOOL_LINK_MODE_100000baseSR4_Full_BIT = 37,
ETHTOOL_LINK_MODE_100000baseCR4_Full_BIT = 38,
ETHTOOL_LINK_MODE_100000baseLR4_ER4_Full_BIT = 39,
ETHTOOL_LINK_MODE_50000baseSR2_Full_BIT = 40,
ETHTOOL_LINK_MODE_1000baseX_Full_BIT = 41,
ETHTOOL_LINK_MODE_10000baseCR_Full_BIT = 42,
ETHTOOL_LINK_MODE_10000baseSR_Full_BIT = 43,
ETHTOOL_LINK_MODE_10000baseLR_Full_BIT = 44,
ETHTOOL_LINK_MODE_10000baseLRM_Full_BIT = 45,
ETHTOOL_LINK_MODE_10000baseER_Full_BIT = 46,
ETHTOOL_LINK_MODE_2500baseT_Full_BIT = 47,
ETHTOOL_LINK_MODE_5000baseT_Full_BIT = 48,
ETHTOOL_LINK_MODE_FEC_NONE_BIT = 49,
ETHTOOL_LINK_MODE_FEC_RS_BIT = 50,
ETHTOOL_LINK_MODE_FEC_BASER_BIT = 51,
ETHTOOL_LINK_MODE_50000baseKR_Full_BIT = 52,
ETHTOOL_LINK_MODE_50000baseSR_Full_BIT = 53,
ETHTOOL_LINK_MODE_50000baseCR_Full_BIT = 54,
ETHTOOL_LINK_MODE_50000baseLR_ER_FR_Full_BIT = 55,
ETHTOOL_LINK_MODE_50000baseDR_Full_BIT = 56,
ETHTOOL_LINK_MODE_100000baseKR2_Full_BIT = 57,
ETHTOOL_LINK_MODE_100000baseSR2_Full_BIT = 58,
ETHTOOL_LINK_MODE_100000baseCR2_Full_BIT = 59,
ETHTOOL_LINK_MODE_100000baseLR2_ER2_FR2_Full_BIT = 60,
ETHTOOL_LINK_MODE_100000baseDR2_Full_BIT = 61,
ETHTOOL_LINK_MODE_200000baseKR4_Full_BIT = 62,
ETHTOOL_LINK_MODE_200000baseSR4_Full_BIT = 63,
ETHTOOL_LINK_MODE_200000baseLR4_ER4_FR4_Full_BIT = 64,
ETHTOOL_LINK_MODE_200000baseDR4_Full_BIT = 65,
ETHTOOL_LINK_MODE_200000baseCR4_Full_BIT = 66,
ETHTOOL_LINK_MODE_100baseT1_Full_BIT = 67,
ETHTOOL_LINK_MODE_1000baseT1_Full_BIT = 68,
ETHTOOL_LINK_MODE_400000baseKR8_Full_BIT = 69,
ETHTOOL_LINK_MODE_400000baseSR8_Full_BIT = 70,
ETHTOOL_LINK_MODE_400000baseLR8_ER8_FR8_Full_BIT = 71,
ETHTOOL_LINK_MODE_400000baseDR8_Full_BIT = 72,
ETHTOOL_LINK_MODE_400000baseCR8_Full_BIT = 73,
ETHTOOL_LINK_MODE_FEC_LLRS_BIT = 74,
ETHTOOL_LINK_MODE_100000baseKR_Full_BIT = 75,
ETHTOOL_LINK_MODE_100000baseSR_Full_BIT = 76,
ETHTOOL_LINK_MODE_100000baseLR_ER_FR_Full_BIT = 77,
ETHTOOL_LINK_MODE_100000baseCR_Full_BIT = 78,
ETHTOOL_LINK_MODE_100000baseDR_Full_BIT = 79,
ETHTOOL_LINK_MODE_200000baseKR2_Full_BIT = 80,
ETHTOOL_LINK_MODE_200000baseSR2_Full_BIT = 81,
ETHTOOL_LINK_MODE_200000baseLR2_ER2_FR2_Full_BIT = 82,
ETHTOOL_LINK_MODE_200000baseDR2_Full_BIT = 83,
ETHTOOL_LINK_MODE_200000baseCR2_Full_BIT = 84,
ETHTOOL_LINK_MODE_400000baseKR4_Full_BIT = 85,
ETHTOOL_LINK_MODE_400000baseSR4_Full_BIT = 86,
ETHTOOL_LINK_MODE_400000baseLR4_ER4_FR4_Full_BIT = 87,
ETHTOOL_LINK_MODE_400000baseDR4_Full_BIT = 88,
ETHTOOL_LINK_MODE_400000baseCR4_Full_BIT = 89,
ETHTOOL_LINK_MODE_100baseFX_Half_BIT = 90,
ETHTOOL_LINK_MODE_100baseFX_Full_BIT = 91,
ETHTOOL_LINK_MODE_10baseT1L_Full_BIT = 92,
__ETHTOOL_LINK_MODE_MASK_NBITS = 93,
};
struct gpio_desc;
struct reset_control;
struct mii_bus;
struct mdio_device {
struct device dev;
struct mii_bus *bus;
char modalias[32];
int (*bus_match)(struct device *, struct device_driver *);
void (*device_free)(struct mdio_device *);
void (*device_remove)(struct mdio_device *);
int addr;
int flags;
struct gpio_desc *reset_gpio;
struct reset_control *reset_ctrl;
unsigned int reset_assert_delay;
unsigned int reset_deassert_delay;
};
struct phy_c45_device_ids {
u32 devices_in_package;
u32 mmds_present;
u32 device_ids[32];
};
enum phy_state {
PHY_DOWN = 0,
PHY_READY = 1,
PHY_HALTED = 2,
PHY_UP = 3,
PHY_RUNNING = 4,
PHY_NOLINK = 5,
PHY_CABLETEST = 6,
};
typedef enum {
PHY_INTERFACE_MODE_NA = 0,
PHY_INTERFACE_MODE_INTERNAL = 1,
PHY_INTERFACE_MODE_MII = 2,
PHY_INTERFACE_MODE_GMII = 3,
PHY_INTERFACE_MODE_SGMII = 4,
PHY_INTERFACE_MODE_TBI = 5,
PHY_INTERFACE_MODE_REVMII = 6,
PHY_INTERFACE_MODE_RMII = 7,
PHY_INTERFACE_MODE_REVRMII = 8,
PHY_INTERFACE_MODE_RGMII = 9,
PHY_INTERFACE_MODE_RGMII_ID = 10,
PHY_INTERFACE_MODE_RGMII_RXID = 11,
PHY_INTERFACE_MODE_RGMII_TXID = 12,
PHY_INTERFACE_MODE_RTBI = 13,
PHY_INTERFACE_MODE_SMII = 14,
PHY_INTERFACE_MODE_XGMII = 15,
PHY_INTERFACE_MODE_XLGMII = 16,
PHY_INTERFACE_MODE_MOCA = 17,
PHY_INTERFACE_MODE_QSGMII = 18,
PHY_INTERFACE_MODE_TRGMII = 19,
PHY_INTERFACE_MODE_100BASEX = 20,
PHY_INTERFACE_MODE_1000BASEX = 21,
PHY_INTERFACE_MODE_2500BASEX = 22,
PHY_INTERFACE_MODE_5GBASER = 23,
PHY_INTERFACE_MODE_RXAUI = 24,
PHY_INTERFACE_MODE_XAUI = 25,
PHY_INTERFACE_MODE_10GBASER = 26,
PHY_INTERFACE_MODE_25GBASER = 27,
PHY_INTERFACE_MODE_USXGMII = 28,
PHY_INTERFACE_MODE_10GKR = 29,
PHY_INTERFACE_MODE_QUSGMII = 30,
PHY_INTERFACE_MODE_1000BASEKX = 31,
PHY_INTERFACE_MODE_MAX = 32,
} phy_interface_t;
struct phylink;
struct pse_control;
struct phy_driver;
struct phy_package_shared;
struct mii_timestamper;
struct phy_device {
struct mdio_device mdio;
struct phy_driver *drv;
u32 phy_id;
struct phy_c45_device_ids c45_ids;
unsigned int is_c45: 1;
unsigned int is_internal: 1;
unsigned int is_pseudo_fixed_link: 1;
unsigned int is_gigabit_capable: 1;
unsigned int has_fixups: 1;
unsigned int suspended: 1;
unsigned int suspended_by_mdio_bus: 1;
unsigned int sysfs_links: 1;
unsigned int loopback_enabled: 1;
unsigned int downshifted_rate: 1;
unsigned int is_on_sfp_module: 1;
unsigned int mac_managed_pm: 1;
unsigned int autoneg: 1;
unsigned int link: 1;
unsigned int autoneg_complete: 1;
unsigned int interrupts: 1;
unsigned int irq_suspended: 1;
unsigned int irq_rerun: 1;
int rate_matching;
enum phy_state state;
u32 dev_flags;
phy_interface_t interface;
int speed;
int duplex;
int port;
int pause;
int asym_pause;
u8 master_slave_get;
u8 master_slave_set;
u8 master_slave_state;
long unsigned int supported[3];
long unsigned int advertising[3];
long unsigned int lp_advertising[3];
long unsigned int adv_old[3];
long unsigned int host_interfaces[1];
u32 eee_broken_modes;
int irq;
void *priv;
struct phy_package_shared *shared;
struct sk_buff *skb;
void *ehdr;
struct nlattr *nest;
struct delayed_work state_queue;
struct mutex lock;
bool sfp_bus_attached;
struct sfp_bus *sfp_bus;
struct phylink *phylink;
struct net_device *attached_dev;
struct mii_timestamper *mii_ts;
struct pse_control *psec;
u8 mdix;
u8 mdix_ctrl;
int pma_extable;
void (*phy_link_change)(struct phy_device *, bool);
void (*adjust_link)(struct net_device *);
const struct macsec_ops *macsec_ops;
long: 32;
};
struct phy_tdr_config {
u32 first;
u32 last;
u32 step;
s8 pair;
};
struct mdio_bus_stats {
u64_stats_t transfers;
u64_stats_t errors;
u64_stats_t writes;
u64_stats_t reads;
struct u64_stats_sync syncp;
long: 32;
};
struct mii_bus {
struct module *owner;
const char *name;
char id[61];
void *priv;
int (*read)(struct mii_bus *, int, int);
int (*write)(struct mii_bus *, int, int, u16);
int (*reset)(struct mii_bus *);
struct mdio_bus_stats stats[32];
struct mutex mdio_lock;
struct device *parent;
enum {
MDIOBUS_ALLOCATED = 1,
MDIOBUS_REGISTERED = 2,
MDIOBUS_UNREGISTERED = 3,
MDIOBUS_RELEASED = 4,
} state;
struct device dev;
struct mdio_device *mdio_map[32];
u32 phy_mask;
u32 phy_ignore_ta_mask;
int irq[32];
int reset_delay_us;
int reset_post_delay_us;
struct gpio_desc *reset_gpiod;
enum {
MDIOBUS_NO_CAP = 0,
MDIOBUS_C22 = 1,
MDIOBUS_C45 = 2,
MDIOBUS_C22_C45 = 3,
} probe_capabilities;
struct mutex shared_lock;
struct phy_package_shared *shared[32];
};
struct mdio_driver_common {
struct device_driver driver;
int flags;
};
struct mii_timestamper {
bool (*rxtstamp)(struct mii_timestamper *, struct sk_buff *, int);
void (*txtstamp)(struct mii_timestamper *, struct sk_buff *, int);
int (*hwtstamp)(struct mii_timestamper *, struct ifreq *);
void (*link_state)(struct mii_timestamper *, struct phy_device *);
int (*ts_info)(struct mii_timestamper *, struct ethtool_ts_info *);
struct device *device;
};
struct phy_package_shared {
int addr;
refcount_t refcnt;
long unsigned int flags;
size_t priv_size;
void *priv;
};
struct phy_driver {
struct mdio_driver_common mdiodrv;
u32 phy_id;
char *name;
u32 phy_id_mask;
const long unsigned int * const features;
u32 flags;
const void *driver_data;
int (*soft_reset)(struct phy_device *);
int (*config_init)(struct phy_device *);
int (*probe)(struct phy_device *);
int (*get_features)(struct phy_device *);
int (*get_rate_matching)(struct phy_device *, phy_interface_t);
int (*suspend)(struct phy_device *);
int (*resume)(struct phy_device *);
int (*config_aneg)(struct phy_device *);
int (*aneg_done)(struct phy_device *);
int (*read_status)(struct phy_device *);
int (*config_intr)(struct phy_device *);
irqreturn_t (*handle_interrupt)(struct phy_device *);
void (*remove)(struct phy_device *);
int (*match_phy_device)(struct phy_device *);
int (*set_wol)(struct phy_device *, struct ethtool_wolinfo *);
void (*get_wol)(struct phy_device *, struct ethtool_wolinfo *);
void (*link_change_notify)(struct phy_device *);
int (*read_mmd)(struct phy_device *, int, u16);
int (*write_mmd)(struct phy_device *, int, u16, u16);
int (*read_page)(struct phy_device *);
int (*write_page)(struct phy_device *, int);
int (*module_info)(struct phy_device *, struct ethtool_modinfo *);
int (*module_eeprom)(struct phy_device *, struct ethtool_eeprom *, u8 *);
int (*cable_test_start)(struct phy_device *);
int (*cable_test_tdr_start)(struct phy_device *, const struct phy_tdr_config *);
int (*cable_test_get_status)(struct phy_device *, bool *);
int (*get_sset_count)(struct phy_device *);
void (*get_strings)(struct phy_device *, u8 *);
void (*get_stats)(struct phy_device *, struct ethtool_stats *, u64 *);
int (*get_tunable)(struct phy_device *, struct ethtool_tunable *, void *);
int (*set_tunable)(struct phy_device *, struct ethtool_tunable *, const void *);
int (*set_loopback)(struct phy_device *, bool);
int (*get_sqi)(struct phy_device *);
int (*get_sqi_max)(struct phy_device *);
};
struct system_device_crosststamp {
ktime_t device;
ktime_t sys_realtime;
ktime_t sys_monoraw;
};
struct msix_entry {
u32 vector;
u16 entry;
};
struct ethhdr {
unsigned char h_dest[6];
unsigned char h_source[6];
__be16 h_proto;
};
enum {
IFLA_VF_LINK_STATE_AUTO = 0,
IFLA_VF_LINK_STATE_ENABLE = 1,
IFLA_VF_LINK_STATE_DISABLE = 2,
__IFLA_VF_LINK_STATE_MAX = 3,
};
struct gro_list {
struct list_head list;
int count;
};
struct napi_struct {
struct list_head poll_list;
long unsigned int state;
int weight;
int defer_hard_irqs_count;
long unsigned int gro_bitmask;
int (*poll)(struct napi_struct *, int);
int poll_owner;
struct net_device *dev;
struct gro_list gro_hash[8];
struct sk_buff *skb;
struct list_head rx_list;
int rx_count;
long: 32;
struct hrtimer timer;
struct list_head dev_list;
struct hlist_node napi_hash_node;
unsigned int napi_id;
struct task_struct *thread;
};
struct hwtstamp_config {
int flags;
int tx_type;
int rx_filter;
};
struct ethtool_drvinfo {
__u32 cmd;
char driver[32];
char version[32];
char fw_version[32];
char bus_info[32];
char erom_version[32];
char reserved2[12];
__u32 n_priv_flags;
__u32 n_stats;
__u32 testinfo_len;
__u32 eedump_len;
__u32 regdump_len;
};
struct ethtool_regs {
__u32 cmd;
__u32 version;
__u32 len;
__u8 data[0];
};
struct ethtool_eee {
__u32 cmd;
__u32 supported;
__u32 advertised;
__u32 lp_advertised;
__u32 eee_active;
__u32 eee_enabled;
__u32 tx_lpi_enabled;
__u32 tx_lpi_timer;
__u32 reserved[2];
};
struct ethtool_coalesce {
__u32 cmd;
__u32 rx_coalesce_usecs;
__u32 rx_max_coalesced_frames;
__u32 rx_coalesce_usecs_irq;
__u32 rx_max_coalesced_frames_irq;
__u32 tx_coalesce_usecs;
__u32 tx_max_coalesced_frames;
__u32 tx_coalesce_usecs_irq;
__u32 tx_max_coalesced_frames_irq;
__u32 stats_block_coalesce_usecs;
__u32 use_adaptive_rx_coalesce;
__u32 use_adaptive_tx_coalesce;
__u32 pkt_rate_low;
__u32 rx_coalesce_usecs_low;
__u32 rx_max_coalesced_frames_low;
__u32 tx_coalesce_usecs_low;
__u32 tx_max_coalesced_frames_low;
__u32 pkt_rate_high;
__u32 rx_coalesce_usecs_high;
__u32 rx_max_coalesced_frames_high;
__u32 tx_coalesce_usecs_high;
__u32 tx_max_coalesced_frames_high;
__u32 rate_sample_interval;
};
struct ethtool_ringparam {
__u32 cmd;
__u32 rx_max_pending;
__u32 rx_mini_max_pending;
__u32 rx_jumbo_max_pending;
__u32 tx_max_pending;
__u32 rx_pending;
__u32 rx_mini_pending;
__u32 rx_jumbo_pending;
__u32 tx_pending;
};
struct ethtool_channels {
__u32 cmd;
__u32 max_rx;
__u32 max_tx;
__u32 max_other;
__u32 max_combined;
__u32 rx_count;
__u32 tx_count;
__u32 other_count;
__u32 combined_count;
};
struct ethtool_pauseparam {
__u32 cmd;
__u32 autoneg;
__u32 rx_pause;
__u32 tx_pause;
};
enum ethtool_link_ext_state {
ETHTOOL_LINK_EXT_STATE_AUTONEG = 0,
ETHTOOL_LINK_EXT_STATE_LINK_TRAINING_FAILURE = 1,
ETHTOOL_LINK_EXT_STATE_LINK_LOGICAL_MISMATCH = 2,
ETHTOOL_LINK_EXT_STATE_BAD_SIGNAL_INTEGRITY = 3,
ETHTOOL_LINK_EXT_STATE_NO_CABLE = 4,
ETHTOOL_LINK_EXT_STATE_CABLE_ISSUE = 5,
ETHTOOL_LINK_EXT_STATE_EEPROM_ISSUE = 6,
ETHTOOL_LINK_EXT_STATE_CALIBRATION_FAILURE = 7,
ETHTOOL_LINK_EXT_STATE_POWER_BUDGET_EXCEEDED = 8,
ETHTOOL_LINK_EXT_STATE_OVERHEAT = 9,
ETHTOOL_LINK_EXT_STATE_MODULE = 10,
};
enum ethtool_link_ext_substate_autoneg {
ETHTOOL_LINK_EXT_SUBSTATE_AN_NO_PARTNER_DETECTED = 1,
ETHTOOL_LINK_EXT_SUBSTATE_AN_ACK_NOT_RECEIVED = 2,
ETHTOOL_LINK_EXT_SUBSTATE_AN_NEXT_PAGE_EXCHANGE_FAILED = 3,
ETHTOOL_LINK_EXT_SUBSTATE_AN_NO_PARTNER_DETECTED_FORCE_MODE = 4,
ETHTOOL_LINK_EXT_SUBSTATE_AN_FEC_MISMATCH_DURING_OVERRIDE = 5,
ETHTOOL_LINK_EXT_SUBSTATE_AN_NO_HCD = 6,
};
enum ethtool_link_ext_substate_link_training {
ETHTOOL_LINK_EXT_SUBSTATE_LT_KR_FRAME_LOCK_NOT_ACQUIRED = 1,
ETHTOOL_LINK_EXT_SUBSTATE_LT_KR_LINK_INHIBIT_TIMEOUT = 2,
ETHTOOL_LINK_EXT_SUBSTATE_LT_KR_LINK_PARTNER_DID_NOT_SET_RECEIVER_READY = 3,
ETHTOOL_LINK_EXT_SUBSTATE_LT_REMOTE_FAULT = 4,
};
enum ethtool_link_ext_substate_link_logical_mismatch {
ETHTOOL_LINK_EXT_SUBSTATE_LLM_PCS_DID_NOT_ACQUIRE_BLOCK_LOCK = 1,
ETHTOOL_LINK_EXT_SUBSTATE_LLM_PCS_DID_NOT_ACQUIRE_AM_LOCK = 2,
ETHTOOL_LINK_EXT_SUBSTATE_LLM_PCS_DID_NOT_GET_ALIGN_STATUS = 3,
ETHTOOL_LINK_EXT_SUBSTATE_LLM_FC_FEC_IS_NOT_LOCKED = 4,
ETHTOOL_LINK_EXT_SUBSTATE_LLM_RS_FEC_IS_NOT_LOCKED = 5,
};
enum ethtool_link_ext_substate_bad_signal_integrity {
ETHTOOL_LINK_EXT_SUBSTATE_BSI_LARGE_NUMBER_OF_PHYSICAL_ERRORS = 1,
ETHTOOL_LINK_EXT_SUBSTATE_BSI_UNSUPPORTED_RATE = 2,
ETHTOOL_LINK_EXT_SUBSTATE_BSI_SERDES_REFERENCE_CLOCK_LOST = 3,
ETHTOOL_LINK_EXT_SUBSTATE_BSI_SERDES_ALOS = 4,
};
enum ethtool_link_ext_substate_cable_issue {
ETHTOOL_LINK_EXT_SUBSTATE_CI_UNSUPPORTED_CABLE = 1,
ETHTOOL_LINK_EXT_SUBSTATE_CI_CABLE_TEST_FAILURE = 2,
};
enum ethtool_link_ext_substate_module {
ETHTOOL_LINK_EXT_SUBSTATE_MODULE_CMIS_NOT_READY = 1,
};
enum ethtool_module_power_mode_policy {
ETHTOOL_MODULE_POWER_MODE_POLICY_HIGH = 1,
ETHTOOL_MODULE_POWER_MODE_POLICY_AUTO = 2,
};
enum ethtool_module_power_mode {
ETHTOOL_MODULE_POWER_MODE_LOW = 1,
ETHTOOL_MODULE_POWER_MODE_HIGH = 2,
};
struct ethtool_test {
__u32 cmd;
__u32 flags;
__u32 reserved;
__u32 len;
__u64 data[0];
};
struct ethtool_tcpip4_spec {
__be32 ip4src;
__be32 ip4dst;
__be16 psrc;
__be16 pdst;
__u8 tos;
};
struct ethtool_ah_espip4_spec {
__be32 ip4src;
__be32 ip4dst;
__be32 spi;
__u8 tos;
};
struct ethtool_usrip4_spec {
__be32 ip4src;
__be32 ip4dst;
__be32 l4_4_bytes;
__u8 tos;
__u8 ip_ver;
__u8 proto;
};
struct ethtool_tcpip6_spec {
__be32 ip6src[4];
__be32 ip6dst[4];
__be16 psrc;
__be16 pdst;
__u8 tclass;
};
struct ethtool_ah_espip6_spec {
__be32 ip6src[4];
__be32 ip6dst[4];
__be32 spi;
__u8 tclass;
};
struct ethtool_usrip6_spec {
__be32 ip6src[4];
__be32 ip6dst[4];
__be32 l4_4_bytes;
__u8 tclass;
__u8 l4_proto;
};
union ethtool_flow_union {
struct ethtool_tcpip4_spec tcp_ip4_spec;
struct ethtool_tcpip4_spec udp_ip4_spec;
struct ethtool_tcpip4_spec sctp_ip4_spec;
struct ethtool_ah_espip4_spec ah_ip4_spec;
struct ethtool_ah_espip4_spec esp_ip4_spec;
struct ethtool_usrip4_spec usr_ip4_spec;
struct ethtool_tcpip6_spec tcp_ip6_spec;
struct ethtool_tcpip6_spec udp_ip6_spec;
struct ethtool_tcpip6_spec sctp_ip6_spec;
struct ethtool_ah_espip6_spec ah_ip6_spec;
struct ethtool_ah_espip6_spec esp_ip6_spec;
struct ethtool_usrip6_spec usr_ip6_spec;
struct ethhdr ether_spec;
__u8 hdata[52];
};
struct ethtool_flow_ext {
__u8 padding[2];
unsigned char h_dest[6];
__be16 vlan_etype;
__be16 vlan_tci;
__be32 data[2];
};
struct ethtool_rx_flow_spec {
__u32 flow_type;
union ethtool_flow_union h_u;
struct ethtool_flow_ext h_ext;
union ethtool_flow_union m_u;
struct ethtool_flow_ext m_ext;
long: 32;
__u64 ring_cookie;
__u32 location;
long: 32;
};
struct ethtool_rxnfc {
__u32 cmd;
__u32 flow_type;
__u64 data;
struct ethtool_rx_flow_spec fs;
union {
__u32 rule_cnt;
__u32 rss_context;
};
__u32 rule_locs[0];
long: 32;
};
struct ethtool_flash {
__u32 cmd;
__u32 region;
char data[128];
};
struct ethtool_dump {
__u32 cmd;
__u32 version;
__u32 flag;
__u32 len;
__u8 data[0];
};
struct ethtool_fecparam {
__u32 cmd;
__u32 active_fec;
__u32 fec;
__u32 reserved;
};
struct ethtool_link_settings {
__u32 cmd;
__u32 speed;
__u8 duplex;
__u8 port;
__u8 phy_address;
__u8 autoneg;
__u8 mdio_support;
__u8 eth_tp_mdix;
__u8 eth_tp_mdix_ctrl;
__s8 link_mode_masks_nwords;
__u8 transceiver;
__u8 master_slave_cfg;
__u8 master_slave_state;
__u8 rate_matching;
__u32 reserved[7];
__u32 link_mode_masks[0];
};
struct kernel_ethtool_ringparam {
u32 rx_buf_len;
u8 tcp_data_split;
u8 tx_push;
u32 cqe_size;
};
struct ethtool_link_ext_state_info {
enum ethtool_link_ext_state link_ext_state;
union {
enum ethtool_link_ext_substate_autoneg autoneg;
enum ethtool_link_ext_substate_link_training link_training;
enum ethtool_link_ext_substate_link_logical_mismatch link_logical_mismatch;
enum ethtool_link_ext_substate_bad_signal_integrity bad_signal_integrity;
enum ethtool_link_ext_substate_cable_issue cable_issue;
enum ethtool_link_ext_substate_module module;
u32 __link_ext_substate;
};
};
struct ethtool_link_ksettings {
struct ethtool_link_settings base;
struct {
long unsigned int supported[3];
long unsigned int advertising[3];
long unsigned int lp_advertising[3];
} link_modes;
u32 lanes;
};
struct kernel_ethtool_coalesce {
u8 use_cqe_mode_tx;
u8 use_cqe_mode_rx;
};
struct ethtool_eth_mac_stats {
u64 FramesTransmittedOK;
u64 SingleCollisionFrames;
u64 MultipleCollisionFrames;
u64 FramesReceivedOK;
u64 FrameCheckSequenceErrors;
u64 AlignmentErrors;
u64 OctetsTransmittedOK;
u64 FramesWithDeferredXmissions;
u64 LateCollisions;
u64 FramesAbortedDueToXSColls;
u64 FramesLostDueToIntMACXmitError;
u64 CarrierSenseErrors;
u64 OctetsReceivedOK;
u64 FramesLostDueToIntMACRcvError;
u64 MulticastFramesXmittedOK;
u64 BroadcastFramesXmittedOK;
u64 FramesWithExcessiveDeferral;
u64 MulticastFramesReceivedOK;
u64 BroadcastFramesReceivedOK;
u64 InRangeLengthErrors;
u64 OutOfRangeLengthField;
u64 FrameTooLongErrors;
};
struct ethtool_eth_phy_stats {
u64 SymbolErrorDuringCarrier;
};
struct ethtool_eth_ctrl_stats {
u64 MACControlFramesTransmitted;
u64 MACControlFramesReceived;
u64 UnsupportedOpcodesReceived;
};
struct ethtool_pause_stats {
u64 tx_pause_frames;
u64 rx_pause_frames;
};
struct ethtool_fec_stat {
u64 total;
u64 lanes[8];
};
struct ethtool_fec_stats {
struct ethtool_fec_stat corrected_blocks;
struct ethtool_fec_stat uncorrectable_blocks;
struct ethtool_fec_stat corrected_bits;
};
struct ethtool_rmon_hist_range {
u16 low;
u16 high;
};
struct ethtool_rmon_stats {
u64 undersize_pkts;
u64 oversize_pkts;
u64 fragments;
u64 jabbers;
u64 hist[10];
u64 hist_tx[10];
};
struct ethtool_module_eeprom {
u32 offset;
u32 length;
u8 page;
u8 bank;
u8 i2c_address;
u8 *data;
};
struct ethtool_module_power_mode_params {
enum ethtool_module_power_mode_policy policy;
enum ethtool_module_power_mode mode;
};
struct mdio_if_info {
int prtad;
u32 mmds;
unsigned int mode_support;
struct net_device *dev;
int (*mdio_read)(struct net_device *, int, int, u16);
int (*mdio_write)(struct net_device *, int, int, u16, u16);
};
struct cyclecounter {
u64 (*read)(const struct cyclecounter *);
long: 32;
u64 mask;
u32 mult;
u32 shift;
};
struct timecounter {
const struct cyclecounter *cc;
long: 32;
u64 cycle_last;
u64 nsec;
u64 mask;
u64 frac;
};
struct ptp_clock_time {
__s64 sec;
__u32 nsec;
__u32 reserved;
};
struct ptp_extts_request {
unsigned int index;
unsigned int flags;
unsigned int rsv[2];
};
struct ptp_perout_request {
union {
struct ptp_clock_time start;
struct ptp_clock_time phase;
};
struct ptp_clock_time period;
unsigned int index;
unsigned int flags;
union {
struct ptp_clock_time on;
unsigned int rsv[4];
};
};
enum ptp_pin_function {
PTP_PF_NONE = 0,
PTP_PF_EXTTS = 1,
PTP_PF_PEROUT = 2,
PTP_PF_PHYSYNC = 3,
};
struct ptp_pin_desc {
char name[64];
unsigned int index;
unsigned int func;
unsigned int chan;
unsigned int rsv[5];
};
struct ptp_clock_request {
enum {
PTP_CLK_REQ_EXTTS = 0,
PTP_CLK_REQ_PEROUT = 1,
PTP_CLK_REQ_PPS = 2,
} type;
long: 32;
union {
struct ptp_extts_request extts;
struct ptp_perout_request perout;
};
};
struct ptp_system_timestamp {
struct timespec64 pre_ts;
struct timespec64 post_ts;
};
struct ptp_clock_info {
struct module *owner;
char name[32];
s32 max_adj;
int n_alarm;
int n_ext_ts;
int n_per_out;
int n_pins;
int pps;
struct ptp_pin_desc *pin_config;
int (*adjfine)(struct ptp_clock_info *, long int);
int (*adjfreq)(struct ptp_clock_info *, s32);
int (*adjphase)(struct ptp_clock_info *, s32);
int (*adjtime)(struct ptp_clock_info *, s64);
int (*gettime64)(struct ptp_clock_info *, struct timespec64 *);
int (*gettimex64)(struct ptp_clock_info *, struct timespec64 *, struct ptp_system_timestamp *);
int (*getcrosststamp)(struct ptp_clock_info *, struct system_device_crosststamp *);
int (*settime64)(struct ptp_clock_info *, const struct timespec64 *);
int (*getcycles64)(struct ptp_clock_info *, struct timespec64 *);
int (*getcyclesx64)(struct ptp_clock_info *, struct timespec64 *, struct ptp_system_timestamp *);
int (*getcrosscycles)(struct ptp_clock_info *, struct system_device_crosststamp *);
int (*enable)(struct ptp_clock_info *, struct ptp_clock_request *, int);
int (*verify)(struct ptp_clock_info *, unsigned int, enum ptp_pin_function, unsigned int);
long int (*do_aux_work)(struct ptp_clock_info *);
};
struct ixgbe_thermal_diode_data {
u8 location;
u8 temp;
u8 caution_thresh;
u8 max_op_thresh;
};
struct ixgbe_thermal_sensor_data {
struct ixgbe_thermal_diode_data sensor[3];
};
union ixgbe_adv_tx_desc {
struct {
__le64 buffer_addr;
__le32 cmd_type_len;
__le32 olinfo_status;
} read;
struct {
__le64 rsvd;
__le32 nxtseq_seed;
__le32 status;
} wb;
};
typedef u32 ixgbe_autoneg_advertised;
typedef u32 ixgbe_link_speed;
union ixgbe_atr_input {
struct {
u8 vm_pool;
u8 flow_type;
__be16 vlan_id;
__be32 dst_ip[4];
__be32 src_ip[4];
__be16 src_port;
__be16 dst_port;
__be16 flex_bytes;
__be16 bkt_hash;
} formatted;
__be32 dword_stream[11];
};
enum ixgbe_eeprom_type {
ixgbe_eeprom_uninitialized = 0,
ixgbe_eeprom_spi = 1,
ixgbe_flash = 2,
ixgbe_eeprom_none = 3,
};
enum ixgbe_mac_type {
ixgbe_mac_unknown = 0,
ixgbe_mac_82598EB = 1,
ixgbe_mac_82599EB = 2,
ixgbe_mac_X540 = 3,
ixgbe_mac_X550 = 4,
ixgbe_mac_X550EM_x = 5,
ixgbe_mac_x550em_a = 6,
ixgbe_num_macs = 7,
};
enum ixgbe_phy_type {
ixgbe_phy_unknown = 0,
ixgbe_phy_none = 1,
ixgbe_phy_tn = 2,
ixgbe_phy_aq = 3,
ixgbe_phy_x550em_kr = 4,
ixgbe_phy_x550em_kx4 = 5,
ixgbe_phy_x550em_xfi = 6,
ixgbe_phy_x550em_ext_t = 7,
ixgbe_phy_ext_1g_t = 8,
ixgbe_phy_cu_unknown = 9,
ixgbe_phy_qt = 10,
ixgbe_phy_xaui = 11,
ixgbe_phy_nl = 12,
ixgbe_phy_sfp_passive_tyco = 13,
ixgbe_phy_sfp_passive_unknown = 14,
ixgbe_phy_sfp_active_unknown = 15,
ixgbe_phy_sfp_avago = 16,
ixgbe_phy_sfp_ftl = 17,
ixgbe_phy_sfp_ftl_active = 18,
ixgbe_phy_sfp_unknown = 19,
ixgbe_phy_sfp_intel = 20,
ixgbe_phy_qsfp_passive_unknown = 21,
ixgbe_phy_qsfp_active_unknown = 22,
ixgbe_phy_qsfp_intel = 23,
ixgbe_phy_qsfp_unknown = 24,
ixgbe_phy_sfp_unsupported = 25,
ixgbe_phy_sgmii = 26,
ixgbe_phy_fw = 27,
ixgbe_phy_generic = 28,
};
enum ixgbe_sfp_type {
ixgbe_sfp_type_da_cu = 0,
ixgbe_sfp_type_sr = 1,
ixgbe_sfp_type_lr = 2,
ixgbe_sfp_type_da_cu_core0 = 3,
ixgbe_sfp_type_da_cu_core1 = 4,
ixgbe_sfp_type_srlr_core0 = 5,
ixgbe_sfp_type_srlr_core1 = 6,
ixgbe_sfp_type_da_act_lmt_core0 = 7,
ixgbe_sfp_type_da_act_lmt_core1 = 8,
ixgbe_sfp_type_1g_cu_core0 = 9,
ixgbe_sfp_type_1g_cu_core1 = 10,
ixgbe_sfp_type_1g_sx_core0 = 11,
ixgbe_sfp_type_1g_sx_core1 = 12,
ixgbe_sfp_type_1g_lx_core0 = 13,
ixgbe_sfp_type_1g_lx_core1 = 14,
ixgbe_sfp_type_not_present = 65534,
ixgbe_sfp_type_unknown = 65535,
};
enum ixgbe_media_type {
ixgbe_media_type_unknown = 0,
ixgbe_media_type_fiber = 1,
ixgbe_media_type_fiber_qsfp = 2,
ixgbe_media_type_fiber_lco = 3,
ixgbe_media_type_copper = 4,
ixgbe_media_type_backplane = 5,
ixgbe_media_type_cx4 = 6,
ixgbe_media_type_virtual = 7,
};
enum ixgbe_fc_mode {
ixgbe_fc_none = 0,
ixgbe_fc_rx_pause = 1,
ixgbe_fc_tx_pause = 2,
ixgbe_fc_full = 3,
ixgbe_fc_default = 4,
};
enum ixgbe_smart_speed {
ixgbe_smart_speed_auto = 0,
ixgbe_smart_speed_on = 1,
ixgbe_smart_speed_off = 2,
};
enum ixgbe_bus_type {
ixgbe_bus_type_unknown = 0,
ixgbe_bus_type_pci_express = 1,
ixgbe_bus_type_internal = 2,
ixgbe_bus_type_reserved = 3,
};
enum ixgbe_bus_speed {
ixgbe_bus_speed_unknown = 0,
ixgbe_bus_speed_33 = 33,
ixgbe_bus_speed_66 = 66,
ixgbe_bus_speed_100 = 100,
ixgbe_bus_speed_120 = 120,
ixgbe_bus_speed_133 = 133,
ixgbe_bus_speed_2500 = 2500,
ixgbe_bus_speed_5000 = 5000,
ixgbe_bus_speed_8000 = 8000,
ixgbe_bus_speed_reserved = 8001,
};
enum ixgbe_bus_width {
ixgbe_bus_width_unknown = 0,
ixgbe_bus_width_pcie_x1 = 1,
ixgbe_bus_width_pcie_x2 = 2,
ixgbe_bus_width_pcie_x4 = 4,
ixgbe_bus_width_pcie_x8 = 8,
ixgbe_bus_width_32 = 32,
ixgbe_bus_width_64 = 64,
ixgbe_bus_width_reserved = 65,
};
struct ixgbe_addr_filter_info {
u32 num_mc_addrs;
u32 rar_used_count;
u32 mta_in_use;
u32 overflow_promisc;
bool uc_set_promisc;
bool user_set_promisc;
};
struct ixgbe_bus_info {
enum ixgbe_bus_speed speed;
enum ixgbe_bus_width width;
enum ixgbe_bus_type type;
u8 func;
u8 lan_id;
u8 instance_id;
};
struct ixgbe_fc_info {
u32 high_water[8];
u32 low_water[8];
u16 pause_time;
bool send_xon;
bool strict_ieee;
bool disable_fc_autoneg;
bool fc_was_autonegged;
enum ixgbe_fc_mode current_mode;
enum ixgbe_fc_mode requested_mode;
};
struct ixgbe_hw_stats {
u64 crcerrs;
u64 illerrc;
u64 errbc;
u64 mspdc;
u64 mpctotal;
u64 mpc[8];
u64 mlfc;
u64 mrfc;
u64 rlec;
u64 lxontxc;
u64 lxonrxc;
u64 lxofftxc;
u64 lxoffrxc;
u64 pxontxc[8];
u64 pxonrxc[8];
u64 pxofftxc[8];
u64 pxoffrxc[8];
u64 prc64;
u64 prc127;
u64 prc255;
u64 prc511;
u64 prc1023;
u64 prc1522;
u64 gprc;
u64 bprc;
u64 mprc;
u64 gptc;
u64 gorc;
u64 gotc;
u64 rnbc[8];
u64 ruc;
u64 rfc;
u64 roc;
u64 rjc;
u64 mngprc;
u64 mngpdc;
u64 mngptc;
u64 tor;
u64 tpr;
u64 tpt;
u64 ptc64;
u64 ptc127;
u64 ptc255;
u64 ptc511;
u64 ptc1023;
u64 ptc1522;
u64 mptc;
u64 bptc;
u64 xec;
u64 rqsmr[16];
u64 tqsmr[8];
u64 qprc[16];
u64 qptc[16];
u64 qbrc[16];
u64 qbtc[16];
u64 qprdc[16];
u64 pxon2offc[8];
u64 fdirustat_add;
u64 fdirustat_remove;
u64 fdirfstat_fadd;
u64 fdirfstat_fremove;
u64 fdirmatch;
u64 fdirmiss;
u64 fccrc;
u64 fcoerpdc;
u64 fcoeprc;
u64 fcoeptc;
u64 fcoedwrc;
u64 fcoedwtc;
u64 fcoe_noddp;
u64 fcoe_noddp_ext_buff;
u64 b2ospc;
u64 b2ogprc;
u64 o2bgptc;
u64 o2bspc;
};
struct ixgbe_hw;
struct ixgbe_eeprom_operations {
s32 (*init_params)(struct ixgbe_hw *);
s32 (*read)(struct ixgbe_hw *, u16, u16 *);
s32 (*read_buffer)(struct ixgbe_hw *, u16, u16, u16 *);
s32 (*write)(struct ixgbe_hw *, u16, u16);
s32 (*write_buffer)(struct ixgbe_hw *, u16, u16, u16 *);
s32 (*validate_checksum)(struct ixgbe_hw *, u16 *);
s32 (*update_checksum)(struct ixgbe_hw *);
s32 (*calc_checksum)(struct ixgbe_hw *);
};
struct ixgbe_mac_operations {
s32 (*init_hw)(struct ixgbe_hw *);
s32 (*reset_hw)(struct ixgbe_hw *);
s32 (*start_hw)(struct ixgbe_hw *);
s32 (*clear_hw_cntrs)(struct ixgbe_hw *);
enum ixgbe_media_type (*get_media_type)(struct ixgbe_hw *);
s32 (*get_mac_addr)(struct ixgbe_hw *, u8 *);
s32 (*get_san_mac_addr)(struct ixgbe_hw *, u8 *);
s32 (*get_device_caps)(struct ixgbe_hw *, u16 *);
s32 (*get_wwn_prefix)(struct ixgbe_hw *, u16 *, u16 *);
s32 (*stop_adapter)(struct ixgbe_hw *);
s32 (*get_bus_info)(struct ixgbe_hw *);
void (*set_lan_id)(struct ixgbe_hw *);
s32 (*read_analog_reg8)(struct ixgbe_hw *, u32, u8 *);
s32 (*write_analog_reg8)(struct ixgbe_hw *, u32, u8);
s32 (*setup_sfp)(struct ixgbe_hw *);
s32 (*disable_rx_buff)(struct ixgbe_hw *);
s32 (*enable_rx_buff)(struct ixgbe_hw *);
s32 (*enable_rx_dma)(struct ixgbe_hw *, u32);
s32 (*acquire_swfw_sync)(struct ixgbe_hw *, u32);
void (*release_swfw_sync)(struct ixgbe_hw *, u32);
void (*init_swfw_sync)(struct ixgbe_hw *);
s32 (*prot_autoc_read)(struct ixgbe_hw *, bool *, u32 *);
s32 (*prot_autoc_write)(struct ixgbe_hw *, u32, bool);
void (*disable_tx_laser)(struct ixgbe_hw *);
void (*enable_tx_laser)(struct ixgbe_hw *);
void (*flap_tx_laser)(struct ixgbe_hw *);
void (*stop_link_on_d3)(struct ixgbe_hw *);
s32 (*setup_link)(struct ixgbe_hw *, ixgbe_link_speed, bool);
s32 (*setup_mac_link)(struct ixgbe_hw *, ixgbe_link_speed, bool);
s32 (*check_link)(struct ixgbe_hw *, ixgbe_link_speed *, bool *, bool);
s32 (*get_link_capabilities)(struct ixgbe_hw *, ixgbe_link_speed *, bool *);
void (*set_rate_select_speed)(struct ixgbe_hw *, ixgbe_link_speed);
void (*set_rxpba)(struct ixgbe_hw *, int, u32, int);
s32 (*led_on)(struct ixgbe_hw *, u32);
s32 (*led_off)(struct ixgbe_hw *, u32);
s32 (*blink_led_start)(struct ixgbe_hw *, u32);
s32 (*blink_led_stop)(struct ixgbe_hw *, u32);
s32 (*init_led_link_act)(struct ixgbe_hw *);
s32 (*set_rar)(struct ixgbe_hw *, u32, u8 *, u32, u32);
s32 (*clear_rar)(struct ixgbe_hw *, u32);
s32 (*set_vmdq)(struct ixgbe_hw *, u32, u32);
s32 (*set_vmdq_san_mac)(struct ixgbe_hw *, u32);
s32 (*clear_vmdq)(struct ixgbe_hw *, u32, u32);
s32 (*init_rx_addrs)(struct ixgbe_hw *);
s32 (*update_mc_addr_list)(struct ixgbe_hw *, struct net_device *);
s32 (*enable_mc)(struct ixgbe_hw *);
s32 (*disable_mc)(struct ixgbe_hw *);
s32 (*clear_vfta)(struct ixgbe_hw *);
s32 (*set_vfta)(struct ixgbe_hw *, u32, u32, bool, bool);
s32 (*init_uta_tables)(struct ixgbe_hw *);
void (*set_mac_anti_spoofing)(struct ixgbe_hw *, bool, int);
void (*set_vlan_anti_spoofing)(struct ixgbe_hw *, bool, int);
s32 (*fc_enable)(struct ixgbe_hw *);
s32 (*setup_fc)(struct ixgbe_hw *);
void (*fc_autoneg)(struct ixgbe_hw *);
s32 (*set_fw_drv_ver)(struct ixgbe_hw *, u8, u8, u8, u8, u16, const char *);
s32 (*get_thermal_sensor_data)(struct ixgbe_hw *);
s32 (*init_thermal_sensor_thresh)(struct ixgbe_hw *);
bool (*fw_recovery_mode)(struct ixgbe_hw *);
void (*disable_rx)(struct ixgbe_hw *);
void (*enable_rx)(struct ixgbe_hw *);
void (*set_source_address_pruning)(struct ixgbe_hw *, bool, unsigned int);
void (*set_ethertype_anti_spoofing)(struct ixgbe_hw *, bool, int);
s32 (*dmac_config)(struct ixgbe_hw *);
s32 (*dmac_update_tcs)(struct ixgbe_hw *);
s32 (*dmac_config_tcs)(struct ixgbe_hw *);
s32 (*read_iosf_sb_reg)(struct ixgbe_hw *, u32, u32, u32 *);
s32 (*write_iosf_sb_reg)(struct ixgbe_hw *, u32, u32, u32);
};
struct ixgbe_mac_info {
struct ixgbe_mac_operations ops;
enum ixgbe_mac_type type;
u8 addr[6];
u8 perm_addr[6];
u8 san_addr[6];
u16 wwnn_prefix;
u16 wwpn_prefix;
u16 max_msix_vectors;
u32 mta_shadow[128];
s32 mc_filter_type;
u32 mcft_size;
u32 vft_size;
u32 num_rar_entries;
u32 rar_highwater;
u32 rx_pb_size;
u32 max_tx_queues;
u32 max_rx_queues;
u32 orig_autoc;
u32 orig_autoc2;
bool orig_link_settings_stored;
bool autotry_restart;
u8 flags;
u8 san_mac_rar_index;
struct ixgbe_thermal_sensor_data thermal_sensor_data;
bool set_lben;
u8 led_link_act;
};
struct ixgbe_phy_operations {
s32 (*identify)(struct ixgbe_hw *);
s32 (*identify_sfp)(struct ixgbe_hw *);
s32 (*init)(struct ixgbe_hw *);
s32 (*reset)(struct ixgbe_hw *);
s32 (*read_reg)(struct ixgbe_hw *, u32, u32, u16 *);
s32 (*write_reg)(struct ixgbe_hw *, u32, u32, u16);
s32 (*read_reg_mdi)(struct ixgbe_hw *, u32, u32, u16 *);
s32 (*write_reg_mdi)(struct ixgbe_hw *, u32, u32, u16);
s32 (*setup_link)(struct ixgbe_hw *);
s32 (*setup_internal_link)(struct ixgbe_hw *);
s32 (*setup_link_speed)(struct ixgbe_hw *, ixgbe_link_speed, bool);
s32 (*check_link)(struct ixgbe_hw *, ixgbe_link_speed *, bool *);
s32 (*read_i2c_byte)(struct ixgbe_hw *, u8, u8, u8 *);
s32 (*write_i2c_byte)(struct ixgbe_hw *, u8, u8, u8);
s32 (*read_i2c_sff8472)(struct ixgbe_hw *, u8, u8 *);
s32 (*read_i2c_eeprom)(struct ixgbe_hw *, u8, u8 *);
s32 (*write_i2c_eeprom)(struct ixgbe_hw *, u8, u8);
s32 (*check_overtemp)(struct ixgbe_hw *);
s32 (*set_phy_power)(struct ixgbe_hw *, bool);
s32 (*enter_lplu)(struct ixgbe_hw *);
s32 (*handle_lasi)(struct ixgbe_hw *);
s32 (*read_i2c_byte_unlocked)(struct ixgbe_hw *, u8, u8, u8 *);
s32 (*write_i2c_byte_unlocked)(struct ixgbe_hw *, u8, u8, u8);
};
struct ixgbe_phy_info {
struct ixgbe_phy_operations ops;
struct mdio_if_info mdio;
enum ixgbe_phy_type type;
u32 id;
enum ixgbe_sfp_type sfp_type;
bool sfp_setup_needed;
u32 revision;
enum ixgbe_media_type media_type;
u32 phy_semaphore_mask;
bool reset_disable;
ixgbe_autoneg_advertised autoneg_advertised;
ixgbe_link_speed speeds_supported;
ixgbe_link_speed eee_speeds_supported;
ixgbe_link_speed eee_speeds_advertised;
enum ixgbe_smart_speed smart_speed;
bool smart_speed_active;
bool multispeed_fiber;
bool reset_if_overtemp;
bool qsfp_shared_i2c_bus;
u32 nw_mng_if_sel;
};
struct ixgbe_link_operations {
s32 (*read_link)(struct ixgbe_hw *, u8, u16, u16 *);
s32 (*read_link_unlocked)(struct ixgbe_hw *, u8, u16, u16 *);
s32 (*write_link)(struct ixgbe_hw *, u8, u16, u16);
s32 (*write_link_unlocked)(struct ixgbe_hw *, u8, u16, u16);
};
struct ixgbe_link_info {
struct ixgbe_link_operations ops;
u8 addr;
};
struct ixgbe_eeprom_info {
struct ixgbe_eeprom_operations ops;
enum ixgbe_eeprom_type type;
u32 semaphore_delay;
u16 word_size;
u16 address_bits;
u16 word_page_size;
u16 ctrl_word_3;
};
struct ixgbe_mbx_stats {
u32 msgs_tx;
u32 msgs_rx;
u32 acks;
u32 reqs;
u32 rsts;
};
struct ixgbe_mbx_operations;
struct ixgbe_mbx_info {
const struct ixgbe_mbx_operations *ops;
struct ixgbe_mbx_stats stats;
u32 timeout;
u32 usec_delay;
u32 v2p_mailbox;
u16 size;
};
struct ixgbe_hw {
u8 *hw_addr;
void *back;
struct ixgbe_mac_info mac;
struct ixgbe_addr_filter_info addr_ctrl;
struct ixgbe_fc_info fc;
struct ixgbe_phy_info phy;
struct ixgbe_link_info link;
struct ixgbe_eeprom_info eeprom;
struct ixgbe_bus_info bus;
struct ixgbe_mbx_info mbx;
const u32 *mvals;
u16 device_id;
u16 vendor_id;
u16 subsystem_device_id;
u16 subsystem_vendor_id;
u8 revision_id;
bool adapter_stopped;
bool force_full_reset;
bool allow_unsupported_sfp;
bool wol_enabled;
bool need_crosstalk_fix;
};
enum ixgbe_pfvf_api_rev {
ixgbe_mbox_api_10 = 0,
ixgbe_mbox_api_20 = 1,
ixgbe_mbox_api_11 = 2,
ixgbe_mbox_api_12 = 3,
ixgbe_mbox_api_13 = 4,
ixgbe_mbox_api_14 = 5,
ixgbe_mbox_api_unknown = 6,
};
struct ixgbe_mbx_operations {
s32 (*init_params)(struct ixgbe_hw *);
s32 (*read)(struct ixgbe_hw *, u32 *, u16, u16);
s32 (*write)(struct ixgbe_hw *, u32 *, u16, u16);
s32 (*read_posted)(struct ixgbe_hw *, u32 *, u16, u16);
s32 (*write_posted)(struct ixgbe_hw *, u32 *, u16, u16);
s32 (*check_for_msg)(struct ixgbe_hw *, u16);
s32 (*check_for_ack)(struct ixgbe_hw *, u16);
s32 (*check_for_rst)(struct ixgbe_hw *, u16);
};
struct ieee_ets {
__u8 willing;
__u8 ets_cap;
__u8 cbs;
__u8 tc_tx_bw[8];
__u8 tc_rx_bw[8];
__u8 tc_tsa[8];
__u8 prio_tc[8];
__u8 tc_reco_bw[8];
__u8 tc_reco_tsa[8];
__u8 reco_prio_tc[8];
};
struct ieee_pfc {
__u8 pfc_cap;
__u8 pfc_en;
__u8 mbc;
__u16 delay;
__u64 requests[8];
__u64 indications[8];
};
enum strict_prio_type {
prio_none = 0,
prio_group = 1,
prio_link = 2,
};
struct dcb_support {
u32 capabilities;
u8 traffic_classes;
u8 pfc_traffic_classes;
};
struct tc_bw_alloc {
u8 bwg_id;
u8 bwg_percent;
u8 link_percent;
u8 up_to_tc_bitmap;
u16 data_credits_refill;
u16 data_credits_max;
enum strict_prio_type prio_type;
};
enum dcb_pfc_type {
pfc_disabled = 0,
pfc_enabled_full = 1,
pfc_enabled_tx = 2,
pfc_enabled_rx = 3,
};
struct tc_configuration {
struct tc_bw_alloc path[2];
enum dcb_pfc_type dcb_pfc;
u16 desc_credits_max;
u8 tc;
};
struct dcb_num_tcs {
u8 pg_tcs;
u8 pfc_tcs;
};
struct ixgbe_dcb_config {
struct dcb_support support;
struct dcb_num_tcs num_tcs;
struct tc_configuration tc_config[8];
u8 bw_percentage[16];
bool pfc_mode_enable;
u32 dcb_cfg_version;
u32 link_speed;
};
struct vf_stats {
u64 gprc;
u64 gorc;
u64 gptc;
u64 gotc;
u64 mprc;
};
struct vf_data_storage {
struct pci_dev *vfdev;
unsigned char vf_mac_addresses[6];
u16 vf_mc_hashes[30];
u16 num_vf_mc_hashes;
bool clear_to_send;
long: 32;
struct vf_stats vfstats;
struct vf_stats last_vfstats;
struct vf_stats saved_rst_vfstats;
bool pf_set_mac;
u16 pf_vlan;
u16 pf_qos;
u16 tx_rate;
int link_enable;
int link_state;
u8 spoofchk_enabled;
bool rss_query_enabled;
u8 trusted;
int xcast_mode;
unsigned int vf_api;
u8 primary_abort_count;
};
enum ixgbevf_xcast_modes {
IXGBEVF_XCAST_MODE_NONE = 0,
IXGBEVF_XCAST_MODE_MULTI = 1,
IXGBEVF_XCAST_MODE_ALLMULTI = 2,
IXGBEVF_XCAST_MODE_PROMISC = 3,
};
struct vf_macvlans {
struct list_head l;
int vf;
bool free;
bool is_macvlan;
u8 vf_macvlan[6];
};
struct ixgbe_tx_buffer {
union ixgbe_adv_tx_desc *next_to_watch;
long unsigned int time_stamp;
union {
struct sk_buff *skb;
struct xdp_frame *xdpf;
};
unsigned int bytecount;
short unsigned int gso_segs;
__be16 protocol;
dma_addr_t dma;
__u32 len;
u32 tx_flags;
};
struct ixgbe_rx_buffer {
union {
struct {
struct sk_buff *skb;
dma_addr_t dma;
struct page *page;
__u32 page_offset;
__u16 pagecnt_bias;
};
struct {
bool discard;
struct xdp_buff *xdp;
};
};
};
struct ixgbe_queue_stats {
u64 packets;
u64 bytes;
};
struct ixgbe_tx_queue_stats {
u64 restart_queue;
u64 tx_busy;
u64 tx_done_old;
};
struct ixgbe_rx_queue_stats {
u64 rsc_count;
u64 rsc_flush;
u64 non_eop_descs;
u64 alloc_rx_page;
u64 alloc_rx_page_failed;
u64 alloc_rx_buff_failed;
u64 csum_err;
};
struct ixgbe_q_vector;
struct ixgbe_ring {
struct ixgbe_ring *next;
struct ixgbe_q_vector *q_vector;
struct net_device *netdev;
struct bpf_prog *xdp_prog;
struct device *dev;
void *desc;
union {
struct ixgbe_tx_buffer *tx_buffer_info;
struct ixgbe_rx_buffer *rx_buffer_info;
};
long unsigned int state;
u8 *tail;
dma_addr_t dma;
unsigned int size;
u16 count;
u8 queue_index;
u8 reg_idx;
u16 next_to_use;
u16 next_to_clean;
long unsigned int last_rx_timestamp;
union {
u16 next_to_alloc;
struct {
u8 atr_sample_rate;
u8 atr_count;
};
};
u8 dcb_tc;
long: 32;
struct ixgbe_queue_stats stats;
struct u64_stats_sync syncp;
long: 32;
union {
struct ixgbe_tx_queue_stats tx_stats;
struct ixgbe_rx_queue_stats rx_stats;
};
u16 rx_offset;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct xdp_rxq_info xdp_rxq;
spinlock_t tx_lock;
struct xsk_buff_pool *xsk_pool;
u16 ring_idx;
u16 rx_buf_len;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct ixgbe_ring_container {
struct ixgbe_ring *ring;
long unsigned int next_update;
unsigned int total_bytes;
unsigned int total_packets;
u16 work_limit;
u8 count;
u8 itr;
};
struct ixgbe_adapter;
struct ixgbe_q_vector {
struct ixgbe_adapter *adapter;
u16 v_idx;
u16 itr;
struct ixgbe_ring_container rx;
struct ixgbe_ring_container tx;
struct napi_struct napi;
cpumask_t affinity_mask;
int numa_node;
struct callback_head rcu;
char name[25];
long: 32;
struct ixgbe_ring ring[0];
};
enum ixgbe_ring_f_enum {
RING_F_NONE = 0,
RING_F_VMDQ = 1,
RING_F_RSS = 2,
RING_F_FDIR = 3,
RING_F_ARRAY_SIZE = 4,
};
struct ixgbe_ring_feature {
u16 limit;
u16 indices;
u16 mask;
u16 offset;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct ptp_clock;
struct ixgbe_mac_addr;
struct ixgbe_jump_table;
struct ixgbe_adapter {
long unsigned int active_vlans[128];
struct net_device *netdev;
struct bpf_prog *xdp_prog;
struct pci_dev *pdev;
struct mii_bus *mii_bus;
long unsigned int state;
u32 flags;
u32 flags2;
int num_tx_queues;
u16 tx_itr_setting;
u16 tx_work_limit;
long: 32;
u64 tx_ipsec;
int num_rx_queues;
u16 rx_itr_setting;
u64 rx_ipsec;
__be16 vxlan_port;
__be16 geneve_port;
int num_xdp_queues;
struct ixgbe_ring *xdp_ring[64];
long unsigned int *af_xdp_zc_qps;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct ixgbe_ring *tx_ring[64];
u64 restart_queue;
u64 lsc_int;
u32 tx_timeout_count;
struct ixgbe_ring *rx_ring[64];
int num_rx_pools;
int num_rx_queues_per_pool;
long: 32;
u64 hw_csum_rx_error;
u64 hw_rx_no_dma_resources;
u64 rsc_total_count;
u64 rsc_total_flush;
u64 non_eop_descs;
u32 alloc_rx_page;
u32 alloc_rx_page_failed;
u32 alloc_rx_buff_failed;
struct ixgbe_q_vector *q_vector[64];
struct ieee_pfc *ixgbe_ieee_pfc;
struct ieee_ets *ixgbe_ieee_ets;
struct ixgbe_dcb_config dcb_cfg;
struct ixgbe_dcb_config temp_dcb_cfg;
u8 hw_tcs;
u8 dcb_set_bitmap;
u8 dcbx_cap;
enum ixgbe_fc_mode last_lfc_mode;
int num_q_vectors;
int max_q_vectors;
long: 32;
struct ixgbe_ring_feature ring_feature[4];
struct msix_entry *msix_entries;
u32 test_icr;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct ixgbe_ring test_tx_ring;
struct ixgbe_ring test_rx_ring;
struct ixgbe_hw hw;
u16 msg_enable;
struct ixgbe_hw_stats stats;
u64 tx_busy;
unsigned int tx_ring_count;
unsigned int xdp_ring_count;
unsigned int rx_ring_count;
u32 link_speed;
bool link_up;
long unsigned int sfp_poll_time;
long unsigned int link_check_timeout;
struct timer_list service_timer;
struct work_struct service_task;
struct hlist_head fdir_filter_list;
long unsigned int fdir_overflow;
union ixgbe_atr_input fdir_mask;
int fdir_filter_count;
u32 fdir_pballoc;
u32 atr_sample_rate;
spinlock_t fdir_perfect_lock;
u8 *io_addr;
u32 wol;
u16 bridge_mode;
char eeprom_id[32];
u16 eeprom_cap;
u32 interrupt_event;
u32 led_reg;
struct ptp_clock *ptp_clock;
struct ptp_clock_info ptp_caps;
struct work_struct ptp_tx_work;
struct sk_buff *ptp_tx_skb;
struct hwtstamp_config tstamp_config;
long unsigned int ptp_tx_start;
long unsigned int last_overflow_check;
long unsigned int last_rx_ptp_check;
long unsigned int last_rx_timestamp;
spinlock_t tmreg_lock;
struct cyclecounter hw_cc;
struct timecounter hw_tc;
u32 base_incval;
u32 tx_hwtstamp_timeouts;
u32 tx_hwtstamp_skipped;
u32 rx_hwtstamp_cleared;
void (*ptp_setup_sdp)(struct ixgbe_adapter *);
long unsigned int active_vfs[2];
unsigned int num_vfs;
struct vf_data_storage *vfinfo;
int vf_rate_link_speed;
struct vf_macvlans vf_mvs;
struct vf_macvlans *mv_list;
u32 timer_event_accumulator;
u32 vferr_refcount;
struct ixgbe_mac_addr *mac_table;
struct kobject *info_kobj;
struct dentry *ixgbe_dbg_adapter;
u8 default_up;
long unsigned int fwd_bitmask[2];
struct ixgbe_jump_table *jump_tables[10];
long unsigned int tables;
u8 rss_indir_tbl[512];
u32 *rss_key;
spinlock_t vfs_lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct ixgbe_mac_addr {
u8 addr[6];
u16 pool;
u16 state;
};
enum ixgbe_state_t {
__IXGBE_TESTING = 0,
__IXGBE_RESETTING = 1,
__IXGBE_DOWN = 2,
__IXGBE_DISABLED = 3,
__IXGBE_REMOVING = 4,
__IXGBE_SERVICE_SCHED = 5,
__IXGBE_SERVICE_INITED = 6,
__IXGBE_IN_SFP_INIT = 7,
__IXGBE_PTP_RUNNING = 8,
__IXGBE_PTP_TX_IN_PROGRESS = 9,
__IXGBE_RESET_REQUESTED = 10,
};
enum {
NETIF_F_SG_BIT = 0,
NETIF_F_IP_CSUM_BIT = 1,
__UNUSED_NETIF_F_1 = 2,
NETIF_F_HW_CSUM_BIT = 3,
NETIF_F_IPV6_CSUM_BIT = 4,
NETIF_F_HIGHDMA_BIT = 5,
NETIF_F_FRAGLIST_BIT = 6,
NETIF_F_HW_VLAN_CTAG_TX_BIT = 7,
NETIF_F_HW_VLAN_CTAG_RX_BIT = 8,
NETIF_F_HW_VLAN_CTAG_FILTER_BIT = 9,
NETIF_F_VLAN_CHALLENGED_BIT = 10,
NETIF_F_GSO_BIT = 11,
NETIF_F_LLTX_BIT = 12,
NETIF_F_NETNS_LOCAL_BIT = 13,
NETIF_F_GRO_BIT = 14,
NETIF_F_LRO_BIT = 15,
NETIF_F_GSO_SHIFT = 16,
NETIF_F_TSO_BIT = 16,
NETIF_F_GSO_ROBUST_BIT = 17,
NETIF_F_TSO_ECN_BIT = 18,
NETIF_F_TSO_MANGLEID_BIT = 19,
NETIF_F_TSO6_BIT = 20,
NETIF_F_FSO_BIT = 21,
NETIF_F_GSO_GRE_BIT = 22,
NETIF_F_GSO_GRE_CSUM_BIT = 23,
NETIF_F_GSO_IPXIP4_BIT = 24,
NETIF_F_GSO_IPXIP6_BIT = 25,
NETIF_F_GSO_UDP_TUNNEL_BIT = 26,
NETIF_F_GSO_UDP_TUNNEL_CSUM_BIT = 27,
NETIF_F_GSO_PARTIAL_BIT = 28,
NETIF_F_GSO_TUNNEL_REMCSUM_BIT = 29,
NETIF_F_GSO_SCTP_BIT = 30,
NETIF_F_GSO_ESP_BIT = 31,
NETIF_F_GSO_UDP_BIT = 32,
NETIF_F_GSO_UDP_L4_BIT = 33,
NETIF_F_GSO_FRAGLIST_BIT = 34,
NETIF_F_GSO_LAST = 34,
NETIF_F_FCOE_CRC_BIT = 35,
NETIF_F_SCTP_CRC_BIT = 36,
NETIF_F_FCOE_MTU_BIT = 37,
NETIF_F_NTUPLE_BIT = 38,
NETIF_F_RXHASH_BIT = 39,
NETIF_F_RXCSUM_BIT = 40,
NETIF_F_NOCACHE_COPY_BIT = 41,
NETIF_F_LOOPBACK_BIT = 42,
NETIF_F_RXFCS_BIT = 43,
NETIF_F_RXALL_BIT = 44,
NETIF_F_HW_VLAN_STAG_TX_BIT = 45,
NETIF_F_HW_VLAN_STAG_RX_BIT = 46,
NETIF_F_HW_VLAN_STAG_FILTER_BIT = 47,
NETIF_F_HW_L2FW_DOFFLOAD_BIT = 48,
NETIF_F_HW_TC_BIT = 49,
NETIF_F_HW_ESP_BIT = 50,
NETIF_F_HW_ESP_TX_CSUM_BIT = 51,
NETIF_F_RX_UDP_TUNNEL_PORT_BIT = 52,
NETIF_F_HW_TLS_TX_BIT = 53,
NETIF_F_HW_TLS_RX_BIT = 54,
NETIF_F_GRO_HW_BIT = 55,
NETIF_F_HW_TLS_RECORD_BIT = 56,
NETIF_F_GRO_FRAGLIST_BIT = 57,
NETIF_F_HW_MACSEC_BIT = 58,
NETIF_F_GRO_UDP_FWD_BIT = 59,
NETIF_F_HW_HSR_TAG_INS_BIT = 60,
NETIF_F_HW_HSR_TAG_RM_BIT = 61,
NETIF_F_HW_HSR_FWD_BIT = 62,
NETIF_F_HW_HSR_DUP_BIT = 63,
NETDEV_FEATURE_COUNT = 64,
};
enum skb_drop_reason {
SKB_NOT_DROPPED_YET = 0,
SKB_DROP_REASON_NOT_SPECIFIED = 1,
SKB_DROP_REASON_NO_SOCKET = 2,
SKB_DROP_REASON_PKT_TOO_SMALL = 3,
SKB_DROP_REASON_TCP_CSUM = 4,
SKB_DROP_REASON_SOCKET_FILTER = 5,
SKB_DROP_REASON_UDP_CSUM = 6,
SKB_DROP_REASON_NETFILTER_DROP = 7,
SKB_DROP_REASON_OTHERHOST = 8,
SKB_DROP_REASON_IP_CSUM = 9,
SKB_DROP_REASON_IP_INHDR = 10,
SKB_DROP_REASON_IP_RPFILTER = 11,
SKB_DROP_REASON_UNICAST_IN_L2_MULTICAST = 12,
SKB_DROP_REASON_XFRM_POLICY = 13,
SKB_DROP_REASON_IP_NOPROTO = 14,
SKB_DROP_REASON_SOCKET_RCVBUFF = 15,
SKB_DROP_REASON_PROTO_MEM = 16,
SKB_DROP_REASON_TCP_MD5NOTFOUND = 17,
SKB_DROP_REASON_TCP_MD5UNEXPECTED = 18,
SKB_DROP_REASON_TCP_MD5FAILURE = 19,
SKB_DROP_REASON_SOCKET_BACKLOG = 20,
SKB_DROP_REASON_TCP_FLAGS = 21,
SKB_DROP_REASON_TCP_ZEROWINDOW = 22,
SKB_DROP_REASON_TCP_OLD_DATA = 23,
SKB_DROP_REASON_TCP_OVERWINDOW = 24,
SKB_DROP_REASON_TCP_OFOMERGE = 25,
SKB_DROP_REASON_TCP_RFC7323_PAWS = 26,
SKB_DROP_REASON_TCP_INVALID_SEQUENCE = 27,
SKB_DROP_REASON_TCP_RESET = 28,
SKB_DROP_REASON_TCP_INVALID_SYN = 29,
SKB_DROP_REASON_TCP_CLOSE = 30,
SKB_DROP_REASON_TCP_FASTOPEN = 31,
SKB_DROP_REASON_TCP_OLD_ACK = 32,
SKB_DROP_REASON_TCP_TOO_OLD_ACK = 33,
SKB_DROP_REASON_TCP_ACK_UNSENT_DATA = 34,
SKB_DROP_REASON_TCP_OFO_QUEUE_PRUNE = 35,
SKB_DROP_REASON_TCP_OFO_DROP = 36,
SKB_DROP_REASON_IP_OUTNOROUTES = 37,
SKB_DROP_REASON_BPF_CGROUP_EGRESS = 38,
SKB_DROP_REASON_IPV6DISABLED = 39,
SKB_DROP_REASON_NEIGH_CREATEFAIL = 40,
SKB_DROP_REASON_NEIGH_FAILED = 41,
SKB_DROP_REASON_NEIGH_QUEUEFULL = 42,
SKB_DROP_REASON_NEIGH_DEAD = 43,
SKB_DROP_REASON_TC_EGRESS = 44,
SKB_DROP_REASON_QDISC_DROP = 45,
SKB_DROP_REASON_CPU_BACKLOG = 46,
SKB_DROP_REASON_XDP = 47,
SKB_DROP_REASON_TC_INGRESS = 48,
SKB_DROP_REASON_UNHANDLED_PROTO = 49,
SKB_DROP_REASON_SKB_CSUM = 50,
SKB_DROP_REASON_SKB_GSO_SEG = 51,
SKB_DROP_REASON_SKB_UCOPY_FAULT = 52,
SKB_DROP_REASON_DEV_HDR = 53,
SKB_DROP_REASON_DEV_READY = 54,
SKB_DROP_REASON_FULL_RING = 55,
SKB_DROP_REASON_NOMEM = 56,
SKB_DROP_REASON_HDR_TRUNC = 57,
SKB_DROP_REASON_TAP_FILTER = 58,
SKB_DROP_REASON_TAP_TXFILTER = 59,
SKB_DROP_REASON_ICMP_CSUM = 60,
SKB_DROP_REASON_INVALID_PROTO = 61,
SKB_DROP_REASON_IP_INADDRERRORS = 62,
SKB_DROP_REASON_IP_INNOROUTES = 63,
SKB_DROP_REASON_PKT_TOO_BIG = 64,
SKB_DROP_REASON_MAX = 65,
};
struct pernet_operations {
struct list_head list;
int (*init)(struct net *);
void (*pre_exit)(struct net *);
void (*exit)(struct net *);
void (*exit_batch)(struct list_head *);
unsigned int *id;
size_t size;
};
struct scm_creds {
u32 pid;
kuid_t uid;
kgid_t gid;
};
struct netlink_skb_parms {
struct scm_creds creds;
__u32 portid;
__u32 dst_group;
__u32 flags;
struct sock *sk;
bool nsid_is_set;
int nsid;
};
enum net_device_flags {
IFF_UP = 1,
IFF_BROADCAST = 2,
IFF_DEBUG = 4,
IFF_LOOPBACK = 8,
IFF_POINTOPOINT = 16,
IFF_NOTRAILERS = 32,
IFF_RUNNING = 64,
IFF_NOARP = 128,
IFF_PROMISC = 256,
IFF_ALLMULTI = 512,
IFF_MASTER = 1024,
IFF_SLAVE = 2048,
IFF_MULTICAST = 4096,
IFF_PORTSEL = 8192,
IFF_AUTOMEDIA = 16384,
IFF_DYNAMIC = 32768,
IFF_LOWER_UP = 65536,
IFF_DORMANT = 131072,
IFF_ECHO = 262144,
};
enum tc_link_layer {
TC_LINKLAYER_UNAWARE = 0,
TC_LINKLAYER_ETHERNET = 1,
TC_LINKLAYER_ATM = 2,
};
struct tc_ratespec {
unsigned char cell_log;
__u8 linklayer;
short unsigned int overhead;
short int cell_align;
short unsigned int mpu;
__u32 rate;
};
enum {
TCA_STAB_UNSPEC = 0,
TCA_STAB_BASE = 1,
TCA_STAB_DATA = 2,
__TCA_STAB_MAX = 3,
};
enum netdev_priv_flags {
IFF_802_1Q_VLAN = 1ULL,
IFF_EBRIDGE = 2ULL,
IFF_BONDING = 4ULL,
IFF_ISATAP = 8ULL,
IFF_WAN_HDLC = 16ULL,
IFF_XMIT_DST_RELEASE = 32ULL,
IFF_DONT_BRIDGE = 64ULL,
IFF_DISABLE_NETPOLL = 128ULL,
IFF_MACVLAN_PORT = 256ULL,
IFF_BRIDGE_PORT = 512ULL,
IFF_OVS_DATAPATH = 1024ULL,
IFF_TX_SKB_SHARING = 2048ULL,
IFF_UNICAST_FLT = 4096ULL,
IFF_TEAM_PORT = 8192ULL,
IFF_SUPP_NOFCS = 16384ULL,
IFF_LIVE_ADDR_CHANGE = 32768ULL,
IFF_MACVLAN = 65536ULL,
IFF_XMIT_DST_RELEASE_PERM = 131072ULL,
IFF_L3MDEV_MASTER = 262144ULL,
IFF_NO_QUEUE = 524288ULL,
IFF_OPENVSWITCH = 1048576ULL,
IFF_L3MDEV_SLAVE = 2097152ULL,
IFF_TEAM = 4194304ULL,
IFF_RXFH_CONFIGURED = 8388608ULL,
IFF_PHONY_HEADROOM = 16777216ULL,
IFF_MACSEC = 33554432ULL,
IFF_NO_RX_HANDLER = 67108864ULL,
IFF_FAILOVER = 134217728ULL,
IFF_FAILOVER_SLAVE = 268435456ULL,
IFF_L3MDEV_RX_HANDLER = 536870912ULL,
IFF_LIVE_RENAME_OK = 1073741824ULL,
IFF_TX_SKB_NO_LINEAR = 2147483648ULL,
IFF_CHANGE_PROTO_DOWN = 4294967296ULL,
};
enum {
RTM_BASE = 16,
RTM_NEWLINK = 16,
RTM_DELLINK = 17,
RTM_GETLINK = 18,
RTM_SETLINK = 19,
RTM_NEWADDR = 20,
RTM_DELADDR = 21,
RTM_GETADDR = 22,
RTM_NEWROUTE = 24,
RTM_DELROUTE = 25,
RTM_GETROUTE = 26,
RTM_NEWNEIGH = 28,
RTM_DELNEIGH = 29,
RTM_GETNEIGH = 30,
RTM_NEWRULE = 32,
RTM_DELRULE = 33,
RTM_GETRULE = 34,
RTM_NEWQDISC = 36,
RTM_DELQDISC = 37,
RTM_GETQDISC = 38,
RTM_NEWTCLASS = 40,
RTM_DELTCLASS = 41,
RTM_GETTCLASS = 42,
RTM_NEWTFILTER = 44,
RTM_DELTFILTER = 45,
RTM_GETTFILTER = 46,
RTM_NEWACTION = 48,
RTM_DELACTION = 49,
RTM_GETACTION = 50,
RTM_NEWPREFIX = 52,
RTM_GETMULTICAST = 58,
RTM_GETANYCAST = 62,
RTM_NEWNEIGHTBL = 64,
RTM_GETNEIGHTBL = 66,
RTM_SETNEIGHTBL = 67,
RTM_NEWNDUSEROPT = 68,
RTM_NEWADDRLABEL = 72,
RTM_DELADDRLABEL = 73,
RTM_GETADDRLABEL = 74,
RTM_GETDCB = 78,
RTM_SETDCB = 79,
RTM_NEWNETCONF = 80,
RTM_DELNETCONF = 81,
RTM_GETNETCONF = 82,
RTM_NEWMDB = 84,
RTM_DELMDB = 85,
RTM_GETMDB = 86,
RTM_NEWNSID = 88,
RTM_DELNSID = 89,
RTM_GETNSID = 90,
RTM_NEWSTATS = 92,
RTM_GETSTATS = 94,
RTM_SETSTATS = 95,
RTM_NEWCACHEREPORT = 96,
RTM_NEWCHAIN = 100,
RTM_DELCHAIN = 101,
RTM_GETCHAIN = 102,
RTM_NEWNEXTHOP = 104,
RTM_DELNEXTHOP = 105,
RTM_GETNEXTHOP = 106,
RTM_NEWLINKPROP = 108,
RTM_DELLINKPROP = 109,
RTM_GETLINKPROP = 110,
RTM_NEWVLAN = 112,
RTM_DELVLAN = 113,
RTM_GETVLAN = 114,
RTM_NEWNEXTHOPBUCKET = 116,
RTM_DELNEXTHOPBUCKET = 117,
RTM_GETNEXTHOPBUCKET = 118,
RTM_NEWTUNNEL = 120,
RTM_DELTUNNEL = 121,
RTM_GETTUNNEL = 122,
__RTM_MAX = 123,
};
enum {
TCA_UNSPEC = 0,
TCA_KIND = 1,
TCA_OPTIONS = 2,
TCA_STATS = 3,
TCA_XSTATS = 4,
TCA_RATE = 5,
TCA_FCNT = 6,
TCA_STATS2 = 7,
TCA_STAB = 8,
TCA_PAD = 9,
TCA_DUMP_INVISIBLE = 10,
TCA_CHAIN = 11,
TCA_HW_OFFLOAD = 12,
TCA_INGRESS_BLOCK = 13,
TCA_EGRESS_BLOCK = 14,
TCA_DUMP_FLAGS = 15,
__TCA_MAX = 16,
};
enum rtnetlink_groups {
RTNLGRP_NONE = 0,
RTNLGRP_LINK = 1,
RTNLGRP_NOTIFY = 2,
RTNLGRP_NEIGH = 3,
RTNLGRP_TC = 4,
RTNLGRP_IPV4_IFADDR = 5,
RTNLGRP_IPV4_MROUTE = 6,
RTNLGRP_IPV4_ROUTE = 7,
RTNLGRP_IPV4_RULE = 8,
RTNLGRP_IPV6_IFADDR = 9,
RTNLGRP_IPV6_MROUTE = 10,
RTNLGRP_IPV6_ROUTE = 11,
RTNLGRP_IPV6_IFINFO = 12,
RTNLGRP_DECnet_IFADDR = 13,
RTNLGRP_NOP2 = 14,
RTNLGRP_DECnet_ROUTE = 15,
RTNLGRP_DECnet_RULE = 16,
RTNLGRP_NOP4 = 17,
RTNLGRP_IPV6_PREFIX = 18,
RTNLGRP_IPV6_RULE = 19,
RTNLGRP_ND_USEROPT = 20,
RTNLGRP_PHONET_IFADDR = 21,
RTNLGRP_PHONET_ROUTE = 22,
RTNLGRP_DCB = 23,
RTNLGRP_IPV4_NETCONF = 24,
RTNLGRP_IPV6_NETCONF = 25,
RTNLGRP_MDB = 26,
RTNLGRP_MPLS_ROUTE = 27,
RTNLGRP_NSID = 28,
RTNLGRP_MPLS_NETCONF = 29,
RTNLGRP_IPV4_MROUTE_R = 30,
RTNLGRP_IPV6_MROUTE_R = 31,
RTNLGRP_NEXTHOP = 32,
RTNLGRP_BRVLAN = 33,
RTNLGRP_MCTP_IFADDR = 34,
RTNLGRP_TUNNEL = 35,
RTNLGRP_STATS = 36,
__RTNLGRP_MAX = 37,
};
enum {
NLA_UNSPEC = 0,
NLA_U8 = 1,
NLA_U16 = 2,
NLA_U32 = 3,
NLA_U64 = 4,
NLA_STRING = 5,
NLA_FLAG = 6,
NLA_MSECS = 7,
NLA_NESTED = 8,
NLA_NESTED_ARRAY = 9,
NLA_NUL_STRING = 10,
NLA_BINARY = 11,
NLA_S8 = 12,
NLA_S16 = 13,
NLA_S32 = 14,
NLA_S64 = 15,
NLA_BITFIELD32 = 16,
NLA_REJECT = 17,
NLA_BE16 = 18,
NLA_BE32 = 19,
__NLA_TYPE_MAX = 20,
};
enum netlink_validation {
NL_VALIDATE_LIBERAL = 0,
NL_VALIDATE_TRAILING = 1,
NL_VALIDATE_MAXTYPE = 2,
NL_VALIDATE_UNSPEC = 4,
NL_VALIDATE_STRICT_ATTRS = 8,
NL_VALIDATE_NESTED = 16,
};
typedef int (*rtnl_doit_func)(struct sk_buff *, struct nlmsghdr *, struct netlink_ext_ack *);
typedef int (*rtnl_dumpit_func)(struct sk_buff *, struct netlink_callback *);
struct qdisc_rate_table {
struct tc_ratespec rate;
u32 data[256];
struct qdisc_rate_table *next;
int refcnt;
};
enum qdisc_state_t {
__QDISC_STATE_SCHED = 0,
__QDISC_STATE_DEACTIVATED = 1,
__QDISC_STATE_MISSED = 2,
__QDISC_STATE_DRAINING = 3,
};
struct qdisc_walker {
int stop;
int skip;
int count;
int (*fn)(struct Qdisc *, long unsigned int, struct qdisc_walker *);
};
struct tcf_walker {
int stop;
int skip;
int count;
bool nonempty;
long unsigned int cookie;
int (*fn)(struct tcf_proto *, void *, struct tcf_walker *);
};
struct qdisc_skb_cb {
struct {
unsigned int pkt_len;
u16 slave_dev_queue_mapping;
u16 tc_classid;
};
unsigned char data[20];
};
struct Qdisc_class_common {
u32 classid;
struct hlist_node hnode;
};
struct Qdisc_class_hash {
struct hlist_head *hash;
unsigned int hashsize;
unsigned int hashmask;
unsigned int hashelems;
};
struct qdisc_watchdog {
u64 last_expires;
struct hrtimer timer;
struct Qdisc *qdisc;
long: 32;
};
struct tc_query_caps_base {
enum tc_setup_type type;
void *caps;
};
enum tc_root_command {
TC_ROOT_GRAFT = 0,
};
struct tc_root_qopt_offload {
enum tc_root_command command;
u32 handle;
bool ingress;
};
struct check_loop_arg {
struct qdisc_walker w;
struct Qdisc *p;
int depth;
};
struct tcf_bind_args {
struct tcf_walker w;
long unsigned int base;
long unsigned int cl;
u32 classid;
};
struct tc_bind_class_args {
struct qdisc_walker w;
long unsigned int new_cl;
u32 portid;
u32 clid;
};
struct qdisc_dump_args {
struct qdisc_walker w;
struct sk_buff *skb;
struct netlink_callback *cb;
};
enum tunable_id {
ETHTOOL_ID_UNSPEC = 0,
ETHTOOL_RX_COPYBREAK = 1,
ETHTOOL_TX_COPYBREAK = 2,
ETHTOOL_PFC_PREVENTION_TOUT = 3,
ETHTOOL_TX_COPYBREAK_BUF_SIZE = 4,
__ETHTOOL_TUNABLE_COUNT = 5,
};
enum phy_tunable_id {
ETHTOOL_PHY_ID_UNSPEC = 0,
ETHTOOL_PHY_DOWNSHIFT = 1,
ETHTOOL_PHY_FAST_LINK_DOWN = 2,
ETHTOOL_PHY_EDPD = 3,
__ETHTOOL_PHY_TUNABLE_COUNT = 4,
};
enum {
ETH_RSS_HASH_TOP_BIT = 0,
ETH_RSS_HASH_XOR_BIT = 1,
ETH_RSS_HASH_CRC32_BIT = 2,
ETH_RSS_HASH_FUNCS_COUNT = 3,
};
enum {
ETHTOOL_MSG_USER_NONE = 0,
ETHTOOL_MSG_STRSET_GET = 1,
ETHTOOL_MSG_LINKINFO_GET = 2,
ETHTOOL_MSG_LINKINFO_SET = 3,
ETHTOOL_MSG_LINKMODES_GET = 4,
ETHTOOL_MSG_LINKMODES_SET = 5,
ETHTOOL_MSG_LINKSTATE_GET = 6,
ETHTOOL_MSG_DEBUG_GET = 7,
ETHTOOL_MSG_DEBUG_SET = 8,
ETHTOOL_MSG_WOL_GET = 9,
ETHTOOL_MSG_WOL_SET = 10,
ETHTOOL_MSG_FEATURES_GET = 11,
ETHTOOL_MSG_FEATURES_SET = 12,
ETHTOOL_MSG_PRIVFLAGS_GET = 13,
ETHTOOL_MSG_PRIVFLAGS_SET = 14,
ETHTOOL_MSG_RINGS_GET = 15,
ETHTOOL_MSG_RINGS_SET = 16,
ETHTOOL_MSG_CHANNELS_GET = 17,
ETHTOOL_MSG_CHANNELS_SET = 18,
ETHTOOL_MSG_COALESCE_GET = 19,
ETHTOOL_MSG_COALESCE_SET = 20,
ETHTOOL_MSG_PAUSE_GET = 21,
ETHTOOL_MSG_PAUSE_SET = 22,
ETHTOOL_MSG_EEE_GET = 23,
ETHTOOL_MSG_EEE_SET = 24,
ETHTOOL_MSG_TSINFO_GET = 25,
ETHTOOL_MSG_CABLE_TEST_ACT = 26,
ETHTOOL_MSG_CABLE_TEST_TDR_ACT = 27,
ETHTOOL_MSG_TUNNEL_INFO_GET = 28,
ETHTOOL_MSG_FEC_GET = 29,
ETHTOOL_MSG_FEC_SET = 30,
ETHTOOL_MSG_MODULE_EEPROM_GET = 31,
ETHTOOL_MSG_STATS_GET = 32,
ETHTOOL_MSG_PHC_VCLOCKS_GET = 33,
ETHTOOL_MSG_MODULE_GET = 34,
ETHTOOL_MSG_MODULE_SET = 35,
ETHTOOL_MSG_PSE_GET = 36,
ETHTOOL_MSG_PSE_SET = 37,
__ETHTOOL_MSG_USER_CNT = 38,
ETHTOOL_MSG_USER_MAX = 37,
};
enum {
ETHTOOL_MSG_KERNEL_NONE = 0,
ETHTOOL_MSG_STRSET_GET_REPLY = 1,
ETHTOOL_MSG_LINKINFO_GET_REPLY = 2,
ETHTOOL_MSG_LINKINFO_NTF = 3,
ETHTOOL_MSG_LINKMODES_GET_REPLY = 4,
ETHTOOL_MSG_LINKMODES_NTF = 5,
ETHTOOL_MSG_LINKSTATE_GET_REPLY = 6,
ETHTOOL_MSG_DEBUG_GET_REPLY = 7,
ETHTOOL_MSG_DEBUG_NTF = 8,
ETHTOOL_MSG_WOL_GET_REPLY = 9,
ETHTOOL_MSG_WOL_NTF = 10,
ETHTOOL_MSG_FEATURES_GET_REPLY = 11,
ETHTOOL_MSG_FEATURES_SET_REPLY = 12,
ETHTOOL_MSG_FEATURES_NTF = 13,
ETHTOOL_MSG_PRIVFLAGS_GET_REPLY = 14,
ETHTOOL_MSG_PRIVFLAGS_NTF = 15,
ETHTOOL_MSG_RINGS_GET_REPLY = 16,
ETHTOOL_MSG_RINGS_NTF = 17,
ETHTOOL_MSG_CHANNELS_GET_REPLY = 18,
ETHTOOL_MSG_CHANNELS_NTF = 19,
ETHTOOL_MSG_COALESCE_GET_REPLY = 20,
ETHTOOL_MSG_COALESCE_NTF = 21,
ETHTOOL_MSG_PAUSE_GET_REPLY = 22,
ETHTOOL_MSG_PAUSE_NTF = 23,
ETHTOOL_MSG_EEE_GET_REPLY = 24,
ETHTOOL_MSG_EEE_NTF = 25,
ETHTOOL_MSG_TSINFO_GET_REPLY = 26,
ETHTOOL_MSG_CABLE_TEST_NTF = 27,
ETHTOOL_MSG_CABLE_TEST_TDR_NTF = 28,
ETHTOOL_MSG_TUNNEL_INFO_GET_REPLY = 29,
ETHTOOL_MSG_FEC_GET_REPLY = 30,
ETHTOOL_MSG_FEC_NTF = 31,
ETHTOOL_MSG_MODULE_EEPROM_GET_REPLY = 32,
ETHTOOL_MSG_STATS_GET_REPLY = 33,
ETHTOOL_MSG_PHC_VCLOCKS_GET_REPLY = 34,
ETHTOOL_MSG_MODULE_GET_REPLY = 35,
ETHTOOL_MSG_MODULE_NTF = 36,
ETHTOOL_MSG_PSE_GET_REPLY = 37,
__ETHTOOL_MSG_KERNEL_CNT = 38,
ETHTOOL_MSG_KERNEL_MAX = 37,
};
enum {
ETHTOOL_A_HEADER_UNSPEC = 0,
ETHTOOL_A_HEADER_DEV_INDEX = 1,
ETHTOOL_A_HEADER_DEV_NAME = 2,
ETHTOOL_A_HEADER_FLAGS = 3,
__ETHTOOL_A_HEADER_CNT = 4,
ETHTOOL_A_HEADER_MAX = 3,
};
enum {
ETHTOOL_A_STRSET_UNSPEC = 0,
ETHTOOL_A_STRSET_HEADER = 1,
ETHTOOL_A_STRSET_STRINGSETS = 2,
ETHTOOL_A_STRSET_COUNTS_ONLY = 3,
__ETHTOOL_A_STRSET_CNT = 4,
ETHTOOL_A_STRSET_MAX = 3,
};
enum {
ETHTOOL_A_LINKINFO_UNSPEC = 0,
ETHTOOL_A_LINKINFO_HEADER = 1,
ETHTOOL_A_LINKINFO_PORT = 2,
ETHTOOL_A_LINKINFO_PHYADDR = 3,
ETHTOOL_A_LINKINFO_TP_MDIX = 4,
ETHTOOL_A_LINKINFO_TP_MDIX_CTRL = 5,
ETHTOOL_A_LINKINFO_TRANSCEIVER = 6,
__ETHTOOL_A_LINKINFO_CNT = 7,
ETHTOOL_A_LINKINFO_MAX = 6,
};
enum {
ETHTOOL_A_LINKMODES_UNSPEC = 0,
ETHTOOL_A_LINKMODES_HEADER = 1,
ETHTOOL_A_LINKMODES_AUTONEG = 2,
ETHTOOL_A_LINKMODES_OURS = 3,
ETHTOOL_A_LINKMODES_PEER = 4,
ETHTOOL_A_LINKMODES_SPEED = 5,
ETHTOOL_A_LINKMODES_DUPLEX = 6,
ETHTOOL_A_LINKMODES_MASTER_SLAVE_CFG = 7,
ETHTOOL_A_LINKMODES_MASTER_SLAVE_STATE = 8,
ETHTOOL_A_LINKMODES_LANES = 9,
ETHTOOL_A_LINKMODES_RATE_MATCHING = 10,
__ETHTOOL_A_LINKMODES_CNT = 11,
ETHTOOL_A_LINKMODES_MAX = 10,
};
enum {
ETHTOOL_A_LINKSTATE_UNSPEC = 0,
ETHTOOL_A_LINKSTATE_HEADER = 1,
ETHTOOL_A_LINKSTATE_LINK = 2,
ETHTOOL_A_LINKSTATE_SQI = 3,
ETHTOOL_A_LINKSTATE_SQI_MAX = 4,
ETHTOOL_A_LINKSTATE_EXT_STATE = 5,
ETHTOOL_A_LINKSTATE_EXT_SUBSTATE = 6,
__ETHTOOL_A_LINKSTATE_CNT = 7,
ETHTOOL_A_LINKSTATE_MAX = 6,
};
enum {
ETHTOOL_A_DEBUG_UNSPEC = 0,
ETHTOOL_A_DEBUG_HEADER = 1,
ETHTOOL_A_DEBUG_MSGMASK = 2,
__ETHTOOL_A_DEBUG_CNT = 3,
ETHTOOL_A_DEBUG_MAX = 2,
};
enum {
ETHTOOL_A_WOL_UNSPEC = 0,
ETHTOOL_A_WOL_HEADER = 1,
ETHTOOL_A_WOL_MODES = 2,
ETHTOOL_A_WOL_SOPASS = 3,
__ETHTOOL_A_WOL_CNT = 4,
ETHTOOL_A_WOL_MAX = 3,
};
enum {
ETHTOOL_A_FEATURES_UNSPEC = 0,
ETHTOOL_A_FEATURES_HEADER = 1,
ETHTOOL_A_FEATURES_HW = 2,
ETHTOOL_A_FEATURES_WANTED = 3,
ETHTOOL_A_FEATURES_ACTIVE = 4,
ETHTOOL_A_FEATURES_NOCHANGE = 5,
__ETHTOOL_A_FEATURES_CNT = 6,
ETHTOOL_A_FEATURES_MAX = 5,
};
enum {
ETHTOOL_A_PRIVFLAGS_UNSPEC = 0,
ETHTOOL_A_PRIVFLAGS_HEADER = 1,
ETHTOOL_A_PRIVFLAGS_FLAGS = 2,
__ETHTOOL_A_PRIVFLAGS_CNT = 3,
ETHTOOL_A_PRIVFLAGS_MAX = 2,
};
enum {
ETHTOOL_A_RINGS_UNSPEC = 0,
ETHTOOL_A_RINGS_HEADER = 1,
ETHTOOL_A_RINGS_RX_MAX = 2,
ETHTOOL_A_RINGS_RX_MINI_MAX = 3,
ETHTOOL_A_RINGS_RX_JUMBO_MAX = 4,
ETHTOOL_A_RINGS_TX_MAX = 5,
ETHTOOL_A_RINGS_RX = 6,
ETHTOOL_A_RINGS_RX_MINI = 7,
ETHTOOL_A_RINGS_RX_JUMBO = 8,
ETHTOOL_A_RINGS_TX = 9,
ETHTOOL_A_RINGS_RX_BUF_LEN = 10,
ETHTOOL_A_RINGS_TCP_DATA_SPLIT = 11,
ETHTOOL_A_RINGS_CQE_SIZE = 12,
ETHTOOL_A_RINGS_TX_PUSH = 13,
__ETHTOOL_A_RINGS_CNT = 14,
ETHTOOL_A_RINGS_MAX = 13,
};
enum {
ETHTOOL_A_CHANNELS_UNSPEC = 0,
ETHTOOL_A_CHANNELS_HEADER = 1,
ETHTOOL_A_CHANNELS_RX_MAX = 2,
ETHTOOL_A_CHANNELS_TX_MAX = 3,
ETHTOOL_A_CHANNELS_OTHER_MAX = 4,
ETHTOOL_A_CHANNELS_COMBINED_MAX = 5,
ETHTOOL_A_CHANNELS_RX_COUNT = 6,
ETHTOOL_A_CHANNELS_TX_COUNT = 7,
ETHTOOL_A_CHANNELS_OTHER_COUNT = 8,
ETHTOOL_A_CHANNELS_COMBINED_COUNT = 9,
__ETHTOOL_A_CHANNELS_CNT = 10,
ETHTOOL_A_CHANNELS_MAX = 9,
};
enum {
ETHTOOL_A_COALESCE_UNSPEC = 0,
ETHTOOL_A_COALESCE_HEADER = 1,
ETHTOOL_A_COALESCE_RX_USECS = 2,
ETHTOOL_A_COALESCE_RX_MAX_FRAMES = 3,
ETHTOOL_A_COALESCE_RX_USECS_IRQ = 4,
ETHTOOL_A_COALESCE_RX_MAX_FRAMES_IRQ = 5,
ETHTOOL_A_COALESCE_TX_USECS = 6,
ETHTOOL_A_COALESCE_TX_MAX_FRAMES = 7,
ETHTOOL_A_COALESCE_TX_USECS_IRQ = 8,
ETHTOOL_A_COALESCE_TX_MAX_FRAMES_IRQ = 9,
ETHTOOL_A_COALESCE_STATS_BLOCK_USECS = 10,
ETHTOOL_A_COALESCE_USE_ADAPTIVE_RX = 11,
ETHTOOL_A_COALESCE_USE_ADAPTIVE_TX = 12,
ETHTOOL_A_COALESCE_PKT_RATE_LOW = 13,
ETHTOOL_A_COALESCE_RX_USECS_LOW = 14,
ETHTOOL_A_COALESCE_RX_MAX_FRAMES_LOW = 15,
ETHTOOL_A_COALESCE_TX_USECS_LOW = 16,
ETHTOOL_A_COALESCE_TX_MAX_FRAMES_LOW = 17,
ETHTOOL_A_COALESCE_PKT_RATE_HIGH = 18,
ETHTOOL_A_COALESCE_RX_USECS_HIGH = 19,
ETHTOOL_A_COALESCE_RX_MAX_FRAMES_HIGH = 20,
ETHTOOL_A_COALESCE_TX_USECS_HIGH = 21,
ETHTOOL_A_COALESCE_TX_MAX_FRAMES_HIGH = 22,
ETHTOOL_A_COALESCE_RATE_SAMPLE_INTERVAL = 23,
ETHTOOL_A_COALESCE_USE_CQE_MODE_TX = 24,
ETHTOOL_A_COALESCE_USE_CQE_MODE_RX = 25,
__ETHTOOL_A_COALESCE_CNT = 26,
ETHTOOL_A_COALESCE_MAX = 25,
};
enum {
ETHTOOL_A_PAUSE_UNSPEC = 0,
ETHTOOL_A_PAUSE_HEADER = 1,
ETHTOOL_A_PAUSE_AUTONEG = 2,
ETHTOOL_A_PAUSE_RX = 3,
ETHTOOL_A_PAUSE_TX = 4,
ETHTOOL_A_PAUSE_STATS = 5,
__ETHTOOL_A_PAUSE_CNT = 6,
ETHTOOL_A_PAUSE_MAX = 5,
};
enum {
ETHTOOL_A_EEE_UNSPEC = 0,
ETHTOOL_A_EEE_HEADER = 1,
ETHTOOL_A_EEE_MODES_OURS = 2,
ETHTOOL_A_EEE_MODES_PEER = 3,
ETHTOOL_A_EEE_ACTIVE = 4,
ETHTOOL_A_EEE_ENABLED = 5,
ETHTOOL_A_EEE_TX_LPI_ENABLED = 6,
ETHTOOL_A_EEE_TX_LPI_TIMER = 7,
__ETHTOOL_A_EEE_CNT = 8,
ETHTOOL_A_EEE_MAX = 7,
};
enum {
ETHTOOL_A_TSINFO_UNSPEC = 0,
ETHTOOL_A_TSINFO_HEADER = 1,
ETHTOOL_A_TSINFO_TIMESTAMPING = 2,
ETHTOOL_A_TSINFO_TX_TYPES = 3,
ETHTOOL_A_TSINFO_RX_FILTERS = 4,
ETHTOOL_A_TSINFO_PHC_INDEX = 5,
__ETHTOOL_A_TSINFO_CNT = 6,
ETHTOOL_A_TSINFO_MAX = 5,
};
enum {
ETHTOOL_A_PHC_VCLOCKS_UNSPEC = 0,
ETHTOOL_A_PHC_VCLOCKS_HEADER = 1,
ETHTOOL_A_PHC_VCLOCKS_NUM = 2,
ETHTOOL_A_PHC_VCLOCKS_INDEX = 3,
__ETHTOOL_A_PHC_VCLOCKS_CNT = 4,
ETHTOOL_A_PHC_VCLOCKS_MAX = 3,
};
enum {
ETHTOOL_A_CABLE_TEST_UNSPEC = 0,
ETHTOOL_A_CABLE_TEST_HEADER = 1,
__ETHTOOL_A_CABLE_TEST_CNT = 2,
ETHTOOL_A_CABLE_TEST_MAX = 1,
};
enum {
ETHTOOL_A_CABLE_TEST_TDR_UNSPEC = 0,
ETHTOOL_A_CABLE_TEST_TDR_HEADER = 1,
ETHTOOL_A_CABLE_TEST_TDR_CFG = 2,
__ETHTOOL_A_CABLE_TEST_TDR_CNT = 3,
ETHTOOL_A_CABLE_TEST_TDR_MAX = 2,
};
enum {
ETHTOOL_A_TUNNEL_INFO_UNSPEC = 0,
ETHTOOL_A_TUNNEL_INFO_HEADER = 1,
ETHTOOL_A_TUNNEL_INFO_UDP_PORTS = 2,
__ETHTOOL_A_TUNNEL_INFO_CNT = 3,
ETHTOOL_A_TUNNEL_INFO_MAX = 2,
};
enum {
ETHTOOL_A_FEC_UNSPEC = 0,
ETHTOOL_A_FEC_HEADER = 1,
ETHTOOL_A_FEC_MODES = 2,
ETHTOOL_A_FEC_AUTO = 3,
ETHTOOL_A_FEC_ACTIVE = 4,
ETHTOOL_A_FEC_STATS = 5,
__ETHTOOL_A_FEC_CNT = 6,
ETHTOOL_A_FEC_MAX = 5,
};
enum {
ETHTOOL_A_MODULE_EEPROM_UNSPEC = 0,
ETHTOOL_A_MODULE_EEPROM_HEADER = 1,
ETHTOOL_A_MODULE_EEPROM_OFFSET = 2,
ETHTOOL_A_MODULE_EEPROM_LENGTH = 3,
ETHTOOL_A_MODULE_EEPROM_PAGE = 4,
ETHTOOL_A_MODULE_EEPROM_BANK = 5,
ETHTOOL_A_MODULE_EEPROM_I2C_ADDRESS = 6,
ETHTOOL_A_MODULE_EEPROM_DATA = 7,
__ETHTOOL_A_MODULE_EEPROM_CNT = 8,
ETHTOOL_A_MODULE_EEPROM_MAX = 7,
};
enum {
ETHTOOL_A_STATS_UNSPEC = 0,
ETHTOOL_A_STATS_PAD = 1,
ETHTOOL_A_STATS_HEADER = 2,
ETHTOOL_A_STATS_GROUPS = 3,
ETHTOOL_A_STATS_GRP = 4,
__ETHTOOL_A_STATS_CNT = 5,
ETHTOOL_A_STATS_MAX = 4,
};
enum {
ETHTOOL_STATS_ETH_PHY = 0,
ETHTOOL_STATS_ETH_MAC = 1,
ETHTOOL_STATS_ETH_CTRL = 2,
ETHTOOL_STATS_RMON = 3,
__ETHTOOL_STATS_CNT = 4,
};
enum {
ETHTOOL_A_STATS_ETH_PHY_5_SYM_ERR = 0,
__ETHTOOL_A_STATS_ETH_PHY_CNT = 1,
ETHTOOL_A_STATS_ETH_PHY_MAX = 0,
};
enum {
ETHTOOL_A_STATS_ETH_MAC_2_TX_PKT = 0,
ETHTOOL_A_STATS_ETH_MAC_3_SINGLE_COL = 1,
ETHTOOL_A_STATS_ETH_MAC_4_MULTI_COL = 2,
ETHTOOL_A_STATS_ETH_MAC_5_RX_PKT = 3,
ETHTOOL_A_STATS_ETH_MAC_6_FCS_ERR = 4,
ETHTOOL_A_STATS_ETH_MAC_7_ALIGN_ERR = 5,
ETHTOOL_A_STATS_ETH_MAC_8_TX_BYTES = 6,
ETHTOOL_A_STATS_ETH_MAC_9_TX_DEFER = 7,
ETHTOOL_A_STATS_ETH_MAC_10_LATE_COL = 8,
ETHTOOL_A_STATS_ETH_MAC_11_XS_COL = 9,
ETHTOOL_A_STATS_ETH_MAC_12_TX_INT_ERR = 10,
ETHTOOL_A_STATS_ETH_MAC_13_CS_ERR = 11,
ETHTOOL_A_STATS_ETH_MAC_14_RX_BYTES = 12,
ETHTOOL_A_STATS_ETH_MAC_15_RX_INT_ERR = 13,
ETHTOOL_A_STATS_ETH_MAC_18_TX_MCAST = 14,
ETHTOOL_A_STATS_ETH_MAC_19_TX_BCAST = 15,
ETHTOOL_A_STATS_ETH_MAC_20_XS_DEFER = 16,
ETHTOOL_A_STATS_ETH_MAC_21_RX_MCAST = 17,
ETHTOOL_A_STATS_ETH_MAC_22_RX_BCAST = 18,
ETHTOOL_A_STATS_ETH_MAC_23_IR_LEN_ERR = 19,
ETHTOOL_A_STATS_ETH_MAC_24_OOR_LEN = 20,
ETHTOOL_A_STATS_ETH_MAC_25_TOO_LONG_ERR = 21,
__ETHTOOL_A_STATS_ETH_MAC_CNT = 22,
ETHTOOL_A_STATS_ETH_MAC_MAX = 21,
};
enum {
ETHTOOL_A_STATS_ETH_CTRL_3_TX = 0,
ETHTOOL_A_STATS_ETH_CTRL_4_RX = 1,
ETHTOOL_A_STATS_ETH_CTRL_5_RX_UNSUP = 2,
__ETHTOOL_A_STATS_ETH_CTRL_CNT = 3,
ETHTOOL_A_STATS_ETH_CTRL_MAX = 2,
};
enum {
ETHTOOL_A_STATS_RMON_UNDERSIZE = 0,
ETHTOOL_A_STATS_RMON_OVERSIZE = 1,
ETHTOOL_A_STATS_RMON_FRAG = 2,
ETHTOOL_A_STATS_RMON_JABBER = 3,
__ETHTOOL_A_STATS_RMON_CNT = 4,
ETHTOOL_A_STATS_RMON_MAX = 3,
};
enum {
ETHTOOL_A_MODULE_UNSPEC = 0,
ETHTOOL_A_MODULE_HEADER = 1,
ETHTOOL_A_MODULE_POWER_MODE_POLICY = 2,
ETHTOOL_A_MODULE_POWER_MODE = 3,
__ETHTOOL_A_MODULE_CNT = 4,
ETHTOOL_A_MODULE_MAX = 3,
};
enum {
ETHTOOL_A_PSE_UNSPEC = 0,
ETHTOOL_A_PSE_HEADER = 1,
ETHTOOL_A_PODL_PSE_ADMIN_STATE = 2,
ETHTOOL_A_PODL_PSE_ADMIN_CONTROL = 3,
ETHTOOL_A_PODL_PSE_PW_D_STATUS = 4,
__ETHTOOL_A_PSE_CNT = 5,
ETHTOOL_A_PSE_MAX = 4,
};
enum {
IPSTATS_MIB_NUM = 0,
IPSTATS_MIB_INPKTS = 1,
IPSTATS_MIB_INOCTETS = 2,
IPSTATS_MIB_INDELIVERS = 3,
IPSTATS_MIB_OUTFORWDATAGRAMS = 4,
IPSTATS_MIB_OUTPKTS = 5,
IPSTATS_MIB_OUTOCTETS = 6,
IPSTATS_MIB_INHDRERRORS = 7,
IPSTATS_MIB_INTOOBIGERRORS = 8,
IPSTATS_MIB_INNOROUTES = 9,
IPSTATS_MIB_INADDRERRORS = 10,
IPSTATS_MIB_INUNKNOWNPROTOS = 11,
IPSTATS_MIB_INTRUNCATEDPKTS = 12,
IPSTATS_MIB_INDISCARDS = 13,
IPSTATS_MIB_OUTDISCARDS = 14,
IPSTATS_MIB_OUTNOROUTES = 15,
IPSTATS_MIB_REASMTIMEOUT = 16,
IPSTATS_MIB_REASMREQDS = 17,
IPSTATS_MIB_REASMOKS = 18,
IPSTATS_MIB_REASMFAILS = 19,
IPSTATS_MIB_FRAGOKS = 20,
IPSTATS_MIB_FRAGFAILS = 21,
IPSTATS_MIB_FRAGCREATES = 22,
IPSTATS_MIB_INMCASTPKTS = 23,
IPSTATS_MIB_OUTMCASTPKTS = 24,
IPSTATS_MIB_INBCASTPKTS = 25,
IPSTATS_MIB_OUTBCASTPKTS = 26,
IPSTATS_MIB_INMCASTOCTETS = 27,
IPSTATS_MIB_OUTMCASTOCTETS = 28,
IPSTATS_MIB_INBCASTOCTETS = 29,
IPSTATS_MIB_OUTBCASTOCTETS = 30,
IPSTATS_MIB_CSUMERRORS = 31,
IPSTATS_MIB_NOECTPKTS = 32,
IPSTATS_MIB_ECT1PKTS = 33,
IPSTATS_MIB_ECT0PKTS = 34,
IPSTATS_MIB_CEPKTS = 35,
IPSTATS_MIB_REASM_OVERLAPS = 36,
__IPSTATS_MIB_MAX = 37,
};
enum {
ICMP_MIB_NUM = 0,
ICMP_MIB_INMSGS = 1,
ICMP_MIB_INERRORS = 2,
ICMP_MIB_INDESTUNREACHS = 3,
ICMP_MIB_INTIMEEXCDS = 4,
ICMP_MIB_INPARMPROBS = 5,
ICMP_MIB_INSRCQUENCHS = 6,
ICMP_MIB_INREDIRECTS = 7,
ICMP_MIB_INECHOS = 8,
ICMP_MIB_INECHOREPS = 9,
ICMP_MIB_INTIMESTAMPS = 10,
ICMP_MIB_INTIMESTAMPREPS = 11,
ICMP_MIB_INADDRMASKS = 12,
ICMP_MIB_INADDRMASKREPS = 13,
ICMP_MIB_OUTMSGS = 14,
ICMP_MIB_OUTERRORS = 15,
ICMP_MIB_OUTDESTUNREACHS = 16,
ICMP_MIB_OUTTIMEEXCDS = 17,
ICMP_MIB_OUTPARMPROBS = 18,
ICMP_MIB_OUTSRCQUENCHS = 19,
ICMP_MIB_OUTREDIRECTS = 20,
ICMP_MIB_OUTECHOS = 21,
ICMP_MIB_OUTECHOREPS = 22,
ICMP_MIB_OUTTIMESTAMPS = 23,
ICMP_MIB_OUTTIMESTAMPREPS = 24,
ICMP_MIB_OUTADDRMASKS = 25,
ICMP_MIB_OUTADDRMASKREPS = 26,
ICMP_MIB_CSUMERRORS = 27,
__ICMP_MIB_MAX = 28,
};
enum {
ICMP6_MIB_NUM = 0,
ICMP6_MIB_INMSGS = 1,
ICMP6_MIB_INERRORS = 2,
ICMP6_MIB_OUTMSGS = 3,
ICMP6_MIB_OUTERRORS = 4,
ICMP6_MIB_CSUMERRORS = 5,
__ICMP6_MIB_MAX = 6,
};
enum {
TCP_MIB_NUM = 0,
TCP_MIB_RTOALGORITHM = 1,
TCP_MIB_RTOMIN = 2,
TCP_MIB_RTOMAX = 3,
TCP_MIB_MAXCONN = 4,
TCP_MIB_ACTIVEOPENS = 5,
TCP_MIB_PASSIVEOPENS = 6,
TCP_MIB_ATTEMPTFAILS = 7,
TCP_MIB_ESTABRESETS = 8,
TCP_MIB_CURRESTAB = 9,
TCP_MIB_INSEGS = 10,
TCP_MIB_OUTSEGS = 11,
TCP_MIB_RETRANSSEGS = 12,
TCP_MIB_INERRS = 13,
TCP_MIB_OUTRSTS = 14,
TCP_MIB_CSUMERRORS = 15,
__TCP_MIB_MAX = 16,
};
enum {
UDP_MIB_NUM = 0,
UDP_MIB_INDATAGRAMS = 1,
UDP_MIB_NOPORTS = 2,
UDP_MIB_INERRORS = 3,
UDP_MIB_OUTDATAGRAMS = 4,
UDP_MIB_RCVBUFERRORS = 5,
UDP_MIB_SNDBUFERRORS = 6,
UDP_MIB_CSUMERRORS = 7,
UDP_MIB_IGNOREDMULTI = 8,
UDP_MIB_MEMERRORS = 9,
__UDP_MIB_MAX = 10,
};
enum {
LINUX_MIB_NUM = 0,
LINUX_MIB_SYNCOOKIESSENT = 1,
LINUX_MIB_SYNCOOKIESRECV = 2,
LINUX_MIB_SYNCOOKIESFAILED = 3,
LINUX_MIB_EMBRYONICRSTS = 4,
LINUX_MIB_PRUNECALLED = 5,
LINUX_MIB_RCVPRUNED = 6,
LINUX_MIB_OFOPRUNED = 7,
LINUX_MIB_OUTOFWINDOWICMPS = 8,
LINUX_MIB_LOCKDROPPEDICMPS = 9,
LINUX_MIB_ARPFILTER = 10,
LINUX_MIB_TIMEWAITED = 11,
LINUX_MIB_TIMEWAITRECYCLED = 12,
LINUX_MIB_TIMEWAITKILLED = 13,
LINUX_MIB_PAWSACTIVEREJECTED = 14,
LINUX_MIB_PAWSESTABREJECTED = 15,
LINUX_MIB_DELAYEDACKS = 16,
LINUX_MIB_DELAYEDACKLOCKED = 17,
LINUX_MIB_DELAYEDACKLOST = 18,
LINUX_MIB_LISTENOVERFLOWS = 19,
LINUX_MIB_LISTENDROPS = 20,
LINUX_MIB_TCPHPHITS = 21,
LINUX_MIB_TCPPUREACKS = 22,
LINUX_MIB_TCPHPACKS = 23,
LINUX_MIB_TCPRENORECOVERY = 24,
LINUX_MIB_TCPSACKRECOVERY = 25,
LINUX_MIB_TCPSACKRENEGING = 26,
LINUX_MIB_TCPSACKREORDER = 27,
LINUX_MIB_TCPRENOREORDER = 28,
LINUX_MIB_TCPTSREORDER = 29,
LINUX_MIB_TCPFULLUNDO = 30,
LINUX_MIB_TCPPARTIALUNDO = 31,
LINUX_MIB_TCPDSACKUNDO = 32,
LINUX_MIB_TCPLOSSUNDO = 33,
LINUX_MIB_TCPLOSTRETRANSMIT = 34,
LINUX_MIB_TCPRENOFAILURES = 35,
LINUX_MIB_TCPSACKFAILURES = 36,
LINUX_MIB_TCPLOSSFAILURES = 37,
LINUX_MIB_TCPFASTRETRANS = 38,
LINUX_MIB_TCPSLOWSTARTRETRANS = 39,
LINUX_MIB_TCPTIMEOUTS = 40,
LINUX_MIB_TCPLOSSPROBES = 41,
LINUX_MIB_TCPLOSSPROBERECOVERY = 42,
LINUX_MIB_TCPRENORECOVERYFAIL = 43,
LINUX_MIB_TCPSACKRECOVERYFAIL = 44,
LINUX_MIB_TCPRCVCOLLAPSED = 45,
LINUX_MIB_TCPDSACKOLDSENT = 46,
LINUX_MIB_TCPDSACKOFOSENT = 47,
LINUX_MIB_TCPDSACKRECV = 48,
LINUX_MIB_TCPDSACKOFORECV = 49,
LINUX_MIB_TCPABORTONDATA = 50,
LINUX_MIB_TCPABORTONCLOSE = 51,
LINUX_MIB_TCPABORTONMEMORY = 52,
LINUX_MIB_TCPABORTONTIMEOUT = 53,
LINUX_MIB_TCPABORTONLINGER = 54,
LINUX_MIB_TCPABORTFAILED = 55,
LINUX_MIB_TCPMEMORYPRESSURES = 56,
LINUX_MIB_TCPMEMORYPRESSURESCHRONO = 57,
LINUX_MIB_TCPSACKDISCARD = 58,
LINUX_MIB_TCPDSACKIGNOREDOLD = 59,
LINUX_MIB_TCPDSACKIGNOREDNOUNDO = 60,
LINUX_MIB_TCPSPURIOUSRTOS = 61,
LINUX_MIB_TCPMD5NOTFOUND = 62,
LINUX_MIB_TCPMD5UNEXPECTED = 63,
LINUX_MIB_TCPMD5FAILURE = 64,
LINUX_MIB_SACKSHIFTED = 65,
LINUX_MIB_SACKMERGED = 66,
LINUX_MIB_SACKSHIFTFALLBACK = 67,
LINUX_MIB_TCPBACKLOGDROP = 68,
LINUX_MIB_PFMEMALLOCDROP = 69,
LINUX_MIB_TCPMINTTLDROP = 70,
LINUX_MIB_TCPDEFERACCEPTDROP = 71,
LINUX_MIB_IPRPFILTER = 72,
LINUX_MIB_TCPTIMEWAITOVERFLOW = 73,
LINUX_MIB_TCPREQQFULLDOCOOKIES = 74,
LINUX_MIB_TCPREQQFULLDROP = 75,
LINUX_MIB_TCPRETRANSFAIL = 76,
LINUX_MIB_TCPRCVCOALESCE = 77,
LINUX_MIB_TCPBACKLOGCOALESCE = 78,
LINUX_MIB_TCPOFOQUEUE = 79,
LINUX_MIB_TCPOFODROP = 80,
LINUX_MIB_TCPOFOMERGE = 81,
LINUX_MIB_TCPCHALLENGEACK = 82,
LINUX_MIB_TCPSYNCHALLENGE = 83,
LINUX_MIB_TCPFASTOPENACTIVE = 84,
LINUX_MIB_TCPFASTOPENACTIVEFAIL = 85,
LINUX_MIB_TCPFASTOPENPASSIVE = 86,
LINUX_MIB_TCPFASTOPENPASSIVEFAIL = 87,
LINUX_MIB_TCPFASTOPENLISTENOVERFLOW = 88,
LINUX_MIB_TCPFASTOPENCOOKIEREQD = 89,
LINUX_MIB_TCPFASTOPENBLACKHOLE = 90,
LINUX_MIB_TCPSPURIOUS_RTX_HOSTQUEUES = 91,
LINUX_MIB_BUSYPOLLRXPACKETS = 92,
LINUX_MIB_TCPAUTOCORKING = 93,
LINUX_MIB_TCPFROMZEROWINDOWADV = 94,
LINUX_MIB_TCPTOZEROWINDOWADV = 95,
LINUX_MIB_TCPWANTZEROWINDOWADV = 96,
LINUX_MIB_TCPSYNRETRANS = 97,
LINUX_MIB_TCPORIGDATASENT = 98,
LINUX_MIB_TCPHYSTARTTRAINDETECT = 99,
LINUX_MIB_TCPHYSTARTTRAINCWND = 100,
LINUX_MIB_TCPHYSTARTDELAYDETECT = 101,
LINUX_MIB_TCPHYSTARTDELAYCWND = 102,
LINUX_MIB_TCPACKSKIPPEDSYNRECV = 103,
LINUX_MIB_TCPACKSKIPPEDPAWS = 104,
LINUX_MIB_TCPACKSKIPPEDSEQ = 105,
LINUX_MIB_TCPACKSKIPPEDFINWAIT2 = 106,
LINUX_MIB_TCPACKSKIPPEDTIMEWAIT = 107,
LINUX_MIB_TCPACKSKIPPEDCHALLENGE = 108,
LINUX_MIB_TCPWINPROBE = 109,
LINUX_MIB_TCPKEEPALIVE = 110,
LINUX_MIB_TCPMTUPFAIL = 111,
LINUX_MIB_TCPMTUPSUCCESS = 112,
LINUX_MIB_TCPDELIVERED = 113,
LINUX_MIB_TCPDELIVEREDCE = 114,
LINUX_MIB_TCPACKCOMPRESSED = 115,
LINUX_MIB_TCPZEROWINDOWDROP = 116,
LINUX_MIB_TCPRCVQDROP = 117,
LINUX_MIB_TCPWQUEUETOOBIG = 118,
LINUX_MIB_TCPFASTOPENPASSIVEALTKEY = 119,
LINUX_MIB_TCPTIMEOUTREHASH = 120,
LINUX_MIB_TCPDUPLICATEDATAREHASH = 121,
LINUX_MIB_TCPDSACKRECVSEGS = 122,
LINUX_MIB_TCPDSACKIGNOREDDUBIOUS = 123,
LINUX_MIB_TCPMIGRATEREQSUCCESS = 124,
LINUX_MIB_TCPMIGRATEREQFAILURE = 125,
__LINUX_MIB_MAX = 126,
};
enum {
LINUX_MIB_XFRMNUM = 0,
LINUX_MIB_XFRMINERROR = 1,
LINUX_MIB_XFRMINBUFFERERROR = 2,
LINUX_MIB_XFRMINHDRERROR = 3,
LINUX_MIB_XFRMINNOSTATES = 4,
LINUX_MIB_XFRMINSTATEPROTOERROR = 5,
LINUX_MIB_XFRMINSTATEMODEERROR = 6,
LINUX_MIB_XFRMINSTATESEQERROR = 7,
LINUX_MIB_XFRMINSTATEEXPIRED = 8,
LINUX_MIB_XFRMINSTATEMISMATCH = 9,
LINUX_MIB_XFRMINSTATEINVALID = 10,
LINUX_MIB_XFRMINTMPLMISMATCH = 11,
LINUX_MIB_XFRMINNOPOLS = 12,
LINUX_MIB_XFRMINPOLBLOCK = 13,
LINUX_MIB_XFRMINPOLERROR = 14,
LINUX_MIB_XFRMOUTERROR = 15,
LINUX_MIB_XFRMOUTBUNDLEGENERROR = 16,
LINUX_MIB_XFRMOUTBUNDLECHECKERROR = 17,
LINUX_MIB_XFRMOUTNOSTATES = 18,
LINUX_MIB_XFRMOUTSTATEPROTOERROR = 19,
LINUX_MIB_XFRMOUTSTATEMODEERROR = 20,
LINUX_MIB_XFRMOUTSTATESEQERROR = 21,
LINUX_MIB_XFRMOUTSTATEEXPIRED = 22,
LINUX_MIB_XFRMOUTPOLBLOCK = 23,
LINUX_MIB_XFRMOUTPOLDEAD = 24,
LINUX_MIB_XFRMOUTPOLERROR = 25,
LINUX_MIB_XFRMFWDHDRERROR = 26,
LINUX_MIB_XFRMOUTSTATEINVALID = 27,
LINUX_MIB_XFRMACQUIREERROR = 28,
__LINUX_MIB_XFRMMAX = 29,
};
enum {
LINUX_MIB_TLSNUM = 0,
LINUX_MIB_TLSCURRTXSW = 1,
LINUX_MIB_TLSCURRRXSW = 2,
LINUX_MIB_TLSCURRTXDEVICE = 3,
LINUX_MIB_TLSCURRRXDEVICE = 4,
LINUX_MIB_TLSTXSW = 5,
LINUX_MIB_TLSRXSW = 6,
LINUX_MIB_TLSTXDEVICE = 7,
LINUX_MIB_TLSRXDEVICE = 8,
LINUX_MIB_TLSDECRYPTERROR = 9,
LINUX_MIB_TLSRXDEVICERESYNC = 10,
LINUX_MIB_TLSDECRYPTRETRY = 11,
LINUX_MIB_TLSRXNOPADVIOL = 12,
__LINUX_MIB_TLSMAX = 13,
};
enum nf_inet_hooks {
NF_INET_PRE_ROUTING = 0,
NF_INET_LOCAL_IN = 1,
NF_INET_FORWARD = 2,
NF_INET_LOCAL_OUT = 3,
NF_INET_POST_ROUTING = 4,
NF_INET_NUMHOOKS = 5,
NF_INET_INGRESS = 5,
};
enum {
NFPROTO_UNSPEC = 0,
NFPROTO_INET = 1,
NFPROTO_IPV4 = 2,
NFPROTO_ARP = 3,
NFPROTO_NETDEV = 5,
NFPROTO_BRIDGE = 7,
NFPROTO_IPV6 = 10,
NFPROTO_NUMPROTO = 11,
};
enum tcp_conntrack {
TCP_CONNTRACK_NONE = 0,
TCP_CONNTRACK_SYN_SENT = 1,
TCP_CONNTRACK_SYN_RECV = 2,
TCP_CONNTRACK_ESTABLISHED = 3,
TCP_CONNTRACK_FIN_WAIT = 4,
TCP_CONNTRACK_CLOSE_WAIT = 5,
TCP_CONNTRACK_LAST_ACK = 6,
TCP_CONNTRACK_TIME_WAIT = 7,
TCP_CONNTRACK_CLOSE = 8,
TCP_CONNTRACK_LISTEN = 9,
TCP_CONNTRACK_MAX = 10,
TCP_CONNTRACK_IGNORE = 11,
TCP_CONNTRACK_RETRANS = 12,
TCP_CONNTRACK_UNACK = 13,
TCP_CONNTRACK_TIMEOUT_MAX = 14,
};
enum ct_dccp_states {
CT_DCCP_NONE = 0,
CT_DCCP_REQUEST = 1,
CT_DCCP_RESPOND = 2,
CT_DCCP_PARTOPEN = 3,
CT_DCCP_OPEN = 4,
CT_DCCP_CLOSEREQ = 5,
CT_DCCP_CLOSING = 6,
CT_DCCP_TIMEWAIT = 7,
CT_DCCP_IGNORE = 8,
CT_DCCP_INVALID = 9,
__CT_DCCP_MAX = 10,
};
enum ip_conntrack_dir {
IP_CT_DIR_ORIGINAL = 0,
IP_CT_DIR_REPLY = 1,
IP_CT_DIR_MAX = 2,
};
enum sctp_conntrack {
SCTP_CONNTRACK_NONE = 0,
SCTP_CONNTRACK_CLOSED = 1,
SCTP_CONNTRACK_COOKIE_WAIT = 2,
SCTP_CONNTRACK_COOKIE_ECHOED = 3,
SCTP_CONNTRACK_ESTABLISHED = 4,
SCTP_CONNTRACK_SHUTDOWN_SENT = 5,
SCTP_CONNTRACK_SHUTDOWN_RECD = 6,
SCTP_CONNTRACK_SHUTDOWN_ACK_SENT = 7,
SCTP_CONNTRACK_HEARTBEAT_SENT = 8,
SCTP_CONNTRACK_HEARTBEAT_ACKED = 9,
SCTP_CONNTRACK_MAX = 10,
};
enum udp_conntrack {
UDP_CT_UNREPLIED = 0,
UDP_CT_REPLIED = 1,
UDP_CT_MAX = 2,
};
enum gre_conntrack {
GRE_CT_UNREPLIED = 0,
GRE_CT_REPLIED = 1,
GRE_CT_MAX = 2,
};
enum {
XFRM_POLICY_IN = 0,
XFRM_POLICY_OUT = 1,
XFRM_POLICY_FWD = 2,
XFRM_POLICY_MASK = 3,
XFRM_POLICY_MAX = 3,
};
enum netns_bpf_attach_type {
NETNS_BPF_INVALID = -1,
NETNS_BPF_FLOW_DISSECTOR = 0,
NETNS_BPF_SK_LOOKUP = 1,
MAX_NETNS_BPF_ATTACH_TYPE = 2,
};
struct genlmsghdr {
__u8 cmd;
__u8 version;
__u16 reserved;
};
struct genl_info {
u32 snd_seq;
u32 snd_portid;
struct nlmsghdr *nlhdr;
struct genlmsghdr *genlhdr;
void *userhdr;
struct nlattr **attrs;
possible_net_t _net;
void *user_ptr[2];
struct netlink_ext_ack *extack;
};
struct ethnl_req_info {
struct net_device *dev;
netdevice_tracker dev_tracker;
u32 flags;
};
struct ethnl_reply_data {
struct net_device *dev;
};
struct ethnl_request_ops {
u8 request_cmd;
u8 reply_cmd;
u16 hdr_attr;
unsigned int req_info_size;
unsigned int reply_data_size;
bool allow_nodev_do;
int (*parse_request)(struct ethnl_req_info *, struct nlattr **, struct netlink_ext_ack *);
int (*prepare_data)(const struct ethnl_req_info *, struct ethnl_reply_data *, struct genl_info *);
int (*reply_size)(const struct ethnl_req_info *, const struct ethnl_reply_data *);
int (*fill_reply)(struct sk_buff *, const struct ethnl_req_info *, const struct ethnl_reply_data *);
void (*cleanup_data)(struct ethnl_reply_data *);
};
typedef const char (* const ethnl_string_array_t)[32];
struct debug_reply_data {
struct ethnl_reply_data base;
u32 msg_mask;
};
typedef __u16 __sum16;
enum {
DUMP_PREFIX_NONE = 0,
DUMP_PREFIX_ADDRESS = 1,
DUMP_PREFIX_OFFSET = 2,
};
struct static_key_true {
struct static_key key;
};
struct rhltable {
struct rhashtable ht;
};
struct in_addr {
__be32 s_addr;
};
struct ip_mreqn {
struct in_addr imr_multiaddr;
struct in_addr imr_address;
int imr_ifindex;
};
struct flow_dissector_key_control {
u16 thoff;
u16 addr_type;
u32 flags;
};
struct flow_dissector_key_basic {
__be16 n_proto;
u8 ip_proto;
u8 padding;
};
struct flow_dissector_key_tags {
u32 flow_label;
};
struct flow_dissector_key_vlan {
union {
struct {
u16 vlan_id: 12;
u16 vlan_dei: 1;
u16 vlan_priority: 3;
};
__be16 vlan_tci;
};
__be16 vlan_tpid;
__be16 vlan_eth_type;
u16 padding;
};
struct flow_dissector_key_keyid {
__be32 keyid;
};
struct flow_dissector_key_ipv4_addrs {
__be32 src;
__be32 dst;
};
struct flow_dissector_key_ipv6_addrs {
struct in6_addr src;
struct in6_addr dst;
};
struct flow_dissector_key_tipc {
__be32 key;
};
struct flow_dissector_key_addrs {
union {
struct flow_dissector_key_ipv4_addrs v4addrs;
struct flow_dissector_key_ipv6_addrs v6addrs;
struct flow_dissector_key_tipc tipckey;
};
};
struct flow_dissector_key_ports {
union {
__be32 ports;
struct {
__be16 src;
__be16 dst;
};
};
};
struct flow_dissector_key_icmp {
struct {
u8 type;
u8 code;
};
u16 id;
};
enum flow_dissector_key_id {
FLOW_DISSECTOR_KEY_CONTROL = 0,
FLOW_DISSECTOR_KEY_BASIC = 1,
FLOW_DISSECTOR_KEY_IPV4_ADDRS = 2,
FLOW_DISSECTOR_KEY_IPV6_ADDRS = 3,
FLOW_DISSECTOR_KEY_PORTS = 4,
FLOW_DISSECTOR_KEY_PORTS_RANGE = 5,
FLOW_DISSECTOR_KEY_ICMP = 6,
FLOW_DISSECTOR_KEY_ETH_ADDRS = 7,
FLOW_DISSECTOR_KEY_TIPC = 8,
FLOW_DISSECTOR_KEY_ARP = 9,
FLOW_DISSECTOR_KEY_VLAN = 10,
FLOW_DISSECTOR_KEY_FLOW_LABEL = 11,
FLOW_DISSECTOR_KEY_GRE_KEYID = 12,
FLOW_DISSECTOR_KEY_MPLS_ENTROPY = 13,
FLOW_DISSECTOR_KEY_ENC_KEYID = 14,
FLOW_DISSECTOR_KEY_ENC_IPV4_ADDRS = 15,
FLOW_DISSECTOR_KEY_ENC_IPV6_ADDRS = 16,
FLOW_DISSECTOR_KEY_ENC_CONTROL = 17,
FLOW_DISSECTOR_KEY_ENC_PORTS = 18,
FLOW_DISSECTOR_KEY_MPLS = 19,
FLOW_DISSECTOR_KEY_TCP = 20,
FLOW_DISSECTOR_KEY_IP = 21,
FLOW_DISSECTOR_KEY_CVLAN = 22,
FLOW_DISSECTOR_KEY_ENC_IP = 23,
FLOW_DISSECTOR_KEY_ENC_OPTS = 24,
FLOW_DISSECTOR_KEY_META = 25,
FLOW_DISSECTOR_KEY_CT = 26,
FLOW_DISSECTOR_KEY_HASH = 27,
FLOW_DISSECTOR_KEY_NUM_OF_VLANS = 28,
FLOW_DISSECTOR_KEY_PPPOE = 29,
FLOW_DISSECTOR_KEY_L2TPV3 = 30,
FLOW_DISSECTOR_KEY_MAX = 31,
};
struct flow_dissector {
unsigned int used_keys;
short unsigned int offset[31];
};
struct flow_keys {
struct flow_dissector_key_control control;
struct flow_dissector_key_basic basic;
struct flow_dissector_key_tags tags;
struct flow_dissector_key_vlan vlan;
struct flow_dissector_key_vlan cvlan;
struct flow_dissector_key_keyid keyid;
struct flow_dissector_key_ports ports;
struct flow_dissector_key_icmp icmp;
struct flow_dissector_key_addrs addrs;
long: 32;
};
struct inet_ehash_bucket;
struct inet_bind_hashbucket;
struct inet_listen_hashbucket;
struct inet_hashinfo {
struct inet_ehash_bucket *ehash;
spinlock_t *ehash_locks;
unsigned int ehash_mask;
unsigned int ehash_locks_mask;
struct kmem_cache *bind_bucket_cachep;
struct inet_bind_hashbucket *bhash;
struct kmem_cache *bind2_bucket_cachep;
struct inet_bind_hashbucket *bhash2;
unsigned int bhash_size;
unsigned int lhash2_mask;
struct inet_listen_hashbucket *lhash2;
bool pernet;
};
struct ipv4_devconf {
void *sysctl;
int data[33];
long unsigned int state[2];
};
struct ip_ra_chain {
struct ip_ra_chain *next;
struct sock *sk;
union {
void (*destructor)(struct sock *);
struct sock *saved_sk;
};
struct callback_head rcu;
};
struct fib_table {
struct hlist_node tb_hlist;
u32 tb_id;
int tb_num_default;
struct callback_head rcu;
long unsigned int *tb_data;
long unsigned int __data[0];
};
struct inet_peer_base {
struct rb_root rb_root;
seqlock_t lock;
int total;
};
struct tcp_fastopen_context {
siphash_key_t key[2];
int num;
struct callback_head rcu;
long: 32;
};
struct mr_table_ops {
const struct rhashtable_params *rht_params;
void *cmparg_any;
};
struct vif_device {
struct net_device *dev;
netdevice_tracker dev_tracker;
long unsigned int bytes_in;
long unsigned int bytes_out;
long unsigned int pkt_in;
long unsigned int pkt_out;
long unsigned int rate_limit;
unsigned char threshold;
short unsigned int flags;
int link;
struct netdev_phys_item_id dev_parent_id;
__be32 local;
__be32 remote;
};
struct mr_table {
struct list_head list;
possible_net_t net;
struct mr_table_ops ops;
u32 id;
struct sock *mroute_sk;
struct timer_list ipmr_expire_timer;
struct list_head mfc_unres_queue;
struct vif_device vif_table[32];
struct rhltable mfc_hash;
struct list_head mfc_cache_list;
int maxvif;
atomic_t cache_resolve_queue_len;
bool mroute_do_assert;
bool mroute_do_pim;
bool mroute_do_wrvifwhole;
int mroute_reg_vif_num;
};
struct rt6key {
struct in6_addr addr;
int plen;
};
struct rtable;
struct fnhe_hash_bucket;
struct fib_nh_common {
struct net_device *nhc_dev;
netdevice_tracker nhc_dev_tracker;
int nhc_oif;
unsigned char nhc_scope;
u8 nhc_family;
u8 nhc_gw_family;
unsigned char nhc_flags;
struct lwtunnel_state *nhc_lwtstate;
union {
__be32 ipv4;
struct in6_addr ipv6;
} nhc_gw;
int nhc_weight;
atomic_t nhc_upper_bound;
struct rtable **nhc_pcpu_rth_output;
struct rtable *nhc_rth_input;
struct fnhe_hash_bucket *nhc_exceptions;
};
struct rt6_exception_bucket;
struct fib6_nh {
struct fib_nh_common nh_common;
long unsigned int last_probe;
struct rt6_info **rt6i_pcpu;
struct rt6_exception_bucket *rt6i_exception_bucket;
};
struct fib6_node;
struct dst_metrics;
struct nexthop;
struct fib6_info {
struct fib6_table *fib6_table;
struct fib6_info *fib6_next;
struct fib6_node *fib6_node;
union {
struct list_head fib6_siblings;
struct list_head nh_list;
};
unsigned int fib6_nsiblings;
refcount_t fib6_ref;
long unsigned int expires;
struct dst_metrics *fib6_metrics;
struct rt6key fib6_dst;
u32 fib6_flags;
struct rt6key fib6_src;
struct rt6key fib6_prefsrc;
u32 fib6_metric;
u8 fib6_protocol;
u8 fib6_type;
u8 offload;
u8 trap;
u8 offload_failed;
u8 should_flush: 1;
u8 dst_nocount: 1;
u8 dst_nopolicy: 1;
u8 fib6_destroying: 1;
u8 unused: 4;
struct callback_head rcu;
struct nexthop *nh;
struct fib6_nh fib6_nh[0];
};
struct uncached_list;
struct rt6_info {
struct dst_entry dst;
struct fib6_info *from;
int sernum;
struct rt6key rt6i_dst;
struct rt6key rt6i_src;
struct in6_addr rt6i_gateway;
struct inet6_dev *rt6i_idev;
u32 rt6i_flags;
struct list_head rt6i_uncached;
struct uncached_list *rt6i_uncached_list;
short unsigned int rt6i_nfheader_len;
};
struct rt6_statistics {
__u32 fib_nodes;
__u32 fib_route_nodes;
__u32 fib_rt_entries;
__u32 fib_rt_cache;
__u32 fib_discarded_routes;
atomic_t fib_rt_alloc;
};
struct fib6_node {
struct fib6_node *parent;
struct fib6_node *left;
struct fib6_node *right;
struct fib6_info *leaf;
__u16 fn_bit;
__u16 fn_flags;
int fn_sernum;
struct fib6_info *rr_ptr;
struct callback_head rcu;
};
struct fib6_table {
struct hlist_node tb6_hlist;
u32 tb6_id;
spinlock_t tb6_lock;
struct fib6_node tb6_root;
struct inet_peer_base tb6_peers;
unsigned int flags;
unsigned int fib_seq;
};
struct nf_hook_state;
typedef unsigned int nf_hookfn(void *, struct sk_buff *, const struct nf_hook_state *);
struct nf_hook_entry {
nf_hookfn *hook;
void *priv;
};
struct nf_hook_entries {
u16 num_hook_entries;
struct nf_hook_entry hooks[0];
};
struct hlist_nulls_head {
struct hlist_nulls_node *first;
};
typedef union {
__be32 a4;
__be32 a6[4];
struct in6_addr in6;
} xfrm_address_t;
struct xfrm_id {
xfrm_address_t daddr;
__be32 spi;
__u8 proto;
};
struct xfrm_sec_ctx {
__u8 ctx_doi;
__u8 ctx_alg;
__u16 ctx_len;
__u32 ctx_sid;
char ctx_str[0];
};
struct xfrm_selector {
xfrm_address_t daddr;
xfrm_address_t saddr;
__be16 dport;
__be16 dport_mask;
__be16 sport;
__be16 sport_mask;
__u16 family;
__u8 prefixlen_d;
__u8 prefixlen_s;
__u8 proto;
int ifindex;
__kernel_uid32_t user;
};
struct xfrm_lifetime_cfg {
__u64 soft_byte_limit;
__u64 hard_byte_limit;
__u64 soft_packet_limit;
__u64 hard_packet_limit;
__u64 soft_add_expires_seconds;
__u64 hard_add_expires_seconds;
__u64 soft_use_expires_seconds;
__u64 hard_use_expires_seconds;
};
struct xfrm_lifetime_cur {
__u64 bytes;
__u64 packets;
__u64 add_time;
__u64 use_time;
};
struct xfrm_replay_state {
__u32 oseq;
__u32 seq;
__u32 bitmap;
};
struct xfrm_replay_state_esn {
unsigned int bmp_len;
__u32 oseq;
__u32 seq;
__u32 oseq_hi;
__u32 seq_hi;
__u32 replay_window;
__u32 bmp[0];
};
struct xfrm_algo {
char alg_name[64];
unsigned int alg_key_len;
char alg_key[0];
};
struct xfrm_algo_auth {
char alg_name[64];
unsigned int alg_key_len;
unsigned int alg_trunc_len;
char alg_key[0];
};
struct xfrm_algo_aead {
char alg_name[64];
unsigned int alg_key_len;
unsigned int alg_icv_len;
char alg_key[0];
};
struct xfrm_stats {
__u32 replay_window;
__u32 replay;
__u32 integrity_failed;
};
enum {
XFRM_POLICY_TYPE_MAIN = 0,
XFRM_POLICY_TYPE_SUB = 1,
XFRM_POLICY_TYPE_MAX = 2,
XFRM_POLICY_TYPE_ANY = 255,
};
enum {
XFRM_MSG_BASE = 16,
XFRM_MSG_NEWSA = 16,
XFRM_MSG_DELSA = 17,
XFRM_MSG_GETSA = 18,
XFRM_MSG_NEWPOLICY = 19,
XFRM_MSG_DELPOLICY = 20,
XFRM_MSG_GETPOLICY = 21,
XFRM_MSG_ALLOCSPI = 22,
XFRM_MSG_ACQUIRE = 23,
XFRM_MSG_EXPIRE = 24,
XFRM_MSG_UPDPOLICY = 25,
XFRM_MSG_UPDSA = 26,
XFRM_MSG_POLEXPIRE = 27,
XFRM_MSG_FLUSHSA = 28,
XFRM_MSG_FLUSHPOLICY = 29,
XFRM_MSG_NEWAE = 30,
XFRM_MSG_GETAE = 31,
XFRM_MSG_REPORT = 32,
XFRM_MSG_MIGRATE = 33,
XFRM_MSG_NEWSADINFO = 34,
XFRM_MSG_GETSADINFO = 35,
XFRM_MSG_NEWSPDINFO = 36,
XFRM_MSG_GETSPDINFO = 37,
XFRM_MSG_MAPPING = 38,
XFRM_MSG_SETDEFAULT = 39,
XFRM_MSG_GETDEFAULT = 40,
__XFRM_MSG_MAX = 41,
};
struct xfrm_encap_tmpl {
__u16 encap_type;
__be16 encap_sport;
__be16 encap_dport;
xfrm_address_t encap_oa;
};
enum xfrm_attr_type_t {
XFRMA_UNSPEC = 0,
XFRMA_ALG_AUTH = 1,
XFRMA_ALG_CRYPT = 2,
XFRMA_ALG_COMP = 3,
XFRMA_ENCAP = 4,
XFRMA_TMPL = 5,
XFRMA_SA = 6,
XFRMA_POLICY = 7,
XFRMA_SEC_CTX = 8,
XFRMA_LTIME_VAL = 9,
XFRMA_REPLAY_VAL = 10,
XFRMA_REPLAY_THRESH = 11,
XFRMA_ETIMER_THRESH = 12,
XFRMA_SRCADDR = 13,
XFRMA_COADDR = 14,
XFRMA_LASTUSED = 15,
XFRMA_POLICY_TYPE = 16,
XFRMA_MIGRATE = 17,
XFRMA_ALG_AEAD = 18,
XFRMA_KMADDRESS = 19,
XFRMA_ALG_AUTH_TRUNC = 20,
XFRMA_MARK = 21,
XFRMA_TFCPAD = 22,
XFRMA_REPLAY_ESN_VAL = 23,
XFRMA_SA_EXTRA_FLAGS = 24,
XFRMA_PROTO = 25,
XFRMA_ADDRESS_FILTER = 26,
XFRMA_PAD = 27,
XFRMA_OFFLOAD_DEV = 28,
XFRMA_SET_MARK = 29,
XFRMA_SET_MARK_MASK = 30,
XFRMA_IF_ID = 31,
XFRMA_MTIMER_THRESH = 32,
__XFRMA_MAX = 33,
};
struct xfrm_mark {
__u32 v;
__u32 m;
};
struct xfrm_address_filter {
xfrm_address_t saddr;
xfrm_address_t daddr;
__u16 family;
__u8 splen;
__u8 dplen;
};
enum macsec_validation_type {
MACSEC_VALIDATE_DISABLED = 0,
MACSEC_VALIDATE_CHECK = 1,
MACSEC_VALIDATE_STRICT = 2,
__MACSEC_VALIDATE_END = 3,
MACSEC_VALIDATE_MAX = 2,
};
enum macsec_offload {
MACSEC_OFFLOAD_OFF = 0,
MACSEC_OFFLOAD_PHY = 1,
MACSEC_OFFLOAD_MAC = 2,
__MACSEC_OFFLOAD_END = 3,
MACSEC_OFFLOAD_MAX = 2,
};
struct iphdr {
__u8 ihl: 4;
__u8 version: 4;
__u8 tos;
__be16 tot_len;
__be16 id;
__be16 frag_off;
__u8 ttl;
__u8 protocol;
__sum16 check;
union {
struct {
__be32 saddr;
__be32 daddr;
};
struct {
__be32 saddr;
__be32 daddr;
} addrs;
};
};
struct ip_tunnel_parm {
char name[16];
int link;
__be16 i_flags;
__be16 o_flags;
__be32 i_key;
__be32 o_key;
struct iphdr iph;
};
struct in_ifaddr;
struct ip_mc_list;
struct in_device {
struct net_device *dev;
netdevice_tracker dev_tracker;
refcount_t refcnt;
int dead;
struct in_ifaddr *ifa_list;
struct ip_mc_list *mc_list;
struct ip_mc_list **mc_hash;
int mc_count;
spinlock_t mc_tomb_lock;
struct ip_mc_list *mc_tomb;
long unsigned int mr_v1_seen;
long unsigned int mr_v2_seen;
long unsigned int mr_maxdelay;
long unsigned int mr_qi;
long unsigned int mr_qri;
unsigned char mr_qrv;
unsigned char mr_gq_running;
u32 mr_ifc_count;
struct timer_list mr_gq_timer;
struct timer_list mr_ifc_timer;
struct neigh_parms *arp_parms;
struct ipv4_devconf cnf;
struct callback_head callback_head;
};
enum {
IPV4_DEVCONF_FORWARDING = 1,
IPV4_DEVCONF_MC_FORWARDING = 2,
IPV4_DEVCONF_PROXY_ARP = 3,
IPV4_DEVCONF_ACCEPT_REDIRECTS = 4,
IPV4_DEVCONF_SECURE_REDIRECTS = 5,
IPV4_DEVCONF_SEND_REDIRECTS = 6,
IPV4_DEVCONF_SHARED_MEDIA = 7,
IPV4_DEVCONF_RP_FILTER = 8,
IPV4_DEVCONF_ACCEPT_SOURCE_ROUTE = 9,
IPV4_DEVCONF_BOOTP_RELAY = 10,
IPV4_DEVCONF_LOG_MARTIANS = 11,
IPV4_DEVCONF_TAG = 12,
IPV4_DEVCONF_ARPFILTER = 13,
IPV4_DEVCONF_MEDIUM_ID = 14,
IPV4_DEVCONF_NOXFRM = 15,
IPV4_DEVCONF_NOPOLICY = 16,
IPV4_DEVCONF_FORCE_IGMP_VERSION = 17,
IPV4_DEVCONF_ARP_ANNOUNCE = 18,
IPV4_DEVCONF_ARP_IGNORE = 19,
IPV4_DEVCONF_PROMOTE_SECONDARIES = 20,
IPV4_DEVCONF_ARP_ACCEPT = 21,
IPV4_DEVCONF_ARP_NOTIFY = 22,
IPV4_DEVCONF_ACCEPT_LOCAL = 23,
IPV4_DEVCONF_SRC_VMARK = 24,
IPV4_DEVCONF_PROXY_ARP_PVLAN = 25,
IPV4_DEVCONF_ROUTE_LOCALNET = 26,
IPV4_DEVCONF_IGMPV2_UNSOLICITED_REPORT_INTERVAL = 27,
IPV4_DEVCONF_IGMPV3_UNSOLICITED_REPORT_INTERVAL = 28,
IPV4_DEVCONF_IGNORE_ROUTES_WITH_LINKDOWN = 29,
IPV4_DEVCONF_DROP_UNICAST_IN_L2_MULTICAST = 30,
IPV4_DEVCONF_DROP_GRATUITOUS_ARP = 31,
IPV4_DEVCONF_BC_FORWARDING = 32,
IPV4_DEVCONF_ARP_EVICT_NOCARRIER = 33,
__IPV4_DEVCONF_MAX = 34,
};
struct rtmsg {
unsigned char rtm_family;
unsigned char rtm_dst_len;
unsigned char rtm_src_len;
unsigned char rtm_tos;
unsigned char rtm_table;
unsigned char rtm_protocol;
unsigned char rtm_scope;
unsigned char rtm_type;
unsigned int rtm_flags;
};
enum {
RTN_UNSPEC = 0,
RTN_UNICAST = 1,
RTN_LOCAL = 2,
RTN_BROADCAST = 3,
RTN_ANYCAST = 4,
RTN_MULTICAST = 5,
RTN_BLACKHOLE = 6,
RTN_UNREACHABLE = 7,
RTN_PROHIBIT = 8,
RTN_THROW = 9,
RTN_NAT = 10,
RTN_XRESOLVE = 11,
__RTN_MAX = 12,
};
enum rt_scope_t {
RT_SCOPE_UNIVERSE = 0,
RT_SCOPE_SITE = 200,
RT_SCOPE_LINK = 253,
RT_SCOPE_HOST = 254,
RT_SCOPE_NOWHERE = 255,
};
enum rt_class_t {
RT_TABLE_UNSPEC = 0,
RT_TABLE_COMPAT = 252,
RT_TABLE_DEFAULT = 253,
RT_TABLE_MAIN = 254,
RT_TABLE_LOCAL = 255,
RT_TABLE_MAX = 4294967295,
};
enum rtattr_type_t {
RTA_UNSPEC = 0,
RTA_DST = 1,
RTA_SRC = 2,
RTA_IIF = 3,
RTA_OIF = 4,
RTA_GATEWAY = 5,
RTA_PRIORITY = 6,
RTA_PREFSRC = 7,
RTA_METRICS = 8,
RTA_MULTIPATH = 9,
RTA_PROTOINFO = 10,
RTA_FLOW = 11,
RTA_CACHEINFO = 12,
RTA_SESSION = 13,
RTA_MP_ALGO = 14,
RTA_TABLE = 15,
RTA_MARK = 16,
RTA_MFC_STATS = 17,
RTA_VIA = 18,
RTA_NEWDST = 19,
RTA_PREF = 20,
RTA_ENCAP_TYPE = 21,
RTA_ENCAP = 22,
RTA_EXPIRES = 23,
RTA_PAD = 24,
RTA_UID = 25,
RTA_TTL_PROPAGATE = 26,
RTA_IP_PROTO = 27,
RTA_SPORT = 28,
RTA_DPORT = 29,
RTA_NH_ID = 30,
__RTA_MAX = 31,
};
struct rtvia {
__kernel_sa_family_t rtvia_family;
__u8 rtvia_addr[0];
};
struct in_ifaddr {
struct hlist_node hash;
struct in_ifaddr *ifa_next;
struct in_device *ifa_dev;
struct callback_head callback_head;
__be32 ifa_local;
__be32 ifa_address;
__be32 ifa_mask;
__u32 ifa_rt_priority;
__be32 ifa_broadcast;
unsigned char ifa_scope;
unsigned char ifa_prefixlen;
unsigned char ifa_proto;
__u32 ifa_flags;
char ifa_label[16];
__u32 ifa_valid_lft;
__u32 ifa_preferred_lft;
long unsigned int ifa_cstamp;
long unsigned int ifa_tstamp;
};
struct ip_sf_list;
struct ip_mc_list {
struct in_device *interface;
__be32 multiaddr;
unsigned int sfmode;
struct ip_sf_list *sources;
struct ip_sf_list *tomb;
long unsigned int sfcount[2];
union {
struct ip_mc_list *next;
struct ip_mc_list *next_rcu;
};
struct ip_mc_list *next_hash;
struct timer_list timer;
int users;
refcount_t refcnt;
spinlock_t lock;
char tm_running;
char reporter;
char unsolicit_count;
char loaded;
unsigned char gsquery;
unsigned char crcount;
struct callback_head rcu;
};
struct ip_sf_socklist {
unsigned int sl_max;
unsigned int sl_count;
struct callback_head rcu;
__be32 sl_addr[0];
};
struct ip_mc_socklist {
struct ip_mc_socklist *next_rcu;
struct ip_mreqn multi;
unsigned int sfmode;
struct ip_sf_socklist *sflist;
struct callback_head rcu;
};
struct ip_sf_list {
struct ip_sf_list *sf_next;
long unsigned int sf_count[2];
__be32 sf_inaddr;
unsigned char sf_gsresp;
unsigned char sf_oldin;
unsigned char sf_crcount;
};
struct nl_info {
struct nlmsghdr *nlh;
struct net *nl_net;
u32 portid;
u8 skip_notify: 1;
u8 skip_notify_kernel: 1;
};
enum rtnl_link_flags {
RTNL_FLAG_DOIT_UNLOCKED = 1,
RTNL_FLAG_BULK_DEL_SUPPORTED = 2,
};
struct xfrm_state_walk {
struct list_head all;
u8 state;
u8 dying;
u8 proto;
u32 seq;
struct xfrm_address_filter *filter;
};
enum xfrm_replay_mode {
XFRM_REPLAY_MODE_LEGACY = 0,
XFRM_REPLAY_MODE_BMP = 1,
XFRM_REPLAY_MODE_ESN = 2,
};
struct xfrm_dev_offload {
struct net_device *dev;
netdevice_tracker dev_tracker;
struct net_device *real_dev;
long unsigned int offload_handle;
u8 dir: 2;
};
struct xfrm_mode {
u8 encap;
u8 family;
u8 flags;
};
struct xfrm_type;
struct xfrm_type_offload;
struct xfrm_state {
possible_net_t xs_net;
union {
struct hlist_node gclist;
struct hlist_node bydst;
};
struct hlist_node bysrc;
struct hlist_node byspi;
struct hlist_node byseq;
refcount_t refcnt;
spinlock_t lock;
struct xfrm_id id;
struct xfrm_selector sel;
struct xfrm_mark mark;
u32 if_id;
u32 tfcpad;
u32 genid;
struct xfrm_state_walk km;
struct {
u32 reqid;
u8 mode;
u8 replay_window;
u8 aalgo;
u8 ealgo;
u8 calgo;
u8 flags;
u16 family;
xfrm_address_t saddr;
int header_len;
int trailer_len;
u32 extra_flags;
struct xfrm_mark smark;
} props;
long: 32;
struct xfrm_lifetime_cfg lft;
struct xfrm_algo_auth *aalg;
struct xfrm_algo *ealg;
struct xfrm_algo *calg;
struct xfrm_algo_aead *aead;
const char *geniv;
__be16 new_mapping_sport;
u32 new_mapping;
u32 mapping_maxage;
struct xfrm_encap_tmpl *encap;
struct sock *encap_sk;
xfrm_address_t *coaddr;
struct xfrm_state *tunnel;
atomic_t tunnel_users;
struct xfrm_replay_state replay;
struct xfrm_replay_state_esn *replay_esn;
struct xfrm_replay_state preplay;
struct xfrm_replay_state_esn *preplay_esn;
enum xfrm_replay_mode repl_mode;
u32 xflags;
u32 replay_maxage;
u32 replay_maxdiff;
struct timer_list rtimer;
struct xfrm_stats stats;
long: 32;
struct xfrm_lifetime_cur curlft;
struct hrtimer mtimer;
struct xfrm_dev_offload xso;
long int saved_tmo;
long: 32;
time64_t lastused;
struct page_frag xfrag;
const struct xfrm_type *type;
struct xfrm_mode inner_mode;
struct xfrm_mode inner_mode_iaf;
struct xfrm_mode outer_mode;
const struct xfrm_type_offload *type_offload;
struct xfrm_sec_ctx *security;
void *data;
long: 32;
};
struct lwtunnel_state {
__u16 type;
__u16 flags;
__u16 headroom;
atomic_t refcnt;
int (*orig_output)(struct net *, struct sock *, struct sk_buff *);
int (*orig_input)(struct sk_buff *);
struct callback_head rcu;
__u8 data[0];
};
struct dst_metrics {
u32 metrics[17];
refcount_t refcnt;
};
struct sk_filter {
refcount_t refcnt;
struct callback_head rcu;
struct bpf_prog *prog;
};
struct xfrm_policy_walk_entry {
struct list_head all;
u8 dead;
};
struct xfrm_policy_queue {
struct sk_buff_head hold_queue;
struct timer_list hold_timer;
long unsigned int timeout;
};
struct xfrm_tmpl {
struct xfrm_id id;
xfrm_address_t saddr;
short unsigned int encap_family;
u32 reqid;
u8 mode;
u8 share;
u8 optional;
u8 allalgs;
u32 aalgos;
u32 ealgos;
u32 calgos;
};
struct xfrm_policy {
possible_net_t xp_net;
struct hlist_node bydst;
struct hlist_node byidx;
rwlock_t lock;
refcount_t refcnt;
u32 pos;
struct timer_list timer;
atomic_t genid;
u32 priority;
u32 index;
u32 if_id;
struct xfrm_mark mark;
struct xfrm_selector selector;
struct xfrm_lifetime_cfg lft;
struct xfrm_lifetime_cur curlft;
struct xfrm_policy_walk_entry walk;
struct xfrm_policy_queue polq;
bool bydst_reinsert;
u8 type;
u8 action;
u8 flags;
u8 xfrm_nr;
u16 family;
struct xfrm_sec_ctx *security;
struct xfrm_tmpl xfrm_vec[6];
struct hlist_node bydst_inexact_list;
struct callback_head rcu;
};
struct sock_reuseport {
struct callback_head rcu;
u16 max_socks;
u16 num_socks;
u16 num_closed_socks;
unsigned int synq_overflow_ts;
unsigned int reuseport_id;
unsigned int bind_inany: 1;
unsigned int has_conns: 1;
struct bpf_prog *prog;
struct sock *socks[0];
};
enum sock_flags {
SOCK_DEAD = 0,
SOCK_DONE = 1,
SOCK_URGINLINE = 2,
SOCK_KEEPOPEN = 3,
SOCK_LINGER = 4,
SOCK_DESTROY = 5,
SOCK_BROADCAST = 6,
SOCK_TIMESTAMP = 7,
SOCK_ZAPPED = 8,
SOCK_USE_WRITE_QUEUE = 9,
SOCK_DBG = 10,
SOCK_RCVTSTAMP = 11,
SOCK_RCVTSTAMPNS = 12,
SOCK_LOCALROUTE = 13,
SOCK_MEMALLOC = 14,
SOCK_TIMESTAMPING_RX_SOFTWARE = 15,
SOCK_FASYNC = 16,
SOCK_RXQ_OVFL = 17,
SOCK_ZEROCOPY = 18,
SOCK_WIFI_STATUS = 19,
SOCK_NOFCS = 20,
SOCK_FILTER_LOCKED = 21,
SOCK_SELECT_ERR_QUEUE = 22,
SOCK_RCU_FREE = 23,
SOCK_TXTIME = 24,
SOCK_XDP = 25,
SOCK_TSTAMP_NEW = 26,
SOCK_RCVMARK = 27,
};
typedef u8 dscp_t;
struct in6_pktinfo {
struct in6_addr ipi6_addr;
int ipi6_ifindex;
};
struct ipv6_rt_hdr {
__u8 nexthdr;
__u8 hdrlen;
__u8 type;
__u8 segments_left;
};
struct ipv6_opt_hdr {
__u8 nexthdr;
__u8 hdrlen;
};
struct ip_options {
__be32 faddr;
__be32 nexthop;
unsigned char optlen;
unsigned char srr;
unsigned char rr;
unsigned char ts;
unsigned char is_strictroute: 1;
unsigned char srr_is_hit: 1;
unsigned char is_changed: 1;
unsigned char rr_needaddr: 1;
unsigned char ts_needtime: 1;
unsigned char ts_needaddr: 1;
unsigned char router_alert;
unsigned char cipso;
unsigned char __pad2;
unsigned char __data[0];
};
struct ip_options_rcu {
struct callback_head rcu;
struct ip_options opt;
};
struct ipv6_txoptions {
refcount_t refcnt;
int tot_len;
__u16 opt_flen;
__u16 opt_nflen;
struct ipv6_opt_hdr *hopopt;
struct ipv6_opt_hdr *dst0opt;
struct ipv6_rt_hdr *srcrt;
struct ipv6_opt_hdr *dst1opt;
struct callback_head rcu;
};
struct inet_cork {
unsigned int flags;
__be32 addr;
struct ip_options *opt;
unsigned int fragsize;
int length;
struct dst_entry *dst;
u8 tx_flags;
__u8 ttl;
__s16 tos;
char priority;
__u16 gso_size;
u64 transmit_time;
u32 mark;
long: 32;
};
struct inet_cork_full {
struct inet_cork base;
struct flowi fl;
};
struct ipv6_pinfo;
struct inet_sock {
struct sock sk;
struct ipv6_pinfo *pinet6;
__be32 inet_saddr;
__s16 uc_ttl;
__u16 cmsg_flags;
struct ip_options_rcu *inet_opt;
__be16 inet_sport;
__u16 inet_id;
__u8 tos;
__u8 min_ttl;
__u8 mc_ttl;
__u8 pmtudisc;
__u8 recverr: 1;
__u8 is_icsk: 1;
__u8 freebind: 1;
__u8 hdrincl: 1;
__u8 mc_loop: 1;
__u8 transparent: 1;
__u8 mc_all: 1;
__u8 nodefrag: 1;
__u8 bind_address_no_port: 1;
__u8 recverr_rfc4884: 1;
__u8 defer_connect: 1;
__u8 rcv_tos;
__u8 convert_csum;
int uc_index;
int mc_index;
__be32 mc_addr;
struct ip_mc_socklist *mc_list;
long: 32;
struct inet_cork_full cork;
};
struct inet6_cork {
struct ipv6_txoptions *opt;
u8 hop_limit;
u8 tclass;
};
struct ipv6_mc_socklist;
struct ipv6_ac_socklist;
struct ipv6_fl_socklist;
struct ipv6_pinfo {
struct in6_addr saddr;
struct in6_pktinfo sticky_pktinfo;
const struct in6_addr *daddr_cache;
__be32 flow_label;
__u32 frag_size;
__u16 __unused_1: 7;
__s16 hop_limit: 9;
__u16 mc_loop: 1;
__u16 __unused_2: 6;
__s16 mcast_hops: 9;
int ucast_oif;
int mcast_oif;
union {
struct {
__u16 srcrt: 1;
__u16 osrcrt: 1;
__u16 rxinfo: 1;
__u16 rxoinfo: 1;
__u16 rxhlim: 1;
__u16 rxohlim: 1;
__u16 hopopts: 1;
__u16 ohopopts: 1;
__u16 dstopts: 1;
__u16 odstopts: 1;
__u16 rxflow: 1;
__u16 rxtclass: 1;
__u16 rxpmtu: 1;
__u16 rxorigdstaddr: 1;
__u16 recvfragsize: 1;
} bits;
__u16 all;
} rxopt;
__u16 recverr: 1;
__u16 sndflow: 1;
__u16 repflow: 1;
__u16 pmtudisc: 3;
__u16 padding: 1;
__u16 srcprefs: 3;
__u16 dontfrag: 1;
__u16 autoflowlabel: 1;
__u16 autoflowlabel_set: 1;
__u16 mc_all: 1;
__u16 recverr_rfc4884: 1;
__u16 rtalert_isolate: 1;
__u8 min_hopcount;
__u8 tclass;
__be32 rcv_flowinfo;
__u32 dst_cookie;
struct ipv6_mc_socklist *ipv6_mc_list;
struct ipv6_ac_socklist *ipv6_ac_list;
struct ipv6_fl_socklist *ipv6_fl_list;
struct ipv6_txoptions *opt;
struct sk_buff *pktoptions;
struct sk_buff *rxpmtu;
struct inet6_cork cork;
};
struct tcphdr {
__be16 source;
__be16 dest;
__be32 seq;
__be32 ack_seq;
__u16 res1: 4;
__u16 doff: 4;
__u16 fin: 1;
__u16 syn: 1;
__u16 rst: 1;
__u16 psh: 1;
__u16 ack: 1;
__u16 urg: 1;
__u16 ece: 1;
__u16 cwr: 1;
__be16 window;
__sum16 check;
__be16 urg_ptr;
};
struct udphdr {
__be16 source;
__be16 dest;
__be16 len;
__sum16 check;
};
struct ip6_sf_socklist;
struct ipv6_mc_socklist {
struct in6_addr addr;
int ifindex;
unsigned int sfmode;
struct ipv6_mc_socklist *next;
struct ip6_sf_socklist *sflist;
struct callback_head rcu;
};
struct ipv6_ac_socklist {
struct in6_addr acl_addr;
int acl_ifindex;
struct ipv6_ac_socklist *acl_next;
};
struct ip6_flowlabel;
struct ipv6_fl_socklist {
struct ipv6_fl_socklist *next;
struct ip6_flowlabel *fl;
struct callback_head rcu;
};
struct ip6_sf_socklist {
unsigned int sl_max;
unsigned int sl_count;
struct callback_head rcu;
struct in6_addr sl_addr[0];
};
struct ip6_flowlabel {
struct ip6_flowlabel *next;
__be32 label;
atomic_t users;
struct in6_addr dst;
struct ipv6_txoptions *opt;
long unsigned int linger;
struct callback_head rcu;
u8 share;
union {
struct pid *pid;
kuid_t uid;
} owner;
long unsigned int lastuse;
long unsigned int expires;
struct net *fl_net;
};
struct ipv4_addr_key {
__be32 addr;
int vif;
};
struct inetpeer_addr {
union {
struct ipv4_addr_key a4;
struct in6_addr a6;
u32 key[4];
};
__u16 family;
};
struct inet_peer {
struct rb_node rb_node;
struct inetpeer_addr daddr;
u32 metrics[17];
u32 rate_tokens;
u32 n_redirects;
long unsigned int rate_last;
union {
struct {
atomic_t rid;
};
struct callback_head rcu;
};
__u32 dtime;
refcount_t refcnt;
};
struct fib_nh_exception {
struct fib_nh_exception *fnhe_next;
int fnhe_genid;
__be32 fnhe_daddr;
u32 fnhe_pmtu;
bool fnhe_mtu_locked;
__be32 fnhe_gw;
long unsigned int fnhe_expires;
struct rtable *fnhe_rth_input;
struct rtable *fnhe_rth_output;
long unsigned int fnhe_stamp;
struct callback_head rcu;
};
struct rtable {
struct dst_entry dst;
int rt_genid;
unsigned int rt_flags;
__u16 rt_type;
__u8 rt_is_input;
__u8 rt_uses_gateway;
int rt_iif;
u8 rt_gw_family;
union {
__be32 rt_gw4;
struct in6_addr rt_gw6;
};
u32 rt_mtu_locked: 1;
u32 rt_pmtu: 31;
struct list_head rt_uncached;
struct uncached_list *rt_uncached_list;
};
struct fnhe_hash_bucket {
struct fib_nh_exception *chain;
};
struct fib_info;
struct fib_nh {
struct fib_nh_common nh_common;
struct hlist_node nh_hash;
struct fib_info *nh_parent;
__u32 nh_tclassid;
__be32 nh_saddr;
int nh_saddr_genid;
};
struct fib_info {
struct hlist_node fib_hash;
struct hlist_node fib_lhash;
struct list_head nh_list;
struct net *fib_net;
refcount_t fib_treeref;
refcount_t fib_clntref;
unsigned int fib_flags;
unsigned char fib_dead;
unsigned char fib_protocol;
unsigned char fib_scope;
unsigned char fib_type;
__be32 fib_prefsrc;
u32 fib_tb_id;
u32 fib_priority;
struct dst_metrics *fib_metrics;
int fib_nhs;
bool fib_nh_is_v6;
bool nh_updated;
struct nexthop *nh;
struct callback_head rcu;
struct fib_nh fib_nh[0];
};
struct nh_info;
struct nh_group;
struct nexthop {
struct rb_node rb_node;
struct list_head fi_list;
struct list_head f6i_list;
struct list_head fdb_list;
struct list_head grp_list;
struct net *net;
u32 id;
u8 protocol;
u8 nh_flags;
bool is_group;
refcount_t refcnt;
struct callback_head rcu;
union {
struct nh_info *nh_info;
struct nh_group *nh_grp;
};
};
struct fib_result {
__be32 prefix;
unsigned char prefixlen;
unsigned char nh_sel;
unsigned char type;
unsigned char scope;
u32 tclassid;
struct fib_nh_common *nhc;
struct fib_info *fi;
struct fib_table *table;
struct hlist_head *fa_head;
};
struct fib_rt_info {
struct fib_info *fi;
u32 tb_id;
__be32 dst;
int dst_len;
dscp_t dscp;
u8 type;
u8 offload: 1;
u8 trap: 1;
u8 offload_failed: 1;
u8 unused: 5;
};
struct nf_hook_state {
u8 hook;
u8 pf;
struct net_device *in;
struct net_device *out;
struct sock *sk;
struct net *net;
int (*okfn)(struct net *, struct sock *, struct sk_buff *);
};
enum lwtunnel_encap_types {
LWTUNNEL_ENCAP_NONE = 0,
LWTUNNEL_ENCAP_MPLS = 1,
LWTUNNEL_ENCAP_IP = 2,
LWTUNNEL_ENCAP_ILA = 3,
LWTUNNEL_ENCAP_IP6 = 4,
LWTUNNEL_ENCAP_SEG6 = 5,
LWTUNNEL_ENCAP_BPF = 6,
LWTUNNEL_ENCAP_SEG6_LOCAL = 7,
LWTUNNEL_ENCAP_RPL = 8,
LWTUNNEL_ENCAP_IOAM6 = 9,
LWTUNNEL_ENCAP_XFRM = 10,
__LWTUNNEL_ENCAP_MAX = 11,
};
struct fib6_result;
struct fib6_config;
struct ipv6_stub {
int (*ipv6_sock_mc_join)(struct sock *, int, const struct in6_addr *);
int (*ipv6_sock_mc_drop)(struct sock *, int, const struct in6_addr *);
struct dst_entry * (*ipv6_dst_lookup_flow)(struct net *, const struct sock *, struct flowi6 *, const struct in6_addr *);
int (*ipv6_route_input)(struct sk_buff *);
struct fib6_table * (*fib6_get_table)(struct net *, u32);
int (*fib6_lookup)(struct net *, int, struct flowi6 *, struct fib6_result *, int);
int (*fib6_table_lookup)(struct net *, struct fib6_table *, int, struct flowi6 *, struct fib6_result *, int);
void (*fib6_select_path)(const struct net *, struct fib6_result *, struct flowi6 *, int, bool, const struct sk_buff *, int);
u32 (*ip6_mtu_from_fib6)(const struct fib6_result *, const struct in6_addr *, const struct in6_addr *);
int (*fib6_nh_init)(struct net *, struct fib6_nh *, struct fib6_config *, gfp_t, struct netlink_ext_ack *);
void (*fib6_nh_release)(struct fib6_nh *);
void (*fib6_nh_release_dsts)(struct fib6_nh *);
void (*fib6_update_sernum)(struct net *, struct fib6_info *);
int (*ip6_del_rt)(struct net *, struct fib6_info *, bool);
void (*fib6_rt_update)(struct net *, struct fib6_info *, struct nl_info *);
void (*udpv6_encap_enable)();
void (*ndisc_send_na)(struct net_device *, const struct in6_addr *, const struct in6_addr *, bool, bool, bool, bool);
void (*xfrm6_local_rxpmtu)(struct sk_buff *, u32);
int (*xfrm6_udp_encap_rcv)(struct sock *, struct sk_buff *);
int (*xfrm6_rcv_encap)(struct sk_buff *, int, __be32, int);
struct neigh_table *nd_tbl;
int (*ipv6_fragment)(struct net *, struct sock *, struct sk_buff *, int (*)(struct net *, struct sock *, struct sk_buff *));
struct net_device * (*ipv6_dev_find)(struct net *, const struct in6_addr *, struct net_device *);
};
struct fib6_result {
struct fib6_nh *nh;
struct fib6_info *f6i;
u32 fib6_flags;
u8 fib6_type;
struct rt6_info *rt6;
};
struct fib6_config {
u32 fc_table;
u32 fc_metric;
int fc_dst_len;
int fc_src_len;
int fc_ifindex;
u32 fc_flags;
u32 fc_protocol;
u16 fc_type;
u16 fc_delete_all_nh: 1;
u16 fc_ignore_dev_down: 1;
u16 __unused: 14;
u32 fc_nh_id;
struct in6_addr fc_dst;
struct in6_addr fc_src;
struct in6_addr fc_prefsrc;
struct in6_addr fc_gateway;
long unsigned int fc_expires;
struct nlattr *fc_mx;
int fc_mx_len;
int fc_mp_len;
struct nlattr *fc_mp;
struct nl_info fc_nlinfo;
struct nlattr *fc_encap;
u16 fc_encap_type;
bool fc_is_fdb;
};
enum {
__ND_OPT_PREFIX_INFO_END = 0,
ND_OPT_SOURCE_LL_ADDR = 1,
ND_OPT_TARGET_LL_ADDR = 2,
ND_OPT_PREFIX_INFO = 3,
ND_OPT_REDIRECT_HDR = 4,
ND_OPT_MTU = 5,
ND_OPT_NONCE = 14,
__ND_OPT_ARRAY_MAX = 15,
ND_OPT_ROUTE_INFO = 24,
ND_OPT_RDNSS = 25,
ND_OPT_DNSSL = 31,
ND_OPT_6CO = 34,
ND_OPT_CAPTIVE_PORTAL = 37,
ND_OPT_PREF64 = 38,
__ND_OPT_MAX = 39,
};
struct nd_opt_hdr {
__u8 nd_opt_type;
__u8 nd_opt_len;
};
struct ndisc_options {
struct nd_opt_hdr *nd_opt_array[15];
struct nd_opt_hdr *nd_opts_ri;
struct nd_opt_hdr *nd_opts_ri_end;
struct nd_opt_hdr *nd_useropts;
struct nd_opt_hdr *nd_useropts_end;
};
struct prefix_info {
__u8 type;
__u8 length;
__u8 prefix_len;
__u8 reserved: 6;
__u8 autoconf: 1;
__u8 onlink: 1;
__be32 valid;
__be32 prefered;
__be32 reserved2;
struct in6_addr prefix;
};
struct uncached_list {
spinlock_t lock;
struct list_head head;
struct list_head quarantine;
};
struct ip_rt_acct {
__u32 o_bytes;
__u32 o_packets;
__u32 i_bytes;
__u32 i_packets;
};
struct rt_cache_stat {
unsigned int in_slow_tot;
unsigned int in_slow_mc;
unsigned int in_no_route;
unsigned int in_brd;
unsigned int in_martian_dst;
unsigned int in_martian_src;
unsigned int out_slow_tot;
unsigned int out_slow_mc;
};
struct rt6_exception_bucket {
struct hlist_head chain;
int depth;
};
struct dst_cache_pcpu;
struct dst_cache {
struct dst_cache_pcpu *cache;
long unsigned int reset_ts;
};
struct nh_info {
struct hlist_node dev_hash;
struct nexthop *nh_parent;
u8 family;
bool reject_nh;
bool fdb_nh;
union {
struct fib_nh_common fib_nhc;
struct fib_nh fib_nh;
struct fib6_nh fib6_nh;
};
};
struct nh_grp_entry;
struct nh_res_bucket {
struct nh_grp_entry *nh_entry;
atomic_long_t used_time;
long unsigned int migrated_time;
bool occupied;
u8 nh_flags;
};
struct nh_grp_entry {
struct nexthop *nh;
u8 weight;
union {
struct {
atomic_t upper_bound;
} hthr;
struct {
struct list_head uw_nh_entry;
u16 count_buckets;
u16 wants_buckets;
} res;
};
struct list_head nh_list;
struct nexthop *nh_parent;
};
struct nh_res_table {
struct net *net;
u32 nhg_id;
struct delayed_work upkeep_dw;
struct list_head uw_nh_entries;
long unsigned int unbalanced_since;
u32 idle_timer;
u32 unbalanced_timer;
u16 num_nh_buckets;
struct nh_res_bucket nh_buckets[0];
};
struct nh_group {
struct nh_group *spare;
u16 num_nh;
bool is_multipath;
bool hash_threshold;
bool resilient;
bool fdb_nh;
bool has_v4;
struct nh_res_table *res_table;
struct nh_grp_entry nh_entries[0];
};
struct ip_tunnel_key {
__be64 tun_id;
union {
struct {
__be32 src;
__be32 dst;
} ipv4;
struct {
struct in6_addr src;
struct in6_addr dst;
} ipv6;
} u;
__be16 tun_flags;
u8 tos;
u8 ttl;
__be32 label;
__be16 tp_src;
__be16 tp_dst;
__u8 flow_flags;
};
struct ip_tunnel_info {
struct ip_tunnel_key key;
struct dst_cache dst_cache;
u8 options_len;
u8 mode;
long: 32;
};
typedef u64 sci_t;
typedef u32 ssci_t;
union salt {
struct {
u32 ssci;
u64 pn;
};
u8 bytes[12];
};
typedef union salt salt_t;
union pn {
struct {
u32 lower;
u32 upper;
};
u64 full64;
};
typedef union pn pn_t;
struct crypto_aead;
struct macsec_key {
u8 id[16];
struct crypto_aead *tfm;
salt_t salt;
};
struct macsec_rx_sc_stats {
__u64 InOctetsValidated;
__u64 InOctetsDecrypted;
__u64 InPktsUnchecked;
__u64 InPktsDelayed;
__u64 InPktsOK;
__u64 InPktsInvalid;
__u64 InPktsLate;
__u64 InPktsNotValid;
__u64 InPktsNotUsingSA;
__u64 InPktsUnusedSA;
};
struct macsec_rx_sa_stats {
__u32 InPktsOK;
__u32 InPktsInvalid;
__u32 InPktsNotValid;
__u32 InPktsNotUsingSA;
__u32 InPktsUnusedSA;
};
struct macsec_tx_sa_stats {
__u32 OutPktsProtected;
__u32 OutPktsEncrypted;
};
struct macsec_tx_sc_stats {
__u64 OutPktsProtected;
__u64 OutPktsEncrypted;
__u64 OutOctetsProtected;
__u64 OutOctetsEncrypted;
};
struct macsec_dev_stats {
__u64 OutPktsUntagged;
__u64 InPktsUntagged;
__u64 OutPktsTooLong;
__u64 InPktsNoTag;
__u64 InPktsBadTag;
__u64 InPktsUnknownSCI;
__u64 InPktsNoSCI;
__u64 InPktsOverrun;
};
struct macsec_rx_sc;
struct macsec_rx_sa {
struct macsec_key key;
ssci_t ssci;
spinlock_t lock;
union {
pn_t next_pn_halves;
u64 next_pn;
};
refcount_t refcnt;
bool active;
struct macsec_rx_sa_stats *stats;
struct macsec_rx_sc *sc;
struct callback_head rcu;
};
struct pcpu_rx_sc_stats;
struct macsec_rx_sc {
struct macsec_rx_sc *next;
long: 32;
sci_t sci;
bool active;
struct macsec_rx_sa *sa[4];
struct pcpu_rx_sc_stats *stats;
refcount_t refcnt;
struct callback_head callback_head;
long: 32;
};
struct pcpu_rx_sc_stats {
struct macsec_rx_sc_stats stats;
struct u64_stats_sync syncp;
long: 32;
};
struct pcpu_tx_sc_stats {
struct macsec_tx_sc_stats stats;
struct u64_stats_sync syncp;
long: 32;
};
struct macsec_tx_sa {
struct macsec_key key;
ssci_t ssci;
spinlock_t lock;
union {
pn_t next_pn_halves;
u64 next_pn;
};
refcount_t refcnt;
bool active;
struct macsec_tx_sa_stats *stats;
struct callback_head rcu;
long: 32;
};
struct metadata_dst;
struct macsec_tx_sc {
bool active;
u8 encoding_sa;
bool encrypt;
bool send_sci;
bool end_station;
bool scb;
struct macsec_tx_sa *sa[4];
struct pcpu_tx_sc_stats *stats;
struct metadata_dst *md_dst;
};
enum metadata_type {
METADATA_IP_TUNNEL = 0,
METADATA_HW_PORT_MUX = 1,
METADATA_MACSEC = 2,
METADATA_XFRM = 3,
};
struct hw_port_info {
struct net_device *lower_dev;
u32 port_id;
};
struct macsec_info {
sci_t sci;
};
struct xfrm_md_info {
u32 if_id;
int link;
};
struct metadata_dst {
struct dst_entry dst;
enum metadata_type type;
union {
struct ip_tunnel_info tun_info;
struct hw_port_info port_info;
struct macsec_info macsec_info;
struct xfrm_md_info xfrm_info;
} u;
};
struct macsec_secy {
struct net_device *netdev;
unsigned int n_rx_sc;
sci_t sci;
u16 key_len;
u16 icv_len;
enum macsec_validation_type validate_frames;
bool xpn;
bool operational;
bool protect_frames;
bool replay_protect;
u32 replay_window;
struct macsec_tx_sc tx_sc;
struct macsec_rx_sc *rx_sc;
long: 32;
};
struct macsec_context {
union {
struct net_device *netdev;
struct phy_device *phydev;
};
enum macsec_offload offload;
struct macsec_secy *secy;
struct macsec_rx_sc *rx_sc;
struct {
unsigned char assoc_num;
u8 key[128];
union {
struct macsec_rx_sa *rx_sa;
struct macsec_tx_sa *tx_sa;
};
} sa;
union {
struct macsec_tx_sc_stats *tx_sc_stats;
struct macsec_tx_sa_stats *tx_sa_stats;
struct macsec_rx_sc_stats *rx_sc_stats;
struct macsec_rx_sa_stats *rx_sa_stats;
struct macsec_dev_stats *dev_stats;
} stats;
};
struct inet_skb_parm {
int iif;
struct ip_options opt;
u16 flags;
u16 frag_max_size;
};
struct inet_ehash_bucket {
struct hlist_nulls_head chain;
};
struct inet_bind_hashbucket {
spinlock_t lock;
struct hlist_head chain;
};
struct inet_listen_hashbucket {
spinlock_t lock;
struct hlist_nulls_head nulls_head;
};
enum {
BPF_MAP_VALUE_OFF_MAX = 8,
BPF_MAP_OFF_ARR_MAX = 10,
};
enum bpf_type_flag {
PTR_MAYBE_NULL = 256,
MEM_RDONLY = 512,
MEM_ALLOC = 1024,
MEM_USER = 2048,
MEM_PERCPU = 4096,
OBJ_RELEASE = 8192,
PTR_UNTRUSTED = 16384,
MEM_UNINIT = 32768,
DYNPTR_TYPE_LOCAL = 65536,
DYNPTR_TYPE_RINGBUF = 131072,
MEM_FIXED_SIZE = 262144,
__BPF_TYPE_FLAG_MAX = 262145,
__BPF_TYPE_LAST_FLAG = 262144,
};
enum bpf_arg_type {
ARG_DONTCARE = 0,
ARG_CONST_MAP_PTR = 1,
ARG_PTR_TO_MAP_KEY = 2,
ARG_PTR_TO_MAP_VALUE = 3,
ARG_PTR_TO_MEM = 4,
ARG_CONST_SIZE = 5,
ARG_CONST_SIZE_OR_ZERO = 6,
ARG_PTR_TO_CTX = 7,
ARG_ANYTHING = 8,
ARG_PTR_TO_SPIN_LOCK = 9,
ARG_PTR_TO_SOCK_COMMON = 10,
ARG_PTR_TO_INT = 11,
ARG_PTR_TO_LONG = 12,
ARG_PTR_TO_SOCKET = 13,
ARG_PTR_TO_BTF_ID = 14,
ARG_PTR_TO_ALLOC_MEM = 15,
ARG_CONST_ALLOC_SIZE_OR_ZERO = 16,
ARG_PTR_TO_BTF_ID_SOCK_COMMON = 17,
ARG_PTR_TO_PERCPU_BTF_ID = 18,
ARG_PTR_TO_FUNC = 19,
ARG_PTR_TO_STACK = 20,
ARG_PTR_TO_CONST_STR = 21,
ARG_PTR_TO_TIMER = 22,
ARG_PTR_TO_KPTR = 23,
ARG_PTR_TO_DYNPTR = 24,
__BPF_ARG_TYPE_MAX = 25,
ARG_PTR_TO_MAP_VALUE_OR_NULL = 259,
ARG_PTR_TO_MEM_OR_NULL = 260,
ARG_PTR_TO_CTX_OR_NULL = 263,
ARG_PTR_TO_SOCKET_OR_NULL = 269,
ARG_PTR_TO_ALLOC_MEM_OR_NULL = 271,
ARG_PTR_TO_STACK_OR_NULL = 276,
ARG_PTR_TO_BTF_ID_OR_NULL = 270,
ARG_PTR_TO_UNINIT_MEM = 32772,
ARG_PTR_TO_FIXED_SIZE_MEM = 262148,
__BPF_ARG_TYPE_LIMIT = 524287,
};
enum bpf_return_type {
RET_INTEGER = 0,
RET_VOID = 1,
RET_PTR_TO_MAP_VALUE = 2,
RET_PTR_TO_SOCKET = 3,
RET_PTR_TO_TCP_SOCK = 4,
RET_PTR_TO_SOCK_COMMON = 5,
RET_PTR_TO_ALLOC_MEM = 6,
RET_PTR_TO_MEM_OR_BTF_ID = 7,
RET_PTR_TO_BTF_ID = 8,
__BPF_RET_TYPE_MAX = 9,
RET_PTR_TO_MAP_VALUE_OR_NULL = 258,
RET_PTR_TO_SOCKET_OR_NULL = 259,
RET_PTR_TO_TCP_SOCK_OR_NULL = 260,
RET_PTR_TO_SOCK_COMMON_OR_NULL = 261,
RET_PTR_TO_ALLOC_MEM_OR_NULL = 1286,
RET_PTR_TO_DYNPTR_MEM_OR_NULL = 262,
RET_PTR_TO_BTF_ID_OR_NULL = 264,
__BPF_RET_TYPE_LIMIT = 524287,
};
enum bpf_cgroup_storage_type {
BPF_CGROUP_STORAGE_SHARED = 0,
BPF_CGROUP_STORAGE_PERCPU = 1,
__BPF_CGROUP_STORAGE_MAX = 2,
};
enum bpf_tramp_prog_type {
BPF_TRAMP_FENTRY = 0,
BPF_TRAMP_FEXIT = 1,
BPF_TRAMP_MODIFY_RETURN = 2,
BPF_TRAMP_MAX = 3,
BPF_TRAMP_REPLACE = 4,
};
struct ack_sample {
u32 pkts_acked;
s32 rtt_us;
u32 in_flight;
};
struct rate_sample {
u64 prior_mstamp;
u32 prior_delivered;
u32 prior_delivered_ce;
s32 delivered;
s32 delivered_ce;
long int interval_us;
u32 snd_interval_us;
u32 rcv_interval_us;
long int rtt_us;
int losses;
u32 acked_sacked;
u32 prior_in_flight;
u32 last_end_seq;
bool is_app_limited;
bool is_retrans;
bool is_ack_delayed;
long: 32;
};
struct icmphdr {
__u8 type;
__u8 code;
__sum16 checksum;
union {
struct {
__be16 id;
__be16 sequence;
} echo;
__be32 gateway;
struct {
__be16 __unused;
__be16 mtu;
} frag;
__u8 reserved[4];
} un;
};
struct xfrm_type {
struct module *owner;
u8 proto;
u8 flags;
int (*init_state)(struct xfrm_state *, struct netlink_ext_ack *);
void (*destructor)(struct xfrm_state *);
int (*input)(struct xfrm_state *, struct sk_buff *);
int (*output)(struct xfrm_state *, struct sk_buff *);
int (*reject)(struct xfrm_state *, struct sk_buff *, const struct flowi *);
};
struct xfrm_type_offload {
struct module *owner;
u8 proto;
void (*encap)(struct xfrm_state *, struct sk_buff *);
int (*input_tail)(struct xfrm_state *, struct sk_buff *);
int (*xmit)(struct xfrm_state *, struct sk_buff *, netdev_features_t);
};
struct xfrm_dst {
union {
struct dst_entry dst;
struct rtable rt;
struct rt6_info rt6;
} u;
struct dst_entry *route;
struct dst_entry *child;
struct dst_entry *path;
struct xfrm_policy *pols[2];
int num_pols;
int num_xfrms;
u32 xfrm_genid;
u32 policy_genid;
u32 route_mtu_cached;
u32 child_mtu_cached;
u32 route_cookie;
u32 path_cookie;
};
enum netevent_notif_type {
NETEVENT_NEIGH_UPDATE = 1,
NETEVENT_REDIRECT = 2,
NETEVENT_DELAY_PROBE_TIME_UPDATE = 3,
NETEVENT_IPV4_MPATH_HASH_UPDATE = 4,
NETEVENT_IPV6_MPATH_HASH_UPDATE = 5,
NETEVENT_IPV4_FWD_UPDATE_PRIORITY_UPDATE = 6,
};
struct fib_alias {
struct hlist_node fa_list;
struct fib_info *fa_info;
dscp_t fa_dscp;
u8 fa_type;
u8 fa_state;
u8 fa_slen;
u32 tb_id;
s16 fa_default;
u8 offload;
u8 trap;
u8 offload_failed;
struct callback_head rcu;
};
struct fib_prop {
int error;
u8 scope;
};
struct bpf_iter_meta {
union {
struct seq_file *seq;
};
u64 session_id;
u64 seq_num;
};
struct seq_net_private {
struct net *net;
netns_tracker ns_tracker;
};
struct rtgenmsg {
unsigned char rtgen_family;
};
struct fib_notifier_info {
int family;
struct netlink_ext_ack *extack;
};
enum fib_event_type {
FIB_EVENT_ENTRY_REPLACE = 0,
FIB_EVENT_ENTRY_APPEND = 1,
FIB_EVENT_ENTRY_ADD = 2,
FIB_EVENT_ENTRY_DEL = 3,
FIB_EVENT_RULE_ADD = 4,
FIB_EVENT_RULE_DEL = 5,
FIB_EVENT_NH_ADD = 6,
FIB_EVENT_NH_DEL = 7,
FIB_EVENT_VIF_ADD = 8,
FIB_EVENT_VIF_DEL = 9,
};
struct fib_dump_filter {
u32 table_id;
bool filter_set;
bool dump_routes;
bool dump_exceptions;
unsigned char protocol;
unsigned char rt_type;
unsigned int flags;
struct net_device *dev;
};
struct fib6_gc_args {
int timeout;
int more;
};
enum fib6_walk_state {
FWS_L = 0,
FWS_R = 1,
FWS_C = 2,
FWS_U = 3,
};
struct fib6_walker {
struct list_head lh;
struct fib6_node *root;
struct fib6_node *node;
struct fib6_info *leaf;
enum fib6_walk_state state;
unsigned int skip;
unsigned int count;
unsigned int skip_in_node;
int (*func)(struct fib6_walker *);
void *args;
};
typedef struct rt6_info * (*pol_lookup_t)(struct net *, struct fib6_table *, struct flowi6 *, const struct sk_buff *, int);
struct fib6_entry_notifier_info {
struct fib_notifier_info info;
struct fib6_info *rt;
unsigned int nsiblings;
};
struct ipv6_route_iter {
struct seq_net_private p;
struct fib6_walker w;
loff_t skip;
struct fib6_table *tbl;
int sernum;
};
struct bpf_iter__ipv6_route {
union {
struct bpf_iter_meta *meta;
};
union {
struct fib6_info *rt;
};
};
struct rt6_rtnl_dump_arg {
struct sk_buff *skb;
struct netlink_callback *cb;
struct net *net;
struct fib_dump_filter filter;
};
struct fib6_cleaner {
struct fib6_walker w;
struct net *net;
int (*func)(struct fib6_info *, void *);
int sernum;
void *arg;
bool skip_notify;
};
enum {
FIB6_NO_SERNUM_CHANGE = 0,
};
struct fib6_dump_arg {
struct net *net;
struct notifier_block *nb;
struct netlink_ext_ack *extack;
};
struct fib6_nh_pcpu_arg {
struct fib6_info *from;
const struct fib6_table *table;
};
struct lookup_args {
int offset;
const struct in6_addr *addr;
};
struct rhlist_head {
struct rhash_head rhead;
struct rhlist_head *next;
};
struct rhash_lock_head;
struct bucket_table {
unsigned int size;
unsigned int nest;
u32 hash_rnd;
struct list_head walkers;
struct callback_head rcu;
struct bucket_table *future_tbl;
struct lockdep_map dep_map;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct rhash_lock_head *buckets[0];
};
enum sock_type {
SOCK_DGRAM = 1,
SOCK_STREAM = 2,
SOCK_RAW = 3,
SOCK_RDM = 4,
SOCK_SEQPACKET = 5,
SOCK_DCCP = 6,
SOCK_PACKET = 10,
};
struct sockaddr_in6 {
short unsigned int sin6_family;
__be16 sin6_port;
__be32 sin6_flowinfo;
struct in6_addr sin6_addr;
__u32 sin6_scope_id;
};
struct icmp6_filter {
__u32 data[8];
};
typedef struct bio_vec skb_frag_t;
struct skb_shared_info {
__u8 flags;
__u8 meta_len;
__u8 nr_frags;
__u8 tx_flags;
short unsigned int gso_size;
short unsigned int gso_segs;
struct sk_buff *frag_list;
long: 32;
struct skb_shared_hwtstamps hwtstamps;
unsigned int gso_type;
u32 tskey;
atomic_t dataref;
unsigned int xdp_frags_size;
void *destructor_arg;
skb_frag_t frags[16];
long: 32;
};
struct nlmsgerr {
int error;
struct nlmsghdr msg;
};
enum netdev_cmd {
NETDEV_UP = 1,
NETDEV_DOWN = 2,
NETDEV_REBOOT = 3,
NETDEV_CHANGE = 4,
NETDEV_REGISTER = 5,
NETDEV_UNREGISTER = 6,
NETDEV_CHANGEMTU = 7,
NETDEV_CHANGEADDR = 8,
NETDEV_PRE_CHANGEADDR = 9,
NETDEV_GOING_DOWN = 10,
NETDEV_CHANGENAME = 11,
NETDEV_FEAT_CHANGE = 12,
NETDEV_BONDING_FAILOVER = 13,
NETDEV_PRE_UP = 14,
NETDEV_PRE_TYPE_CHANGE = 15,
NETDEV_POST_TYPE_CHANGE = 16,
NETDEV_POST_INIT = 17,
NETDEV_RELEASE = 18,
NETDEV_NOTIFY_PEERS = 19,
NETDEV_JOIN = 20,
NETDEV_CHANGEUPPER = 21,
NETDEV_RESEND_IGMP = 22,
NETDEV_PRECHANGEMTU = 23,
NETDEV_CHANGEINFODATA = 24,
NETDEV_BONDING_INFO = 25,
NETDEV_PRECHANGEUPPER = 26,
NETDEV_CHANGELOWERSTATE = 27,
NETDEV_UDP_TUNNEL_PUSH_INFO = 28,
NETDEV_UDP_TUNNEL_DROP_INFO = 29,
NETDEV_CHANGE_TX_QUEUE_LEN = 30,
NETDEV_CVLAN_FILTER_PUSH_INFO = 31,
NETDEV_CVLAN_FILTER_DROP_INFO = 32,
NETDEV_SVLAN_FILTER_PUSH_INFO = 33,
NETDEV_SVLAN_FILTER_DROP_INFO = 34,
NETDEV_OFFLOAD_XSTATS_ENABLE = 35,
NETDEV_OFFLOAD_XSTATS_DISABLE = 36,
NETDEV_OFFLOAD_XSTATS_REPORT_USED = 37,
NETDEV_OFFLOAD_XSTATS_REPORT_DELTA = 38,
};
struct netdev_notifier_info {
struct net_device *dev;
struct netlink_ext_ack *extack;
};
struct __una_u32 {
u32 x;
};
struct rhash_lock_head {};
struct ipv6hdr {
__u8 priority: 4;
__u8 version: 4;
__u8 flow_lbl[3];
__be16 payload_len;
__u8 nexthdr;
__u8 hop_limit;
union {
struct {
struct in6_addr saddr;
struct in6_addr daddr;
};
struct {
struct in6_addr saddr;
struct in6_addr daddr;
} addrs;
};
};
enum nla_policy_validation {
NLA_VALIDATE_NONE = 0,
NLA_VALIDATE_RANGE = 1,
NLA_VALIDATE_RANGE_WARN_TOO_LONG = 2,
NLA_VALIDATE_MIN = 3,
NLA_VALIDATE_MAX = 4,
NLA_VALIDATE_MASK = 5,
NLA_VALIDATE_RANGE_PTR = 6,
NLA_VALIDATE_FUNCTION = 7,
};
struct raw_hashinfo {
spinlock_t lock;
struct hlist_nulls_head ht[256];
};
struct inet6_skb_parm {
int iif;
__be16 ra;
__u16 dst0;
__u16 srcrt;
__u16 dst1;
__u16 lastopt;
__u16 nhoff;
__u16 flags;
__u16 frag_max_size;
__u16 srhoff;
};
struct raw6_sock {
struct inet_sock inet;
__u32 checksum;
__u32 offset;
struct icmp6_filter filter;
__u32 ip6mr_table;
struct ipv6_pinfo inet6;
};
struct inet6_protocol {
int (*handler)(struct sk_buff *);
int (*err_handler)(struct sk_buff *, struct inet6_skb_parm *, u8, u8, int, __be32);
unsigned int flags;
};
enum {
PIM_TYPE_HELLO = 0,
PIM_TYPE_REGISTER = 1,
PIM_TYPE_REGISTER_STOP = 2,
PIM_TYPE_JOIN_PRUNE = 3,
PIM_TYPE_BOOTSTRAP = 4,
PIM_TYPE_ASSERT = 5,
PIM_TYPE_GRAFT = 6,
PIM_TYPE_GRAFT_ACK = 7,
PIM_TYPE_CANDIDATE_RP_ADV = 8,
};
struct pimreghdr {
__u8 type;
__u8 reserved;
__be16 csum;
__be32 flags;
};
typedef short unsigned int mifi_t;
typedef __u32 if_mask;
struct if_set {
if_mask ifs_bits[8];
};
struct mif6ctl {
mifi_t mif6c_mifi;
unsigned char mif6c_flags;
unsigned char vifc_threshold;
__u16 mif6c_pifi;
unsigned int vifc_rate_limit;
};
struct mf6cctl {
struct sockaddr_in6 mf6cc_origin;
struct sockaddr_in6 mf6cc_mcastgrp;
mifi_t mf6cc_parent;
struct if_set mf6cc_ifset;
};
struct sioc_sg_req6 {
struct sockaddr_in6 src;
struct sockaddr_in6 grp;
long unsigned int pktcnt;
long unsigned int bytecnt;
long unsigned int wrong_if;
};
struct sioc_mif_req6 {
mifi_t mifi;
long unsigned int icount;
long unsigned int ocount;
long unsigned int ibytes;
long unsigned int obytes;
};
struct mrt6msg {
__u8 im6_mbz;
__u8 im6_msgtype;
__u16 im6_mif;
__u32 im6_pad;
struct in6_addr im6_src;
struct in6_addr im6_dst;
};
enum {
IP6MRA_CREPORT_UNSPEC = 0,
IP6MRA_CREPORT_MSGTYPE = 1,
IP6MRA_CREPORT_MIF_ID = 2,
IP6MRA_CREPORT_SRC_ADDR = 3,
IP6MRA_CREPORT_DST_ADDR = 4,
IP6MRA_CREPORT_PKT = 5,
__IP6MRA_CREPORT_MAX = 6,
};
struct vif_entry_notifier_info {
struct fib_notifier_info info;
struct net_device *dev;
short unsigned int vif_index;
short unsigned int vif_flags;
u32 tb_id;
};
enum {
MFC_STATIC = 1,
MFC_OFFLOAD = 2,
};
struct mr_mfc {
struct rhlist_head mnode;
short unsigned int mfc_parent;
int mfc_flags;
union {
struct {
long unsigned int expires;
struct sk_buff_head unresolved;
} unres;
struct {
long unsigned int last_assert;
int minvif;
int maxvif;
long unsigned int bytes;
long unsigned int pkt;
long unsigned int wrong_if;
long unsigned int lastuse;
unsigned char ttls[32];
refcount_t refcount;
} res;
} mfc_un;
struct list_head list;
struct callback_head rcu;
void (*free)(struct callback_head *);
};
struct mfc_entry_notifier_info {
struct fib_notifier_info info;
struct mr_mfc *mfc;
u32 tb_id;
};
struct mr_vif_iter {
struct seq_net_private p;
struct mr_table *mrt;
int ct;
};
struct mr_mfc_iter {
struct seq_net_private p;
struct mr_table *mrt;
struct list_head *cache;
spinlock_t *lock;
};
struct mfc6_cache_cmp_arg {
struct in6_addr mf6c_mcastgrp;
struct in6_addr mf6c_origin;
};
struct mfc6_cache {
struct mr_mfc _c;
union {
struct {
struct in6_addr mf6c_mcastgrp;
struct in6_addr mf6c_origin;
};
struct mfc6_cache_cmp_arg cmparg;
};
};
enum {
NETCONFA_UNSPEC = 0,
NETCONFA_IFINDEX = 1,
NETCONFA_FORWARDING = 2,
NETCONFA_RP_FILTER = 3,
NETCONFA_MC_FORWARDING = 4,
NETCONFA_PROXY_NEIGH = 5,
NETCONFA_IGNORE_ROUTES_WITH_LINKDOWN = 6,
NETCONFA_INPUT = 7,
NETCONFA_BC_FORWARDING = 8,
__NETCONFA_MAX = 9,
};
struct xdr_array2_desc;
typedef int (*xdr_xcode_elem_t)(struct xdr_array2_desc *, void *);
struct xdr_array2_desc {
unsigned int elem_size;
unsigned int array_len;
unsigned int array_maxlen;
xdr_xcode_elem_t xcode;
};
enum {
PROC_ROOT_INO = 1,
PROC_IPC_INIT_INO = 4026531839,
PROC_UTS_INIT_INO = 4026531838,
PROC_USER_INIT_INO = 4026531837,
PROC_PID_INIT_INO = 4026531836,
PROC_CGROUP_INIT_INO = 4026531835,
PROC_TIME_INIT_INO = 4026531834,
};
typedef initcall_t initcall_entry_t;
enum system_states {
SYSTEM_BOOTING = 0,
SYSTEM_SCHEDULING = 1,
SYSTEM_FREEING_INITMEM = 2,
SYSTEM_RUNNING = 3,
SYSTEM_HALT = 4,
SYSTEM_POWER_OFF = 5,
SYSTEM_RESTART = 6,
SYSTEM_SUSPEND = 7,
};
enum cpuhp_state {
CPUHP_INVALID = -1,
CPUHP_OFFLINE = 0,
CPUHP_CREATE_THREADS = 1,
CPUHP_PERF_PREPARE = 2,
CPUHP_PERF_X86_PREPARE = 3,
CPUHP_PERF_X86_AMD_UNCORE_PREP = 4,
CPUHP_PERF_POWER = 5,
CPUHP_PERF_SUPERH = 6,
CPUHP_X86_HPET_DEAD = 7,
CPUHP_X86_APB_DEAD = 8,
CPUHP_X86_MCE_DEAD = 9,
CPUHP_VIRT_NET_DEAD = 10,
CPUHP_SLUB_DEAD = 11,
CPUHP_DEBUG_OBJ_DEAD = 12,
CPUHP_MM_WRITEBACK_DEAD = 13,
CPUHP_MM_DEMOTION_DEAD = 14,
CPUHP_MM_VMSTAT_DEAD = 15,
CPUHP_SOFTIRQ_DEAD = 16,
CPUHP_NET_MVNETA_DEAD = 17,
CPUHP_CPUIDLE_DEAD = 18,
CPUHP_ARM64_FPSIMD_DEAD = 19,
CPUHP_ARM_OMAP_WAKE_DEAD = 20,
CPUHP_IRQ_POLL_DEAD = 21,
CPUHP_BLOCK_SOFTIRQ_DEAD = 22,
CPUHP_BIO_DEAD = 23,
CPUHP_ACPI_CPUDRV_DEAD = 24,
CPUHP_S390_PFAULT_DEAD = 25,
CPUHP_BLK_MQ_DEAD = 26,
CPUHP_FS_BUFF_DEAD = 27,
CPUHP_PRINTK_DEAD = 28,
CPUHP_MM_MEMCQ_DEAD = 29,
CPUHP_XFS_DEAD = 30,
CPUHP_PERCPU_CNT_DEAD = 31,
CPUHP_RADIX_DEAD = 32,
CPUHP_PAGE_ALLOC = 33,
CPUHP_NET_DEV_DEAD = 34,
CPUHP_PCI_XGENE_DEAD = 35,
CPUHP_IOMMU_IOVA_DEAD = 36,
CPUHP_LUSTRE_CFS_DEAD = 37,
CPUHP_AP_ARM_CACHE_B15_RAC_DEAD = 38,
CPUHP_PADATA_DEAD = 39,
CPUHP_AP_DTPM_CPU_DEAD = 40,
CPUHP_RANDOM_PREPARE = 41,
CPUHP_WORKQUEUE_PREP = 42,
CPUHP_POWER_NUMA_PREPARE = 43,
CPUHP_HRTIMERS_PREPARE = 44,
CPUHP_PROFILE_PREPARE = 45,
CPUHP_X2APIC_PREPARE = 46,
CPUHP_SMPCFD_PREPARE = 47,
CPUHP_RELAY_PREPARE = 48,
CPUHP_SLAB_PREPARE = 49,
CPUHP_MD_RAID5_PREPARE = 50,
CPUHP_RCUTREE_PREP = 51,
CPUHP_CPUIDLE_COUPLED_PREPARE = 52,
CPUHP_POWERPC_PMAC_PREPARE = 53,
CPUHP_POWERPC_MMU_CTX_PREPARE = 54,
CPUHP_XEN_PREPARE = 55,
CPUHP_XEN_EVTCHN_PREPARE = 56,
CPUHP_ARM_SHMOBILE_SCU_PREPARE = 57,
CPUHP_SH_SH3X_PREPARE = 58,
CPUHP_NET_FLOW_PREPARE = 59,
CPUHP_TOPOLOGY_PREPARE = 60,
CPUHP_NET_IUCV_PREPARE = 61,
CPUHP_ARM_BL_PREPARE = 62,
CPUHP_TRACE_RB_PREPARE = 63,
CPUHP_MM_ZS_PREPARE = 64,
CPUHP_MM_ZSWP_MEM_PREPARE = 65,
CPUHP_MM_ZSWP_POOL_PREPARE = 66,
CPUHP_KVM_PPC_BOOK3S_PREPARE = 67,
CPUHP_ZCOMP_PREPARE = 68,
CPUHP_TIMERS_PREPARE = 69,
CPUHP_MIPS_SOC_PREPARE = 70,
CPUHP_BP_PREPARE_DYN = 71,
CPUHP_BP_PREPARE_DYN_END = 91,
CPUHP_BRINGUP_CPU = 92,
CPUHP_AP_IDLE_DEAD = 93,
CPUHP_AP_OFFLINE = 94,
CPUHP_AP_SCHED_STARTING = 95,
CPUHP_AP_RCUTREE_DYING = 96,
CPUHP_AP_CPU_PM_STARTING = 97,
CPUHP_AP_IRQ_GIC_STARTING = 98,
CPUHP_AP_IRQ_HIP04_STARTING = 99,
CPUHP_AP_IRQ_APPLE_AIC_STARTING = 100,
CPUHP_AP_IRQ_ARMADA_XP_STARTING = 101,
CPUHP_AP_IRQ_BCM2836_STARTING = 102,
CPUHP_AP_IRQ_MIPS_GIC_STARTING = 103,
CPUHP_AP_IRQ_RISCV_STARTING = 104,
CPUHP_AP_IRQ_LOONGARCH_STARTING = 105,
CPUHP_AP_IRQ_SIFIVE_PLIC_STARTING = 106,
CPUHP_AP_ARM_MVEBU_COHERENCY = 107,
CPUHP_AP_MICROCODE_LOADER = 108,
CPUHP_AP_PERF_X86_AMD_UNCORE_STARTING = 109,
CPUHP_AP_PERF_X86_STARTING = 110,
CPUHP_AP_PERF_X86_AMD_IBS_STARTING = 111,
CPUHP_AP_PERF_X86_CQM_STARTING = 112,
CPUHP_AP_PERF_X86_CSTATE_STARTING = 113,
CPUHP_AP_PERF_XTENSA_STARTING = 114,
CPUHP_AP_MIPS_OP_LOONGSON3_STARTING = 115,
CPUHP_AP_ARM_SDEI_STARTING = 116,
CPUHP_AP_ARM_VFP_STARTING = 117,
CPUHP_AP_ARM64_DEBUG_MONITORS_STARTING = 118,
CPUHP_AP_PERF_ARM_HW_BREAKPOINT_STARTING = 119,
CPUHP_AP_PERF_ARM_ACPI_STARTING = 120,
CPUHP_AP_PERF_ARM_STARTING = 121,
CPUHP_AP_PERF_RISCV_STARTING = 122,
CPUHP_AP_ARM_L2X0_STARTING = 123,
CPUHP_AP_EXYNOS4_MCT_TIMER_STARTING = 124,
CPUHP_AP_ARM_ARCH_TIMER_STARTING = 125,
CPUHP_AP_ARM_GLOBAL_TIMER_STARTING = 126,
CPUHP_AP_JCORE_TIMER_STARTING = 127,
CPUHP_AP_ARM_TWD_STARTING = 128,
CPUHP_AP_QCOM_TIMER_STARTING = 129,
CPUHP_AP_TEGRA_TIMER_STARTING = 130,
CPUHP_AP_ARMADA_TIMER_STARTING = 131,
CPUHP_AP_MARCO_TIMER_STARTING = 132,
CPUHP_AP_MIPS_GIC_TIMER_STARTING = 133,
CPUHP_AP_ARC_TIMER_STARTING = 134,
CPUHP_AP_RISCV_TIMER_STARTING = 135,
CPUHP_AP_CLINT_TIMER_STARTING = 136,
CPUHP_AP_CSKY_TIMER_STARTING = 137,
CPUHP_AP_TI_GP_TIMER_STARTING = 138,
CPUHP_AP_HYPERV_TIMER_STARTING = 139,
CPUHP_AP_KVM_STARTING = 140,
CPUHP_AP_KVM_ARM_VGIC_INIT_STARTING = 141,
CPUHP_AP_KVM_ARM_VGIC_STARTING = 142,
CPUHP_AP_KVM_ARM_TIMER_STARTING = 143,
CPUHP_AP_DUMMY_TIMER_STARTING = 144,
CPUHP_AP_ARM_XEN_STARTING = 145,
CPUHP_AP_ARM_CORESIGHT_STARTING = 146,
CPUHP_AP_ARM_CORESIGHT_CTI_STARTING = 147,
CPUHP_AP_ARM64_ISNDEP_STARTING = 148,
CPUHP_AP_SMPCFD_DYING = 149,
CPUHP_AP_X86_TBOOT_DYING = 150,
CPUHP_AP_ARM_CACHE_B15_RAC_DYING = 151,
CPUHP_AP_ONLINE = 152,
CPUHP_TEARDOWN_CPU = 153,
CPUHP_AP_ONLINE_IDLE = 154,
CPUHP_AP_SCHED_WAIT_EMPTY = 155,
CPUHP_AP_SMPBOOT_THREADS = 156,
CPUHP_AP_X86_VDSO_VMA_ONLINE = 157,
CPUHP_AP_IRQ_AFFINITY_ONLINE = 158,
CPUHP_AP_BLK_MQ_ONLINE = 159,
CPUHP_AP_ARM_MVEBU_SYNC_CLOCKS = 160,
CPUHP_AP_X86_INTEL_EPB_ONLINE = 161,
CPUHP_AP_PERF_ONLINE = 162,
CPUHP_AP_PERF_X86_ONLINE = 163,
CPUHP_AP_PERF_X86_UNCORE_ONLINE = 164,
CPUHP_AP_PERF_X86_AMD_UNCORE_ONLINE = 165,
CPUHP_AP_PERF_X86_AMD_POWER_ONLINE = 166,
CPUHP_AP_PERF_X86_RAPL_ONLINE = 167,
CPUHP_AP_PERF_X86_CQM_ONLINE = 168,
CPUHP_AP_PERF_X86_CSTATE_ONLINE = 169,
CPUHP_AP_PERF_X86_IDXD_ONLINE = 170,
CPUHP_AP_PERF_S390_CF_ONLINE = 171,
CPUHP_AP_PERF_S390_SF_ONLINE = 172,
CPUHP_AP_PERF_ARM_CCI_ONLINE = 173,
CPUHP_AP_PERF_ARM_CCN_ONLINE = 174,
CPUHP_AP_PERF_ARM_HISI_CPA_ONLINE = 175,
CPUHP_AP_PERF_ARM_HISI_DDRC_ONLINE = 176,
CPUHP_AP_PERF_ARM_HISI_HHA_ONLINE = 177,
CPUHP_AP_PERF_ARM_HISI_L3_ONLINE = 178,
CPUHP_AP_PERF_ARM_HISI_PA_ONLINE = 179,
CPUHP_AP_PERF_ARM_HISI_SLLC_ONLINE = 180,
CPUHP_AP_PERF_ARM_HISI_PCIE_PMU_ONLINE = 181,
CPUHP_AP_PERF_ARM_HNS3_PMU_ONLINE = 182,
CPUHP_AP_PERF_ARM_L2X0_ONLINE = 183,
CPUHP_AP_PERF_ARM_QCOM_L2_ONLINE = 184,
CPUHP_AP_PERF_ARM_QCOM_L3_ONLINE = 185,
CPUHP_AP_PERF_ARM_APM_XGENE_ONLINE = 186,
CPUHP_AP_PERF_ARM_CAVIUM_TX2_UNCORE_ONLINE = 187,
CPUHP_AP_PERF_ARM_MARVELL_CN10K_DDR_ONLINE = 188,
CPUHP_AP_PERF_POWERPC_NEST_IMC_ONLINE = 189,
CPUHP_AP_PERF_POWERPC_CORE_IMC_ONLINE = 190,
CPUHP_AP_PERF_POWERPC_THREAD_IMC_ONLINE = 191,
CPUHP_AP_PERF_POWERPC_TRACE_IMC_ONLINE = 192,
CPUHP_AP_PERF_POWERPC_HV_24x7_ONLINE = 193,
CPUHP_AP_PERF_POWERPC_HV_GPCI_ONLINE = 194,
CPUHP_AP_PERF_CSKY_ONLINE = 195,
CPUHP_AP_WATCHDOG_ONLINE = 196,
CPUHP_AP_WORKQUEUE_ONLINE = 197,
CPUHP_AP_RANDOM_ONLINE = 198,
CPUHP_AP_RCUTREE_ONLINE = 199,
CPUHP_AP_BASE_CACHEINFO_ONLINE = 200,
CPUHP_AP_ONLINE_DYN = 201,
CPUHP_AP_ONLINE_DYN_END = 231,
CPUHP_AP_MM_DEMOTION_ONLINE = 232,
CPUHP_AP_X86_HPET_ONLINE = 233,
CPUHP_AP_X86_KVM_CLK_ONLINE = 234,
CPUHP_AP_ACTIVE = 235,
CPUHP_ONLINE = 236,
};
enum skb_ext_id {
SKB_EXT_SEC_PATH = 0,
SKB_EXT_NUM = 1,
};
struct trace_event_raw_initcall_level {
struct trace_entry ent;
u32 __data_loc_level;
char __data[0];
};
struct trace_event_raw_initcall_start {
struct trace_entry ent;
initcall_t func;
char __data[0];
};
struct trace_event_raw_initcall_finish {
struct trace_entry ent;
initcall_t func;
int ret;
char __data[0];
};
struct trace_event_data_offsets_initcall_level {
u32 level;
};
struct trace_event_data_offsets_initcall_start {};
struct trace_event_data_offsets_initcall_finish {};
typedef void (*btf_trace_initcall_level)(void *, const char *);
typedef void (*btf_trace_initcall_start)(void *, initcall_t);
typedef void (*btf_trace_initcall_finish)(void *, initcall_t, int);
struct blacklist_entry {
struct list_head next;
char *buf;
};
typedef long unsigned int irq_hw_number_t;
enum {
IRQ_SET_MASK_OK = 0,
IRQ_SET_MASK_OK_NOCOPY = 1,
IRQ_SET_MASK_OK_DONE = 2,
};
enum irq_domain_bus_token {
DOMAIN_BUS_ANY = 0,
DOMAIN_BUS_WIRED = 1,
DOMAIN_BUS_GENERIC_MSI = 2,
DOMAIN_BUS_PCI_MSI = 3,
DOMAIN_BUS_PLATFORM_MSI = 4,
DOMAIN_BUS_NEXUS = 5,
DOMAIN_BUS_IPI = 6,
DOMAIN_BUS_FSL_MC_MSI = 7,
DOMAIN_BUS_TI_SCI_INTA_MSI = 8,
DOMAIN_BUS_WAKEUP = 9,
DOMAIN_BUS_VMD_MSI = 10,
};
struct irq_domain_ops;
struct irq_domain_chip_generic;
struct irq_domain {
struct list_head link;
const char *name;
const struct irq_domain_ops *ops;
void *host_data;
unsigned int flags;
unsigned int mapcount;
struct fwnode_handle *fwnode;
enum irq_domain_bus_token bus_token;
struct irq_domain_chip_generic *gc;
struct device *dev;
struct irq_domain *parent;
irq_hw_number_t hwirq_max;
unsigned int revmap_size;
struct xarray revmap_tree;
struct mutex revmap_mutex;
struct irq_data *revmap[0];
};
enum {
IRQD_TRIGGER_MASK = 15,
IRQD_SETAFFINITY_PENDING = 256,
IRQD_ACTIVATED = 512,
IRQD_NO_BALANCING = 1024,
IRQD_PER_CPU = 2048,
IRQD_AFFINITY_SET = 4096,
IRQD_LEVEL = 8192,
IRQD_WAKEUP_STATE = 16384,
IRQD_MOVE_PCNTXT = 32768,
IRQD_IRQ_DISABLED = 65536,
IRQD_IRQ_MASKED = 131072,
IRQD_IRQ_INPROGRESS = 262144,
IRQD_WAKEUP_ARMED = 524288,
IRQD_FORWARDED_TO_VCPU = 1048576,
IRQD_AFFINITY_MANAGED = 2097152,
IRQD_IRQ_STARTED = 4194304,
IRQD_MANAGED_SHUTDOWN = 8388608,
IRQD_SINGLE_TARGET = 16777216,
IRQD_DEFAULT_TRIGGER_SET = 33554432,
IRQD_CAN_RESERVE = 67108864,
IRQD_MSI_NOMASK_QUIRK = 134217728,
IRQD_HANDLE_ENFORCE_IRQCTX = 268435456,
IRQD_AFFINITY_ON_ACTIVATE = 536870912,
IRQD_IRQ_ENABLED_ON_SUSPEND = 1073741824,
};
enum {
IRQCHIP_SET_TYPE_MASKED = 1,
IRQCHIP_EOI_IF_HANDLED = 2,
IRQCHIP_MASK_ON_SUSPEND = 4,
IRQCHIP_ONOFFLINE_ENABLED = 8,
IRQCHIP_SKIP_SET_WAKE = 16,
IRQCHIP_ONESHOT_SAFE = 32,
IRQCHIP_EOI_THREADED = 64,
IRQCHIP_SUPPORTS_LEVEL_MSI = 128,
IRQCHIP_SUPPORTS_NMI = 256,
IRQCHIP_ENABLE_WAKEUP_ON_SUSPEND = 512,
IRQCHIP_AFFINITY_PRE_STARTUP = 1024,
IRQCHIP_IMMUTABLE = 2048,
};
struct irq_domain_chip_generic {
unsigned int irqs_per_chip;
unsigned int num_chips;
unsigned int irq_flags_to_clear;
unsigned int irq_flags_to_set;
enum irq_gc_flags gc_flags;
struct irq_chip_generic *gc[0];
};
enum {
IRQC_IS_HARDIRQ = 0,
IRQC_IS_NESTED = 1,
};
struct irq_fwspec {
struct fwnode_handle *fwnode;
int param_count;
u32 param[16];
};
struct irq_domain_ops {
int (*match)(struct irq_domain *, struct device_node *, enum irq_domain_bus_token);
int (*select)(struct irq_domain *, struct irq_fwspec *, enum irq_domain_bus_token);
int (*map)(struct irq_domain *, unsigned int, irq_hw_number_t);
void (*unmap)(struct irq_domain *, unsigned int);
int (*xlate)(struct irq_domain *, struct device_node *, const u32 *, unsigned int, long unsigned int *, unsigned int *);
int (*alloc)(struct irq_domain *, unsigned int, unsigned int, void *);
void (*free)(struct irq_domain *, unsigned int, unsigned int);
int (*activate)(struct irq_domain *, struct irq_data *, bool);
void (*deactivate)(struct irq_domain *, struct irq_data *);
int (*translate)(struct irq_domain *, struct irq_fwspec *, long unsigned int *, unsigned int *);
};
typedef void (*task_work_func_t)(struct callback_head *);
enum {
IRQTF_RUNTHREAD = 0,
IRQTF_WARNED = 1,
IRQTF_AFFINITY = 2,
IRQTF_FORCED_THREAD = 3,
IRQTF_READY = 4,
};
enum {
IRQS_AUTODETECT = 1,
IRQS_SPURIOUS_DISABLED = 2,
IRQS_POLL_INPROGRESS = 8,
IRQS_ONESHOT = 32,
IRQS_REPLAY = 64,
IRQS_WAITING = 128,
IRQS_PENDING = 512,
IRQS_SUSPENDED = 2048,
IRQS_TIMINGS = 4096,
IRQS_NMI = 8192,
};
enum {
_IRQ_DEFAULT_INIT_FLAGS = 0,
_IRQ_PER_CPU = 512,
_IRQ_LEVEL = 256,
_IRQ_NOPROBE = 1024,
_IRQ_NOREQUEST = 2048,
_IRQ_NOTHREAD = 65536,
_IRQ_NOAUTOEN = 4096,
_IRQ_MOVE_PCNTXT = 16384,
_IRQ_NO_BALANCING = 8192,
_IRQ_NESTED_THREAD = 32768,
_IRQ_PER_CPU_DEVID = 131072,
_IRQ_IS_POLLED = 262144,
_IRQ_DISABLE_UNLAZY = 524288,
_IRQ_HIDDEN = 1048576,
_IRQ_NO_DEBUG = 2097152,
_IRQF_MODIFY_MASK = 2096911,
};
typedef struct {
seqcount_t seqcount;
} seqcount_latch_t;
struct latch_tree_root {
seqcount_latch_t seq;
struct rb_root tree[2];
};
struct latch_tree_ops {
bool (*less)(struct latch_tree_node *, struct latch_tree_node *);
int (*comp)(void *, struct latch_tree_node *);
};
struct mod_tree_root {
struct latch_tree_root root;
long unsigned int addr_min;
long unsigned int addr_max;
};
enum clocksource_ids {
CSID_GENERIC = 0,
CSID_ARM_ARCH_COUNTER = 1,
CSID_MAX = 2,
};
enum vdso_clock_mode {
VDSO_CLOCKMODE_NONE = 0,
VDSO_CLOCKMODE_R4K = 1,
VDSO_CLOCKMODE_GIC = 2,
VDSO_CLOCKMODE_MAX = 3,
VDSO_CLOCKMODE_TIMENS = 2147483647,
};
struct clocksource {
u64 (*read)(struct clocksource *);
long: 32;
u64 mask;
u32 mult;
u32 shift;
u64 max_idle_ns;
u32 maxadj;
u32 uncertainty_margin;
u64 max_cycles;
const char *name;
struct list_head list;
int rating;
enum clocksource_ids id;
enum vdso_clock_mode vdso_clock_mode;
long unsigned int flags;
int (*enable)(struct clocksource *);
void (*disable)(struct clocksource *);
void (*suspend)(struct clocksource *);
void (*resume)(struct clocksource *);
void (*mark_unstable)(struct clocksource *);
void (*tick_stable)(struct clocksource *);
struct list_head wd_list;
long: 32;
u64 cs_last;
u64 wd_last;
struct module *owner;
long: 32;
};
struct syscore_ops {
struct list_head node;
int (*suspend)();
void (*resume)();
void (*shutdown)();
};
struct clock_read_data {
u64 epoch_ns;
u64 epoch_cyc;
u64 sched_clock_mask;
u64 (*read_sched_clock)();
u32 mult;
u32 shift;
long: 32;
};
struct clock_data {
seqcount_latch_t seq;
long: 32;
struct clock_read_data read_data[2];
ktime_t wrap_kt;
long unsigned int rate;
u64 (*actual_read_sched_clock)();
};
struct plist_head {
struct list_head node_list;
};
struct hrtimer_sleeper {
struct hrtimer timer;
struct task_struct *task;
long: 32;
};
struct rt_mutex_base;
struct ww_acquire_ctx;
struct rt_mutex_waiter {
struct rb_node tree_entry;
struct rb_node pi_tree_entry;
struct task_struct *task;
struct rt_mutex_base *lock;
unsigned int wake_state;
int prio;
u64 deadline;
struct ww_acquire_ctx *ww_ctx;
long: 32;
};
struct robust_list {
struct robust_list *next;
};
struct robust_list_head {
struct robust_list list;
long int futex_offset;
struct robust_list *list_op_pending;
};
struct rt_mutex_base {
raw_spinlock_t wait_lock;
struct rb_root_cached waiters;
struct task_struct *owner;
};
union futex_key {
struct {
u64 i_seq;
long unsigned int pgoff;
unsigned int offset;
} shared;
struct {
union {
struct mm_struct *mm;
u64 __tmp;
};
long unsigned int address;
unsigned int offset;
} private;
struct {
u64 ptr;
long unsigned int word;
unsigned int offset;
} both;
};
struct futex_pi_state {
struct list_head list;
struct rt_mutex_base pi_mutex;
struct task_struct *owner;
refcount_t refcount;
union futex_key key;
};
enum {
FUTEX_STATE_OK = 0,
FUTEX_STATE_EXITING = 1,
FUTEX_STATE_DEAD = 2,
};
struct wake_q_head {
struct wake_q_node *first;
struct wake_q_node **lastp;
};
struct futex_hash_bucket {
atomic_t waiters;
spinlock_t lock;
struct plist_head chain;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct futex_q {
struct plist_node list;
struct task_struct *task;
spinlock_t *lock_ptr;
long: 32;
union futex_key key;
struct futex_pi_state *pi_state;
struct rt_mutex_waiter *rt_waiter;
union futex_key *requeue_pi_key;
u32 bitset;
atomic_t requeue_state;
long: 32;
};
enum futex_access {
FUTEX_READ = 0,
FUTEX_WRITE = 1,
};
struct rt_wake_q_head {
struct wake_q_head head;
struct task_struct *rtlock_task;
};
typedef struct {} local_lock_t;
struct radix_tree_preload {
local_lock_t lock;
unsigned int nr;
struct xa_node *nodes;
};
struct kernel_clone_args {
u64 flags;
int *pidfd;
int *child_tid;
int *parent_tid;
int exit_signal;
long unsigned int stack;
long unsigned int stack_size;
long unsigned int tls;
pid_t *set_tid;
size_t set_tid_size;
int cgroup;
int io_thread;
int kthread;
int idle;
int (*fn)(void *);
void *fn_arg;
struct cgroup *cgrp;
struct css_set *cset;
long: 32;
};
enum kernfs_node_type {
KERNFS_DIR = 1,
KERNFS_FILE = 2,
KERNFS_LINK = 4,
};
enum kernfs_root_flag {
KERNFS_ROOT_CREATE_DEACTIVATED = 1,
KERNFS_ROOT_EXTRA_OPEN_PERM_CHECK = 2,
KERNFS_ROOT_SUPPORT_EXPORTOP = 4,
KERNFS_ROOT_SUPPORT_USER_XATTR = 8,
};
struct kernfs_syscall_ops {
int (*show_options)(struct seq_file *, struct kernfs_root *);
int (*mkdir)(struct kernfs_node *, const char *, umode_t);
int (*rmdir)(struct kernfs_node *);
int (*rename)(struct kernfs_node *, struct kernfs_node *, const char *);
int (*show_path)(struct seq_file *, struct kernfs_node *, struct kernfs_root *);
};
struct kernfs_fs_context {
struct kernfs_root *root;
void *ns_tag;
long unsigned int magic;
bool new_sb_created;
};
enum {
CSS_NO_REF = 1,
CSS_ONLINE = 2,
CSS_RELEASED = 4,
CSS_VISIBLE = 8,
CSS_DYING = 16,
};
enum {
CGRP_NOTIFY_ON_RELEASE = 0,
CGRP_CPUSET_CLONE_CHILDREN = 1,
CGRP_FREEZE = 2,
CGRP_FROZEN = 3,
CGRP_KILL = 4,
};
enum {
CGRP_ROOT_NOPREFIX = 2,
CGRP_ROOT_XATTR = 4,
CGRP_ROOT_NS_DELEGATE = 8,
CGRP_ROOT_FAVOR_DYNMODS = 16,
CGRP_ROOT_CPUSET_V2_MODE = 65536,
CGRP_ROOT_MEMORY_LOCAL_EVENTS = 131072,
CGRP_ROOT_MEMORY_RECURSIVE_PROT = 262144,
};
enum {
CFTYPE_ONLY_ON_ROOT = 1,
CFTYPE_NOT_ON_ROOT = 2,
CFTYPE_NS_DELEGATABLE = 4,
CFTYPE_NO_PREFIX = 8,
CFTYPE_WORLD_WRITABLE = 16,
CFTYPE_DEBUG = 32,
__CFTYPE_ONLY_ON_DFL = 65536,
__CFTYPE_NOT_ON_DFL = 131072,
__CFTYPE_ADDED = 262144,
};
struct cgroup_taskset {
struct list_head src_csets;
struct list_head dst_csets;
int nr_tasks;
int ssid;
struct list_head *csets;
struct css_set *cur_cset;
struct task_struct *cur_task;
};
struct css_task_iter {
struct cgroup_subsys *ss;
unsigned int flags;
struct list_head *cset_pos;
struct list_head *cset_head;
struct list_head *tcset_pos;
struct list_head *tcset_head;
struct list_head *task_pos;
struct list_head *cur_tasks_head;
struct css_set *cur_cset;
struct css_set *cur_dcset;
struct task_struct *cur_task;
struct list_head iters_node;
};
struct cgroup_fs_context {
struct kernfs_fs_context kfc;
struct cgroup_root *root;
struct cgroup_namespace *ns;
unsigned int flags;
bool cpuset_clone_children;
bool none;
bool all_ss;
u16 subsys_mask;
char *name;
char *release_agent;
};
struct cgroup_pidlist;
struct cgroup_file_ctx {
struct cgroup_namespace *ns;
struct {
void *trigger;
} psi;
struct {
bool started;
struct css_task_iter iter;
} procs;
struct {
struct cgroup_pidlist *pidlist;
} procs1;
};
struct cgrp_cset_link {
struct cgroup *cgrp;
struct css_set *cset;
struct list_head cset_link;
struct list_head cgrp_link;
};
struct cgroup_mgctx {
struct list_head preloaded_src_csets;
struct list_head preloaded_dst_csets;
struct cgroup_taskset tset;
u16 ss_mask;
};
struct trace_event_raw_cgroup_root {
struct trace_entry ent;
int root;
u16 ss_mask;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_cgroup {
struct trace_entry ent;
int root;
int level;
u64 id;
u32 __data_loc_path;
char __data[0];
long: 32;
};
struct trace_event_raw_cgroup_migrate {
struct trace_entry ent;
int dst_root;
int dst_level;
u64 dst_id;
int pid;
u32 __data_loc_dst_path;
u32 __data_loc_comm;
char __data[0];
long: 32;
};
struct trace_event_raw_cgroup_event {
struct trace_entry ent;
int root;
int level;
u64 id;
u32 __data_loc_path;
int val;
char __data[0];
};
struct trace_event_data_offsets_cgroup_root {
u32 name;
};
struct trace_event_data_offsets_cgroup {
u32 path;
};
struct trace_event_data_offsets_cgroup_migrate {
u32 dst_path;
u32 comm;
};
struct trace_event_data_offsets_cgroup_event {
u32 path;
};
typedef void (*btf_trace_cgroup_setup_root)(void *, struct cgroup_root *);
typedef void (*btf_trace_cgroup_destroy_root)(void *, struct cgroup_root *);
typedef void (*btf_trace_cgroup_remount)(void *, struct cgroup_root *);
typedef void (*btf_trace_cgroup_mkdir)(void *, struct cgroup *, const char *);
typedef void (*btf_trace_cgroup_rmdir)(void *, struct cgroup *, const char *);
typedef void (*btf_trace_cgroup_release)(void *, struct cgroup *, const char *);
typedef void (*btf_trace_cgroup_rename)(void *, struct cgroup *, const char *);
typedef void (*btf_trace_cgroup_freeze)(void *, struct cgroup *, const char *);
typedef void (*btf_trace_cgroup_unfreeze)(void *, struct cgroup *, const char *);
typedef void (*btf_trace_cgroup_attach_task)(void *, struct cgroup *, const char *, struct task_struct *, bool);
typedef void (*btf_trace_cgroup_transfer_tasks)(void *, struct cgroup *, const char *, struct task_struct *, bool);
typedef void (*btf_trace_cgroup_notify_populated)(void *, struct cgroup *, const char *, int);
typedef void (*btf_trace_cgroup_notify_frozen)(void *, struct cgroup *, const char *, int);
enum cgroup_opt_features {
OPT_FEATURE_COUNT = 0,
};
enum cgroup2_param {
Opt_nsdelegate = 0,
Opt_favordynmods = 1,
Opt_memory_localevents = 2,
Opt_memory_recursiveprot = 3,
nr__cgroup2_params = 4,
};
typedef struct {
long unsigned int val;
} swp_entry_t;
typedef unsigned int isolate_mode_t;
enum positive_aop_returns {
AOP_WRITEPAGE_ACTIVATE = 524288,
AOP_TRUNCATED_PAGE = 524289,
};
struct hstate {};
typedef struct page *new_page_t(struct page *, long unsigned int);
typedef void free_page_t(struct page *, long unsigned int);
struct movable_operations {
bool (*isolate_page)(struct page *, isolate_mode_t);
int (*migrate_page)(struct page *, struct page *, enum migrate_mode);
void (*putback_page)(struct page *);
};
enum ttu_flags {
TTU_SPLIT_HUGE_PMD = 4,
TTU_IGNORE_MLOCK = 8,
TTU_SYNC = 16,
TTU_IGNORE_HWPOISON = 32,
TTU_BATCH_FLUSH = 64,
TTU_RMAP_LOCKED = 128,
};
typedef int rmap_t;
struct page_vma_mapped_walk {
long unsigned int pfn;
long unsigned int nr_pages;
long unsigned int pgoff;
struct vm_area_struct *vma;
long unsigned int address;
pmd_t *pmd;
pte_t *pte;
spinlock_t *ptl;
unsigned int flags;
};
struct rmap_walk_control {
void *arg;
bool try_lock;
bool contended;
bool (*rmap_one)(struct folio *, struct vm_area_struct *, long unsigned int, void *);
int (*done)(struct folio *);
struct anon_vma * (*anon_lock)(struct folio *, struct rmap_walk_control *);
bool (*invalid_vma)(struct vm_area_struct *, void *);
};
struct migration_target_control {
int nid;
nodemask_t *nmask;
gfp_t gfp_mask;
};
struct hugepage_subpool;
struct tm {
int tm_sec;
int tm_min;
int tm_hour;
int tm_mday;
int tm_mon;
long int tm_year;
int tm_wday;
int tm_yday;
};
struct fd {
struct file *file;
unsigned int flags;
};
struct mount_attr {
__u64 attr_set;
__u64 attr_clr;
__u64 propagation;
__u64 userns_fd;
};
struct proc_mounts {
struct mnt_namespace *ns;
struct path root;
int (*show)(struct seq_file *, struct vfsmount *);
struct mount cursor;
};
struct mount_kattr {
unsigned int attr_set;
unsigned int attr_clr;
unsigned int propagation;
unsigned int lookup_flags;
bool recurse;
struct user_namespace *mnt_userns;
};
enum umount_tree_flags {
UMOUNT_SYNC = 1,
UMOUNT_PROPAGATE = 2,
UMOUNT_CONNECTED = 4,
};
struct kioctx;
struct kioctx_table {
struct callback_head rcu;
unsigned int nr;
struct kioctx *table[0];
};
typedef __kernel_rwf_t rwf_t;
typedef __kernel_ulong_t aio_context_t;
enum {
IOCB_CMD_PREAD = 0,
IOCB_CMD_PWRITE = 1,
IOCB_CMD_FSYNC = 2,
IOCB_CMD_FDSYNC = 3,
IOCB_CMD_POLL = 5,
IOCB_CMD_NOOP = 6,
IOCB_CMD_PREADV = 7,
IOCB_CMD_PWRITEV = 8,
};
struct io_event {
__u64 data;
__u64 obj;
__s64 res;
__s64 res2;
};
struct iocb {
__u64 aio_data;
__u32 aio_key;
__kernel_rwf_t aio_rw_flags;
__u16 aio_lio_opcode;
__s16 aio_reqprio;
__u32 aio_fildes;
__u64 aio_buf;
__u64 aio_nbytes;
__s64 aio_offset;
__u64 aio_reserved2;
__u32 aio_flags;
__u32 aio_resfd;
};
typedef int kiocb_cancel_fn(struct kiocb *);
struct pseudo_fs_context {
const struct super_operations *ops;
const struct xattr_handler **xattr;
const struct dentry_operations *dops;
long unsigned int magic;
};
struct aio_ring {
unsigned int id;
unsigned int nr;
unsigned int head;
unsigned int tail;
unsigned int magic;
unsigned int compat_features;
unsigned int incompat_features;
unsigned int header_length;
struct io_event io_events[0];
};
struct kioctx_cpu;
struct ctx_rq_wait;
struct kioctx {
struct percpu_ref users;
atomic_t dead;
struct percpu_ref reqs;
long unsigned int user_id;
struct kioctx_cpu *cpu;
unsigned int req_batch;
unsigned int max_reqs;
unsigned int nr_events;
long unsigned int mmap_base;
long unsigned int mmap_size;
struct page **ring_pages;
long int nr_pages;
struct rcu_work free_rwork;
struct ctx_rq_wait *rq_wait;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct {
atomic_t reqs_available;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct {
spinlock_t ctx_lock;
struct list_head active_reqs;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct {
struct mutex ring_lock;
wait_queue_head_t wait;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct {
unsigned int tail;
unsigned int completed_events;
spinlock_t completion_lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct page *internal_pages[8];
struct file *aio_ring_file;
unsigned int id;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct kioctx_cpu {
unsigned int reqs_available;
};
struct ctx_rq_wait {
struct completion comp;
atomic_t count;
};
struct fsync_iocb {
struct file *file;
struct work_struct work;
bool datasync;
struct cred *creds;
};
struct poll_iocb {
struct file *file;
struct wait_queue_head *head;
__poll_t events;
bool cancelled;
bool work_scheduled;
bool work_need_resched;
struct wait_queue_entry wait;
struct work_struct work;
};
struct aio_kiocb {
union {
struct file *ki_filp;
struct kiocb rw;
struct fsync_iocb fsync;
struct poll_iocb poll;
};
struct kioctx *ki_ctx;
kiocb_cancel_fn *ki_cancel;
struct io_event ki_res;
struct list_head ki_list;
refcount_t ki_refcnt;
struct eventfd_ctx *ki_eventfd;
};
struct aio_poll_table {
struct poll_table_struct pt;
struct aio_kiocb *iocb;
bool queued;
int error;
};
struct __aio_sigset {
const sigset_t *sigmask;
size_t sigsetsize;
};
struct simple_xattr {
struct list_head list;
char *name;
size_t size;
char value[0];
};
enum kernfs_node_flag {
KERNFS_ACTIVATED = 16,
KERNFS_NS = 32,
KERNFS_HAS_SEQ_SHOW = 64,
KERNFS_HAS_MMAP = 128,
KERNFS_LOCKDEP = 256,
KERNFS_HIDDEN = 512,
KERNFS_SUICIDAL = 1024,
KERNFS_SUICIDED = 2048,
KERNFS_EMPTY_DIR = 4096,
KERNFS_HAS_RELEASE = 8192,
KERNFS_REMOVING = 16384,
};
struct kernfs_root {
struct kernfs_node *kn;
unsigned int flags;
struct idr ino_idr;
u32 last_id_lowbits;
u32 id_highbits;
struct kernfs_syscall_ops *syscall_ops;
struct list_head supers;
wait_queue_head_t deactivate_waitq;
struct rw_semaphore kernfs_rwsem;
};
struct kernfs_iattrs {
kuid_t ia_uid;
kgid_t ia_gid;
struct timespec64 ia_atime;
struct timespec64 ia_mtime;
struct timespec64 ia_ctime;
struct simple_xattrs xattrs;
atomic_t nr_user_xattrs;
atomic_t user_xattr_size;
long: 32;
};
struct kernfs_super_info {
struct super_block *sb;
struct kernfs_root *root;
const void *ns;
struct list_head node;
};
enum {
EXT4_INODE_SECRM = 0,
EXT4_INODE_UNRM = 1,
EXT4_INODE_COMPR = 2,
EXT4_INODE_SYNC = 3,
EXT4_INODE_IMMUTABLE = 4,
EXT4_INODE_APPEND = 5,
EXT4_INODE_NODUMP = 6,
EXT4_INODE_NOATIME = 7,
EXT4_INODE_DIRTY = 8,
EXT4_INODE_COMPRBLK = 9,
EXT4_INODE_NOCOMPR = 10,
EXT4_INODE_ENCRYPT = 11,
EXT4_INODE_INDEX = 12,
EXT4_INODE_IMAGIC = 13,
EXT4_INODE_JOURNAL_DATA = 14,
EXT4_INODE_NOTAIL = 15,
EXT4_INODE_DIRSYNC = 16,
EXT4_INODE_TOPDIR = 17,
EXT4_INODE_HUGE_FILE = 18,
EXT4_INODE_EXTENTS = 19,
EXT4_INODE_VERITY = 20,
EXT4_INODE_EA_INODE = 21,
EXT4_INODE_DAX = 25,
EXT4_INODE_INLINE_DATA = 28,
EXT4_INODE_PROJINHERIT = 29,
EXT4_INODE_CASEFOLD = 30,
EXT4_INODE_RESERVED = 31,
};
struct extent_status {
struct rb_node rb_node;
ext4_lblk_t es_lblk;
ext4_lblk_t es_len;
long: 32;
ext4_fsblk_t es_pblk;
};
struct ext4_es_tree {
struct rb_root root;
struct extent_status *cache_es;
};
struct ext4_pending_tree {
struct rb_root root;
};
struct ext4_inode_info {
__le32 i_data[15];
__u32 i_dtime;
ext4_fsblk_t i_file_acl;
ext4_group_t i_block_group;
ext4_lblk_t i_dir_start_lookup;
long unsigned int i_state_flags;
long unsigned int i_flags;
struct rw_semaphore xattr_sem;
union {
struct list_head i_orphan;
unsigned int i_orphan_idx;
};
struct list_head i_fc_dilist;
struct list_head i_fc_list;
ext4_lblk_t i_fc_lblk_start;
ext4_lblk_t i_fc_lblk_len;
atomic_t i_fc_updates;
wait_queue_head_t i_fc_wait;
struct mutex i_fc_lock;
long: 32;
loff_t i_disksize;
struct rw_semaphore i_data_sem;
long: 32;
struct inode vfs_inode;
struct jbd2_inode *jinode;
spinlock_t i_raw_lock;
struct timespec64 i_crtime;
atomic_t i_prealloc_active;
struct list_head i_prealloc_list;
spinlock_t i_prealloc_lock;
struct ext4_es_tree i_es_tree;
rwlock_t i_es_lock;
struct list_head i_es_list;
unsigned int i_es_all_nr;
unsigned int i_es_shk_nr;
ext4_lblk_t i_es_shrink_lblk;
ext4_group_t i_last_alloc_group;
unsigned int i_reserved_data_blocks;
struct ext4_pending_tree i_pending_tree;
__u16 i_extra_isize;
u16 i_inline_off;
u16 i_inline_size;
qsize_t i_reserved_quota;
spinlock_t i_completed_io_lock;
struct list_head i_rsv_conversion_list;
struct work_struct i_rsv_conversion_work;
atomic_t i_unwritten;
spinlock_t i_block_reservation_lock;
tid_t i_sync_tid;
tid_t i_datasync_tid;
struct dquot *i_dquot[3];
__u32 i_csum_seed;
kprojid_t i_projid;
};
enum {
EXT4_STATE_JDATA = 0,
EXT4_STATE_NEW = 1,
EXT4_STATE_XATTR = 2,
EXT4_STATE_NO_EXPAND = 3,
EXT4_STATE_DA_ALLOC_CLOSE = 4,
EXT4_STATE_EXT_MIGRATE = 5,
EXT4_STATE_NEWENTRY = 6,
EXT4_STATE_MAY_INLINE_DATA = 7,
EXT4_STATE_EXT_PRECACHED = 8,
EXT4_STATE_LUSTRE_EA_INODE = 9,
EXT4_STATE_VERITY_IN_PROGRESS = 10,
EXT4_STATE_FC_COMMITTING = 11,
EXT4_STATE_ORPHAN_FILE = 12,
};
struct ext4_extent {
__le32 ee_block;
__le16 ee_len;
__le16 ee_start_hi;
__le32 ee_start_lo;
};
struct ext4_extent_idx {
__le32 ei_block;
__le32 ei_leaf_lo;
__le16 ei_leaf_hi;
__u16 ei_unused;
};
struct ext4_extent_header {
__le16 eh_magic;
__le16 eh_entries;
__le16 eh_max;
__le16 eh_depth;
__le32 eh_generation;
};
struct ext4_ext_path {
ext4_fsblk_t p_block;
__u16 p_depth;
__u16 p_maxdepth;
struct ext4_extent *p_ext;
struct ext4_extent_idx *p_idx;
struct ext4_extent_header *p_hdr;
struct buffer_head *p_bh;
long: 32;
};
struct migrate_struct {
ext4_lblk_t first_block;
ext4_lblk_t last_block;
ext4_lblk_t curr_block;
long: 32;
ext4_fsblk_t first_pblock;
ext4_fsblk_t last_pblock;
};
typedef int get_block_t(struct inode *, sector_t, struct buffer_head *, int);
typedef long unsigned int ext2_fsblk_t;
struct ext2_reserve_window {
ext2_fsblk_t _rsv_start;
ext2_fsblk_t _rsv_end;
};
struct ext2_reserve_window_node {
struct rb_node rsv_node;
__u32 rsv_goal_size;
__u32 rsv_alloc_hit;
struct ext2_reserve_window rsv_window;
};
struct ext2_block_alloc_info {
struct ext2_reserve_window_node rsv_window_node;
__u32 last_alloc_logical_block;
ext2_fsblk_t last_alloc_physical_block;
};
struct ext2_super_block;
struct ext2_sb_info {
long unsigned int s_frag_size;
long unsigned int s_frags_per_block;
long unsigned int s_inodes_per_block;
long unsigned int s_frags_per_group;
long unsigned int s_blocks_per_group;
long unsigned int s_inodes_per_group;
long unsigned int s_itb_per_group;
long unsigned int s_gdb_count;
long unsigned int s_desc_per_block;
long unsigned int s_groups_count;
long unsigned int s_overhead_last;
long unsigned int s_blocks_last;
struct buffer_head *s_sbh;
struct ext2_super_block *s_es;
struct buffer_head **s_group_desc;
long unsigned int s_mount_opt;
long unsigned int s_sb_block;
kuid_t s_resuid;
kgid_t s_resgid;
short unsigned int s_mount_state;
short unsigned int s_pad;
int s_addr_per_block_bits;
int s_desc_per_block_bits;
int s_inode_size;
int s_first_ino;
spinlock_t s_next_gen_lock;
u32 s_next_generation;
long unsigned int s_dir_count;
u8 *s_debts;
struct percpu_counter s_freeblocks_counter;
struct percpu_counter s_freeinodes_counter;
struct percpu_counter s_dirs_counter;
struct blockgroup_lock *s_blockgroup_lock;
spinlock_t s_rsv_window_lock;
struct rb_root s_rsv_window_root;
struct ext2_reserve_window_node s_rsv_window_head;
spinlock_t s_lock;
struct mb_cache *s_ea_block_cache;
struct dax_device *s_daxdev;
long: 32;
u64 s_dax_part_off;
};
struct ext2_super_block {
__le32 s_inodes_count;
__le32 s_blocks_count;
__le32 s_r_blocks_count;
__le32 s_free_blocks_count;
__le32 s_free_inodes_count;
__le32 s_first_data_block;
__le32 s_log_block_size;
__le32 s_log_frag_size;
__le32 s_blocks_per_group;
__le32 s_frags_per_group;
__le32 s_inodes_per_group;
__le32 s_mtime;
__le32 s_wtime;
__le16 s_mnt_count;
__le16 s_max_mnt_count;
__le16 s_magic;
__le16 s_state;
__le16 s_errors;
__le16 s_minor_rev_level;
__le32 s_lastcheck;
__le32 s_checkinterval;
__le32 s_creator_os;
__le32 s_rev_level;
__le16 s_def_resuid;
__le16 s_def_resgid;
__le32 s_first_ino;
__le16 s_inode_size;
__le16 s_block_group_nr;
__le32 s_feature_compat;
__le32 s_feature_incompat;
__le32 s_feature_ro_compat;
__u8 s_uuid[16];
char s_volume_name[16];
char s_last_mounted[64];
__le32 s_algorithm_usage_bitmap;
__u8 s_prealloc_blocks;
__u8 s_prealloc_dir_blocks;
__u16 s_padding1;
__u8 s_journal_uuid[16];
__u32 s_journal_inum;
__u32 s_journal_dev;
__u32 s_last_orphan;
__u32 s_hash_seed[4];
__u8 s_def_hash_version;
__u8 s_reserved_char_pad;
__u16 s_reserved_word_pad;
__le32 s_default_mount_opts;
__le32 s_first_meta_bg;
__u32 s_reserved[190];
};
struct ext2_dir_entry_2 {
__le32 inode;
__le16 rec_len;
__u8 name_len;
__u8 file_type;
char name[0];
};
struct ext2_inode_info {
__le32 i_data[15];
__u32 i_flags;
__u32 i_faddr;
__u8 i_frag_no;
__u8 i_frag_size;
__u16 i_state;
__u32 i_file_acl;
__u32 i_dir_acl;
__u32 i_dtime;
__u32 i_block_group;
struct ext2_block_alloc_info *i_block_alloc_info;
__u32 i_dir_start_lookup;
rwlock_t i_meta_lock;
struct mutex truncate_mutex;
struct inode vfs_inode;
struct list_head i_orphan;
struct dquot *i_dquot[3];
long: 32;
};
typedef int filler_t(struct file *, struct folio *);
typedef struct ext2_dir_entry_2 ext2_dirent;
struct rpc_task_setup {
struct rpc_task *task;
struct rpc_clnt *rpc_client;
struct rpc_xprt *rpc_xprt;
struct rpc_cred *rpc_op_cred;
const struct rpc_message *rpc_message;
const struct rpc_call_ops *callback_ops;
void *callback_data;
struct workqueue_struct *workqueue;
short unsigned int flags;
signed char priority;
};
enum nfs3_stable_how {
NFS_UNSTABLE = 0,
NFS_DATA_SYNC = 1,
NFS_FILE_SYNC = 2,
NFS_INVALID_STABLE_HOW = -1,
};
struct nfs4_label {
uint32_t lfs;
uint32_t pi;
u32 len;
char *label;
};
struct nfs4_stateid_struct {
union {
char data[16];
struct {
__be32 seqid;
char other[12];
};
};
enum {
NFS4_INVALID_STATEID_TYPE = 0,
NFS4_SPECIAL_STATEID_TYPE = 1,
NFS4_OPEN_STATEID_TYPE = 2,
NFS4_LOCK_STATEID_TYPE = 3,
NFS4_DELEGATION_STATEID_TYPE = 4,
NFS4_LAYOUT_STATEID_TYPE = 5,
NFS4_PNFS_DS_STATEID_TYPE = 6,
NFS4_REVOKED_STATEID_TYPE = 7,
} type;
};
typedef struct nfs4_stateid_struct nfs4_stateid;
enum nfs4_change_attr_type {
NFS4_CHANGE_TYPE_IS_MONOTONIC_INCR = 0,
NFS4_CHANGE_TYPE_IS_VERSION_COUNTER = 1,
NFS4_CHANGE_TYPE_IS_VERSION_COUNTER_NOPNFS = 2,
NFS4_CHANGE_TYPE_IS_TIME_METADATA = 3,
NFS4_CHANGE_TYPE_IS_UNDEFINED = 4,
};
struct nfs4_string {
unsigned int len;
char *data;
};
struct nfs_fsid {
uint64_t major;
uint64_t minor;
};
struct nfs4_threshold {
__u32 bm;
__u32 l_type;
__u64 rd_sz;
__u64 wr_sz;
__u64 rd_io_sz;
__u64 wr_io_sz;
};
struct nfs_fattr {
unsigned int valid;
umode_t mode;
__u32 nlink;
kuid_t uid;
kgid_t gid;
dev_t rdev;
__u64 size;
union {
struct {
__u32 blocksize;
__u32 blocks;
} nfs2;
struct {
__u64 used;
} nfs3;
} du;
struct nfs_fsid fsid;
__u64 fileid;
__u64 mounted_on_fileid;
struct timespec64 atime;
struct timespec64 mtime;
struct timespec64 ctime;
__u64 change_attr;
__u64 pre_change_attr;
__u64 pre_size;
struct timespec64 pre_mtime;
struct timespec64 pre_ctime;
long unsigned int time_start;
long unsigned int gencount;
struct nfs4_string *owner_name;
struct nfs4_string *group_name;
struct nfs4_threshold *mdsthreshold;
struct nfs4_label *label;
};
struct nfs_fsinfo {
struct nfs_fattr *fattr;
__u32 rtmax;
__u32 rtpref;
__u32 rtmult;
__u32 wtmax;
__u32 wtpref;
__u32 wtmult;
__u32 dtpref;
__u64 maxfilesize;
struct timespec64 time_delta;
__u32 lease_time;
__u32 nlayouttypes;
__u32 layouttype[8];
__u32 blksize;
__u32 clone_blksize;
enum nfs4_change_attr_type change_attr_type;
__u32 xattr_support;
};
struct nfs_fsstat {
struct nfs_fattr *fattr;
long: 32;
__u64 tbytes;
__u64 fbytes;
__u64 abytes;
__u64 tfiles;
__u64 ffiles;
__u64 afiles;
};
struct nfs_pathconf {
struct nfs_fattr *fattr;
__u32 max_link;
__u32 max_namelen;
};
struct nfs4_change_info {
u32 atomic;
long: 32;
u64 before;
u64 after;
};
struct nfs4_slot;
struct nfs4_sequence_args {
struct nfs4_slot *sa_slot;
u8 sa_cache_this: 1;
u8 sa_privileged: 1;
};
struct nfs4_sequence_res {
struct nfs4_slot *sr_slot;
long unsigned int sr_timestamp;
int sr_status;
u32 sr_status_flags;
u32 sr_highest_slotid;
u32 sr_target_highest_slotid;
};
struct nfs_open_context;
struct nfs_lock_context {
refcount_t count;
struct list_head list;
struct nfs_open_context *open_context;
fl_owner_t lockowner;
atomic_t io_count;
struct callback_head callback_head;
};
struct nfs4_state;
struct nfs_open_context {
struct nfs_lock_context lock_context;
fl_owner_t flock_owner;
struct dentry *dentry;
const struct cred *cred;
struct rpc_cred *ll_cred;
struct nfs4_state *state;
fmode_t mode;
long unsigned int flags;
int error;
struct list_head list;
struct nfs4_threshold *mdsthreshold;
struct callback_head callback_head;
};
struct nfs_auth_info {
unsigned int flavor_len;
rpc_authflavor_t flavors[12];
};
struct nfs_client;
struct nfs_iostats;
struct nfs_server {
struct nfs_client *nfs_client;
struct list_head client_link;
struct list_head master_link;
struct rpc_clnt *client;
struct rpc_clnt *client_acl;
struct nlm_host *nlm_host;
struct nfs_iostats *io_stats;
atomic_long_t writeback;
unsigned int write_congested;
unsigned int flags;
unsigned int fattr_valid;
unsigned int caps;
unsigned int rsize;
unsigned int rpages;
unsigned int wsize;
unsigned int wpages;
unsigned int wtmult;
unsigned int dtsize;
short unsigned int port;
unsigned int bsize;
unsigned int acregmin;
unsigned int acregmax;
unsigned int acdirmin;
unsigned int acdirmax;
unsigned int namelen;
unsigned int options;
unsigned int clone_blksize;
enum nfs4_change_attr_type change_attr_type;
struct nfs_fsid fsid;
__u64 maxfilesize;
struct timespec64 time_delta;
long unsigned int mount_time;
struct super_block *super;
dev_t s_dev;
struct nfs_auth_info auth_info;
u32 pnfs_blksize;
struct ida openowner_id;
struct ida lockowner_id;
struct list_head state_owners_lru;
struct list_head layouts;
struct list_head delegations;
struct list_head ss_copies;
long unsigned int mig_gen;
long unsigned int mig_status;
void (*destroy)(struct nfs_server *);
atomic_t active;
struct __kernel_sockaddr_storage mountd_address;
size_t mountd_addrlen;
u32 mountd_version;
short unsigned int mountd_port;
short unsigned int mountd_protocol;
struct rpc_wait_queue uoc_rpcwaitq;
unsigned int read_hdrsize;
const struct cred *cred;
bool has_sec_mnt_opts;
long: 32;
};
struct nfs_rpc_ops;
struct nfs_subversion;
struct nfs_client {
refcount_t cl_count;
atomic_t cl_mds_count;
int cl_cons_state;
long unsigned int cl_res_state;
long unsigned int cl_flags;
struct __kernel_sockaddr_storage cl_addr;
size_t cl_addrlen;
char *cl_hostname;
char *cl_acceptor;
struct list_head cl_share_link;
struct list_head cl_superblocks;
struct rpc_clnt *cl_rpcclient;
const struct nfs_rpc_ops *rpc_ops;
int cl_proto;
struct nfs_subversion *cl_nfs_mod;
u32 cl_minorversion;
unsigned int cl_nconnect;
unsigned int cl_max_connect;
const char *cl_principal;
char cl_ipaddr[48];
struct net *cl_net;
struct list_head pending_cb_stateids;
};
struct nfs_write_verifier {
char data[8];
};
struct nfs_writeverf {
struct nfs_write_verifier verifier;
enum nfs3_stable_how committed;
};
struct nfs_pgio_args {
struct nfs4_sequence_args seq_args;
struct nfs_fh *fh;
struct nfs_open_context *context;
struct nfs_lock_context *lock_context;
nfs4_stateid stateid;
__u64 offset;
__u32 count;
unsigned int pgbase;
struct page **pages;
union {
unsigned int replen;
struct {
const u32 *bitmask;
u32 bitmask_store[3];
enum nfs3_stable_how stable;
};
};
};
struct nfs_pgio_res {
struct nfs4_sequence_res seq_res;
struct nfs_fattr *fattr;
long: 32;
__u64 count;
__u32 op_status;
union {
struct {
unsigned int replen;
int eof;
};
struct {
struct nfs_writeverf *verf;
const struct nfs_server *server;
};
};
long: 32;
};
struct nfs_commitargs {
struct nfs4_sequence_args seq_args;
struct nfs_fh *fh;
long: 32;
__u64 offset;
__u32 count;
const u32 *bitmask;
};
struct nfs_commitres {
struct nfs4_sequence_res seq_res;
__u32 op_status;
struct nfs_fattr *fattr;
struct nfs_writeverf *verf;
const struct nfs_server *server;
};
struct nfs_removeargs {
struct nfs4_sequence_args seq_args;
const struct nfs_fh *fh;
long: 32;
struct qstr name;
};
struct nfs_removeres {
struct nfs4_sequence_res seq_res;
struct nfs_server *server;
struct nfs_fattr *dir_attr;
struct nfs4_change_info cinfo;
};
struct nfs_renameargs {
struct nfs4_sequence_args seq_args;
const struct nfs_fh *old_dir;
const struct nfs_fh *new_dir;
const struct qstr *old_name;
const struct qstr *new_name;
};
struct nfs_renameres {
struct nfs4_sequence_res seq_res;
struct nfs_server *server;
long: 32;
struct nfs4_change_info old_cinfo;
struct nfs_fattr *old_fattr;
long: 32;
struct nfs4_change_info new_cinfo;
struct nfs_fattr *new_fattr;
long: 32;
};
struct nfs_entry {
__u64 ino;
__u64 cookie;
const char *name;
unsigned int len;
int eof;
struct nfs_fh *fh;
struct nfs_fattr *fattr;
unsigned char d_type;
struct nfs_server *server;
long: 32;
};
struct nfs_readdir_arg {
struct dentry *dentry;
const struct cred *cred;
__be32 *verf;
long: 32;
u64 cookie;
struct page **pages;
unsigned int page_len;
bool plus;
long: 32;
};
struct nfs_readdir_res {
__be32 *verf;
};
struct pnfs_ds_commit_info {};
struct nfs_page_array {
struct page **pagevec;
unsigned int npages;
struct page *page_array[8];
};
struct nfs_page;
struct pnfs_layout_segment;
struct nfs_pgio_completion_ops;
struct nfs_rw_ops;
struct nfs_io_completion;
struct nfs_direct_req;
struct nfs_pgio_header {
struct inode *inode;
const struct cred *cred;
struct list_head pages;
struct nfs_page *req;
struct nfs_writeverf verf;
fmode_t rw_mode;
struct pnfs_layout_segment *lseg;
loff_t io_start;
const struct rpc_call_ops *mds_ops;
void (*release)(struct nfs_pgio_header *);
const struct nfs_pgio_completion_ops *completion_ops;
const struct nfs_rw_ops *rw_ops;
struct nfs_io_completion *io_completion;
struct nfs_direct_req *dreq;
int pnfs_error;
int error;
unsigned int good_bytes;
long unsigned int flags;
struct rpc_task task;
struct nfs_fattr fattr;
struct nfs_pgio_args args;
struct nfs_pgio_res res;
long unsigned int timestamp;
int (*pgio_done_cb)(struct rpc_task *, struct nfs_pgio_header *);
__u64 mds_offset;
struct nfs_page_array page_array;
struct nfs_client *ds_clp;
u32 ds_commit_idx;
u32 pgio_mirror_idx;
long: 32;
};
struct nfs_page {
struct list_head wb_list;
struct page *wb_page;
struct nfs_lock_context *wb_lock_context;
long unsigned int wb_index;
unsigned int wb_offset;
unsigned int wb_pgbase;
unsigned int wb_bytes;
struct kref wb_kref;
long unsigned int wb_flags;
struct nfs_write_verifier wb_verf;
struct nfs_page *wb_this_page;
struct nfs_page *wb_head;
short unsigned int wb_nio;
};
struct nfs_pgio_completion_ops {
void (*error_cleanup)(struct list_head *, int);
void (*init_hdr)(struct nfs_pgio_header *);
void (*completion)(struct nfs_pgio_header *);
void (*reschedule_io)(struct nfs_pgio_header *);
};
struct nfs_rw_ops {
struct nfs_pgio_header * (*rw_alloc_header)();
void (*rw_free_header)(struct nfs_pgio_header *);
int (*rw_done)(struct rpc_task *, struct nfs_pgio_header *, struct inode *);
void (*rw_result)(struct rpc_task *, struct nfs_pgio_header *);
void (*rw_initiate)(struct nfs_pgio_header *, struct rpc_message *, const struct nfs_rpc_ops *, struct rpc_task_setup *, int);
};
struct nfs_mds_commit_info {
atomic_t rpcs_out;
atomic_long_t ncommit;
struct list_head list;
};
struct nfs_direct_req {
struct kref kref;
struct nfs_open_context *ctx;
struct nfs_lock_context *l_ctx;
struct kiocb *iocb;
struct inode *inode;
atomic_t io_count;
spinlock_t lock;
long: 32;
loff_t io_start;
ssize_t count;
ssize_t max_count;
ssize_t bytes_left;
ssize_t error;
struct completion completion;
struct nfs_mds_commit_info mds_cinfo;
struct pnfs_ds_commit_info ds_cinfo;
struct work_struct work;
int flags;
long: 32;
};
struct nfs_commit_data;
struct nfs_commit_info;
struct nfs_commit_completion_ops {
void (*completion)(struct nfs_commit_data *);
void (*resched_write)(struct nfs_commit_info *, struct nfs_page *);
};
struct nfs_commit_data {
struct rpc_task task;
struct inode *inode;
const struct cred *cred;
struct nfs_fattr fattr;
struct nfs_writeverf verf;
struct list_head pages;
struct list_head list;
struct nfs_direct_req *dreq;
struct nfs_commitargs args;
struct nfs_commitres res;
struct nfs_open_context *context;
struct pnfs_layout_segment *lseg;
struct nfs_client *ds_clp;
int ds_commit_index;
loff_t lwb;
const struct rpc_call_ops *mds_ops;
const struct nfs_commit_completion_ops *completion_ops;
int (*commit_done_cb)(struct rpc_task *, struct nfs_commit_data *);
long unsigned int flags;
};
struct nfs_commit_info {
struct inode *inode;
struct nfs_mds_commit_info *mds;
struct pnfs_ds_commit_info *ds;
struct nfs_direct_req *dreq;
const struct nfs_commit_completion_ops *completion_ops;
};
struct nfs_unlinkdata {
struct nfs_removeargs args;
struct nfs_removeres res;
struct dentry *dentry;
wait_queue_head_t wq;
const struct cred *cred;
long: 32;
struct nfs_fattr dir_attr;
long int timeout;
long: 32;
};
struct nfs_renamedata {
struct nfs_renameargs args;
struct nfs_renameres res;
struct rpc_task task;
const struct cred *cred;
struct inode *old_dir;
struct dentry *old_dentry;
long: 32;
struct nfs_fattr old_fattr;
struct inode *new_dir;
struct dentry *new_dentry;
struct nfs_fattr new_fattr;
void (*complete)(struct rpc_task *, struct nfs_renamedata *);
long int timeout;
bool cancelled;
long: 32;
};
struct nfs_access_entry;
struct nfs_client_initdata;
struct nfs_rpc_ops {
u32 version;
const struct dentry_operations *dentry_ops;
const struct inode_operations *dir_inode_ops;
const struct inode_operations *file_inode_ops;
const struct file_operations *file_ops;
const struct nlmclnt_operations *nlmclnt_ops;
int (*getroot)(struct nfs_server *, struct nfs_fh *, struct nfs_fsinfo *);
int (*submount)(struct fs_context *, struct nfs_server *);
int (*try_get_tree)(struct fs_context *);
int (*getattr)(struct nfs_server *, struct nfs_fh *, struct nfs_fattr *, struct inode *);
int (*setattr)(struct dentry *, struct nfs_fattr *, struct iattr *);
int (*lookup)(struct inode *, struct dentry *, struct nfs_fh *, struct nfs_fattr *);
int (*lookupp)(struct inode *, struct nfs_fh *, struct nfs_fattr *);
int (*access)(struct inode *, struct nfs_access_entry *, const struct cred *);
int (*readlink)(struct inode *, struct page *, unsigned int, unsigned int);
int (*create)(struct inode *, struct dentry *, struct iattr *, int);
int (*remove)(struct inode *, struct dentry *);
void (*unlink_setup)(struct rpc_message *, struct dentry *, struct inode *);
void (*unlink_rpc_prepare)(struct rpc_task *, struct nfs_unlinkdata *);
int (*unlink_done)(struct rpc_task *, struct inode *);
void (*rename_setup)(struct rpc_message *, struct dentry *, struct dentry *);
void (*rename_rpc_prepare)(struct rpc_task *, struct nfs_renamedata *);
int (*rename_done)(struct rpc_task *, struct inode *, struct inode *);
int (*link)(struct inode *, struct inode *, const struct qstr *);
int (*symlink)(struct inode *, struct dentry *, struct page *, unsigned int, struct iattr *);
int (*mkdir)(struct inode *, struct dentry *, struct iattr *);
int (*rmdir)(struct inode *, const struct qstr *);
int (*readdir)(struct nfs_readdir_arg *, struct nfs_readdir_res *);
int (*mknod)(struct inode *, struct dentry *, struct iattr *, dev_t);
int (*statfs)(struct nfs_server *, struct nfs_fh *, struct nfs_fsstat *);
int (*fsinfo)(struct nfs_server *, struct nfs_fh *, struct nfs_fsinfo *);
int (*pathconf)(struct nfs_server *, struct nfs_fh *, struct nfs_pathconf *);
int (*set_capabilities)(struct nfs_server *, struct nfs_fh *);
int (*decode_dirent)(struct xdr_stream *, struct nfs_entry *, bool);
int (*pgio_rpc_prepare)(struct rpc_task *, struct nfs_pgio_header *);
void (*read_setup)(struct nfs_pgio_header *, struct rpc_message *);
int (*read_done)(struct rpc_task *, struct nfs_pgio_header *);
void (*write_setup)(struct nfs_pgio_header *, struct rpc_message *, struct rpc_clnt **);
int (*write_done)(struct rpc_task *, struct nfs_pgio_header *);
void (*commit_setup)(struct nfs_commit_data *, struct rpc_message *, struct rpc_clnt **);
void (*commit_rpc_prepare)(struct rpc_task *, struct nfs_commit_data *);
int (*commit_done)(struct rpc_task *, struct nfs_commit_data *);
int (*lock)(struct file *, int, struct file_lock *);
int (*lock_check_bounds)(const struct file_lock *);
void (*clear_acl_cache)(struct inode *);
void (*close_context)(struct nfs_open_context *, int);
struct inode * (*open_context)(struct inode *, struct nfs_open_context *, int, struct iattr *, int *);
int (*have_delegation)(struct inode *, fmode_t);
struct nfs_client * (*alloc_client)(const struct nfs_client_initdata *);
struct nfs_client * (*init_client)(struct nfs_client *, const struct nfs_client_initdata *);
void (*free_client)(struct nfs_client *);
struct nfs_server * (*create_server)(struct fs_context *);
struct nfs_server * (*clone_server)(struct nfs_server *, struct nfs_fh *, struct nfs_fattr *, rpc_authflavor_t);
int (*discover_trunking)(struct nfs_server *, struct nfs_fh *);
void (*enable_swap)(struct inode *);
void (*disable_swap)(struct inode *);
};
struct nfs_access_entry {
struct rb_node rb_node;
struct list_head lru;
kuid_t fsuid;
kgid_t fsgid;
struct group_info *group_info;
__u32 mask;
struct callback_head callback_head;
};
struct nfs_client_initdata {
long unsigned int init_flags;
const char *hostname;
const struct __kernel_sockaddr_storage *addr;
const char *nodename;
const char *ip_addr;
size_t addrlen;
struct nfs_subversion *nfs_mod;
int proto;
u32 minorversion;
unsigned int nconnect;
unsigned int max_connect;
struct net *net;
const struct rpc_timeout *timeparms;
const struct cred *cred;
};
struct nfs_subversion {
struct module *owner;
struct file_system_type *nfs_fs;
const struct rpc_version *rpc_vers;
const struct nfs_rpc_ops *rpc_ops;
const struct super_operations *sops;
const struct xattr_handler **xattr;
struct list_head list;
};
enum dentry_d_lock_class {
DENTRY_D_LOCK_NORMAL = 0,
DENTRY_D_LOCK_NESTED = 1,
};
typedef unsigned int autofs_wqt_t;
struct autofs_packet_hdr {
int proto_version;
int type;
};
struct autofs_packet_expire {
struct autofs_packet_hdr hdr;
int len;
char name[256];
};
enum autofs_notify {
NFY_NONE = 0,
NFY_MOUNT = 1,
NFY_EXPIRE = 2,
};
struct autofs_sb_info;
struct autofs_info {
struct dentry *dentry;
int flags;
struct completion expire_complete;
struct list_head active;
struct list_head expiring;
struct autofs_sb_info *sbi;
long unsigned int last_used;
int count;
kuid_t uid;
kgid_t gid;
struct callback_head rcu;
};
struct autofs_wait_queue;
struct autofs_sb_info {
u32 magic;
int pipefd;
struct file *pipe;
struct pid *oz_pgrp;
int version;
int sub_version;
int min_proto;
int max_proto;
unsigned int flags;
long unsigned int exp_timeout;
unsigned int type;
struct super_block *sb;
struct mutex wq_mutex;
struct mutex pipe_mutex;
spinlock_t fs_lock;
struct autofs_wait_queue *queues;
spinlock_t lookup_lock;
struct list_head active_list;
struct list_head expiring_list;
struct callback_head rcu;
};
struct autofs_wait_queue {
wait_queue_head_t queue;
struct autofs_wait_queue *next;
autofs_wqt_t wait_queue_token;
long: 32;
struct qstr name;
u32 offset;
u32 dev;
u64 ino;
kuid_t uid;
kgid_t gid;
pid_t pid;
pid_t tgid;
int status;
unsigned int wait_ctr;
};
typedef int __kernel_key_t;
typedef __kernel_key_t key_t;
struct kern_ipc_perm {
spinlock_t lock;
bool deleted;
int id;
key_t key;
kuid_t uid;
kgid_t gid;
kuid_t cuid;
kgid_t cgid;
umode_t mode;
long unsigned int seq;
void *security;
struct rhash_head khtnode;
struct callback_head rcu;
refcount_t refcount;
long: 32;
};
struct ipc_ids {
int in_use;
short unsigned int seq;
struct rw_semaphore rwsem;
struct idr ipcs_idr;
int max_idx;
int last_idx;
struct rhashtable key_ht;
};
struct ipc_namespace {
struct ipc_ids ids[3];
int sem_ctls[4];
int used_sems;
unsigned int msg_ctlmax;
unsigned int msg_ctlmnb;
unsigned int msg_ctlmni;
long: 32;
struct percpu_counter percpu_msg_bytes;
struct percpu_counter percpu_msg_hdrs;
size_t shm_ctlmax;
size_t shm_ctlall;
long unsigned int shm_tot;
int shm_ctlmni;
int shm_rmid_forced;
struct notifier_block ipcns_nb;
struct vfsmount *mq_mnt;
unsigned int mq_queues_count;
unsigned int mq_queues_max;
unsigned int mq_msg_max;
unsigned int mq_msgsize_max;
unsigned int mq_msg_default;
unsigned int mq_msgsize_default;
struct ctl_table_set mq_set;
struct ctl_table_header *mq_sysctls;
struct ctl_table_set ipc_set;
struct ctl_table_header *ipc_sysctls;
struct user_namespace *user_ns;
struct ucounts *ucounts;
struct llist_node mnt_llist;
struct ns_common ns;
};
struct hash_alg_common {
unsigned int digestsize;
unsigned int statesize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct ahash_request {
struct crypto_async_request base;
unsigned int nbytes;
struct scatterlist *src;
u8 *result;
void *priv;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__ctx[0];
};
struct crypto_ahash;
struct ahash_alg {
int (*init)(struct ahash_request *);
int (*update)(struct ahash_request *);
int (*final)(struct ahash_request *);
int (*finup)(struct ahash_request *);
int (*digest)(struct ahash_request *);
int (*export)(struct ahash_request *, void *);
int (*import)(struct ahash_request *, const void *);
int (*setkey)(struct crypto_ahash *, const u8 *, unsigned int);
int (*init_tfm)(struct crypto_ahash *);
void (*exit_tfm)(struct crypto_ahash *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct hash_alg_common halg;
};
struct crypto_ahash {
int (*init)(struct ahash_request *);
int (*update)(struct ahash_request *);
int (*final)(struct ahash_request *);
int (*finup)(struct ahash_request *);
int (*digest)(struct ahash_request *);
int (*export)(struct ahash_request *, void *);
int (*import)(struct ahash_request *, const void *);
int (*setkey)(struct crypto_ahash *, const u8 *, unsigned int);
unsigned int reqsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_tfm base;
};
struct shash_desc {
struct crypto_shash *tfm;
long: 32;
void *__ctx[0];
};
struct shash_alg {
int (*init)(struct shash_desc *);
int (*update)(struct shash_desc *, const u8 *, unsigned int);
int (*final)(struct shash_desc *, u8 *);
int (*finup)(struct shash_desc *, const u8 *, unsigned int, u8 *);
int (*digest)(struct shash_desc *, const u8 *, unsigned int, u8 *);
int (*export)(struct shash_desc *, void *);
int (*import)(struct shash_desc *, const void *);
int (*setkey)(struct crypto_shash *, const u8 *, unsigned int);
int (*init_tfm)(struct crypto_shash *);
void (*exit_tfm)(struct crypto_shash *);
unsigned int descsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
unsigned int digestsize;
unsigned int statesize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct crypto_hash_walk {
char *data;
unsigned int offset;
unsigned int alignmask;
struct page *pg;
unsigned int entrylen;
unsigned int total;
struct scatterlist *sg;
unsigned int flags;
};
struct ahash_instance {
void (*free)(struct ahash_instance *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
union {
struct {
char head[256];
struct crypto_instance base;
} s;
struct ahash_alg alg;
};
};
struct crypto_ahash_spawn {
struct crypto_spawn base;
};
struct crypto_report_hash {
char type[64];
unsigned int blocksize;
unsigned int digestsize;
};
struct ahash_request_priv {
crypto_completion_t complete;
void *data;
u8 *result;
u32 flags;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *ubuf[0];
};
typedef bool (*sb_for_each_fn)(struct sbitmap *, unsigned int, void *);
struct sbq_wait {
struct sbitmap_queue *sbq;
struct wait_queue_entry wait;
};
typedef bool busy_tag_iter_fn(struct request *, void *);
enum {
BLK_MQ_F_SHOULD_MERGE = 1,
BLK_MQ_F_TAG_QUEUE_SHARED = 2,
BLK_MQ_F_STACKING = 4,
BLK_MQ_F_TAG_HCTX_SHARED = 8,
BLK_MQ_F_BLOCKING = 32,
BLK_MQ_F_NO_SCHED = 64,
BLK_MQ_F_NO_SCHED_BY_DEFAULT = 128,
BLK_MQ_F_ALLOC_POLICY_START_BIT = 8,
BLK_MQ_F_ALLOC_POLICY_BITS = 1,
BLK_MQ_S_STOPPED = 0,
BLK_MQ_S_TAG_ACTIVE = 1,
BLK_MQ_S_SCHED_RESTART = 2,
BLK_MQ_S_INACTIVE = 3,
BLK_MQ_MAX_DEPTH = 10240,
BLK_MQ_CPU_WORK_BATCH = 8,
};
enum {
BLK_MQ_REQ_NOWAIT = 1,
BLK_MQ_REQ_RESERVED = 2,
BLK_MQ_REQ_PM = 4,
};
enum {
BLK_MQ_UNIQUE_TAG_BITS = 16,
BLK_MQ_UNIQUE_TAG_MASK = 65535,
};
enum {
BLK_MQ_NO_TAG = 4294967295,
BLK_MQ_TAG_MIN = 1,
BLK_MQ_TAG_MAX = 4294967294,
};
struct bt_iter_data {
struct blk_mq_hw_ctx *hctx;
struct request_queue *q;
busy_tag_iter_fn *fn;
void *data;
bool reserved;
};
struct bt_tags_iter_data {
struct blk_mq_tags *tags;
busy_tag_iter_fn *fn;
void *data;
unsigned int flags;
};
struct virtio_device_id {
__u32 device;
__u32 vendor;
};
struct virtio_device;
struct virtqueue {
struct list_head list;
void (*callback)(struct virtqueue *);
const char *name;
struct virtio_device *vdev;
unsigned int index;
unsigned int num_free;
unsigned int num_max;
void *priv;
bool reset;
};
struct vringh_config_ops;
struct virtio_config_ops;
struct virtio_device {
int index;
bool failed;
bool config_enabled;
bool config_change_pending;
spinlock_t config_lock;
spinlock_t vqs_list_lock;
struct device dev;
struct virtio_device_id id;
const struct virtio_config_ops *config;
const struct vringh_config_ops *vringh_config;
struct list_head vqs;
u64 features;
void *priv;
long: 32;
};
typedef void vq_callback_t(struct virtqueue *);
struct irq_affinity;
struct virtio_shm_region;
struct virtio_config_ops {
void (*get)(struct virtio_device *, unsigned int, void *, unsigned int);
void (*set)(struct virtio_device *, unsigned int, const void *, unsigned int);
u32 (*generation)(struct virtio_device *);
u8 (*get_status)(struct virtio_device *);
void (*set_status)(struct virtio_device *, u8);
void (*reset)(struct virtio_device *);
int (*find_vqs)(struct virtio_device *, unsigned int, struct virtqueue **, vq_callback_t **, const char * const *, const bool *, struct irq_affinity *);
void (*del_vqs)(struct virtio_device *);
void (*synchronize_cbs)(struct virtio_device *);
u64 (*get_features)(struct virtio_device *);
int (*finalize_features)(struct virtio_device *);
const char * (*bus_name)(struct virtio_device *);
int (*set_vq_affinity)(struct virtqueue *, const struct cpumask *);
const struct cpumask * (*get_vq_affinity)(struct virtio_device *, int);
bool (*get_shm_region)(struct virtio_device *, struct virtio_shm_region *, u8);
int (*disable_vq_and_reset)(struct virtqueue *);
int (*enable_vq_after_reset)(struct virtqueue *);
};
struct virtio_shm_region {
u64 addr;
u64 len;
};
enum io_uring_cmd_flags {
IO_URING_F_COMPLETE_DEFER = 1,
IO_URING_F_UNLOCKED = 2,
IO_URING_F_NONBLOCK = -2147483648,
IO_URING_F_SQE128 = 4,
IO_URING_F_CQE32 = 8,
IO_URING_F_IOPOLL = 16,
IO_URING_F_MULTISHOT = 32,
};
struct epoll_event {
__poll_t events;
long: 32;
__u64 data;
};
enum {
REQ_F_FIXED_FILE = 1,
REQ_F_IO_DRAIN = 2,
REQ_F_LINK = 4,
REQ_F_HARDLINK = 8,
REQ_F_FORCE_ASYNC = 16,
REQ_F_BUFFER_SELECT = 32,
REQ_F_CQE_SKIP = 64,
REQ_F_FAIL = 256,
REQ_F_INFLIGHT = 512,
REQ_F_CUR_POS = 1024,
REQ_F_NOWAIT = 2048,
REQ_F_LINK_TIMEOUT = 4096,
REQ_F_NEED_CLEANUP = 8192,
REQ_F_POLLED = 16384,
REQ_F_BUFFER_SELECTED = 32768,
REQ_F_BUFFER_RING = 65536,
REQ_F_REISSUE = 131072,
REQ_F_SUPPORT_NOWAIT = 1073741824,
REQ_F_ISREG = 2147483648,
REQ_F_CREDS = 262144,
REQ_F_REFCOUNT = 524288,
REQ_F_ARM_LTIMEOUT = 1048576,
REQ_F_ASYNC_DATA = 2097152,
REQ_F_SKIP_LINK_CQES = 4194304,
REQ_F_SINGLE_POLL = 8388608,
REQ_F_DOUBLE_POLL = 16777216,
REQ_F_PARTIAL_IO = 33554432,
REQ_F_APOLL_MULTISHOT = 134217728,
REQ_F_CQE32_INIT = 67108864,
REQ_F_CLEAR_POLLIN = 268435456,
REQ_F_HASH_LOCKED = 536870912,
};
enum {
IOU_OK = 0,
IOU_ISSUE_SKIP_COMPLETE = -529,
IOU_STOP_MULTISHOT = -158,
};
struct io_epoll {
struct file *file;
int epfd;
int op;
int fd;
struct epoll_event event;
};
struct match_token {
int token;
const char *pattern;
};
enum {
MAX_OPT_ARGS = 3,
};
typedef struct {
char *from;
char *to;
} substring_t;
typedef int __kernel_ptrdiff_t;
typedef __kernel_ptrdiff_t ptrdiff_t;
struct region {
unsigned int start;
unsigned int off;
unsigned int group_len;
unsigned int end;
unsigned int nbits;
};
enum {
REG_OP_ISFREE = 0,
REG_OP_ALLOC = 1,
REG_OP_RELEASE = 2,
};
typedef unsigned char Byte;
typedef long unsigned int uLong;
struct internal_state;
struct z_stream_s {
const Byte *next_in;
uLong avail_in;
uLong total_in;
Byte *next_out;
uLong avail_out;
uLong total_out;
char *msg;
struct internal_state *state;
void *workspace;
int data_type;
uLong adler;
uLong reserved;
};
typedef struct z_stream_s z_stream;
typedef z_stream *z_streamp;
typedef u16 uint16_t;
typedef struct {
const uint8_t *externalDict;
size_t extDictSize;
const uint8_t *prefixEnd;
size_t prefixSize;
} LZ4_streamDecode_t_internal;
typedef union {
long long unsigned int table[4];
LZ4_streamDecode_t_internal internal_donotuse;
} LZ4_streamDecode_t;
typedef uint8_t BYTE;
typedef uint16_t U16;
typedef uint32_t U32;
typedef uintptr_t uptrval;
typedef enum {
noDict = 0,
withPrefix64k = 1,
usingExtDict = 2,
} dict_directive;
typedef enum {
endOnOutputSize = 0,
endOnInputSize = 1,
} endCondition_directive;
typedef enum {
decode_full_block = 0,
partial_decode = 1,
} earlyEnd_directive;
typedef struct scatterlist *sg_alloc_fn(unsigned int, gfp_t);
typedef void sg_free_fn(struct scatterlist *, unsigned int);
struct sg_pool {
size_t size;
char *name;
struct kmem_cache *slab;
mempool_t *pool;
};
union ieee754dp {
struct {
u64 mant: 52;
unsigned int bexp: 11;
unsigned int sign: 1;
};
u64 bits;
};
enum {
IEEE754_CLASS_NORM = 0,
IEEE754_CLASS_ZERO = 1,
IEEE754_CLASS_DNORM = 2,
IEEE754_CLASS_INF = 3,
IEEE754_CLASS_SNAN = 4,
IEEE754_CLASS_QNAN = 5,
};
struct _ieee754_csr {
unsigned int rm: 2;
unsigned int sx: 5;
unsigned int mx: 5;
unsigned int cx: 6;
unsigned int nan2008: 1;
unsigned int abs2008: 1;
unsigned int pad0: 3;
unsigned int c: 1;
unsigned int nod: 1;
unsigned int fcc: 7;
};
union ieee754sp {
struct {
unsigned int mant: 23;
unsigned int bexp: 8;
unsigned int sign: 1;
};
u32 bits;
};
struct pci_cap_saved_data {
u16 cap_nr;
bool cap_extended;
unsigned int size;
u32 data[0];
};
struct pci_cap_saved_state {
struct hlist_node next;
struct pci_cap_saved_data cap;
};
struct fb_videomode {
const char *name;
u32 refresh;
u32 xres;
u32 yres;
u32 pixclock;
u32 left_margin;
u32 right_margin;
u32 upper_margin;
u32 lower_margin;
u32 hsync_len;
u32 vsync_len;
u32 sync;
u32 vmode;
u32 flag;
};
struct fb_cvt_data {
u32 xres;
u32 yres;
u32 refresh;
u32 f_refresh;
u32 pixclock;
u32 hperiod;
u32 hblank;
u32 hfreq;
u32 htotal;
u32 vtotal;
u32 vsync;
u32 hsync;
u32 h_front_porch;
u32 h_back_porch;
u32 v_front_porch;
u32 v_back_porch;
u32 h_margin;
u32 v_margin;
u32 interlace;
u32 aspect_ratio;
u32 active_pixels;
u32 flags;
u32 status;
};
enum gpiod_flags {
GPIOD_ASIS = 0,
GPIOD_IN = 1,
GPIOD_OUT_LOW = 3,
GPIOD_OUT_HIGH = 7,
GPIOD_OUT_LOW_OPEN_DRAIN = 11,
GPIOD_OUT_HIGH_OPEN_DRAIN = 15,
};
struct clk_gpio {
struct clk_hw hw;
struct gpio_desc *gpiod;
};
typedef short unsigned int ushort;
typedef unsigned int uint;
struct atomic_notifier_head {
spinlock_t lock;
struct notifier_block *head;
};
struct device_attribute {
struct attribute attr;
ssize_t (*show)(struct device *, struct device_attribute *, char *);
ssize_t (*store)(struct device *, struct device_attribute *, const char *, size_t);
};
struct console_font_op {
unsigned int op;
unsigned int flags;
unsigned int width;
unsigned int height;
unsigned int charcount;
unsigned char *data;
};
struct console_font {
unsigned int width;
unsigned int height;
unsigned int charcount;
unsigned char *data;
};
enum con_scroll {
SM_UP = 0,
SM_DOWN = 1,
};
enum vc_intensity {
VCI_HALF_BRIGHT = 0,
VCI_NORMAL = 1,
VCI_BOLD = 2,
VCI_MASK = 3,
};
struct vc_data;
struct consw {
struct module *owner;
const char * (*con_startup)();
void (*con_init)(struct vc_data *, int);
void (*con_deinit)(struct vc_data *);
void (*con_clear)(struct vc_data *, int, int, int, int);
void (*con_putc)(struct vc_data *, int, int, int);
void (*con_putcs)(struct vc_data *, const short unsigned int *, int, int, int);
void (*con_cursor)(struct vc_data *, int);
bool (*con_scroll)(struct vc_data *, unsigned int, unsigned int, enum con_scroll, unsigned int);
int (*con_switch)(struct vc_data *);
int (*con_blank)(struct vc_data *, int, int);
int (*con_font_set)(struct vc_data *, struct console_font *, unsigned int);
int (*con_font_get)(struct vc_data *, struct console_font *);
int (*con_font_default)(struct vc_data *, struct console_font *, char *);
int (*con_resize)(struct vc_data *, unsigned int, unsigned int, unsigned int);
void (*con_set_palette)(struct vc_data *, const unsigned char *);
void (*con_scrolldelta)(struct vc_data *, int);
int (*con_set_origin)(struct vc_data *);
void (*con_save_screen)(struct vc_data *);
u8 (*con_build_attr)(struct vc_data *, u8, enum vc_intensity, bool, bool, bool, bool);
void (*con_invert_region)(struct vc_data *, u16 *, int);
u16 * (*con_screen_pos)(const struct vc_data *, int);
long unsigned int (*con_getxy)(struct vc_data *, long unsigned int, int *, int *);
void (*con_flush_scrollback)(struct vc_data *);
int (*con_debug_enter)(struct vc_data *);
int (*con_debug_leave)(struct vc_data *);
};
struct vc_state {
unsigned int x;
unsigned int y;
unsigned char color;
unsigned char Gx_charset[2];
unsigned int charset: 1;
enum vc_intensity intensity;
bool italic;
bool underline;
bool blink;
bool reverse;
};
struct vt_mode {
char mode;
char waitv;
short int relsig;
short int acqsig;
short int frsig;
};
struct uni_pagedict;
struct uni_screen;
struct vc_data {
struct tty_port port;
struct vc_state state;
struct vc_state saved_state;
short unsigned int vc_num;
unsigned int vc_cols;
unsigned int vc_rows;
unsigned int vc_size_row;
unsigned int vc_scan_lines;
unsigned int vc_cell_height;
long unsigned int vc_origin;
long unsigned int vc_scr_end;
long unsigned int vc_visible_origin;
unsigned int vc_top;
unsigned int vc_bottom;
const struct consw *vc_sw;
short unsigned int *vc_screenbuf;
unsigned int vc_screenbuf_size;
unsigned char vc_mode;
unsigned char vc_attr;
unsigned char vc_def_color;
unsigned char vc_ulcolor;
unsigned char vc_itcolor;
unsigned char vc_halfcolor;
unsigned int vc_cursor_type;
short unsigned int vc_complement_mask;
short unsigned int vc_s_complement_mask;
long unsigned int vc_pos;
short unsigned int vc_hi_font_mask;
struct console_font vc_font;
short unsigned int vc_video_erase_char;
unsigned int vc_state;
unsigned int vc_npar;
unsigned int vc_par[16];
struct vt_mode vt_mode;
struct pid *vt_pid;
int vt_newvt;
wait_queue_head_t paste_wait;
unsigned int vc_disp_ctrl: 1;
unsigned int vc_toggle_meta: 1;
unsigned int vc_decscnm: 1;
unsigned int vc_decom: 1;
unsigned int vc_decawm: 1;
unsigned int vc_deccm: 1;
unsigned int vc_decim: 1;
unsigned int vc_priv: 3;
unsigned int vc_need_wrap: 1;
unsigned int vc_can_do_color: 1;
unsigned int vc_report_mouse: 2;
unsigned char vc_utf: 1;
unsigned char vc_utf_count;
int vc_utf_char;
long unsigned int vc_tab_stop[8];
unsigned char vc_palette[48];
short unsigned int *vc_translate;
unsigned int vc_resize_user;
unsigned int vc_bell_pitch;
unsigned int vc_bell_duration;
short unsigned int vc_cur_blink_ms;
struct vc_data **vc_display_fg;
struct uni_pagedict *uni_pagedict;
struct uni_pagedict **uni_pagedict_loc;
struct uni_screen *vc_uni_screen;
};
struct console {
char name[16];
void (*write)(struct console *, const char *, unsigned int);
int (*read)(struct console *, char *, unsigned int);
struct tty_driver * (*device)(struct console *, int *);
void (*unblank)();
int (*setup)(struct console *, char *);
int (*exit)(struct console *);
int (*match)(struct console *, char *, int, char *);
short int flags;
short int index;
int cflag;
uint ispeed;
uint ospeed;
long: 32;
u64 seq;
long unsigned int dropped;
void *data;
struct console *next;
long: 32;
};
typedef uint32_t char32_t;
struct uni_screen {
char32_t *lines[0];
};
struct vc {
struct vc_data *d;
struct work_struct SAK_work;
};
enum translation_map {
LAT1_MAP = 0,
GRAF_MAP = 1,
IBMPC_MAP = 2,
USER_MAP = 3,
FIRST_MAP = 0,
LAST_MAP = 3,
};
struct vt_notifier_param {
struct vc_data *vc;
unsigned int c;
};
struct tiocl_selection {
short unsigned int xs;
short unsigned int ys;
short unsigned int xe;
short unsigned int ye;
short unsigned int sel_mode;
};
struct con_driver {
const struct consw *con;
const char *desc;
struct device *dev;
int node;
int first;
int last;
int flag;
};
enum {
blank_off = 0,
blank_normal_wait = 1,
blank_vesa_wait = 2,
};
enum {
EPecma = 0,
EPdec = 1,
EPeq = 2,
EPgt = 3,
EPlt = 4,
};
struct rgb {
u8 r;
u8 g;
u8 b;
};
enum {
ESnormal = 0,
ESesc = 1,
ESsquare = 2,
ESgetpars = 3,
ESfunckey = 4,
EShash = 5,
ESsetG0 = 6,
ESsetG1 = 7,
ESpercent = 8,
EScsiignore = 9,
ESnonstd = 10,
ESpalette = 11,
ESosc = 12,
ESapc = 13,
ESpm = 14,
ESdcs = 15,
};
struct interval {
uint32_t first;
uint32_t last;
};
struct vc_draw_region {
long unsigned int from;
long unsigned int to;
int x;
};
struct klist_node;
struct klist {
spinlock_t k_lock;
struct list_head k_list;
void (*get)(struct klist_node *);
void (*put)(struct klist_node *);
};
struct klist_node {
void *n_klist;
struct list_head n_node;
struct kref n_ref;
};
struct subsys_private {
struct kset subsys;
struct kset *devices_kset;
struct list_head interfaces;
struct mutex mutex;
struct kset *drivers_kset;
struct klist klist_devices;
struct klist klist_drivers;
struct blocking_notifier_head bus_notifier;
unsigned int drivers_autoprobe: 1;
struct bus_type *bus;
struct kset glue_dirs;
struct class *class;
};
struct driver_private {
struct kobject kobj;
struct klist klist_devices;
struct klist_node knode_bus;
struct module_kobject *mkobj;
struct device_driver *driver;
};
struct device_private {
struct klist klist_children;
struct klist_node knode_parent;
struct klist_node knode_driver;
struct klist_node knode_bus;
struct klist_node knode_class;
struct list_head deferred_probe;
struct device_driver *async_driver;
char *deferred_probe_reason;
struct device *device;
u8 dead: 1;
};
enum kernel_read_file_id {
READING_UNKNOWN = 0,
READING_FIRMWARE = 1,
READING_MODULE = 2,
READING_KEXEC_IMAGE = 3,
READING_KEXEC_INITRAMFS = 4,
READING_POLICY = 5,
READING_X509_CERTIFICATE = 6,
READING_MAX_ID = 7,
};
struct firmware {
size_t size;
const u8 *data;
void *priv;
};
typedef void * (*ZSTD_allocFunction)(void *, size_t);
typedef void (*ZSTD_freeFunction)(void *, void *);
typedef struct {
ZSTD_allocFunction customAlloc;
ZSTD_freeFunction customFree;
void *opaque;
} ZSTD_customMem;
enum fw_opt {
FW_OPT_UEVENT = 1,
FW_OPT_NOWAIT = 2,
FW_OPT_USERHELPER = 4,
FW_OPT_NO_WARN = 8,
FW_OPT_NOCACHE = 16,
FW_OPT_NOFALLBACK_SYSFS = 32,
FW_OPT_FALLBACK_PLATFORM = 64,
FW_OPT_PARTIAL = 128,
};
enum fw_status {
FW_STATUS_UNKNOWN = 0,
FW_STATUS_LOADING = 1,
FW_STATUS_DONE = 2,
FW_STATUS_ABORTED = 3,
};
struct fw_state {
struct completion completion;
enum fw_status status;
};
struct firmware_cache;
struct fw_priv {
struct kref ref;
struct list_head list;
struct firmware_cache *fwc;
struct fw_state fw_st;
void *data;
size_t size;
size_t allocated_size;
size_t offset;
u32 opt_flags;
const char *fw_name;
};
struct firmware_cache {
spinlock_t lock;
struct list_head head;
int state;
};
struct firmware_work {
struct work_struct work;
struct module *module;
const char *name;
struct device *device;
void *context;
void (*cont)(const struct firmware *, void *);
u32 opt_flags;
};
struct scsi_lun {
__u8 scsi_lun[8];
};
struct scsi_sense_hdr {
u8 response_code;
u8 sense_key;
u8 asc;
u8 ascq;
u8 byte4;
u8 byte5;
u8 byte6;
u8 additional_length;
};
struct mtd_concat {
struct mtd_info mtd;
int num_subdev;
struct mtd_info **subdev;
};
typedef union {
long unsigned int x[1];
} map_word;
typedef enum {
FL_READY = 0,
FL_STATUS = 1,
FL_CFI_QUERY = 2,
FL_JEDEC_QUERY = 3,
FL_ERASING = 4,
FL_ERASE_SUSPENDING = 5,
FL_ERASE_SUSPENDED = 6,
FL_WRITING = 7,
FL_WRITING_TO_BUFFER = 8,
FL_OTP_WRITE = 9,
FL_WRITE_SUSPENDING = 10,
FL_WRITE_SUSPENDED = 11,
FL_PM_SUSPENDED = 12,
FL_SYNCING = 13,
FL_UNLOADING = 14,
FL_LOCKING = 15,
FL_UNLOCKING = 16,
FL_POINT = 17,
FL_XIP_WHILE_ERASING = 18,
FL_XIP_WHILE_WRITING = 19,
FL_SHUTDOWN = 20,
FL_READING = 21,
FL_CACHEDPRG = 22,
FL_RESETTING = 23,
FL_OTPING = 24,
FL_PREPARING_ERASE = 25,
FL_VERIFYING_ERASE = 26,
FL_UNKNOWN = 27,
} flstate_t;
struct flchip {
long unsigned int start;
int ref_point_counter;
flstate_t state;
flstate_t oldstate;
unsigned int write_suspended: 1;
unsigned int erase_suspended: 1;
long unsigned int in_progress_block_addr;
long unsigned int in_progress_block_mask;
struct mutex mutex;
wait_queue_head_t wq;
int word_write_time;
int buffer_write_time;
int erase_time;
int word_write_time_max;
int buffer_write_time_max;
int erase_time_max;
void *priv;
};
struct flchip_shared {
struct mutex lock;
struct flchip *writing;
struct flchip *erasing;
};
struct cfi_ident {
uint8_t qry[3];
uint16_t P_ID;
uint16_t P_ADR;
uint16_t A_ID;
uint16_t A_ADR;
uint8_t VccMin;
uint8_t VccMax;
uint8_t VppMin;
uint8_t VppMax;
uint8_t WordWriteTimeoutTyp;
uint8_t BufWriteTimeoutTyp;
uint8_t BlockEraseTimeoutTyp;
uint8_t ChipEraseTimeoutTyp;
uint8_t WordWriteTimeoutMax;
uint8_t BufWriteTimeoutMax;
uint8_t BlockEraseTimeoutMax;
uint8_t ChipEraseTimeoutMax;
uint8_t DevSize;
uint16_t InterfaceDesc;
uint16_t MaxBufWriteSize;
uint8_t NumEraseRegions;
uint32_t EraseRegionInfo[0];
} __attribute__((packed));
struct cfi_extquery {
uint8_t pri[3];
uint8_t MajorVersion;
uint8_t MinorVersion;
};
struct cfi_pri_intelext {
uint8_t pri[3];
uint8_t MajorVersion;
uint8_t MinorVersion;
uint32_t FeatureSupport;
uint8_t SuspendCmdSupport;
uint16_t BlkStatusRegMask;
uint8_t VccOptimal;
uint8_t VppOptimal;
uint8_t NumProtectionFields;
uint16_t ProtRegAddr;
uint8_t FactProtRegSize;
uint8_t UserProtRegSize;
uint8_t extra[0];
} __attribute__((packed));
struct cfi_intelext_blockinfo {
uint16_t NumIdentBlocks;
uint16_t BlockSize;
uint16_t MinBlockEraseCycles;
uint8_t BitsPerCell;
uint8_t BlockCap;
};
struct cfi_intelext_regioninfo {
uint16_t NumIdentPartitions;
uint8_t NumOpAllowed;
uint8_t NumOpAllowedSimProgMode;
uint8_t NumOpAllowedSimEraMode;
uint8_t NumBlockTypes;
struct cfi_intelext_blockinfo BlockTypes[1];
};
struct cfi_intelext_programming_regioninfo {
uint8_t ProgRegShift;
uint8_t Reserved1;
uint8_t ControlValid;
uint8_t Reserved2;
uint8_t ControlInvalid;
uint8_t Reserved3;
};
struct cfi_pri_atmel {
uint8_t pri[3];
uint8_t MajorVersion;
uint8_t MinorVersion;
uint8_t Features;
uint8_t BottomBoot;
uint8_t BurstMode;
uint8_t PageMode;
};
struct cfi_private {
uint16_t cmdset;
void *cmdset_priv;
int interleave;
int device_type;
int cfi_mode;
int addr_unlock1;
int addr_unlock2;
struct mtd_info * (*cmdset_setup)(struct map_info *);
struct cfi_ident *cfiq;
int mfr;
int id;
int numchips;
map_word sector_erase_cmd;
long unsigned int chipshift;
const char *im_name;
long unsigned int quirks;
struct flchip chips[0];
};
struct cfi_fixup {
uint16_t mfr;
uint16_t id;
void (*fixup)(struct mtd_info *);
};
typedef int (*varsize_frob_t)(struct map_info *, struct flchip *, long unsigned int, int, void *);
enum fwh_lock_state {
FWH_UNLOCKED = 0,
FWH_DENY_WRITE = 1,
FWH_IMMUTABLE = 2,
FWH_DENY_READ = 4,
};
struct fwh_xxlock_thunk {
enum fwh_lock_state val;
flstate_t state;
};
enum ixgbe_atr_flow_type {
IXGBE_ATR_FLOW_TYPE_IPV4 = 0,
IXGBE_ATR_FLOW_TYPE_UDPV4 = 1,
IXGBE_ATR_FLOW_TYPE_TCPV4 = 2,
IXGBE_ATR_FLOW_TYPE_SCTPV4 = 3,
IXGBE_ATR_FLOW_TYPE_IPV6 = 4,
IXGBE_ATR_FLOW_TYPE_UDPV6 = 5,
IXGBE_ATR_FLOW_TYPE_TCPV6 = 6,
IXGBE_ATR_FLOW_TYPE_SCTPV6 = 7,
};
union ixgbe_atr_hash_dword {
struct {
u8 vm_pool;
u8 flow_type;
__be16 vlan_id;
} formatted;
__be32 ip;
struct {
__be16 src;
__be16 dst;
} port;
__be16 flex_bytes;
__be32 dword;
};
enum ixgbe_mvals {
IXGBE_EEC_IDX = 0,
IXGBE_FLA_IDX = 1,
IXGBE_GRC_IDX = 2,
IXGBE_FACTPS_IDX = 3,
IXGBE_SWSM_IDX = 4,
IXGBE_SWFW_SYNC_IDX = 5,
IXGBE_FWSM_IDX = 6,
IXGBE_SDP0_GPIEN_IDX = 7,
IXGBE_SDP1_GPIEN_IDX = 8,
IXGBE_SDP2_GPIEN_IDX = 9,
IXGBE_EICR_GPI_SDP0_IDX = 10,
IXGBE_EICR_GPI_SDP1_IDX = 11,
IXGBE_EICR_GPI_SDP2_IDX = 12,
IXGBE_CIAA_IDX = 13,
IXGBE_CIAD_IDX = 14,
IXGBE_I2C_CLK_IN_IDX = 15,
IXGBE_I2C_CLK_OUT_IDX = 16,
IXGBE_I2C_DATA_IN_IDX = 17,
IXGBE_I2C_DATA_OUT_IDX = 18,
IXGBE_I2C_DATA_OE_N_EN_IDX = 19,
IXGBE_I2C_BB_EN_IDX = 20,
IXGBE_I2C_CLK_OE_N_EN_IDX = 21,
IXGBE_I2CCTL_IDX = 22,
IXGBE_MVALS_IDX_LIMIT = 23,
};
struct ixgbe_info {
enum ixgbe_mac_type mac;
s32 (*get_invariants)(struct ixgbe_hw *);
const struct ixgbe_mac_operations *mac_ops;
const struct ixgbe_eeprom_operations *eeprom_ops;
const struct ixgbe_phy_operations *phy_ops;
const struct ixgbe_mbx_operations *mbx_ops;
const struct ixgbe_link_operations *link_ops;
const u32 *mvals;
};
struct rtc_time {
int tm_sec;
int tm_min;
int tm_hour;
int tm_mday;
int tm_mon;
int tm_year;
int tm_wday;
int tm_yday;
int tm_isdst;
};
typedef __u64 timeu64_t;
typedef int (*nvmem_reg_read_t)(void *, unsigned int, void *, size_t);
typedef int (*nvmem_reg_write_t)(void *, unsigned int, void *, size_t);
typedef int (*nvmem_cell_post_process_t)(void *, const char *, unsigned int, void *, size_t);
enum nvmem_type {
NVMEM_TYPE_UNKNOWN = 0,
NVMEM_TYPE_EEPROM = 1,
NVMEM_TYPE_OTP = 2,
NVMEM_TYPE_BATTERY_BACKED = 3,
NVMEM_TYPE_FRAM = 4,
};
struct nvmem_keepout {
unsigned int start;
unsigned int end;
unsigned char value;
};
struct nvmem_cell_info;
struct nvmem_config {
struct device *dev;
const char *name;
int id;
struct module *owner;
struct gpio_desc *wp_gpio;
const struct nvmem_cell_info *cells;
int ncells;
const struct nvmem_keepout *keepout;
unsigned int nkeepout;
enum nvmem_type type;
bool read_only;
bool root_only;
bool ignore_wp;
struct device_node *of_node;
bool no_of_node;
nvmem_reg_read_t reg_read;
nvmem_reg_write_t reg_write;
nvmem_cell_post_process_t cell_post_process;
int size;
int word_size;
int stride;
void *priv;
bool compat;
struct device *base_dev;
};
struct nvmem_cell_info {
const char *name;
unsigned int offset;
unsigned int bytes;
unsigned int bit_offset;
unsigned int nbits;
struct device_node *np;
};
struct rtc_wkalrm {
unsigned char enabled;
unsigned char pending;
struct rtc_time time;
};
struct rtc_param {
__u64 param;
union {
__u64 uvalue;
__s64 svalue;
__u64 ptr;
};
__u32 index;
__u32 __pad;
};
struct rtc_class_ops {
int (*ioctl)(struct device *, unsigned int, long unsigned int);
int (*read_time)(struct device *, struct rtc_time *);
int (*set_time)(struct device *, struct rtc_time *);
int (*read_alarm)(struct device *, struct rtc_wkalrm *);
int (*set_alarm)(struct device *, struct rtc_wkalrm *);
int (*proc)(struct device *, struct seq_file *);
int (*alarm_irq_enable)(struct device *, unsigned int);
int (*read_offset)(struct device *, long int *);
int (*set_offset)(struct device *, long int);
int (*param_get)(struct device *, struct rtc_param *);
int (*param_set)(struct device *, struct rtc_param *);
};
struct rtc_device;
struct rtc_timer {
struct timerqueue_node node;
ktime_t period;
void (*func)(struct rtc_device *);
struct rtc_device *rtc;
int enabled;
long: 32;
};
struct rtc_device {
struct device dev;
struct module *owner;
int id;
const struct rtc_class_ops *ops;
struct mutex ops_lock;
struct cdev char_dev;
long unsigned int flags;
long unsigned int irq_data;
spinlock_t irq_lock;
wait_queue_head_t irq_queue;
struct fasync_struct *async_queue;
int irq_freq;
int max_user_freq;
struct timerqueue_head timerqueue;
long: 32;
struct rtc_timer aie_timer;
struct rtc_timer uie_rtctimer;
struct hrtimer pie_timer;
int pie_enabled;
struct work_struct irqwork;
long unsigned int set_offset_nsec;
long unsigned int features[1];
long: 32;
time64_t range_min;
timeu64_t range_max;
time64_t start_secs;
time64_t offset_secs;
bool set_start_time;
long: 32;
};
struct cmos_rtc_board_info {
void (*wake_on)(struct device *);
void (*wake_off)(struct device *);
u32 flags;
int address_space;
u8 rtc_day_alarm;
u8 rtc_mon_alarm;
u8 rtc_century;
};
struct cmos_rtc {
struct rtc_device *rtc;
struct device *dev;
int irq;
struct resource *iomem;
time64_t alarm_expires;
void (*wake_on)(struct device *);
void (*wake_off)(struct device *);
u8 enabled_wake;
u8 suspend_ctrl;
u8 day_alrm;
u8 mon_alrm;
u8 century;
struct rtc_wkalrm saved_wkalrm;
};
struct cmos_read_alarm_callback_param {
struct cmos_rtc *cmos;
struct rtc_time *time;
unsigned char rtc_control;
};
struct cmos_set_alarm_callback_param {
struct cmos_rtc *cmos;
unsigned char mon;
unsigned char mday;
unsigned char hrs;
unsigned char min;
unsigned char sec;
struct rtc_wkalrm *t;
};
struct hd_geometry {
unsigned char heads;
unsigned char sectors;
short unsigned int cylinders;
long unsigned int start;
};
enum blk_crypto_mode_num {
BLK_ENCRYPTION_MODE_INVALID = 0,
BLK_ENCRYPTION_MODE_AES_256_XTS = 1,
BLK_ENCRYPTION_MODE_AES_128_CBC_ESSIV = 2,
BLK_ENCRYPTION_MODE_ADIANTUM = 3,
BLK_ENCRYPTION_MODE_MAX = 4,
};
struct dm_kobject_holder {
struct kobject kobj;
struct completion completion;
};
typedef u16 u_int16_t;
typedef u32 u_int32_t;
typedef u64 u_int64_t;
enum flow_dissect_ret {
FLOW_DISSECT_RET_OUT_GOOD = 0,
FLOW_DISSECT_RET_OUT_BAD = 1,
FLOW_DISSECT_RET_PROTO_AGAIN = 2,
FLOW_DISSECT_RET_IPPROTO_AGAIN = 3,
FLOW_DISSECT_RET_CONTINUE = 4,
};
struct flow_dissector_mpls_lse {
u32 mpls_ttl: 8;
u32 mpls_bos: 1;
u32 mpls_tc: 3;
u32 mpls_label: 20;
};
struct flow_dissector_key_mpls {
struct flow_dissector_mpls_lse ls[7];
u8 used_lses;
};
struct flow_dissector_key_enc_opts {
u8 data[255];
u8 len;
__be16 dst_opt_type;
};
struct flow_dissector_key_arp {
__u32 sip;
__u32 tip;
__u8 op;
unsigned char sha[6];
unsigned char tha[6];
};
struct flow_dissector_key_eth_addrs {
unsigned char dst[6];
unsigned char src[6];
};
struct flow_dissector_key_tcp {
__be16 flags;
};
struct flow_dissector_key_ip {
__u8 tos;
__u8 ttl;
};
struct flow_dissector_key_meta {
int ingress_ifindex;
u16 ingress_iftype;
};
struct flow_dissector_key_ct {
u16 ct_state;
u16 ct_zone;
u32 ct_mark;
u32 ct_labels[4];
};
struct flow_dissector_key_hash {
u32 hash;
};
struct flow_dissector_key_num_of_vlans {
u8 num_of_vlans;
};
struct flow_dissector_key_pppoe {
__be16 session_id;
__be16 ppp_proto;
__be16 type;
};
struct flow_dissector_key_l2tpv3 {
__be32 session_id;
};
struct flow_dissector_key {
enum flow_dissector_key_id key_id;
size_t offset;
};
struct flow_keys_basic {
struct flow_dissector_key_control control;
struct flow_dissector_key_basic basic;
};
struct flow_keys_digest {
u8 data[16];
};
struct bpf_flow_keys;
struct bpf_flow_dissector {
struct bpf_flow_keys *flow_keys;
const struct sk_buff *skb;
const void *data;
const void *data_end;
};
struct bpf_flow_keys {
__u16 nhoff;
__u16 thoff;
__u16 addr_proto;
__u8 is_frag;
__u8 is_first_frag;
__u8 is_encap;
__u8 ip_proto;
__be16 n_proto;
__be16 sport;
__be16 dport;
union {
struct {
__be32 ipv4_src;
__be32 ipv4_dst;
};
struct {
__u32 ipv6_src[4];
__u32 ipv6_dst[4];
};
};
__u32 flags;
__be32 flow_label;
};
enum ip_conntrack_info {
IP_CT_ESTABLISHED = 0,
IP_CT_RELATED = 1,
IP_CT_NEW = 2,
IP_CT_IS_REPLY = 3,
IP_CT_ESTABLISHED_REPLY = 3,
IP_CT_RELATED_REPLY = 4,
IP_CT_NUMBER = 5,
IP_CT_UNTRACKED = 7,
};
struct nf_conntrack {
refcount_t use;
};
union nf_inet_addr {
__u32 all[4];
__be32 ip;
__be32 ip6[4];
struct in_addr in;
struct in6_addr in6;
};
struct ip_ct_tcp_state {
u_int32_t td_end;
u_int32_t td_maxend;
u_int32_t td_maxwin;
u_int32_t td_maxack;
u_int8_t td_scale;
u_int8_t flags;
};
struct ip_ct_tcp {
struct ip_ct_tcp_state seen[2];
u_int8_t state;
u_int8_t last_dir;
u_int8_t retrans;
u_int8_t last_index;
u_int32_t last_seq;
u_int32_t last_ack;
u_int32_t last_end;
u_int16_t last_win;
u_int8_t last_wscale;
u_int8_t last_flags;
};
union nf_conntrack_man_proto {
__be16 all;
struct {
__be16 port;
} tcp;
struct {
__be16 port;
} udp;
struct {
__be16 id;
} icmp;
struct {
__be16 port;
} dccp;
struct {
__be16 port;
} sctp;
struct {
__be16 key;
} gre;
};
struct nf_ct_dccp {
u_int8_t role[2];
u_int8_t state;
u_int8_t last_pkt;
u_int8_t last_dir;
u_int64_t handshake_seq;
};
struct ip_ct_sctp {
enum sctp_conntrack state;
__be32 vtag[2];
u8 last_dir;
u8 flags;
};
struct nf_ct_event;
struct nf_exp_event;
struct nf_ct_event_notifier {
int (*ct_event)(unsigned int, const struct nf_ct_event *);
int (*exp_event)(unsigned int, const struct nf_exp_event *);
};
enum {
TCA_FLOWER_KEY_CT_FLAGS_NEW = 1,
TCA_FLOWER_KEY_CT_FLAGS_ESTABLISHED = 2,
TCA_FLOWER_KEY_CT_FLAGS_RELATED = 4,
TCA_FLOWER_KEY_CT_FLAGS_TRACKED = 8,
TCA_FLOWER_KEY_CT_FLAGS_INVALID = 16,
TCA_FLOWER_KEY_CT_FLAGS_REPLY = 32,
__TCA_FLOWER_KEY_CT_FLAGS_MAX = 33,
};
struct devlink;
enum devlink_port_type {
DEVLINK_PORT_TYPE_NOTSET = 0,
DEVLINK_PORT_TYPE_AUTO = 1,
DEVLINK_PORT_TYPE_ETH = 2,
DEVLINK_PORT_TYPE_IB = 3,
};
enum devlink_port_flavour {
DEVLINK_PORT_FLAVOUR_PHYSICAL = 0,
DEVLINK_PORT_FLAVOUR_CPU = 1,
DEVLINK_PORT_FLAVOUR_DSA = 2,
DEVLINK_PORT_FLAVOUR_PCI_PF = 3,
DEVLINK_PORT_FLAVOUR_PCI_VF = 4,
DEVLINK_PORT_FLAVOUR_VIRTUAL = 5,
DEVLINK_PORT_FLAVOUR_UNUSED = 6,
DEVLINK_PORT_FLAVOUR_PCI_SF = 7,
};
struct devlink_port_phys_attrs {
u32 port_number;
u32 split_subport_number;
};
struct devlink_port_pci_pf_attrs {
u32 controller;
u16 pf;
u8 external: 1;
};
struct devlink_port_pci_vf_attrs {
u32 controller;
u16 pf;
u16 vf;
u8 external: 1;
};
struct devlink_port_pci_sf_attrs {
u32 controller;
u32 sf;
u16 pf;
u8 external: 1;
};
struct devlink_port_attrs {
u8 split: 1;
u8 splittable: 1;
u32 lanes;
enum devlink_port_flavour flavour;
struct netdev_phys_item_id switch_id;
union {
struct devlink_port_phys_attrs phys;
struct devlink_port_pci_pf_attrs pci_pf;
struct devlink_port_pci_vf_attrs pci_vf;
struct devlink_port_pci_sf_attrs pci_sf;
};
};
struct devlink_linecard;
struct devlink_rate;
struct devlink_port {
struct list_head list;
struct list_head region_list;
struct devlink *devlink;
unsigned int index;
spinlock_t type_lock;
enum devlink_port_type type;
enum devlink_port_type desired_type;
void *type_dev;
struct devlink_port_attrs attrs;
u8 attrs_set: 1;
u8 switch_port: 1;
u8 registered: 1;
u8 initialized: 1;
struct delayed_work type_warn_dw;
struct list_head reporter_list;
struct mutex reporters_lock;
struct devlink_rate *devlink_rate;
struct devlink_linecard *linecard;
};
enum {
TCPF_ESTABLISHED = 2,
TCPF_SYN_SENT = 4,
TCPF_SYN_RECV = 8,
TCPF_FIN_WAIT1 = 16,
TCPF_FIN_WAIT2 = 32,
TCPF_TIME_WAIT = 64,
TCPF_CLOSE = 128,
TCPF_CLOSE_WAIT = 256,
TCPF_LAST_ACK = 512,
TCPF_LISTEN = 1024,
TCPF_CLOSING = 2048,
TCPF_NEW_SYN_RECV = 4096,
};
union tcp_word_hdr {
struct tcphdr hdr;
__be32 words[5];
};
struct vlan_hdr {
__be16 h_vlan_TCI;
__be16 h_vlan_encapsulated_proto;
};
enum bpf_ret_code {
BPF_OK = 0,
BPF_DROP = 2,
BPF_REDIRECT = 7,
BPF_LWT_REROUTE = 128,
BPF_FLOW_DISSECTOR_CONTINUE = 129,
};
enum {
BPF_FLOW_DISSECTOR_F_PARSE_1ST_FRAG = 1,
BPF_FLOW_DISSECTOR_F_STOP_AT_FLOW_LABEL = 2,
BPF_FLOW_DISSECTOR_F_STOP_AT_ENCAP = 4,
};
enum devlink_rate_type {
DEVLINK_RATE_TYPE_LEAF = 0,
DEVLINK_RATE_TYPE_NODE = 1,
};
struct devlink_rate {
struct list_head list;
enum devlink_rate_type type;
struct devlink *devlink;
void *priv;
long: 32;
u64 tx_share;
u64 tx_max;
struct devlink_rate *parent;
union {
struct devlink_port *devlink_port;
struct {
char *name;
refcount_t refcnt;
};
};
long: 32;
};
struct frag_hdr {
__u8 nexthdr;
__u8 reserved;
__be16 frag_off;
__be32 identification;
};
struct arphdr {
__be16 ar_hrd;
__be16 ar_pro;
unsigned char ar_hln;
unsigned char ar_pln;
__be16 ar_op;
};
struct gre_base_hdr {
__be16 flags;
__be16 protocol;
};
struct gre_full_hdr {
struct gre_base_hdr fixed_header;
__be16 csum;
__be16 reserved1;
__be32 key;
__be32 seq;
};
struct pptp_gre_header {
struct gre_base_hdr gre_hd;
__be16 payload_len;
__be16 call_id;
__be32 seq;
__be32 ack;
};
struct tipc_basic_hdr {
__be32 w[4];
};
enum sctp_msg_flags {
MSG_NOTIFICATION = 32768,
};
enum dccp_state {
DCCP_OPEN = 1,
DCCP_REQUESTING = 2,
DCCP_LISTEN = 10,
DCCP_RESPOND = 3,
DCCP_ACTIVE_CLOSEREQ = 4,
DCCP_PASSIVE_CLOSE = 8,
DCCP_CLOSING = 11,
DCCP_TIME_WAIT = 6,
DCCP_CLOSED = 7,
DCCP_NEW_SYN_RECV = 12,
DCCP_PARTOPEN = 13,
DCCP_PASSIVE_CLOSEREQ = 14,
DCCP_MAX_STATES = 15,
};
enum l2tp_debug_flags {
L2TP_MSG_DEBUG = 1,
L2TP_MSG_CONTROL = 2,
L2TP_MSG_SEQ = 4,
L2TP_MSG_DATA = 8,
};
struct pppoe_tag {
__be16 tag_type;
__be16 tag_len;
char tag_data[0];
};
struct pppoe_hdr {
__u8 type: 4;
__u8 ver: 4;
__u8 code;
__be16 sid;
__be16 length;
struct pppoe_tag tag[0];
};
struct hsr_tag {
__be16 path_and_LSDU_size;
__be16 sequence_nr;
__be16 encap_proto;
};
struct mpls_label {
__be32 entry;
};
struct clock_identity {
u8 id[8];
};
struct port_identity {
struct clock_identity clock_identity;
__be16 port_number;
};
struct ptp_header {
u8 tsmt;
u8 ver;
__be16 message_length;
u8 domain_number;
u8 reserved1;
u8 flag_field[2];
__be64 correction;
__be32 reserved2;
struct port_identity source_port_identity;
__be16 sequence_id;
u8 control;
u8 log_message_interval;
} __attribute__((packed));
enum batadv_packettype {
BATADV_IV_OGM = 0,
BATADV_BCAST = 1,
BATADV_CODED = 2,
BATADV_ELP = 3,
BATADV_OGM2 = 4,
BATADV_UNICAST = 64,
BATADV_UNICAST_FRAG = 65,
BATADV_UNICAST_4ADDR = 66,
BATADV_ICMP = 67,
BATADV_UNICAST_TVLV = 68,
};
struct batadv_unicast_packet {
__u8 packet_type;
__u8 version;
__u8 ttl;
__u8 ttvn;
__u8 dest[6];
};
struct nf_conntrack_man {
union nf_inet_addr u3;
union nf_conntrack_man_proto u;
u_int16_t l3num;
};
struct nf_conntrack_tuple {
struct nf_conntrack_man src;
struct {
union nf_inet_addr u3;
union {
__be16 all;
struct {
__be16 port;
} tcp;
struct {
__be16 port;
} udp;
struct {
u_int8_t type;
u_int8_t code;
} icmp;
struct {
__be16 port;
} dccp;
struct {
__be16 port;
} sctp;
struct {
__be16 key;
} gre;
} u;
u_int8_t protonum;
u_int8_t dir;
} dst;
};
struct nf_conntrack_tuple_hash {
struct hlist_nulls_node hnnode;
struct nf_conntrack_tuple tuple;
};
struct nf_ct_udp {
long unsigned int stream_ts;
};
struct nf_ct_gre {
unsigned int stream_timeout;
unsigned int timeout;
};
union nf_conntrack_proto {
struct nf_ct_dccp dccp;
struct ip_ct_sctp sctp;
struct ip_ct_tcp tcp;
struct nf_ct_udp udp;
struct nf_ct_gre gre;
unsigned int tmpl_padto;
};
struct nf_ct_ext;
struct nf_conn {
struct nf_conntrack ct_general;
spinlock_t lock;
u32 timeout;
struct nf_conntrack_tuple_hash tuplehash[2];
long unsigned int status;
possible_net_t ct_net;
struct {} __nfct_init_offset;
struct nf_conn *master;
u_int32_t mark;
u_int32_t secmark;
struct nf_ct_ext *ext;
long: 32;
union nf_conntrack_proto proto;
};
struct nf_conntrack_tuple_mask {
struct {
union nf_inet_addr u3;
union nf_conntrack_man_proto u;
} src;
};
struct nf_ct_ext {
u8 offset[4];
u8 len;
unsigned int gen_id;
long: 32;
char data[0];
};
struct nf_conntrack_helper;
struct nf_conntrack_expect {
struct hlist_node lnode;
struct hlist_node hnode;
struct nf_conntrack_tuple tuple;
struct nf_conntrack_tuple_mask mask;
void (*expectfn)(struct nf_conn *, struct nf_conntrack_expect *);
struct nf_conntrack_helper *helper;
struct nf_conn *master;
struct timer_list timeout;
refcount_t use;
unsigned int flags;
unsigned int class;
struct callback_head rcu;
};
enum nf_ct_ext_id {
NF_CT_EXT_HELPER = 0,
NF_CT_EXT_SEQADJ = 1,
NF_CT_EXT_ACCT = 2,
NF_CT_EXT_ECACHE = 3,
NF_CT_EXT_NUM = 4,
};
struct nf_ct_event {
struct nf_conn *ct;
u32 portid;
int report;
};
struct nf_exp_event {
struct nf_conntrack_expect *exp;
u32 portid;
int report;
};
struct nf_conn_labels {
long unsigned int bits[4];
};
struct _flow_keys_digest_data {
__be16 n_proto;
u8 ip_proto;
u8 padding;
__be32 ports;
__be32 src;
__be32 dst;
};
struct tc_prio_qopt {
int bands;
__u8 priomap[16];
};
enum netdev_state_t {
__LINK_STATE_START = 0,
__LINK_STATE_PRESENT = 1,
__LINK_STATE_NOCARRIER = 2,
__LINK_STATE_LINKWATCH_PENDING = 3,
__LINK_STATE_DORMANT = 4,
__LINK_STATE_TESTING = 5,
};
enum netdev_queue_state_t {
__QUEUE_STATE_DRV_XOFF = 0,
__QUEUE_STATE_STACK_XOFF = 1,
__QUEUE_STATE_FROZEN = 2,
};
struct skb_array {
struct ptr_ring ring;
};
enum qdisc_state2_t {
__QDISC_STATE2_RUNNING = 0,
};
struct psched_ratecfg {
u64 rate_bytes_ps;
u32 mult;
u16 overhead;
u16 mpu;
u8 linklayer;
u8 shift;
long: 32;
};
struct psched_pktrate {
u64 rate_pkts_ps;
u32 mult;
u8 shift;
};
struct mini_Qdisc_pair {
struct mini_Qdisc miniq1;
struct mini_Qdisc miniq2;
struct mini_Qdisc **p_miniq;
};
struct xfrm_offload {
struct {
__u32 low;
__u32 hi;
} seq;
__u32 flags;
__u32 status;
__u8 proto;
__u8 inner_ipproto;
};
struct sec_path {
int len;
int olen;
struct xfrm_state *xvec[6];
struct xfrm_offload ovec[1];
};
struct pfifo_fast_priv {
struct skb_array q[3];
};
struct ethtool_cmd {
__u32 cmd;
__u32 supported;
__u32 advertising;
__u16 speed;
__u8 duplex;
__u8 port;
__u8 phy_address;
__u8 transceiver;
__u8 autoneg;
__u8 mdio_support;
__u32 maxtxpkt;
__u32 maxrxpkt;
__u16 speed_hi;
__u8 eth_tp_mdix;
__u8 eth_tp_mdix_ctrl;
__u32 lp_advertising;
__u32 reserved[2];
};
struct ethtool_phy_ops {
int (*get_sset_count)(struct phy_device *);
int (*get_strings)(struct phy_device *, u8 *);
int (*get_stats)(struct phy_device *, struct ethtool_stats *, u64 *);
int (*start_cable_test)(struct phy_device *, struct netlink_ext_ack *);
int (*start_cable_test_tdr)(struct phy_device *, struct netlink_ext_ack *, const struct phy_tdr_config *);
};
enum {
ETHTOOL_UDP_TUNNEL_TYPE_VXLAN = 0,
ETHTOOL_UDP_TUNNEL_TYPE_GENEVE = 1,
ETHTOOL_UDP_TUNNEL_TYPE_VXLAN_GPE = 2,
__ETHTOOL_UDP_TUNNEL_TYPE_CNT = 3,
};
enum {
SOF_TIMESTAMPING_TX_HARDWARE = 1,
SOF_TIMESTAMPING_TX_SOFTWARE = 2,
SOF_TIMESTAMPING_RX_HARDWARE = 4,
SOF_TIMESTAMPING_RX_SOFTWARE = 8,
SOF_TIMESTAMPING_SOFTWARE = 16,
SOF_TIMESTAMPING_SYS_HARDWARE = 32,
SOF_TIMESTAMPING_RAW_HARDWARE = 64,
SOF_TIMESTAMPING_OPT_ID = 128,
SOF_TIMESTAMPING_TX_SCHED = 256,
SOF_TIMESTAMPING_TX_ACK = 512,
SOF_TIMESTAMPING_OPT_CMSG = 1024,
SOF_TIMESTAMPING_OPT_TSONLY = 2048,
SOF_TIMESTAMPING_OPT_STATS = 4096,
SOF_TIMESTAMPING_OPT_PKTINFO = 8192,
SOF_TIMESTAMPING_OPT_TX_SWHW = 16384,
SOF_TIMESTAMPING_BIND_PHC = 32768,
SOF_TIMESTAMPING_LAST = 32768,
SOF_TIMESTAMPING_MASK = 65535,
};
enum hwtstamp_tx_types {
HWTSTAMP_TX_OFF = 0,
HWTSTAMP_TX_ON = 1,
HWTSTAMP_TX_ONESTEP_SYNC = 2,
HWTSTAMP_TX_ONESTEP_P2P = 3,
__HWTSTAMP_TX_CNT = 4,
};
enum hwtstamp_rx_filters {
HWTSTAMP_FILTER_NONE = 0,
HWTSTAMP_FILTER_ALL = 1,
HWTSTAMP_FILTER_SOME = 2,
HWTSTAMP_FILTER_PTP_V1_L4_EVENT = 3,
HWTSTAMP_FILTER_PTP_V1_L4_SYNC = 4,
HWTSTAMP_FILTER_PTP_V1_L4_DELAY_REQ = 5,
HWTSTAMP_FILTER_PTP_V2_L4_EVENT = 6,
HWTSTAMP_FILTER_PTP_V2_L4_SYNC = 7,
HWTSTAMP_FILTER_PTP_V2_L4_DELAY_REQ = 8,
HWTSTAMP_FILTER_PTP_V2_L2_EVENT = 9,
HWTSTAMP_FILTER_PTP_V2_L2_SYNC = 10,
HWTSTAMP_FILTER_PTP_V2_L2_DELAY_REQ = 11,
HWTSTAMP_FILTER_PTP_V2_EVENT = 12,
HWTSTAMP_FILTER_PTP_V2_SYNC = 13,
HWTSTAMP_FILTER_PTP_V2_DELAY_REQ = 14,
HWTSTAMP_FILTER_NTP_ALL = 15,
__HWTSTAMP_FILTER_CNT = 16,
};
struct link_mode_info {
int speed;
u8 lanes;
u8 duplex;
};
struct features_reply_data {
struct ethnl_reply_data base;
u32 hw[2];
u32 wanted[2];
u32 active[2];
u32 nochange[2];
u32 all[2];
};
struct phc_vclocks_reply_data {
struct ethnl_reply_data base;
int num;
int *index;
};
struct fastopen_queue {
struct request_sock *rskq_rst_head;
struct request_sock *rskq_rst_tail;
spinlock_t lock;
int qlen;
int max_qlen;
struct tcp_fastopen_context *ctx;
};
struct request_sock_queue {
spinlock_t rskq_lock;
u8 rskq_defer_accept;
u32 synflood_warned;
atomic_t qlen;
atomic_t young;
struct request_sock *rskq_accept_head;
struct request_sock *rskq_accept_tail;
struct fastopen_queue fastopenq;
};
struct inet_connection_sock_af_ops {
int (*queue_xmit)(struct sock *, struct sk_buff *, struct flowi *);
void (*send_check)(struct sock *, struct sk_buff *);
int (*rebuild_header)(struct sock *);
void (*sk_rx_dst_set)(struct sock *, const struct sk_buff *);
int (*conn_request)(struct sock *, struct sk_buff *);
struct sock * (*syn_recv_sock)(const struct sock *, struct sk_buff *, struct request_sock *, struct dst_entry *, struct request_sock *, bool *);
u16 net_header_len;
u16 net_frag_header_len;
u16 sockaddr_len;
int (*setsockopt)(struct sock *, int, int, sockptr_t, unsigned int);
int (*getsockopt)(struct sock *, int, int, char *, int *);
void (*addr2sockaddr)(struct sock *, struct sockaddr *);
void (*mtu_reduced)(struct sock *);
};
struct inet_bind_bucket;
struct inet_bind2_bucket;
struct tcp_ulp_ops;
struct inet_connection_sock {
struct inet_sock icsk_inet;
struct request_sock_queue icsk_accept_queue;
struct inet_bind_bucket *icsk_bind_hash;
struct inet_bind2_bucket *icsk_bind2_hash;
long unsigned int icsk_timeout;
struct timer_list icsk_retransmit_timer;
struct timer_list icsk_delack_timer;
__u32 icsk_rto;
__u32 icsk_rto_min;
__u32 icsk_delack_max;
__u32 icsk_pmtu_cookie;
const struct tcp_congestion_ops *icsk_ca_ops;
const struct inet_connection_sock_af_ops *icsk_af_ops;
const struct tcp_ulp_ops *icsk_ulp_ops;
void *icsk_ulp_data;
void (*icsk_clean_acked)(struct sock *, u32);
unsigned int (*icsk_sync_mss)(struct sock *, u32);
__u8 icsk_ca_state: 5;
__u8 icsk_ca_initialized: 1;
__u8 icsk_ca_setsockopt: 1;
__u8 icsk_ca_dst_locked: 1;
__u8 icsk_retransmits;
__u8 icsk_pending;
__u8 icsk_backoff;
__u8 icsk_syn_retries;
__u8 icsk_probes_out;
__u16 icsk_ext_hdr_len;
struct {
__u8 pending;
__u8 quick;
__u8 pingpong;
__u8 retry;
__u32 ato;
long unsigned int timeout;
__u32 lrcvtime;
__u16 last_seg_size;
__u16 rcv_mss;
} icsk_ack;
struct {
int search_high;
int search_low;
u32 probe_size: 31;
u32 enabled: 1;
u32 probe_timestamp;
} icsk_mtup;
u32 icsk_probes_tstamp;
u32 icsk_user_timeout;
long: 32;
u64 icsk_ca_priv[13];
};
struct inet_bind_bucket {
possible_net_t ib_net;
int l3mdev;
short unsigned int port;
signed char fastreuse;
signed char fastreuseport;
kuid_t fastuid;
struct in6_addr fast_v6_rcv_saddr;
__be32 fast_rcv_saddr;
short unsigned int fast_sk_family;
bool fast_ipv6_only;
struct hlist_node node;
struct hlist_head owners;
};
struct inet_bind2_bucket {
possible_net_t ib_net;
int l3mdev;
short unsigned int port;
short unsigned int family;
union {
struct in6_addr v6_rcv_saddr;
__be32 rcv_saddr;
};
struct hlist_node node;
struct hlist_head owners;
};
struct tcp_ulp_ops {
struct list_head list;
int (*init)(struct sock *);
void (*update)(struct sock *, struct proto *, void (*)(struct sock *));
void (*release)(struct sock *);
int (*get_info)(const struct sock *, struct sk_buff *);
size_t (*get_info_size)(const struct sock *);
void (*clone)(const struct request_sock *, struct sock *, const gfp_t);
char name[16];
struct module *owner;
};
struct inet_timewait_sock {
struct sock_common __tw_common;
__u32 tw_mark;
volatile unsigned char tw_substate;
unsigned char tw_rcv_wscale;
__be16 tw_sport;
unsigned int tw_transparent: 1;
unsigned int tw_flowlabel: 20;
unsigned int tw_pad: 3;
unsigned int tw_tos: 8;
u32 tw_txhash;
u32 tw_priority;
struct timer_list tw_timer;
struct inet_bind_bucket *tw_tb;
long: 32;
};
enum {
BPF_REG_0 = 0,
BPF_REG_1 = 1,
BPF_REG_2 = 2,
BPF_REG_3 = 3,
BPF_REG_4 = 4,
BPF_REG_5 = 5,
BPF_REG_6 = 6,
BPF_REG_7 = 7,
BPF_REG_8 = 8,
BPF_REG_9 = 9,
BPF_REG_10 = 10,
__MAX_BPF_REG = 11,
};
enum bpf_func_id {
BPF_FUNC_unspec = 0,
BPF_FUNC_map_lookup_elem = 1,
BPF_FUNC_map_update_elem = 2,
BPF_FUNC_map_delete_elem = 3,
BPF_FUNC_probe_read = 4,
BPF_FUNC_ktime_get_ns = 5,
BPF_FUNC_trace_printk = 6,
BPF_FUNC_get_prandom_u32 = 7,
BPF_FUNC_get_smp_processor_id = 8,
BPF_FUNC_skb_store_bytes = 9,
BPF_FUNC_l3_csum_replace = 10,
BPF_FUNC_l4_csum_replace = 11,
BPF_FUNC_tail_call = 12,
BPF_FUNC_clone_redirect = 13,
BPF_FUNC_get_current_pid_tgid = 14,
BPF_FUNC_get_current_uid_gid = 15,
BPF_FUNC_get_current_comm = 16,
BPF_FUNC_get_cgroup_classid = 17,
BPF_FUNC_skb_vlan_push = 18,
BPF_FUNC_skb_vlan_pop = 19,
BPF_FUNC_skb_get_tunnel_key = 20,
BPF_FUNC_skb_set_tunnel_key = 21,
BPF_FUNC_perf_event_read = 22,
BPF_FUNC_redirect = 23,
BPF_FUNC_get_route_realm = 24,
BPF_FUNC_perf_event_output = 25,
BPF_FUNC_skb_load_bytes = 26,
BPF_FUNC_get_stackid = 27,
BPF_FUNC_csum_diff = 28,
BPF_FUNC_skb_get_tunnel_opt = 29,
BPF_FUNC_skb_set_tunnel_opt = 30,
BPF_FUNC_skb_change_proto = 31,
BPF_FUNC_skb_change_type = 32,
BPF_FUNC_skb_under_cgroup = 33,
BPF_FUNC_get_hash_recalc = 34,
BPF_FUNC_get_current_task = 35,
BPF_FUNC_probe_write_user = 36,
BPF_FUNC_current_task_under_cgroup = 37,
BPF_FUNC_skb_change_tail = 38,
BPF_FUNC_skb_pull_data = 39,
BPF_FUNC_csum_update = 40,
BPF_FUNC_set_hash_invalid = 41,
BPF_FUNC_get_numa_node_id = 42,
BPF_FUNC_skb_change_head = 43,
BPF_FUNC_xdp_adjust_head = 44,
BPF_FUNC_probe_read_str = 45,
BPF_FUNC_get_socket_cookie = 46,
BPF_FUNC_get_socket_uid = 47,
BPF_FUNC_set_hash = 48,
BPF_FUNC_setsockopt = 49,
BPF_FUNC_skb_adjust_room = 50,
BPF_FUNC_redirect_map = 51,
BPF_FUNC_sk_redirect_map = 52,
BPF_FUNC_sock_map_update = 53,
BPF_FUNC_xdp_adjust_meta = 54,
BPF_FUNC_perf_event_read_value = 55,
BPF_FUNC_perf_prog_read_value = 56,
BPF_FUNC_getsockopt = 57,
BPF_FUNC_override_return = 58,
BPF_FUNC_sock_ops_cb_flags_set = 59,
BPF_FUNC_msg_redirect_map = 60,
BPF_FUNC_msg_apply_bytes = 61,
BPF_FUNC_msg_cork_bytes = 62,
BPF_FUNC_msg_pull_data = 63,
BPF_FUNC_bind = 64,
BPF_FUNC_xdp_adjust_tail = 65,
BPF_FUNC_skb_get_xfrm_state = 66,
BPF_FUNC_get_stack = 67,
BPF_FUNC_skb_load_bytes_relative = 68,
BPF_FUNC_fib_lookup = 69,
BPF_FUNC_sock_hash_update = 70,
BPF_FUNC_msg_redirect_hash = 71,
BPF_FUNC_sk_redirect_hash = 72,
BPF_FUNC_lwt_push_encap = 73,
BPF_FUNC_lwt_seg6_store_bytes = 74,
BPF_FUNC_lwt_seg6_adjust_srh = 75,
BPF_FUNC_lwt_seg6_action = 76,
BPF_FUNC_rc_repeat = 77,
BPF_FUNC_rc_keydown = 78,
BPF_FUNC_skb_cgroup_id = 79,
BPF_FUNC_get_current_cgroup_id = 80,
BPF_FUNC_get_local_storage = 81,
BPF_FUNC_sk_select_reuseport = 82,
BPF_FUNC_skb_ancestor_cgroup_id = 83,
BPF_FUNC_sk_lookup_tcp = 84,
BPF_FUNC_sk_lookup_udp = 85,
BPF_FUNC_sk_release = 86,
BPF_FUNC_map_push_elem = 87,
BPF_FUNC_map_pop_elem = 88,
BPF_FUNC_map_peek_elem = 89,
BPF_FUNC_msg_push_data = 90,
BPF_FUNC_msg_pop_data = 91,
BPF_FUNC_rc_pointer_rel = 92,
BPF_FUNC_spin_lock = 93,
BPF_FUNC_spin_unlock = 94,
BPF_FUNC_sk_fullsock = 95,
BPF_FUNC_tcp_sock = 96,
BPF_FUNC_skb_ecn_set_ce = 97,
BPF_FUNC_get_listener_sock = 98,
BPF_FUNC_skc_lookup_tcp = 99,
BPF_FUNC_tcp_check_syncookie = 100,
BPF_FUNC_sysctl_get_name = 101,
BPF_FUNC_sysctl_get_current_value = 102,
BPF_FUNC_sysctl_get_new_value = 103,
BPF_FUNC_sysctl_set_new_value = 104,
BPF_FUNC_strtol = 105,
BPF_FUNC_strtoul = 106,
BPF_FUNC_sk_storage_get = 107,
BPF_FUNC_sk_storage_delete = 108,
BPF_FUNC_send_signal = 109,
BPF_FUNC_tcp_gen_syncookie = 110,
BPF_FUNC_skb_output = 111,
BPF_FUNC_probe_read_user = 112,
BPF_FUNC_probe_read_kernel = 113,
BPF_FUNC_probe_read_user_str = 114,
BPF_FUNC_probe_read_kernel_str = 115,
BPF_FUNC_tcp_send_ack = 116,
BPF_FUNC_send_signal_thread = 117,
BPF_FUNC_jiffies64 = 118,
BPF_FUNC_read_branch_records = 119,
BPF_FUNC_get_ns_current_pid_tgid = 120,
BPF_FUNC_xdp_output = 121,
BPF_FUNC_get_netns_cookie = 122,
BPF_FUNC_get_current_ancestor_cgroup_id = 123,
BPF_FUNC_sk_assign = 124,
BPF_FUNC_ktime_get_boot_ns = 125,
BPF_FUNC_seq_printf = 126,
BPF_FUNC_seq_write = 127,
BPF_FUNC_sk_cgroup_id = 128,
BPF_FUNC_sk_ancestor_cgroup_id = 129,
BPF_FUNC_ringbuf_output = 130,
BPF_FUNC_ringbuf_reserve = 131,
BPF_FUNC_ringbuf_submit = 132,
BPF_FUNC_ringbuf_discard = 133,
BPF_FUNC_ringbuf_query = 134,
BPF_FUNC_csum_level = 135,
BPF_FUNC_skc_to_tcp6_sock = 136,
BPF_FUNC_skc_to_tcp_sock = 137,
BPF_FUNC_skc_to_tcp_timewait_sock = 138,
BPF_FUNC_skc_to_tcp_request_sock = 139,
BPF_FUNC_skc_to_udp6_sock = 140,
BPF_FUNC_get_task_stack = 141,
BPF_FUNC_load_hdr_opt = 142,
BPF_FUNC_store_hdr_opt = 143,
BPF_FUNC_reserve_hdr_opt = 144,
BPF_FUNC_inode_storage_get = 145,
BPF_FUNC_inode_storage_delete = 146,
BPF_FUNC_d_path = 147,
BPF_FUNC_copy_from_user = 148,
BPF_FUNC_snprintf_btf = 149,
BPF_FUNC_seq_printf_btf = 150,
BPF_FUNC_skb_cgroup_classid = 151,
BPF_FUNC_redirect_neigh = 152,
BPF_FUNC_per_cpu_ptr = 153,
BPF_FUNC_this_cpu_ptr = 154,
BPF_FUNC_redirect_peer = 155,
BPF_FUNC_task_storage_get = 156,
BPF_FUNC_task_storage_delete = 157,
BPF_FUNC_get_current_task_btf = 158,
BPF_FUNC_bprm_opts_set = 159,
BPF_FUNC_ktime_get_coarse_ns = 160,
BPF_FUNC_ima_inode_hash = 161,
BPF_FUNC_sock_from_file = 162,
BPF_FUNC_check_mtu = 163,
BPF_FUNC_for_each_map_elem = 164,
BPF_FUNC_snprintf = 165,
BPF_FUNC_sys_bpf = 166,
BPF_FUNC_btf_find_by_name_kind = 167,
BPF_FUNC_sys_close = 168,
BPF_FUNC_timer_init = 169,
BPF_FUNC_timer_set_callback = 170,
BPF_FUNC_timer_start = 171,
BPF_FUNC_timer_cancel = 172,
BPF_FUNC_get_func_ip = 173,
BPF_FUNC_get_attach_cookie = 174,
BPF_FUNC_task_pt_regs = 175,
BPF_FUNC_get_branch_snapshot = 176,
BPF_FUNC_trace_vprintk = 177,
BPF_FUNC_skc_to_unix_sock = 178,
BPF_FUNC_kallsyms_lookup_name = 179,
BPF_FUNC_find_vma = 180,
BPF_FUNC_loop = 181,
BPF_FUNC_strncmp = 182,
BPF_FUNC_get_func_arg = 183,
BPF_FUNC_get_func_ret = 184,
BPF_FUNC_get_func_arg_cnt = 185,
BPF_FUNC_get_retval = 186,
BPF_FUNC_set_retval = 187,
BPF_FUNC_xdp_get_buff_len = 188,
BPF_FUNC_xdp_load_bytes = 189,
BPF_FUNC_xdp_store_bytes = 190,
BPF_FUNC_copy_from_user_task = 191,
BPF_FUNC_skb_set_tstamp = 192,
BPF_FUNC_ima_file_hash = 193,
BPF_FUNC_kptr_xchg = 194,
BPF_FUNC_map_lookup_percpu_elem = 195,
BPF_FUNC_skc_to_mptcp_sock = 196,
BPF_FUNC_dynptr_from_mem = 197,
BPF_FUNC_ringbuf_reserve_dynptr = 198,
BPF_FUNC_ringbuf_submit_dynptr = 199,
BPF_FUNC_ringbuf_discard_dynptr = 200,
BPF_FUNC_dynptr_read = 201,
BPF_FUNC_dynptr_write = 202,
BPF_FUNC_dynptr_data = 203,
BPF_FUNC_tcp_raw_gen_syncookie_ipv4 = 204,
BPF_FUNC_tcp_raw_gen_syncookie_ipv6 = 205,
BPF_FUNC_tcp_raw_check_syncookie_ipv4 = 206,
BPF_FUNC_tcp_raw_check_syncookie_ipv6 = 207,
BPF_FUNC_ktime_get_tai_ns = 208,
BPF_FUNC_user_ringbuf_drain = 209,
__BPF_FUNC_MAX_ID = 210,
};
struct bpf_local_storage_data;
struct bpf_local_storage {
struct bpf_local_storage_data *cache[16];
struct hlist_head list;
void *owner;
struct callback_head rcu;
raw_spinlock_t lock;
};
typedef sockptr_t bpfptr_t;
enum {
BTF_KIND_UNKN = 0,
BTF_KIND_INT = 1,
BTF_KIND_PTR = 2,
BTF_KIND_ARRAY = 3,
BTF_KIND_STRUCT = 4,
BTF_KIND_UNION = 5,
BTF_KIND_ENUM = 6,
BTF_KIND_FWD = 7,
BTF_KIND_TYPEDEF = 8,
BTF_KIND_VOLATILE = 9,
BTF_KIND_CONST = 10,
BTF_KIND_RESTRICT = 11,
BTF_KIND_FUNC = 12,
BTF_KIND_FUNC_PROTO = 13,
BTF_KIND_VAR = 14,
BTF_KIND_DATASEC = 15,
BTF_KIND_FLOAT = 16,
BTF_KIND_DECL_TAG = 17,
BTF_KIND_TYPE_TAG = 18,
BTF_KIND_ENUM64 = 19,
NR_BTF_KINDS = 20,
BTF_KIND_MAX = 19,
};
struct btf_member {
__u32 name_off;
__u32 type;
__u32 offset;
};
struct btf_id_set8;
struct btf_kfunc_id_set {
struct module *owner;
struct btf_id_set8 *set;
};
struct btf_id_set8 {
u32 cnt;
u32 flags;
struct {
u32 id;
u32 flags;
} pairs[0];
};
struct bpf_local_storage_map_bucket;
struct bpf_local_storage_map {
struct bpf_map map;
struct bpf_local_storage_map_bucket *buckets;
u32 bucket_log;
u16 elem_size;
u16 cache_idx;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_verifier_log {
u32 level;
char kbuf[1024];
char *ubuf;
u32 len_used;
u32 len_total;
};
struct bpf_subprog_info {
u32 start;
u32 linfo_idx;
u16 stack_depth;
bool has_tail_call;
bool tail_call_reachable;
bool has_ld_abs;
bool is_async_cb;
};
struct bpf_id_pair {
u32 old;
u32 cur;
};
struct bpf_verifier_ops;
struct bpf_verifier_stack_elem;
struct bpf_verifier_state;
struct bpf_verifier_state_list;
struct bpf_insn_aux_data;
struct bpf_verifier_env {
u32 insn_idx;
u32 prev_insn_idx;
struct bpf_prog *prog;
const struct bpf_verifier_ops *ops;
struct bpf_verifier_stack_elem *head;
int stack_size;
bool strict_alignment;
bool test_state_freq;
struct bpf_verifier_state *cur_state;
struct bpf_verifier_state_list **explored_states;
struct bpf_verifier_state_list *free_list;
struct bpf_map *used_maps[64];
struct btf_mod_pair used_btfs[64];
u32 used_map_cnt;
u32 used_btf_cnt;
u32 id_gen;
bool explore_alu_limits;
bool allow_ptr_leaks;
bool allow_uninit_stack;
bool allow_ptr_to_map_access;
bool bpf_capable;
bool bypass_spec_v1;
bool bypass_spec_v4;
bool seen_direct_write;
struct bpf_insn_aux_data *insn_aux_data;
const struct bpf_line_info *prev_linfo;
struct bpf_verifier_log log;
struct bpf_subprog_info subprog_info[257];
struct bpf_id_pair idmap_scratch[75];
struct {
int *insn_state;
int *insn_stack;
int cur_stack;
} cfg;
u32 pass_cnt;
u32 subprog_cnt;
u32 prev_insn_processed;
u32 insn_processed;
u32 prev_jmps_processed;
u32 jmps_processed;
u64 verification_time;
u32 max_states_per_insn;
u32 total_states;
u32 peak_states;
u32 longest_mark_read_walk;
bpfptr_t fd_array;
u32 scratched_regs;
long: 32;
u64 scratched_stack_slots;
u32 prev_log_len;
u32 prev_insn_print_len;
char type_str_buf[64];
};
enum bpf_dynptr_type {
BPF_DYNPTR_TYPE_INVALID = 0,
BPF_DYNPTR_TYPE_LOCAL = 1,
BPF_DYNPTR_TYPE_RINGBUF = 2,
};
struct tnum {
u64 value;
u64 mask;
};
enum bpf_reg_liveness {
REG_LIVE_NONE = 0,
REG_LIVE_READ32 = 1,
REG_LIVE_READ64 = 2,
REG_LIVE_READ = 3,
REG_LIVE_WRITTEN = 4,
REG_LIVE_DONE = 8,
};
struct bpf_reg_state {
enum bpf_reg_type type;
s32 off;
union {
int range;
struct {
struct bpf_map *map_ptr;
u32 map_uid;
};
struct {
struct btf *btf;
u32 btf_id;
};
u32 mem_size;
struct {
enum bpf_dynptr_type type;
bool first_slot;
} dynptr;
struct {
long unsigned int raw1;
long unsigned int raw2;
} raw;
u32 subprogno;
};
u32 id;
u32 ref_obj_id;
struct tnum var_off;
s64 smin_value;
s64 smax_value;
u64 umin_value;
u64 umax_value;
s32 s32_min_value;
s32 s32_max_value;
u32 u32_min_value;
u32 u32_max_value;
struct bpf_reg_state *parent;
u32 frameno;
s32 subreg_def;
enum bpf_reg_liveness live;
bool precise;
long: 32;
};
struct bpf_reference_state;
struct bpf_stack_state;
struct bpf_func_state {
struct bpf_reg_state regs[11];
int callsite;
u32 frameno;
u32 subprogno;
u32 async_entry_cnt;
bool in_callback_fn;
long: 32;
struct tnum callback_ret_range;
bool in_async_callback_fn;
int acquired_refs;
struct bpf_reference_state *refs;
int allocated_stack;
struct bpf_stack_state *stack;
long: 32;
};
struct bpf_func_proto {
u64 (*func)(u64, u64, u64, u64, u64);
bool gpl_only;
bool pkt_access;
enum bpf_return_type ret_type;
union {
struct {
enum bpf_arg_type arg1_type;
enum bpf_arg_type arg2_type;
enum bpf_arg_type arg3_type;
enum bpf_arg_type arg4_type;
enum bpf_arg_type arg5_type;
};
enum bpf_arg_type arg_type[5];
};
union {
struct {
u32 *arg1_btf_id;
u32 *arg2_btf_id;
u32 *arg3_btf_id;
u32 *arg4_btf_id;
u32 *arg5_btf_id;
};
u32 *arg_btf_id[5];
struct {
size_t arg1_size;
size_t arg2_size;
size_t arg3_size;
size_t arg4_size;
size_t arg5_size;
};
size_t arg_size[5];
};
int *ret_btf_id;
bool (*allowed)(const struct bpf_prog *);
};
enum bpf_access_type {
BPF_READ = 1,
BPF_WRITE = 2,
};
struct bpf_insn_access_aux {
enum bpf_reg_type reg_type;
union {
int ctx_field_size;
struct {
struct btf *btf;
u32 btf_id;
};
};
struct bpf_verifier_log *log;
};
struct bpf_verifier_ops {
const struct bpf_func_proto * (*get_func_proto)(enum bpf_func_id, const struct bpf_prog *);
bool (*is_valid_access)(int, int, enum bpf_access_type, const struct bpf_prog *, struct bpf_insn_access_aux *);
int (*gen_prologue)(struct bpf_insn *, bool, const struct bpf_prog *);
int (*gen_ld_abs)(const struct bpf_insn *, struct bpf_insn *);
u32 (*convert_ctx_access)(enum bpf_access_type, const struct bpf_insn *, struct bpf_insn *, struct bpf_prog *, u32 *);
int (*btf_struct_access)(struct bpf_verifier_log *, const struct btf *, const struct btf_type *, int, int, enum bpf_access_type, u32 *, enum bpf_type_flag *);
};
struct bpf_struct_ops {
const struct bpf_verifier_ops *verifier_ops;
int (*init)(struct btf *);
int (*check_member)(const struct btf_type *, const struct btf_member *);
int (*init_member)(const struct btf_type *, const struct btf_member *, void *, const void *);
int (*reg)(void *);
void (*unreg)(void *);
const struct btf_type *type;
const struct btf_type *value_type;
const char *name;
struct btf_func_model func_models[64];
u32 type_id;
u32 value_id;
};
struct bpf_stack_state {
struct bpf_reg_state spilled_ptr;
u8 slot_type[8];
};
struct bpf_reference_state {
int id;
int insn_idx;
int callback_ref;
};
struct bpf_idx_pair {
u32 prev_idx;
u32 idx;
};
struct bpf_verifier_state {
struct bpf_func_state *frame[8];
struct bpf_verifier_state *parent;
u32 branches;
u32 insn_idx;
u32 curframe;
u32 active_spin_lock;
bool speculative;
u32 first_insn_idx;
u32 last_insn_idx;
struct bpf_idx_pair *jmp_history;
u32 jmp_history_cnt;
};
struct bpf_verifier_state_list {
struct bpf_verifier_state state;
struct bpf_verifier_state_list *next;
int miss_cnt;
int hit_cnt;
};
struct bpf_loop_inline_state {
unsigned int initialized: 1;
unsigned int fit_for_inline: 1;
u32 callback_subprogno;
};
struct bpf_insn_aux_data {
union {
enum bpf_reg_type ptr_type;
long unsigned int map_ptr_state;
s32 call_imm;
u32 alu_limit;
struct {
u32 map_index;
u32 map_off;
};
struct {
enum bpf_reg_type reg_type;
union {
struct {
struct btf *btf;
u32 btf_id;
};
u32 mem_size;
};
} btf_var;
struct bpf_loop_inline_state loop_inline_state;
};
long: 32;
u64 map_key_state;
int ctx_field_size;
u32 seen;
bool sanitize_stack_spill;
bool zext_dst;
u8 alu_state;
unsigned int orig_idx;
bool prune_point;
long: 32;
};
struct minmax_sample {
u32 t;
u32 v;
};
struct minmax {
struct minmax_sample s[3];
};
struct tcp_fastopen_cookie {
__le64 val[2];
s8 len;
bool exp;
long: 32;
};
struct tcp_sack_block {
u32 start_seq;
u32 end_seq;
};
struct tcp_options_received {
int ts_recent_stamp;
u32 ts_recent;
u32 rcv_tsval;
u32 rcv_tsecr;
u16 saw_tstamp: 1;
u16 tstamp_ok: 1;
u16 dsack: 1;
u16 wscale_ok: 1;
u16 sack_ok: 3;
u16 smc_ok: 1;
u16 snd_wscale: 4;
u16 rcv_wscale: 4;
u8 saw_unknown: 1;
u8 unused: 7;
u8 num_sacks;
u16 user_mss;
u16 mss_clamp;
};
struct tcp_rack {
u64 mstamp;
u32 rtt_us;
u32 end_seq;
u32 last_delivered;
u8 reo_wnd_steps;
u8 reo_wnd_persist: 5;
u8 dsack_seen: 1;
u8 advanced: 1;
};
struct tcp_sock_af_ops;
struct tcp_md5sig_info;
struct tcp_fastopen_request;
struct tcp_sock {
struct inet_connection_sock inet_conn;
u16 tcp_header_len;
u16 gso_segs;
__be32 pred_flags;
u64 bytes_received;
u32 segs_in;
u32 data_segs_in;
u32 rcv_nxt;
u32 copied_seq;
u32 rcv_wup;
u32 snd_nxt;
u32 segs_out;
u32 data_segs_out;
u64 bytes_sent;
u64 bytes_acked;
u32 dsack_dups;
u32 snd_una;
u32 snd_sml;
u32 rcv_tstamp;
u32 lsndtime;
u32 last_oow_ack_time;
u32 compressed_ack_rcv_nxt;
u32 tsoffset;
struct list_head tsq_node;
struct list_head tsorted_sent_queue;
u32 snd_wl1;
u32 snd_wnd;
u32 max_window;
u32 mss_cache;
u32 window_clamp;
u32 rcv_ssthresh;
struct tcp_rack rack;
u16 advmss;
u8 compressed_ack;
u8 dup_ack_counter: 2;
u8 tlp_retrans: 1;
u8 unused: 5;
u32 chrono_start;
u32 chrono_stat[3];
u8 chrono_type: 2;
u8 rate_app_limited: 1;
u8 fastopen_connect: 1;
u8 fastopen_no_cookie: 1;
u8 is_sack_reneg: 1;
u8 fastopen_client_fail: 2;
u8 nonagle: 4;
u8 thin_lto: 1;
u8 recvmsg_inq: 1;
u8 repair: 1;
u8 frto: 1;
u8 repair_queue;
u8 save_syn: 2;
u8 syn_data: 1;
u8 syn_fastopen: 1;
u8 syn_fastopen_exp: 1;
u8 syn_fastopen_ch: 1;
u8 syn_data_acked: 1;
u8 is_cwnd_limited: 1;
u32 tlp_high_seq;
u32 tcp_tx_delay;
u64 tcp_wstamp_ns;
u64 tcp_clock_cache;
u64 tcp_mstamp;
u32 srtt_us;
u32 mdev_us;
u32 mdev_max_us;
u32 rttvar_us;
u32 rtt_seq;
struct minmax rtt_min;
u32 packets_out;
u32 retrans_out;
u32 max_packets_out;
u32 cwnd_usage_seq;
u16 urg_data;
u8 ecn_flags;
u8 keepalive_probes;
u32 reordering;
u32 reord_seen;
u32 snd_up;
struct tcp_options_received rx_opt;
u32 snd_ssthresh;
u32 snd_cwnd;
u32 snd_cwnd_cnt;
u32 snd_cwnd_clamp;
u32 snd_cwnd_used;
u32 snd_cwnd_stamp;
u32 prior_cwnd;
u32 prr_delivered;
u32 prr_out;
u32 delivered;
u32 delivered_ce;
u32 lost;
u32 app_limited;
u64 first_tx_mstamp;
u64 delivered_mstamp;
u32 rate_delivered;
u32 rate_interval_us;
u32 rcv_wnd;
u32 write_seq;
u32 notsent_lowat;
u32 pushed_seq;
u32 lost_out;
u32 sacked_out;
struct hrtimer pacing_timer;
struct hrtimer compressed_ack_timer;
struct sk_buff *lost_skb_hint;
struct sk_buff *retransmit_skb_hint;
struct rb_root out_of_order_queue;
struct sk_buff *ooo_last_skb;
struct tcp_sack_block duplicate_sack[1];
struct tcp_sack_block selective_acks[4];
struct tcp_sack_block recv_sack_cache[4];
struct sk_buff *highest_sack;
int lost_cnt_hint;
u32 prior_ssthresh;
u32 high_seq;
u32 retrans_stamp;
u32 undo_marker;
int undo_retrans;
long: 32;
u64 bytes_retrans;
u32 total_retrans;
u32 urg_seq;
unsigned int keepalive_time;
unsigned int keepalive_intvl;
int linger2;
u8 bpf_sock_ops_cb_flags;
u8 bpf_chg_cc_inprogress: 1;
u16 timeout_rehash;
u32 rcv_ooopack;
u32 rcv_rtt_last_tsecr;
struct {
u32 rtt_us;
u32 seq;
u64 time;
} rcv_rtt_est;
struct {
u32 space;
u32 seq;
u64 time;
} rcvq_space;
struct {
u32 probe_seq_start;
u32 probe_seq_end;
} mtu_probe;
u32 mtu_info;
const struct tcp_sock_af_ops *af_specific;
struct tcp_md5sig_info *md5sig_info;
struct tcp_fastopen_request *fastopen_req;
struct request_sock *fastopen_rsk;
struct saved_syn *saved_syn;
};
struct tcp_md5sig_key;
struct tcp_sock_af_ops {
struct tcp_md5sig_key * (*md5_lookup)(const struct sock *, const struct sock *);
int (*calc_md5_hash)(char *, const struct tcp_md5sig_key *, const struct sock *, const struct sk_buff *);
int (*md5_parse)(struct sock *, int, sockptr_t, int);
};
struct tcp_md5sig_info {
struct hlist_head head;
struct callback_head rcu;
};
struct tcp_fastopen_request {
struct tcp_fastopen_cookie cookie;
struct msghdr *data;
size_t size;
int copied;
struct ubuf_info *uarg;
};
union tcp_md5_addr {
struct in_addr a4;
struct in6_addr a6;
};
struct tcp_md5sig_key {
struct hlist_node node;
u8 keylen;
u8 family;
u8 prefixlen;
u8 flags;
union tcp_md5_addr addr;
int l3index;
u8 key[80];
struct callback_head rcu;
};
struct bpf_local_storage_map_bucket {
struct hlist_head list;
raw_spinlock_t lock;
};
struct bpf_local_storage_data {
struct bpf_local_storage_map *smap;
long: 32;
u8 data[0];
};
typedef u64 (*btf_bpf_tcp_send_ack)(struct tcp_sock *, u32);
typedef __kernel_clock_t clock_t;
struct icmpv6_echo {
__be16 identifier;
__be16 sequence;
};
struct icmpv6_nd_advt {
__u32 reserved: 5;
__u32 override: 1;
__u32 solicited: 1;
__u32 router: 1;
__u32 reserved2: 24;
};
struct icmpv6_nd_ra {
__u8 hop_limit;
__u8 reserved: 3;
__u8 router_pref: 2;
__u8 home_agent: 1;
__u8 other: 1;
__u8 managed: 1;
__be16 rt_lifetime;
};
struct icmp6hdr {
__u8 icmp6_type;
__u8 icmp6_code;
__sum16 icmp6_cksum;
union {
__be32 un_data32[1];
__be16 un_data16[2];
__u8 un_data8[4];
struct icmpv6_echo u_echo;
struct icmpv6_nd_advt u_nd_advt;
struct icmpv6_nd_ra u_nd_ra;
} icmp6_dataun;
};
struct rtnexthop {
short unsigned int rtnh_len;
unsigned char rtnh_flags;
unsigned char rtnh_hops;
int rtnh_ifindex;
};
struct inet6_ifaddr {
struct in6_addr addr;
__u32 prefix_len;
__u32 rt_priority;
__u32 valid_lft;
__u32 prefered_lft;
refcount_t refcnt;
spinlock_t lock;
int state;
__u32 flags;
__u8 dad_probes;
__u8 stable_privacy_retry;
__u16 scope;
long: 32;
__u64 dad_nonce;
long unsigned int cstamp;
long unsigned int tstamp;
struct delayed_work dad_work;
struct inet6_dev *idev;
struct fib6_info *rt;
struct hlist_node addr_lst;
struct list_head if_list;
struct list_head if_list_aux;
struct list_head tmp_list;
struct inet6_ifaddr *ifpub;
int regen_count;
bool tokenized;
u8 ifa_proto;
struct callback_head rcu;
struct in6_addr peer_addr;
};
struct in6_rtmsg {
struct in6_addr rtmsg_dst;
struct in6_addr rtmsg_src;
struct in6_addr rtmsg_gateway;
__u32 rtmsg_type;
__u16 rtmsg_dst_len;
__u16 rtmsg_src_len;
__u32 rtmsg_metric;
long unsigned int rtmsg_info;
__u32 rtmsg_flags;
int rtmsg_ifindex;
};
union bpf_iter_link_info {
struct {
__u32 map_fd;
} map;
struct {
enum bpf_cgroup_iter_order order;
__u32 cgroup_fd;
__u64 cgroup_id;
} cgroup;
struct {
__u32 tid;
__u32 pid;
__u32 pid_fd;
} task;
};
struct bpf_link_info {
__u32 type;
__u32 id;
__u32 prog_id;
long: 32;
union {
struct {
__u64 tp_name;
__u32 tp_name_len;
long: 32;
} raw_tracepoint;
struct {
__u32 attach_type;
__u32 target_obj_id;
__u32 target_btf_id;
} tracing;
struct {
__u64 cgroup_id;
__u32 attach_type;
long: 32;
} cgroup;
struct {
__u64 target_name;
__u32 target_name_len;
union {
struct {
__u32 map_id;
} map;
};
union {
struct {
__u64 cgroup_id;
__u32 order;
long: 32;
} cgroup;
struct {
__u32 tid;
__u32 pid;
} task;
};
} iter;
struct {
__u32 netns_ino;
__u32 attach_type;
} netns;
struct {
__u32 ifindex;
} xdp;
};
};
struct rt6_exception {
struct hlist_node hlist;
struct rt6_info *rt6i;
long unsigned int stamp;
struct callback_head rcu;
};
struct rd_msg {
struct icmp6hdr icmph;
struct in6_addr target;
struct in6_addr dest;
__u8 opt[0];
};
struct route_info {
__u8 type;
__u8 length;
__u8 prefix_len;
__u8 reserved_l: 3;
__u8 route_pref: 2;
__u8 reserved_h: 3;
__be32 lifetime;
__u8 prefix[0];
};
typedef int (*bpf_iter_attach_target_t)(struct bpf_prog *, union bpf_iter_link_info *, struct bpf_iter_aux_info *);
typedef void (*bpf_iter_detach_target_t)(struct bpf_iter_aux_info *);
typedef void (*bpf_iter_show_fdinfo_t)(const struct bpf_iter_aux_info *, struct seq_file *);
typedef int (*bpf_iter_fill_link_info_t)(const struct bpf_iter_aux_info *, struct bpf_link_info *);
typedef const struct bpf_func_proto * (*bpf_iter_get_func_proto_t)(enum bpf_func_id, const struct bpf_prog *);
struct bpf_iter_reg {
const char *target;
bpf_iter_attach_target_t attach_target;
bpf_iter_detach_target_t detach_target;
bpf_iter_show_fdinfo_t show_fdinfo;
bpf_iter_fill_link_info_t fill_link_info;
bpf_iter_get_func_proto_t get_func_proto;
u32 ctx_arg_info_size;
u32 feature;
struct bpf_ctx_arg_aux ctx_arg_info[2];
const struct bpf_iter_seq_info *seq_info;
};
struct netevent_redirect {
struct dst_entry *old;
struct dst_entry *new;
struct neighbour *neigh;
const void *daddr;
};
struct trace_event_raw_fib6_table_lookup {
struct trace_entry ent;
u32 tb_id;
int err;
int oif;
int iif;
__u8 tos;
__u8 scope;
__u8 flags;
__u8 src[16];
__u8 dst[16];
u16 sport;
u16 dport;
u8 proto;
u8 rt_type;
char name[16];
__u8 gw[16];
char __data[0];
};
struct trace_event_data_offsets_fib6_table_lookup {};
typedef void (*btf_trace_fib6_table_lookup)(void *, const struct net *, const struct fib6_result *, struct fib6_table *, const struct flowi6 *);
enum rt6_nud_state {
RT6_NUD_FAIL_HARD = -3,
RT6_NUD_FAIL_PROBE = -2,
RT6_NUD_FAIL_DO_RR = -1,
RT6_NUD_SUCCEED = 1,
};
struct fib6_nh_dm_arg {
struct net *net;
const struct in6_addr *saddr;
int oif;
int flags;
struct fib6_nh *nh;
};
struct __rt6_probe_work {
struct work_struct work;
struct in6_addr target;
struct net_device *dev;
netdevice_tracker dev_tracker;
};
struct fib6_nh_frl_arg {
u32 flags;
int oif;
int strict;
int *mpri;
bool *do_rr;
struct fib6_nh *nh;
};
struct fib6_nh_excptn_arg {
struct rt6_info *rt;
int plen;
};
struct fib6_nh_match_arg {
const struct net_device *dev;
const struct in6_addr *gw;
struct fib6_nh *match;
};
struct fib6_nh_age_excptn_arg {
struct fib6_gc_args *gc_args;
long unsigned int now;
};
struct fib6_nh_rd_arg {
struct fib6_result *res;
struct flowi6 *fl6;
const struct in6_addr *gw;
struct rt6_info **ret;
};
struct ip6rd_flowi {
struct flowi6 fl6;
struct in6_addr gateway;
};
struct fib6_nh_del_cached_rt_arg {
struct fib6_config *cfg;
struct fib6_info *f6i;
};
struct arg_dev_net_ip {
struct net_device *dev;
struct net *net;
struct in6_addr *addr;
};
struct arg_netdev_event {
const struct net_device *dev;
union {
unsigned char nh_flags;
long unsigned int event;
};
};
struct rt6_mtu_change_arg {
struct net_device *dev;
unsigned int mtu;
struct fib6_info *f6i;
};
struct rt6_nh {
struct fib6_info *fib6_info;
struct fib6_config r_cfg;
struct list_head next;
};
struct fib6_nh_exception_dump_walker {
struct rt6_rtnl_dump_arg *dump;
struct fib6_info *rt;
unsigned int flags;
unsigned int skip;
unsigned int count;
};
struct sockaddr_in {
__kernel_sa_family_t sin_family;
__be16 sin_port;
struct in_addr sin_addr;
unsigned char __pad[8];
};
enum xprt_transports {
XPRT_TRANSPORT_UDP = 17,
XPRT_TRANSPORT_TCP = 6,
XPRT_TRANSPORT_BC_TCP = -2147483642,
XPRT_TRANSPORT_RDMA = 256,
XPRT_TRANSPORT_BC_RDMA = -2147483392,
XPRT_TRANSPORT_LOCAL = 257,
};
struct rpc_sysfs_xprt {
struct kobject kobject;
struct rpc_xprt *xprt;
struct rpc_xprt_switch *xprt_switch;
};
struct rpc_sysfs_xprt_switch {
struct kobject kobject;
struct net *net;
struct rpc_xprt_switch *xprt_switch;
struct rpc_xprt *xprt;
};
struct rpc_sysfs_client {
struct kobject kobject;
struct net *net;
struct rpc_clnt *clnt;
struct rpc_xprt_switch *xprt_switch;
};
struct xprt_addr {
const char *addr;
struct callback_head rcu;
};
struct pci_controller {
struct list_head list;
struct pci_bus *bus;
struct device_node *of_node;
struct pci_ops *pci_ops;
struct resource *mem_resource;
long unsigned int mem_offset;
struct resource *io_resource;
long unsigned int io_offset;
long unsigned int io_map_base;
unsigned int index;
unsigned int need_domain_info;
int (*get_busno)();
void (*set_busno)(int);
};
struct xa_limit {
u32 max;
u32 min;
};
typedef long unsigned int ulong;
struct uasm_label {
u32 *addr;
int lab;
};
struct uasm_reloc {
u32 *addr;
unsigned int type;
int lab;
};
enum tlb_write_entry {
tlb_random = 0,
tlb_indexed = 1,
};
struct work_registers {
int r1;
int r2;
int r3;
};
struct tlb_reg_save {
long unsigned int a;
long unsigned int b;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum label_id {
label_second_part = 1,
label_leave = 2,
label_vmalloc = 3,
label_vmalloc_done = 4,
label_tlbw_hazard_0 = 5,
label_split = 13,
label_tlbl_goaround1 = 14,
label_tlbl_goaround2 = 15,
label_nopage_tlbl = 16,
label_nopage_tlbs = 17,
label_nopage_tlbm = 18,
label_smp_pgtable_change = 19,
label_r3000_write_probe_fail = 20,
label_large_segbits_fault = 21,
};
enum vmalloc64_mode {
not_refill = 0,
refill_scratch = 1,
refill_noscratch = 2,
};
struct mips_huge_tlb_info {
int huge_pte;
int restore_scratch;
bool need_reload_pte;
};
struct sysinfo {
__kernel_long_t uptime;
__kernel_ulong_t loads[3];
__kernel_ulong_t totalram;
__kernel_ulong_t freeram;
__kernel_ulong_t sharedram;
__kernel_ulong_t bufferram;
__kernel_ulong_t totalswap;
__kernel_ulong_t freeswap;
__u16 procs;
__u16 pad;
__kernel_ulong_t totalhigh;
__kernel_ulong_t freehigh;
__u32 mem_unit;
char _f[8];
};
struct rusage {
struct __kernel_old_timeval ru_utime;
struct __kernel_old_timeval ru_stime;
__kernel_long_t ru_maxrss;
__kernel_long_t ru_ixrss;
__kernel_long_t ru_idrss;
__kernel_long_t ru_isrss;
__kernel_long_t ru_minflt;
__kernel_long_t ru_majflt;
__kernel_long_t ru_nswap;
__kernel_long_t ru_inblock;
__kernel_long_t ru_oublock;
__kernel_long_t ru_msgsnd;
__kernel_long_t ru_msgrcv;
__kernel_long_t ru_nsignals;
__kernel_long_t ru_nvcsw;
__kernel_long_t ru_nivcsw;
};
struct rlimit64 {
__u64 rlim_cur;
__u64 rlim_max;
};
typedef int (*proc_visitor)(struct task_struct *, void *);
struct oldold_utsname {
char sysname[9];
char nodename[9];
char release[9];
char version[9];
char machine[9];
};
struct old_utsname {
char sysname[65];
char nodename[65];
char release[65];
char version[65];
char machine[65];
};
enum uts_proc {
UTS_PROC_ARCH = 0,
UTS_PROC_OSTYPE = 1,
UTS_PROC_OSRELEASE = 2,
UTS_PROC_VERSION = 3,
UTS_PROC_HOSTNAME = 4,
UTS_PROC_DOMAINNAME = 5,
};
struct prctl_mm_map {
__u64 start_code;
__u64 end_code;
__u64 start_data;
__u64 end_data;
__u64 start_brk;
__u64 brk;
__u64 start_stack;
__u64 arg_start;
__u64 arg_end;
__u64 env_start;
__u64 env_end;
__u64 *auxv;
__u32 auxv_size;
__u32 exe_fd;
long: 32;
};
struct tms {
__kernel_clock_t tms_utime;
__kernel_clock_t tms_stime;
__kernel_clock_t tms_cutime;
__kernel_clock_t tms_cstime;
};
struct getcpu_cache {
long unsigned int blob[32];
};
enum {
PER_LINUX = 0,
PER_LINUX_32BIT = 8388608,
PER_LINUX_FDPIC = 524288,
PER_SVR4 = 68157441,
PER_SVR3 = 83886082,
PER_SCOSVR3 = 117440515,
PER_OSR5 = 100663299,
PER_WYSEV386 = 83886084,
PER_ISCR4 = 67108869,
PER_BSD = 6,
PER_SUNOS = 67108870,
PER_XENIX = 83886087,
PER_LINUX32 = 8,
PER_LINUX32_3GB = 134217736,
PER_IRIX32 = 67108873,
PER_IRIXN32 = 67108874,
PER_IRIX64 = 67108875,
PER_RISCOS = 12,
PER_SOLARIS = 67108877,
PER_UW7 = 68157454,
PER_OSF4 = 15,
PER_HPUX = 16,
PER_MASK = 255,
};
struct ktime_timestamps {
u64 mono;
u64 boot;
u64 real;
};
struct system_time_snapshot {
u64 cycles;
ktime_t real;
ktime_t raw;
enum clocksource_ids cs_id;
unsigned int clock_was_set_seq;
u8 cs_was_changed_seq;
long: 32;
};
struct system_counterval_t {
u64 cycles;
struct clocksource *cs;
long: 32;
};
struct tk_read_base {
struct clocksource *clock;
long: 32;
u64 mask;
u64 cycle_last;
u32 mult;
u32 shift;
u64 xtime_nsec;
ktime_t base;
u64 base_real;
};
struct timekeeper {
struct tk_read_base tkr_mono;
struct tk_read_base tkr_raw;
u64 xtime_sec;
long unsigned int ktime_sec;
long: 32;
struct timespec64 wall_to_monotonic;
ktime_t offs_real;
ktime_t offs_boot;
ktime_t offs_tai;
s32 tai_offset;
unsigned int clock_was_set_seq;
u8 cs_was_changed_seq;
long: 32;
ktime_t next_leap_ktime;
u64 raw_sec;
struct timespec64 monotonic_to_boot;
u64 cycle_interval;
u64 xtime_interval;
s64 xtime_remainder;
u64 raw_interval;
u64 ntp_tick;
s64 ntp_error;
u32 ntp_error_shift;
u32 ntp_err_mult;
u32 skip_second_overflow;
long: 32;
};
typedef int (*cpu_stop_fn_t)(void *);
struct audit_ntp_data {};
enum timekeeping_adv_mode {
TK_ADV_TICK = 0,
TK_ADV_FREQ = 1,
};
struct tk_fast {
seqcount_latch_t seq;
long: 32;
struct tk_read_base base[2];
};
struct futex_waitv {
__u64 val;
__u64 uaddr;
__u32 flags;
__u32 __reserved;
};
struct futex_vector {
struct futex_waitv w;
struct futex_q q;
};
enum ftrace_dump_mode {
DUMP_NONE = 0,
DUMP_ALL = 1,
DUMP_ORIG = 2,
};
enum {
TRACE_FTRACE_BIT = 0,
TRACE_FTRACE_NMI_BIT = 1,
TRACE_FTRACE_IRQ_BIT = 2,
TRACE_FTRACE_SIRQ_BIT = 3,
TRACE_FTRACE_TRANSITION_BIT = 4,
TRACE_INTERNAL_BIT = 5,
TRACE_INTERNAL_NMI_BIT = 6,
TRACE_INTERNAL_IRQ_BIT = 7,
TRACE_INTERNAL_SIRQ_BIT = 8,
TRACE_INTERNAL_TRANSITION_BIT = 9,
TRACE_BRANCH_BIT = 10,
TRACE_IRQ_BIT = 11,
TRACE_GRAPH_BIT = 12,
TRACE_GRAPH_DEPTH_START_BIT = 13,
TRACE_GRAPH_DEPTH_END_BIT = 14,
TRACE_GRAPH_NOTRACE_BIT = 15,
TRACE_RECORD_RECURSION_BIT = 16,
};
enum {
TRACE_CTX_NMI = 0,
TRACE_CTX_IRQ = 1,
TRACE_CTX_SOFTIRQ = 2,
TRACE_CTX_NORMAL = 3,
TRACE_CTX_TRANSITION = 4,
};
enum {
FTRACE_OPS_FL_ENABLED = 1,
FTRACE_OPS_FL_DYNAMIC = 2,
FTRACE_OPS_FL_SAVE_REGS = 4,
FTRACE_OPS_FL_SAVE_REGS_IF_SUPPORTED = 8,
FTRACE_OPS_FL_RECURSION = 16,
FTRACE_OPS_FL_STUB = 32,
FTRACE_OPS_FL_INITIALIZED = 64,
FTRACE_OPS_FL_DELETED = 128,
FTRACE_OPS_FL_ADDING = 256,
FTRACE_OPS_FL_REMOVING = 512,
FTRACE_OPS_FL_MODIFYING = 1024,
FTRACE_OPS_FL_ALLOC_TRAMP = 2048,
FTRACE_OPS_FL_IPMODIFY = 4096,
FTRACE_OPS_FL_PID = 8192,
FTRACE_OPS_FL_RCU = 16384,
FTRACE_OPS_FL_TRACE_ARRAY = 32768,
FTRACE_OPS_FL_PERMANENT = 65536,
FTRACE_OPS_FL_DIRECT = 131072,
};
struct ftrace_hash {
long unsigned int size_bits;
struct hlist_head *buckets;
long unsigned int count;
long unsigned int flags;
struct callback_head rcu;
};
struct prog_entry;
struct event_filter {
struct prog_entry *prog;
char *filter_string;
};
struct trace_array_cpu;
struct array_buffer {
struct trace_array *tr;
struct trace_buffer *buffer;
struct trace_array_cpu *data;
long: 32;
u64 time_start;
int cpu;
long: 32;
};
struct trace_pid_list;
struct trace_options;
struct trace_func_repeats;
struct trace_array {
struct list_head list;
char *name;
long: 32;
struct array_buffer array_buffer;
struct trace_pid_list *filtered_pids;
struct trace_pid_list *filtered_no_pids;
arch_spinlock_t max_lock;
int buffer_disabled;
int sys_refcount_enter;
int sys_refcount_exit;
struct trace_event_file *enter_syscall_files[4451];
struct trace_event_file *exit_syscall_files[4451];
int stop_count;
int clock_id;
int nr_topts;
bool clear_trace;
int buffer_percent;
unsigned int n_err_log_entries;
struct tracer *current_trace;
unsigned int trace_flags;
unsigned char trace_flags_index[32];
unsigned int flags;
raw_spinlock_t start_lock;
struct list_head err_log;
struct dentry *dir;
struct dentry *options;
struct dentry *percpu_dir;
struct dentry *event_dir;
struct trace_options *topts;
struct list_head systems;
struct list_head events;
struct trace_event_file *trace_marker_file;
cpumask_var_t tracing_cpumask;
int ref;
int trace_ref;
struct ftrace_ops *ops;
struct trace_pid_list *function_pids;
struct trace_pid_list *function_no_pids;
struct list_head func_probes;
struct list_head mod_trace;
struct list_head mod_notrace;
int function_enabled;
int no_filter_buffering_ref;
struct list_head hist_vars;
struct trace_func_repeats *last_func_repeats;
long: 32;
};
struct tracer_flags;
struct tracer {
const char *name;
int (*init)(struct trace_array *);
void (*reset)(struct trace_array *);
void (*start)(struct trace_array *);
void (*stop)(struct trace_array *);
int (*update_thresh)(struct trace_array *);
void (*open)(struct trace_iterator *);
void (*pipe_open)(struct trace_iterator *);
void (*close)(struct trace_iterator *);
void (*pipe_close)(struct trace_iterator *);
ssize_t (*read)(struct trace_iterator *, struct file *, char *, size_t, loff_t *);
ssize_t (*splice_read)(struct trace_iterator *, struct file *, loff_t *, struct pipe_inode_info *, size_t, unsigned int);
void (*print_header)(struct seq_file *);
enum print_line_t (*print_line)(struct trace_iterator *);
int (*set_flag)(struct trace_array *, u32, u32, int);
int (*flag_changed)(struct trace_array *, u32, int);
struct tracer *next;
struct tracer_flags *flags;
int enabled;
bool print_max;
bool allow_instances;
bool noboot;
};
enum trace_flag_type {
TRACE_FLAG_IRQS_OFF = 1,
TRACE_FLAG_IRQS_NOSUPPORT = 2,
TRACE_FLAG_NEED_RESCHED = 4,
TRACE_FLAG_HARDIRQ = 8,
TRACE_FLAG_SOFTIRQ = 16,
TRACE_FLAG_PREEMPT_RESCHED = 32,
TRACE_FLAG_NMI = 64,
TRACE_FLAG_BH_OFF = 128,
};
struct event_subsystem;
struct trace_subsystem_dir {
struct list_head list;
struct event_subsystem *subsystem;
struct trace_array *tr;
struct dentry *entry;
int ref_count;
int nr_events;
};
union lower_chunk {
union lower_chunk *next;
long unsigned int data[512];
};
union upper_chunk {
union upper_chunk *next;
union lower_chunk *data[256];
};
struct trace_pid_list {
raw_spinlock_t lock;
struct irq_work refill_irqwork;
union upper_chunk *upper[256];
union upper_chunk *upper_list;
union lower_chunk *lower_list;
int free_upper_chunks;
int free_lower_chunks;
};
struct trace_array_cpu {
atomic_t disabled;
void *buffer_page;
long unsigned int entries;
long unsigned int saved_latency;
long unsigned int critical_start;
long unsigned int critical_end;
long unsigned int critical_sequence;
long unsigned int nice;
long unsigned int policy;
long unsigned int rt_priority;
long unsigned int skipped_entries;
long: 32;
u64 preempt_timestamp;
pid_t pid;
kuid_t uid;
char comm[16];
int ftrace_ignore_pid;
bool ignore_pid;
};
struct trace_option_dentry;
struct trace_options {
struct tracer *tracer;
struct trace_option_dentry *topts;
};
struct tracer_opt;
struct trace_option_dentry {
struct tracer_opt *opt;
struct tracer_flags *flags;
struct trace_array *tr;
struct dentry *entry;
};
struct trace_func_repeats {
long unsigned int ip;
long unsigned int parent_ip;
long unsigned int count;
long: 32;
u64 ts_last_call;
};
enum {
TRACE_ARRAY_FL_GLOBAL = 1,
};
struct tracer_opt {
const char *name;
u32 bit;
};
struct tracer_flags {
u32 val;
struct tracer_opt *opts;
struct tracer *trace;
};
struct ftrace_func_command {
struct list_head list;
char *name;
int (*func)(struct trace_array *, struct ftrace_hash *, char *, char *, char *, int);
};
struct ftrace_probe_ops {
void (*func)(long unsigned int, long unsigned int, struct trace_array *, struct ftrace_probe_ops *, void *);
int (*init)(struct ftrace_probe_ops *, struct trace_array *, long unsigned int, void *, void **);
void (*free)(struct ftrace_probe_ops *, struct trace_array *, long unsigned int, void *);
int (*print)(struct seq_file *, long unsigned int, struct ftrace_probe_ops *, void *);
};
typedef int (*ftrace_mapper_func)(void *);
enum trace_iterator_bits {
TRACE_ITER_PRINT_PARENT_BIT = 0,
TRACE_ITER_SYM_OFFSET_BIT = 1,
TRACE_ITER_SYM_ADDR_BIT = 2,
TRACE_ITER_VERBOSE_BIT = 3,
TRACE_ITER_RAW_BIT = 4,
TRACE_ITER_HEX_BIT = 5,
TRACE_ITER_BIN_BIT = 6,
TRACE_ITER_BLOCK_BIT = 7,
TRACE_ITER_PRINTK_BIT = 8,
TRACE_ITER_ANNOTATE_BIT = 9,
TRACE_ITER_USERSTACKTRACE_BIT = 10,
TRACE_ITER_SYM_USEROBJ_BIT = 11,
TRACE_ITER_PRINTK_MSGONLY_BIT = 12,
TRACE_ITER_CONTEXT_INFO_BIT = 13,
TRACE_ITER_LATENCY_FMT_BIT = 14,
TRACE_ITER_RECORD_CMD_BIT = 15,
TRACE_ITER_RECORD_TGID_BIT = 16,
TRACE_ITER_OVERWRITE_BIT = 17,
TRACE_ITER_STOP_ON_FREE_BIT = 18,
TRACE_ITER_IRQ_INFO_BIT = 19,
TRACE_ITER_MARKERS_BIT = 20,
TRACE_ITER_EVENT_FORK_BIT = 21,
TRACE_ITER_PAUSE_ON_TRACE_BIT = 22,
TRACE_ITER_HASH_PTR_BIT = 23,
TRACE_ITER_FUNCTION_BIT = 24,
TRACE_ITER_FUNC_FORK_BIT = 25,
TRACE_ITER_DISPLAY_GRAPH_BIT = 26,
TRACE_ITER_STACKTRACE_BIT = 27,
TRACE_ITER_LAST_BIT = 28,
};
struct event_subsystem {
struct list_head list;
const char *name;
struct event_filter *filter;
int ref_count;
};
enum {
TRACE_FUNC_NO_OPTS = 0,
TRACE_FUNC_OPT_STACK = 1,
TRACE_FUNC_OPT_NO_REPEATS = 2,
TRACE_FUNC_OPT_HIGHEST_BIT = 4,
};
enum xdp_action {
XDP_ABORTED = 0,
XDP_DROP = 1,
XDP_PASS = 2,
XDP_TX = 3,
XDP_REDIRECT = 4,
};
struct rnd_state {
__u32 s1;
__u32 s2;
__u32 s3;
__u32 s4;
};
enum bpf_jit_poke_reason {
BPF_POKE_REASON_TAIL_CALL = 0,
};
struct bpf_array_aux {
struct list_head poke_progs;
struct bpf_map *map;
struct mutex poke_mutex;
struct work_struct work;
};
struct bpf_array {
struct bpf_map map;
u32 elem_size;
u32 index_mask;
struct bpf_array_aux *aux;
long: 32;
union {
char value[0];
void *ptrs[0];
void *pptrs[0];
};
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef long unsigned int (*bpf_ctx_copy_t)(void *, const void *, long unsigned int, long unsigned int);
struct bpf_empty_prog_array {
struct bpf_prog_array hdr;
struct bpf_prog *null_prog;
long: 32;
};
enum bpf_text_poke_type {
BPF_MOD_CALL = 0,
BPF_MOD_JUMP = 1,
};
enum xdp_mem_type {
MEM_TYPE_PAGE_SHARED = 0,
MEM_TYPE_PAGE_ORDER0 = 1,
MEM_TYPE_PAGE_POOL = 2,
MEM_TYPE_XSK_BUFF_POOL = 3,
MEM_TYPE_MAX = 4,
};
struct xdp_cpumap_stats {
unsigned int redirect;
unsigned int pass;
unsigned int drop;
};
struct bpf_binary_header {
u32 size;
long: 32;
u8 image[0];
};
typedef void (*bpf_jit_fill_hole_t)(void *, unsigned int);
struct bpf_prog_pack {
struct list_head list;
void *ptr;
long unsigned int bitmap[0];
};
struct bpf_prog_dummy {
struct bpf_prog prog;
};
typedef u64 (*btf_bpf_user_rnd_u32)();
typedef u64 (*btf_bpf_get_raw_cpu_id)();
struct _bpf_dtab_netdev {
struct net_device *dev;
};
struct xdp_mem_allocator {
struct xdp_mem_info mem;
union {
void *allocator;
struct page_pool *page_pool;
};
struct rhash_head node;
struct callback_head rcu;
};
struct trace_event_raw_xdp_exception {
struct trace_entry ent;
int prog_id;
u32 act;
int ifindex;
char __data[0];
};
struct trace_event_raw_xdp_bulk_tx {
struct trace_entry ent;
int ifindex;
u32 act;
int drops;
int sent;
int err;
char __data[0];
};
struct trace_event_raw_xdp_redirect_template {
struct trace_entry ent;
int prog_id;
u32 act;
int ifindex;
int err;
int to_ifindex;
u32 map_id;
int map_index;
char __data[0];
};
struct trace_event_raw_xdp_cpumap_kthread {
struct trace_entry ent;
int map_id;
u32 act;
int cpu;
unsigned int drops;
unsigned int processed;
int sched;
unsigned int xdp_pass;
unsigned int xdp_drop;
unsigned int xdp_redirect;
char __data[0];
};
struct trace_event_raw_xdp_cpumap_enqueue {
struct trace_entry ent;
int map_id;
u32 act;
int cpu;
unsigned int drops;
unsigned int processed;
int to_cpu;
char __data[0];
};
struct trace_event_raw_xdp_devmap_xmit {
struct trace_entry ent;
int from_ifindex;
u32 act;
int to_ifindex;
int drops;
int sent;
int err;
char __data[0];
};
struct trace_event_raw_mem_disconnect {
struct trace_entry ent;
const struct xdp_mem_allocator *xa;
u32 mem_id;
u32 mem_type;
const void *allocator;
char __data[0];
};
struct trace_event_raw_mem_connect {
struct trace_entry ent;
const struct xdp_mem_allocator *xa;
u32 mem_id;
u32 mem_type;
const void *allocator;
const struct xdp_rxq_info *rxq;
int ifindex;
char __data[0];
};
struct trace_event_raw_mem_return_failed {
struct trace_entry ent;
const struct page *page;
u32 mem_id;
u32 mem_type;
char __data[0];
};
struct trace_event_data_offsets_xdp_exception {};
struct trace_event_data_offsets_xdp_bulk_tx {};
struct trace_event_data_offsets_xdp_redirect_template {};
struct trace_event_data_offsets_xdp_cpumap_kthread {};
struct trace_event_data_offsets_xdp_cpumap_enqueue {};
struct trace_event_data_offsets_xdp_devmap_xmit {};
struct trace_event_data_offsets_mem_disconnect {};
struct trace_event_data_offsets_mem_connect {};
struct trace_event_data_offsets_mem_return_failed {};
typedef void (*btf_trace_xdp_exception)(void *, const struct net_device *, const struct bpf_prog *, u32);
typedef void (*btf_trace_xdp_bulk_tx)(void *, const struct net_device *, int, int, int);
typedef void (*btf_trace_xdp_redirect)(void *, const struct net_device *, const struct bpf_prog *, const void *, int, enum bpf_map_type, u32, u32);
typedef void (*btf_trace_xdp_redirect_err)(void *, const struct net_device *, const struct bpf_prog *, const void *, int, enum bpf_map_type, u32, u32);
typedef void (*btf_trace_xdp_redirect_map)(void *, const struct net_device *, const struct bpf_prog *, const void *, int, enum bpf_map_type, u32, u32);
typedef void (*btf_trace_xdp_redirect_map_err)(void *, const struct net_device *, const struct bpf_prog *, const void *, int, enum bpf_map_type, u32, u32);
typedef void (*btf_trace_xdp_cpumap_kthread)(void *, int, unsigned int, unsigned int, int, struct xdp_cpumap_stats *);
typedef void (*btf_trace_xdp_cpumap_enqueue)(void *, int, unsigned int, unsigned int, int);
typedef void (*btf_trace_xdp_devmap_xmit)(void *, const struct net_device *, const struct net_device *, int, int, int);
typedef void (*btf_trace_mem_disconnect)(void *, const struct xdp_mem_allocator *);
typedef void (*btf_trace_mem_connect)(void *, const struct xdp_mem_allocator *, const struct xdp_rxq_info *);
typedef void (*btf_trace_mem_return_failed)(void *, const struct xdp_mem_info *, const struct page *);
struct dma_pool {
struct list_head page_list;
spinlock_t lock;
size_t size;
struct device *dev;
size_t allocation;
size_t boundary;
char name[32];
struct list_head pools;
};
struct dma_page {
struct list_head page_list;
void *vaddr;
dma_addr_t dma;
unsigned int in_use;
unsigned int offset;
};
enum fsnotify_data_type {
FSNOTIFY_EVENT_NONE = 0,
FSNOTIFY_EVENT_PATH = 1,
FSNOTIFY_EVENT_INODE = 2,
FSNOTIFY_EVENT_DENTRY = 3,
FSNOTIFY_EVENT_ERROR = 4,
};
struct linux_dirent64 {
u64 d_ino;
s64 d_off;
short unsigned int d_reclen;
unsigned char d_type;
char d_name[0];
long: 32;
};
struct old_linux_dirent {
long unsigned int d_ino;
long unsigned int d_offset;
short unsigned int d_namlen;
char d_name[1];
};
struct readdir_callback {
struct dir_context ctx;
struct old_linux_dirent *dirent;
int result;
};
struct linux_dirent {
long unsigned int d_ino;
long unsigned int d_off;
short unsigned int d_reclen;
char d_name[1];
};
struct getdents_callback {
struct dir_context ctx;
struct linux_dirent *current_dir;
int prev_reclen;
int count;
int error;
};
struct getdents_callback64 {
struct dir_context ctx;
struct linux_dirent64 *current_dir;
int prev_reclen;
int count;
int error;
};
enum fsconfig_command {
FSCONFIG_SET_FLAG = 0,
FSCONFIG_SET_STRING = 1,
FSCONFIG_SET_BINARY = 2,
FSCONFIG_SET_PATH = 3,
FSCONFIG_SET_PATH_EMPTY = 4,
FSCONFIG_SET_FD = 5,
FSCONFIG_CMD_CREATE = 6,
FSCONFIG_CMD_RECONFIGURE = 7,
};
struct eventfd_ctx {
struct kref kref;
wait_queue_head_t wqh;
__u64 count;
unsigned int flags;
int id;
};
typedef __kernel_uid32_t qid_t;
typedef __kernel_long_t __kernel_off_t;
typedef __kernel_off_t off_t;
enum {
PROC_ENTRY_PERMANENT = 1,
};
enum {
EXT4_MF_MNTDIR_SAMPLED = 0,
EXT4_MF_FS_ABORTED = 1,
EXT4_MF_FC_INELIGIBLE = 2,
};
struct jbd2_journal_block_tail {
__be32 t_checksum;
};
struct trace_event_raw_jbd2_checkpoint {
struct trace_entry ent;
dev_t dev;
int result;
char __data[0];
};
struct trace_event_raw_jbd2_commit {
struct trace_entry ent;
dev_t dev;
char sync_commit;
int transaction;
char __data[0];
};
struct trace_event_raw_jbd2_end_commit {
struct trace_entry ent;
dev_t dev;
char sync_commit;
int transaction;
int head;
char __data[0];
};
struct trace_event_raw_jbd2_submit_inode_data {
struct trace_entry ent;
dev_t dev;
ino_t ino;
char __data[0];
};
struct trace_event_raw_jbd2_handle_start_class {
struct trace_entry ent;
dev_t dev;
long unsigned int tid;
unsigned int type;
unsigned int line_no;
int requested_blocks;
char __data[0];
};
struct trace_event_raw_jbd2_handle_extend {
struct trace_entry ent;
dev_t dev;
long unsigned int tid;
unsigned int type;
unsigned int line_no;
int buffer_credits;
int requested_blocks;
char __data[0];
};
struct trace_event_raw_jbd2_handle_stats {
struct trace_entry ent;
dev_t dev;
long unsigned int tid;
unsigned int type;
unsigned int line_no;
int interval;
int sync;
int requested_blocks;
int dirtied_blocks;
char __data[0];
};
struct trace_event_raw_jbd2_run_stats {
struct trace_entry ent;
dev_t dev;
long unsigned int tid;
long unsigned int wait;
long unsigned int request_delay;
long unsigned int running;
long unsigned int locked;
long unsigned int flushing;
long unsigned int logging;
__u32 handle_count;
__u32 blocks;
__u32 blocks_logged;
char __data[0];
};
struct trace_event_raw_jbd2_checkpoint_stats {
struct trace_entry ent;
dev_t dev;
long unsigned int tid;
long unsigned int chp_time;
__u32 forced_to_close;
__u32 written;
__u32 dropped;
char __data[0];
};
struct trace_event_raw_jbd2_update_log_tail {
struct trace_entry ent;
dev_t dev;
tid_t tail_sequence;
tid_t first_tid;
long unsigned int block_nr;
long unsigned int freed;
char __data[0];
};
struct trace_event_raw_jbd2_write_superblock {
struct trace_entry ent;
dev_t dev;
blk_opf_t write_flags;
char __data[0];
};
struct trace_event_raw_jbd2_lock_buffer_stall {
struct trace_entry ent;
dev_t dev;
long unsigned int stall_ms;
char __data[0];
};
struct trace_event_raw_jbd2_journal_shrink {
struct trace_entry ent;
dev_t dev;
long unsigned int nr_to_scan;
long unsigned int count;
char __data[0];
};
struct trace_event_raw_jbd2_shrink_scan_exit {
struct trace_entry ent;
dev_t dev;
long unsigned int nr_to_scan;
long unsigned int nr_shrunk;
long unsigned int count;
char __data[0];
};
struct trace_event_raw_jbd2_shrink_checkpoint_list {
struct trace_entry ent;
dev_t dev;
tid_t first_tid;
tid_t tid;
tid_t last_tid;
long unsigned int nr_freed;
long unsigned int nr_scanned;
tid_t next_tid;
char __data[0];
};
struct trace_event_data_offsets_jbd2_checkpoint {};
struct trace_event_data_offsets_jbd2_commit {};
struct trace_event_data_offsets_jbd2_end_commit {};
struct trace_event_data_offsets_jbd2_submit_inode_data {};
struct trace_event_data_offsets_jbd2_handle_start_class {};
struct trace_event_data_offsets_jbd2_handle_extend {};
struct trace_event_data_offsets_jbd2_handle_stats {};
struct trace_event_data_offsets_jbd2_run_stats {};
struct trace_event_data_offsets_jbd2_checkpoint_stats {};
struct trace_event_data_offsets_jbd2_update_log_tail {};
struct trace_event_data_offsets_jbd2_write_superblock {};
struct trace_event_data_offsets_jbd2_lock_buffer_stall {};
struct trace_event_data_offsets_jbd2_journal_shrink {};
struct trace_event_data_offsets_jbd2_shrink_scan_exit {};
struct trace_event_data_offsets_jbd2_shrink_checkpoint_list {};
typedef void (*btf_trace_jbd2_checkpoint)(void *, journal_t *, int);
typedef void (*btf_trace_jbd2_start_commit)(void *, journal_t *, transaction_t *);
typedef void (*btf_trace_jbd2_commit_locking)(void *, journal_t *, transaction_t *);
typedef void (*btf_trace_jbd2_commit_flushing)(void *, journal_t *, transaction_t *);
typedef void (*btf_trace_jbd2_commit_logging)(void *, journal_t *, transaction_t *);
typedef void (*btf_trace_jbd2_drop_transaction)(void *, journal_t *, transaction_t *);
typedef void (*btf_trace_jbd2_end_commit)(void *, journal_t *, transaction_t *);
typedef void (*btf_trace_jbd2_submit_inode_data)(void *, struct inode *);
typedef void (*btf_trace_jbd2_handle_start)(void *, dev_t, long unsigned int, unsigned int, unsigned int, int);
typedef void (*btf_trace_jbd2_handle_restart)(void *, dev_t, long unsigned int, unsigned int, unsigned int, int);
typedef void (*btf_trace_jbd2_handle_extend)(void *, dev_t, long unsigned int, unsigned int, unsigned int, int, int);
typedef void (*btf_trace_jbd2_handle_stats)(void *, dev_t, long unsigned int, unsigned int, unsigned int, int, int, int, int);
typedef void (*btf_trace_jbd2_run_stats)(void *, dev_t, long unsigned int, struct transaction_run_stats_s *);
typedef void (*btf_trace_jbd2_checkpoint_stats)(void *, dev_t, long unsigned int, struct transaction_chp_stats_s *);
typedef void (*btf_trace_jbd2_update_log_tail)(void *, journal_t *, tid_t, long unsigned int, long unsigned int);
typedef void (*btf_trace_jbd2_write_superblock)(void *, journal_t *, blk_opf_t);
typedef void (*btf_trace_jbd2_lock_buffer_stall)(void *, dev_t, long unsigned int);
typedef void (*btf_trace_jbd2_shrink_count)(void *, journal_t *, long unsigned int, long unsigned int);
typedef void (*btf_trace_jbd2_shrink_scan_enter)(void *, journal_t *, long unsigned int, long unsigned int);
typedef void (*btf_trace_jbd2_shrink_scan_exit)(void *, journal_t *, long unsigned int, long unsigned int, long unsigned int);
typedef void (*btf_trace_jbd2_shrink_checkpoint_list)(void *, journal_t *, tid_t, tid_t, tid_t, long unsigned int, long unsigned int, tid_t);
struct jbd2_stats_proc_session {
journal_t *journal;
struct transaction_stats_s *stats;
int start;
int max;
};
enum nfs3_createmode {
NFS3_CREATE_UNCHECKED = 0,
NFS3_CREATE_GUARDED = 1,
NFS3_CREATE_EXCLUSIVE = 2,
};
enum nfs3_ftype {
NF3NON = 0,
NF3REG = 1,
NF3DIR = 2,
NF3BLK = 3,
NF3CHR = 4,
NF3LNK = 5,
NF3SOCK = 6,
NF3FIFO = 7,
NF3BAD = 8,
};
struct nfs3_sattrargs {
struct nfs_fh *fh;
struct iattr *sattr;
unsigned int guard;
long: 32;
struct timespec64 guardtime;
};
struct nfs3_diropargs {
struct nfs_fh *fh;
const char *name;
unsigned int len;
};
struct nfs3_accessargs {
struct nfs_fh *fh;
__u32 access;
};
struct nfs3_createargs {
struct nfs_fh *fh;
const char *name;
unsigned int len;
struct iattr *sattr;
enum nfs3_createmode createmode;
__be32 verifier[2];
};
struct nfs3_mkdirargs {
struct nfs_fh *fh;
const char *name;
unsigned int len;
struct iattr *sattr;
};
struct nfs3_symlinkargs {
struct nfs_fh *fromfh;
const char *fromname;
unsigned int fromlen;
struct page **pages;
unsigned int pathlen;
struct iattr *sattr;
};
struct nfs3_mknodargs {
struct nfs_fh *fh;
const char *name;
unsigned int len;
enum nfs3_ftype type;
struct iattr *sattr;
dev_t rdev;
};
struct nfs3_linkargs {
struct nfs_fh *fromfh;
struct nfs_fh *tofh;
const char *toname;
unsigned int tolen;
};
struct nfs3_readdirargs {
struct nfs_fh *fh;
long: 32;
__u64 cookie;
__be32 verf[2];
bool plus;
unsigned int count;
struct page **pages;
long: 32;
};
struct nfs3_diropres {
struct nfs_fattr *dir_attr;
struct nfs_fh *fh;
struct nfs_fattr *fattr;
};
struct nfs3_accessres {
struct nfs_fattr *fattr;
__u32 access;
};
struct nfs3_readlinkargs {
struct nfs_fh *fh;
unsigned int pgbase;
unsigned int pglen;
struct page **pages;
};
struct nfs3_linkres {
struct nfs_fattr *dir_attr;
struct nfs_fattr *fattr;
};
struct nfs3_readdirres {
struct nfs_fattr *dir_attr;
__be32 *verf;
bool plus;
};
struct nfs_iostats {
long long unsigned int bytes[8];
long unsigned int events[27];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct nfs_inode {
__u64 fileid;
struct nfs_fh fh;
long unsigned int flags;
long unsigned int cache_validity;
long unsigned int read_cache_jiffies;
long unsigned int attrtimeo;
long unsigned int attrtimeo_timestamp;
long unsigned int attr_gencount;
struct rb_root access_cache;
struct list_head access_cache_entry_lru;
struct list_head access_cache_inode_lru;
union {
struct {
long unsigned int cache_change_attribute;
__be32 cookieverf[2];
struct rw_semaphore rmdir_sem;
};
struct {
atomic_long_t nrequests;
atomic_long_t redirtied_pages;
struct nfs_mds_commit_info commit_info;
struct mutex commit_mutex;
};
};
struct list_head open_files;
__u64 write_io;
__u64 read_io;
struct inode vfs_inode;
};
enum nfs_stat_bytecounters {
NFSIOS_NORMALREADBYTES = 0,
NFSIOS_NORMALWRITTENBYTES = 1,
NFSIOS_DIRECTREADBYTES = 2,
NFSIOS_DIRECTWRITTENBYTES = 3,
NFSIOS_SERVERREADBYTES = 4,
NFSIOS_SERVERWRITTENBYTES = 5,
NFSIOS_READPAGES = 6,
NFSIOS_WRITEPAGES = 7,
__NFSIOS_BYTESMAX = 8,
};
enum nfs_stat_eventcounters {
NFSIOS_INODEREVALIDATE = 0,
NFSIOS_DENTRYREVALIDATE = 1,
NFSIOS_DATAINVALIDATE = 2,
NFSIOS_ATTRINVALIDATE = 3,
NFSIOS_VFSOPEN = 4,
NFSIOS_VFSLOOKUP = 5,
NFSIOS_VFSACCESS = 6,
NFSIOS_VFSUPDATEPAGE = 7,
NFSIOS_VFSREADPAGE = 8,
NFSIOS_VFSREADPAGES = 9,
NFSIOS_VFSWRITEPAGE = 10,
NFSIOS_VFSWRITEPAGES = 11,
NFSIOS_VFSGETDENTS = 12,
NFSIOS_VFSSETATTR = 13,
NFSIOS_VFSFLUSH = 14,
NFSIOS_VFSFSYNC = 15,
NFSIOS_VFSLOCK = 16,
NFSIOS_VFSRELEASE = 17,
NFSIOS_CONGESTIONWAIT = 18,
NFSIOS_SETATTRTRUNC = 19,
NFSIOS_EXTENDWRITE = 20,
NFSIOS_SILLYRENAME = 21,
NFSIOS_SHORTREAD = 22,
NFSIOS_SHORTWRITE = 23,
NFSIOS_DELAY = 24,
NFSIOS_PNFS_READ = 25,
NFSIOS_PNFS_WRITE = 26,
__NFSIOS_COUNTSMAX = 27,
};
struct nfs3_createdata {
struct rpc_message msg;
union {
struct nfs3_createargs create;
struct nfs3_mkdirargs mkdir;
struct nfs3_symlinkargs symlink;
struct nfs3_mknodargs mknod;
} arg;
struct nfs3_diropres res;
struct nfs_fh fh;
long: 32;
struct nfs_fattr fattr;
struct nfs_fattr dir_attr;
};
struct nlm_share {
struct nlm_share *s_next;
struct nlm_host *s_host;
struct nlm_file *s_file;
struct xdr_netobj s_owner;
u32 s_access;
u32 s_mode;
};
struct msg_msgseg;
struct msg_msg {
struct list_head m_list;
long int m_type;
size_t m_ts;
struct msg_msgseg *next;
void *security;
};
struct msg_msgseg {
struct msg_msgseg *next;
};
struct vfs_cap_data {
__le32 magic_etc;
struct {
__le32 permitted;
__le32 inheritable;
} data[2];
};
struct vfs_ns_cap_data {
__le32 magic_etc;
struct {
__le32 permitted;
__le32 inheritable;
} data[2];
__le32 rootid;
};
struct cpu_vfs_cap_data {
__u32 magic_etc;
kernel_cap_t permitted;
kernel_cap_t inheritable;
kuid_t rootid;
};
struct sembuf {
short unsigned int sem_num;
short int sem_op;
short int sem_flg;
};
enum kernel_load_data_id {
LOADING_UNKNOWN = 0,
LOADING_FIRMWARE = 1,
LOADING_MODULE = 2,
LOADING_KEXEC_IMAGE = 3,
LOADING_KEXEC_INITRAMFS = 4,
LOADING_POLICY = 5,
LOADING_X509_CERTIFICATE = 6,
LOADING_MAX_ID = 7,
};
union security_list_options {
int (*binder_set_context_mgr)(const struct cred *);
int (*binder_transaction)(const struct cred *, const struct cred *);
int (*binder_transfer_binder)(const struct cred *, const struct cred *);
int (*binder_transfer_file)(const struct cred *, const struct cred *, struct file *);
int (*ptrace_access_check)(struct task_struct *, unsigned int);
int (*ptrace_traceme)(struct task_struct *);
int (*capget)(struct task_struct *, kernel_cap_t *, kernel_cap_t *, kernel_cap_t *);
int (*capset)(struct cred *, const struct cred *, const kernel_cap_t *, const kernel_cap_t *, const kernel_cap_t *);
int (*capable)(const struct cred *, struct user_namespace *, int, unsigned int);
int (*quotactl)(int, int, int, struct super_block *);
int (*quota_on)(struct dentry *);
int (*syslog)(int);
int (*settime)(const struct timespec64 *, const struct timezone *);
int (*vm_enough_memory)(struct mm_struct *, long int);
int (*bprm_creds_for_exec)(struct linux_binprm *);
int (*bprm_creds_from_file)(struct linux_binprm *, struct file *);
int (*bprm_check_security)(struct linux_binprm *);
void (*bprm_committing_creds)(struct linux_binprm *);
void (*bprm_committed_creds)(struct linux_binprm *);
int (*fs_context_dup)(struct fs_context *, struct fs_context *);
int (*fs_context_parse_param)(struct fs_context *, struct fs_parameter *);
int (*sb_alloc_security)(struct super_block *);
void (*sb_delete)(struct super_block *);
void (*sb_free_security)(struct super_block *);
void (*sb_free_mnt_opts)(void *);
int (*sb_eat_lsm_opts)(char *, void **);
int (*sb_mnt_opts_compat)(struct super_block *, void *);
int (*sb_remount)(struct super_block *, void *);
int (*sb_kern_mount)(struct super_block *);
int (*sb_show_options)(struct seq_file *, struct super_block *);
int (*sb_statfs)(struct dentry *);
int (*sb_mount)(const char *, const struct path *, const char *, long unsigned int, void *);
int (*sb_umount)(struct vfsmount *, int);
int (*sb_pivotroot)(const struct path *, const struct path *);
int (*sb_set_mnt_opts)(struct super_block *, void *, long unsigned int, long unsigned int *);
int (*sb_clone_mnt_opts)(const struct super_block *, struct super_block *, long unsigned int, long unsigned int *);
int (*move_mount)(const struct path *, const struct path *);
int (*dentry_init_security)(struct dentry *, int, const struct qstr *, const char **, void **, u32 *);
int (*dentry_create_files_as)(struct dentry *, int, struct qstr *, const struct cred *, struct cred *);
int (*path_notify)(const struct path *, u64, unsigned int);
int (*inode_alloc_security)(struct inode *);
void (*inode_free_security)(struct inode *);
int (*inode_init_security)(struct inode *, struct inode *, const struct qstr *, const char **, void **, size_t *);
int (*inode_init_security_anon)(struct inode *, const struct qstr *, const struct inode *);
int (*inode_create)(struct inode *, struct dentry *, umode_t);
int (*inode_link)(struct dentry *, struct inode *, struct dentry *);
int (*inode_unlink)(struct inode *, struct dentry *);
int (*inode_symlink)(struct inode *, struct dentry *, const char *);
int (*inode_mkdir)(struct inode *, struct dentry *, umode_t);
int (*inode_rmdir)(struct inode *, struct dentry *);
int (*inode_mknod)(struct inode *, struct dentry *, umode_t, dev_t);
int (*inode_rename)(struct inode *, struct dentry *, struct inode *, struct dentry *);
int (*inode_readlink)(struct dentry *);
int (*inode_follow_link)(struct dentry *, struct inode *, bool);
int (*inode_permission)(struct inode *, int);
int (*inode_setattr)(struct dentry *, struct iattr *);
int (*inode_getattr)(const struct path *);
int (*inode_setxattr)(struct user_namespace *, struct dentry *, const char *, const void *, size_t, int);
void (*inode_post_setxattr)(struct dentry *, const char *, const void *, size_t, int);
int (*inode_getxattr)(struct dentry *, const char *);
int (*inode_listxattr)(struct dentry *);
int (*inode_removexattr)(struct user_namespace *, struct dentry *, const char *);
int (*inode_need_killpriv)(struct dentry *);
int (*inode_killpriv)(struct user_namespace *, struct dentry *);
int (*inode_getsecurity)(struct user_namespace *, struct inode *, const char *, void **, bool);
int (*inode_setsecurity)(struct inode *, const char *, const void *, size_t, int);
int (*inode_listsecurity)(struct inode *, char *, size_t);
void (*inode_getsecid)(struct inode *, u32 *);
int (*inode_copy_up)(struct dentry *, struct cred **);
int (*inode_copy_up_xattr)(const char *);
int (*kernfs_init_security)(struct kernfs_node *, struct kernfs_node *);
int (*file_permission)(struct file *, int);
int (*file_alloc_security)(struct file *);
void (*file_free_security)(struct file *);
int (*file_ioctl)(struct file *, unsigned int, long unsigned int);
int (*mmap_addr)(long unsigned int);
int (*mmap_file)(struct file *, long unsigned int, long unsigned int, long unsigned int);
int (*file_mprotect)(struct vm_area_struct *, long unsigned int, long unsigned int);
int (*file_lock)(struct file *, unsigned int);
int (*file_fcntl)(struct file *, unsigned int, long unsigned int);
void (*file_set_fowner)(struct file *);
int (*file_send_sigiotask)(struct task_struct *, struct fown_struct *, int);
int (*file_receive)(struct file *);
int (*file_open)(struct file *);
int (*task_alloc)(struct task_struct *, long unsigned int);
void (*task_free)(struct task_struct *);
int (*cred_alloc_blank)(struct cred *, gfp_t);
void (*cred_free)(struct cred *);
int (*cred_prepare)(struct cred *, const struct cred *, gfp_t);
void (*cred_transfer)(struct cred *, const struct cred *);
void (*cred_getsecid)(const struct cred *, u32 *);
int (*kernel_act_as)(struct cred *, u32);
int (*kernel_create_files_as)(struct cred *, struct inode *);
int (*kernel_module_request)(char *);
int (*kernel_load_data)(enum kernel_load_data_id, bool);
int (*kernel_post_load_data)(char *, loff_t, enum kernel_load_data_id, char *);
int (*kernel_read_file)(struct file *, enum kernel_read_file_id, bool);
int (*kernel_post_read_file)(struct file *, char *, loff_t, enum kernel_read_file_id);
int (*task_fix_setuid)(struct cred *, const struct cred *, int);
int (*task_fix_setgid)(struct cred *, const struct cred *, int);
int (*task_fix_setgroups)(struct cred *, const struct cred *);
int (*task_setpgid)(struct task_struct *, pid_t);
int (*task_getpgid)(struct task_struct *);
int (*task_getsid)(struct task_struct *);
void (*current_getsecid_subj)(u32 *);
void (*task_getsecid_obj)(struct task_struct *, u32 *);
int (*task_setnice)(struct task_struct *, int);
int (*task_setioprio)(struct task_struct *, int);
int (*task_getioprio)(struct task_struct *);
int (*task_prlimit)(const struct cred *, const struct cred *, unsigned int);
int (*task_setrlimit)(struct task_struct *, unsigned int, struct rlimit *);
int (*task_setscheduler)(struct task_struct *);
int (*task_getscheduler)(struct task_struct *);
int (*task_movememory)(struct task_struct *);
int (*task_kill)(struct task_struct *, struct kernel_siginfo *, int, const struct cred *);
int (*task_prctl)(int, long unsigned int, long unsigned int, long unsigned int, long unsigned int);
void (*task_to_inode)(struct task_struct *, struct inode *);
int (*userns_create)(const struct cred *);
int (*ipc_permission)(struct kern_ipc_perm *, short int);
void (*ipc_getsecid)(struct kern_ipc_perm *, u32 *);
int (*msg_msg_alloc_security)(struct msg_msg *);
void (*msg_msg_free_security)(struct msg_msg *);
int (*msg_queue_alloc_security)(struct kern_ipc_perm *);
void (*msg_queue_free_security)(struct kern_ipc_perm *);
int (*msg_queue_associate)(struct kern_ipc_perm *, int);
int (*msg_queue_msgctl)(struct kern_ipc_perm *, int);
int (*msg_queue_msgsnd)(struct kern_ipc_perm *, struct msg_msg *, int);
int (*msg_queue_msgrcv)(struct kern_ipc_perm *, struct msg_msg *, struct task_struct *, long int, int);
int (*shm_alloc_security)(struct kern_ipc_perm *);
void (*shm_free_security)(struct kern_ipc_perm *);
int (*shm_associate)(struct kern_ipc_perm *, int);
int (*shm_shmctl)(struct kern_ipc_perm *, int);
int (*shm_shmat)(struct kern_ipc_perm *, char *, int);
int (*sem_alloc_security)(struct kern_ipc_perm *);
void (*sem_free_security)(struct kern_ipc_perm *);
int (*sem_associate)(struct kern_ipc_perm *, int);
int (*sem_semctl)(struct kern_ipc_perm *, int);
int (*sem_semop)(struct kern_ipc_perm *, struct sembuf *, unsigned int, int);
int (*netlink_send)(struct sock *, struct sk_buff *);
void (*d_instantiate)(struct dentry *, struct inode *);
int (*getprocattr)(struct task_struct *, const char *, char **);
int (*setprocattr)(const char *, void *, size_t);
int (*ismaclabel)(const char *);
int (*secid_to_secctx)(u32, char **, u32 *);
int (*secctx_to_secid)(const char *, u32, u32 *);
void (*release_secctx)(char *, u32);
void (*inode_invalidate_secctx)(struct inode *);
int (*inode_notifysecctx)(struct inode *, void *, u32);
int (*inode_setsecctx)(struct dentry *, void *, u32);
int (*inode_getsecctx)(struct inode *, void **, u32 *);
int (*key_alloc)(struct key *, const struct cred *, long unsigned int);
void (*key_free)(struct key *);
int (*key_permission)(key_ref_t, const struct cred *, enum key_need_perm);
int (*key_getsecurity)(struct key *, char **);
int (*bpf)(int, union bpf_attr *, unsigned int);
int (*bpf_map)(struct bpf_map *, fmode_t);
int (*bpf_prog)(struct bpf_prog *);
int (*bpf_map_alloc_security)(struct bpf_map *);
void (*bpf_map_free_security)(struct bpf_map *);
int (*bpf_prog_alloc_security)(struct bpf_prog_aux *);
void (*bpf_prog_free_security)(struct bpf_prog_aux *);
int (*locked_down)(enum lockdown_reason);
int (*perf_event_open)(struct perf_event_attr *, int);
int (*perf_event_alloc)(struct perf_event *);
void (*perf_event_free)(struct perf_event *);
int (*perf_event_read)(struct perf_event *);
int (*perf_event_write)(struct perf_event *);
int (*uring_override_creds)(const struct cred *);
int (*uring_sqpoll)();
int (*uring_cmd)(struct io_uring_cmd *);
};
struct security_hook_heads {
struct hlist_head binder_set_context_mgr;
struct hlist_head binder_transaction;
struct hlist_head binder_transfer_binder;
struct hlist_head binder_transfer_file;
struct hlist_head ptrace_access_check;
struct hlist_head ptrace_traceme;
struct hlist_head capget;
struct hlist_head capset;
struct hlist_head capable;
struct hlist_head quotactl;
struct hlist_head quota_on;
struct hlist_head syslog;
struct hlist_head settime;
struct hlist_head vm_enough_memory;
struct hlist_head bprm_creds_for_exec;
struct hlist_head bprm_creds_from_file;
struct hlist_head bprm_check_security;
struct hlist_head bprm_committing_creds;
struct hlist_head bprm_committed_creds;
struct hlist_head fs_context_dup;
struct hlist_head fs_context_parse_param;
struct hlist_head sb_alloc_security;
struct hlist_head sb_delete;
struct hlist_head sb_free_security;
struct hlist_head sb_free_mnt_opts;
struct hlist_head sb_eat_lsm_opts;
struct hlist_head sb_mnt_opts_compat;
struct hlist_head sb_remount;
struct hlist_head sb_kern_mount;
struct hlist_head sb_show_options;
struct hlist_head sb_statfs;
struct hlist_head sb_mount;
struct hlist_head sb_umount;
struct hlist_head sb_pivotroot;
struct hlist_head sb_set_mnt_opts;
struct hlist_head sb_clone_mnt_opts;
struct hlist_head move_mount;
struct hlist_head dentry_init_security;
struct hlist_head dentry_create_files_as;
struct hlist_head path_notify;
struct hlist_head inode_alloc_security;
struct hlist_head inode_free_security;
struct hlist_head inode_init_security;
struct hlist_head inode_init_security_anon;
struct hlist_head inode_create;
struct hlist_head inode_link;
struct hlist_head inode_unlink;
struct hlist_head inode_symlink;
struct hlist_head inode_mkdir;
struct hlist_head inode_rmdir;
struct hlist_head inode_mknod;
struct hlist_head inode_rename;
struct hlist_head inode_readlink;
struct hlist_head inode_follow_link;
struct hlist_head inode_permission;
struct hlist_head inode_setattr;
struct hlist_head inode_getattr;
struct hlist_head inode_setxattr;
struct hlist_head inode_post_setxattr;
struct hlist_head inode_getxattr;
struct hlist_head inode_listxattr;
struct hlist_head inode_removexattr;
struct hlist_head inode_need_killpriv;
struct hlist_head inode_killpriv;
struct hlist_head inode_getsecurity;
struct hlist_head inode_setsecurity;
struct hlist_head inode_listsecurity;
struct hlist_head inode_getsecid;
struct hlist_head inode_copy_up;
struct hlist_head inode_copy_up_xattr;
struct hlist_head kernfs_init_security;
struct hlist_head file_permission;
struct hlist_head file_alloc_security;
struct hlist_head file_free_security;
struct hlist_head file_ioctl;
struct hlist_head mmap_addr;
struct hlist_head mmap_file;
struct hlist_head file_mprotect;
struct hlist_head file_lock;
struct hlist_head file_fcntl;
struct hlist_head file_set_fowner;
struct hlist_head file_send_sigiotask;
struct hlist_head file_receive;
struct hlist_head file_open;
struct hlist_head task_alloc;
struct hlist_head task_free;
struct hlist_head cred_alloc_blank;
struct hlist_head cred_free;
struct hlist_head cred_prepare;
struct hlist_head cred_transfer;
struct hlist_head cred_getsecid;
struct hlist_head kernel_act_as;
struct hlist_head kernel_create_files_as;
struct hlist_head kernel_module_request;
struct hlist_head kernel_load_data;
struct hlist_head kernel_post_load_data;
struct hlist_head kernel_read_file;
struct hlist_head kernel_post_read_file;
struct hlist_head task_fix_setuid;
struct hlist_head task_fix_setgid;
struct hlist_head task_fix_setgroups;
struct hlist_head task_setpgid;
struct hlist_head task_getpgid;
struct hlist_head task_getsid;
struct hlist_head current_getsecid_subj;
struct hlist_head task_getsecid_obj;
struct hlist_head task_setnice;
struct hlist_head task_setioprio;
struct hlist_head task_getioprio;
struct hlist_head task_prlimit;
struct hlist_head task_setrlimit;
struct hlist_head task_setscheduler;
struct hlist_head task_getscheduler;
struct hlist_head task_movememory;
struct hlist_head task_kill;
struct hlist_head task_prctl;
struct hlist_head task_to_inode;
struct hlist_head userns_create;
struct hlist_head ipc_permission;
struct hlist_head ipc_getsecid;
struct hlist_head msg_msg_alloc_security;
struct hlist_head msg_msg_free_security;
struct hlist_head msg_queue_alloc_security;
struct hlist_head msg_queue_free_security;
struct hlist_head msg_queue_associate;
struct hlist_head msg_queue_msgctl;
struct hlist_head msg_queue_msgsnd;
struct hlist_head msg_queue_msgrcv;
struct hlist_head shm_alloc_security;
struct hlist_head shm_free_security;
struct hlist_head shm_associate;
struct hlist_head shm_shmctl;
struct hlist_head shm_shmat;
struct hlist_head sem_alloc_security;
struct hlist_head sem_free_security;
struct hlist_head sem_associate;
struct hlist_head sem_semctl;
struct hlist_head sem_semop;
struct hlist_head netlink_send;
struct hlist_head d_instantiate;
struct hlist_head getprocattr;
struct hlist_head setprocattr;
struct hlist_head ismaclabel;
struct hlist_head secid_to_secctx;
struct hlist_head secctx_to_secid;
struct hlist_head release_secctx;
struct hlist_head inode_invalidate_secctx;
struct hlist_head inode_notifysecctx;
struct hlist_head inode_setsecctx;
struct hlist_head inode_getsecctx;
struct hlist_head key_alloc;
struct hlist_head key_free;
struct hlist_head key_permission;
struct hlist_head key_getsecurity;
struct hlist_head bpf;
struct hlist_head bpf_map;
struct hlist_head bpf_prog;
struct hlist_head bpf_map_alloc_security;
struct hlist_head bpf_map_free_security;
struct hlist_head bpf_prog_alloc_security;
struct hlist_head bpf_prog_free_security;
struct hlist_head locked_down;
struct hlist_head perf_event_open;
struct hlist_head perf_event_alloc;
struct hlist_head perf_event_free;
struct hlist_head perf_event_read;
struct hlist_head perf_event_write;
struct hlist_head uring_override_creds;
struct hlist_head uring_sqpoll;
struct hlist_head uring_cmd;
};
struct security_hook_list {
struct hlist_node list;
struct hlist_head *head;
union security_list_options hook;
const char *lsm;
};
struct shash_instance {
void (*free)(struct shash_instance *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
union {
struct {
char head[256];
struct crypto_instance base;
} s;
struct shash_alg alg;
};
};
struct crypto_shash_spawn {
struct crypto_spawn base;
};
struct hmac_ctx {
struct crypto_shash *hash;
};
struct fat_boot_sector {
__u8 ignored[3];
__u8 system_id[8];
__u8 sector_size[2];
__u8 sec_per_clus;
__le16 reserved;
__u8 fats;
__u8 dir_entries[2];
__u8 sectors[2];
__u8 media;
__le16 fat_length;
__le16 secs_track;
__le16 heads;
__le32 hidden;
__le32 total_sect;
union {
struct {
__u8 drive_number;
__u8 state;
__u8 signature;
__u8 vol_id[4];
__u8 vol_label[11];
__u8 fs_type[8];
} fat16;
struct {
__le32 length;
__le16 flags;
__u8 version[2];
__le32 root_cluster;
__le16 info_sector;
__le16 backup_boot;
__le16 reserved2[6];
__u8 drive_number;
__u8 state;
__u8 signature;
__u8 vol_id[4];
__u8 vol_label[11];
__u8 fs_type[8];
} fat32;
};
};
struct msdos_partition {
u8 boot_ind;
u8 head;
u8 sector;
u8 cyl;
u8 sys_ind;
u8 end_head;
u8 end_sector;
u8 end_cyl;
__le32 start_sect;
__le32 nr_sects;
};
enum msdos_sys_ind {
DOS_EXTENDED_PARTITION = 5,
LINUX_EXTENDED_PARTITION = 133,
WIN98_EXTENDED_PARTITION = 15,
LINUX_DATA_PARTITION = 131,
LINUX_LVM_PARTITION = 142,
LINUX_RAID_PARTITION = 253,
SOLARIS_X86_PARTITION = 130,
NEW_SOLARIS_X86_PARTITION = 191,
DM6_AUX1PARTITION = 81,
DM6_AUX3PARTITION = 83,
DM6_PARTITION = 84,
EZD_PARTITION = 85,
FREEBSD_PARTITION = 165,
OPENBSD_PARTITION = 166,
NETBSD_PARTITION = 169,
BSDI_PARTITION = 183,
MINIX_PARTITION = 129,
UNIXWARE_PARTITION = 99,
};
struct parsed_partitions {
struct gendisk *disk;
char name[32];
struct {
sector_t from;
sector_t size;
int flags;
bool has_info;
struct partition_meta_info info;
long: 32;
} *parts;
int next;
int limit;
bool access_beyond_eod;
char *pp_buf;
};
typedef struct {
struct folio *v;
} Sector;
struct io_splice {
struct file *file_out;
long: 32;
loff_t off_out;
loff_t off_in;
u64 len;
int splice_fd_in;
unsigned int flags;
};
enum io_uring_op {
IORING_OP_NOP = 0,
IORING_OP_READV = 1,
IORING_OP_WRITEV = 2,
IORING_OP_FSYNC = 3,
IORING_OP_READ_FIXED = 4,
IORING_OP_WRITE_FIXED = 5,
IORING_OP_POLL_ADD = 6,
IORING_OP_POLL_REMOVE = 7,
IORING_OP_SYNC_FILE_RANGE = 8,
IORING_OP_SENDMSG = 9,
IORING_OP_RECVMSG = 10,
IORING_OP_TIMEOUT = 11,
IORING_OP_TIMEOUT_REMOVE = 12,
IORING_OP_ACCEPT = 13,
IORING_OP_ASYNC_CANCEL = 14,
IORING_OP_LINK_TIMEOUT = 15,
IORING_OP_CONNECT = 16,
IORING_OP_FALLOCATE = 17,
IORING_OP_OPENAT = 18,
IORING_OP_CLOSE = 19,
IORING_OP_FILES_UPDATE = 20,
IORING_OP_STATX = 21,
IORING_OP_READ = 22,
IORING_OP_WRITE = 23,
IORING_OP_FADVISE = 24,
IORING_OP_MADVISE = 25,
IORING_OP_SEND = 26,
IORING_OP_RECV = 27,
IORING_OP_OPENAT2 = 28,
IORING_OP_EPOLL_CTL = 29,
IORING_OP_SPLICE = 30,
IORING_OP_PROVIDE_BUFFERS = 31,
IORING_OP_REMOVE_BUFFERS = 32,
IORING_OP_TEE = 33,
IORING_OP_SHUTDOWN = 34,
IORING_OP_RENAMEAT = 35,
IORING_OP_UNLINKAT = 36,
IORING_OP_MKDIRAT = 37,
IORING_OP_SYMLINKAT = 38,
IORING_OP_LINKAT = 39,
IORING_OP_MSG_RING = 40,
IORING_OP_FSETXATTR = 41,
IORING_OP_SETXATTR = 42,
IORING_OP_FGETXATTR = 43,
IORING_OP_GETXATTR = 44,
IORING_OP_SOCKET = 45,
IORING_OP_URING_CMD = 46,
IORING_OP_SEND_ZC = 47,
IORING_OP_SENDMSG_ZC = 48,
IORING_OP_LAST = 49,
};
enum {
SKBFL_ZEROCOPY_ENABLE = 1,
SKBFL_SHARED_FRAG = 2,
SKBFL_PURE_ZEROCOPY = 4,
SKBFL_DONT_ORPHAN = 8,
SKBFL_MANAGED_FRAG_REFS = 16,
};
struct io_notif_data {
struct file *file;
struct ubuf_info uarg;
long unsigned int account_pages;
};
struct assoc_array_ops {
long unsigned int (*get_key_chunk)(const void *, int);
long unsigned int (*get_object_key_chunk)(const void *, int);
bool (*compare_object)(const void *, const void *);
int (*diff_objects)(const void *, const void *);
void (*free_object)(void *);
};
struct assoc_array_node {
struct assoc_array_ptr *back_pointer;
u8 parent_slot;
struct assoc_array_ptr *slots[16];
long unsigned int nr_leaves_on_branch;
};
struct assoc_array_shortcut {
struct assoc_array_ptr *back_pointer;
int parent_slot;
int skip_to_level;
struct assoc_array_ptr *next_node;
long unsigned int index_key[0];
};
struct assoc_array_edit {
struct callback_head rcu;
struct assoc_array *array;
const struct assoc_array_ops *ops;
const struct assoc_array_ops *ops_for_excised_subtree;
struct assoc_array_ptr *leaf;
struct assoc_array_ptr **leaf_p;
struct assoc_array_ptr *dead_leaf;
struct assoc_array_ptr *new_meta[3];
struct assoc_array_ptr *excised_meta[1];
struct assoc_array_ptr *excised_subtree;
struct assoc_array_ptr **set_backpointers[16];
struct assoc_array_ptr *set_backpointers_to;
struct assoc_array_node *adjust_count_on;
long int adjust_count_by;
struct {
struct assoc_array_ptr **ptr;
struct assoc_array_ptr *to;
} set[2];
struct {
u8 *p;
u8 to;
} set_parent_slot[1];
u8 segment_cache[17];
};
enum assoc_array_walk_status {
assoc_array_walk_tree_empty = 0,
assoc_array_walk_found_terminal_node = 1,
assoc_array_walk_found_wrong_shortcut = 2,
};
struct assoc_array_walk_result {
struct {
struct assoc_array_node *node;
int level;
int slot;
} terminal_node;
struct {
struct assoc_array_shortcut *shortcut;
int level;
int sc_level;
long unsigned int sc_segments;
long unsigned int dissimilarity;
} wrong_shortcut;
};
struct assoc_array_delete_collapse_context {
struct assoc_array_node *node;
const void *skip_leaf;
int slot;
};
typedef struct {
unsigned char op;
unsigned char bits;
short unsigned int val;
} code;
typedef enum {
HEAD = 0,
FLAGS = 1,
TIME = 2,
OS = 3,
EXLEN = 4,
EXTRA = 5,
NAME = 6,
COMMENT = 7,
HCRC = 8,
DICTID = 9,
DICT = 10,
TYPE = 11,
TYPEDO = 12,
STORED = 13,
COPY = 14,
TABLE = 15,
LENLENS = 16,
CODELENS = 17,
LEN = 18,
LENEXT = 19,
DIST = 20,
DISTEXT = 21,
MATCH = 22,
LIT = 23,
CHECK = 24,
LENGTH = 25,
DONE = 26,
BAD = 27,
MEM = 28,
SYNC = 29,
} inflate_mode;
struct inflate_state {
inflate_mode mode;
int last;
int wrap;
int havedict;
int flags;
unsigned int dmax;
long unsigned int check;
long unsigned int total;
unsigned int wbits;
unsigned int wsize;
unsigned int whave;
unsigned int write;
unsigned char *window;
long unsigned int hold;
unsigned int bits;
unsigned int length;
unsigned int offset;
unsigned int extra;
const code *lencode;
const code *distcode;
unsigned int lenbits;
unsigned int distbits;
unsigned int ncode;
unsigned int nlen;
unsigned int ndist;
unsigned int have;
code *next;
short unsigned int lens[320];
short unsigned int work[288];
code codes[2048];
};
union uu {
short unsigned int us;
unsigned char b[2];
};
typedef enum {
CODES = 0,
LENS = 1,
DISTS = 2,
} codetype;
struct cpu_rmap {
struct kref refcount;
u16 size;
u16 used;
void **obj;
struct {
u16 index;
u16 dist;
} near[0];
};
struct irq_glue {
struct irq_affinity_notify notify;
struct cpu_rmap *rmap;
u16 index;
};
typedef int word_type;
struct DWstruct {
int low;
int high;
};
typedef union {
struct DWstruct s;
long long int ll;
} DWunion;
enum {
pci_channel_io_normal = 1,
pci_channel_io_frozen = 2,
pci_channel_io_perm_failure = 3,
};
struct pcie_link_state {
struct pci_dev *pdev;
struct pci_dev *downstream;
struct pcie_link_state *root;
struct pcie_link_state *parent;
struct list_head sibling;
u32 aspm_support: 7;
u32 aspm_enabled: 7;
u32 aspm_capable: 7;
u32 aspm_default: 7;
long: 4;
u32 aspm_disable: 7;
u32 clkpm_capable: 1;
u32 clkpm_enabled: 1;
u32 clkpm_default: 1;
u32 clkpm_disable: 1;
};
struct fb_fix_screeninfo {
char id[16];
long unsigned int smem_start;
__u32 smem_len;
__u32 type;
__u32 type_aux;
__u32 visual;
__u16 xpanstep;
__u16 ypanstep;
__u16 ywrapstep;
__u32 line_length;
long unsigned int mmio_start;
__u32 mmio_len;
__u32 accel;
__u16 capabilities;
__u16 reserved[2];
};
struct fb_bitfield {
__u32 offset;
__u32 length;
__u32 msb_right;
};
struct fb_var_screeninfo {
__u32 xres;
__u32 yres;
__u32 xres_virtual;
__u32 yres_virtual;
__u32 xoffset;
__u32 yoffset;
__u32 bits_per_pixel;
__u32 grayscale;
struct fb_bitfield red;
struct fb_bitfield green;
struct fb_bitfield blue;
struct fb_bitfield transp;
__u32 nonstd;
__u32 activate;
__u32 height;
__u32 width;
__u32 accel_flags;
__u32 pixclock;
__u32 left_margin;
__u32 right_margin;
__u32 upper_margin;
__u32 lower_margin;
__u32 hsync_len;
__u32 vsync_len;
__u32 sync;
__u32 vmode;
__u32 rotate;
__u32 colorspace;
__u32 reserved[4];
};
struct fb_cmap {
__u32 start;
__u32 len;
__u16 *red;
__u16 *green;
__u16 *blue;
__u16 *transp;
};
struct fb_copyarea {
__u32 dx;
__u32 dy;
__u32 width;
__u32 height;
__u32 sx;
__u32 sy;
};
struct fb_fillrect {
__u32 dx;
__u32 dy;
__u32 width;
__u32 height;
__u32 color;
__u32 rop;
};
struct fb_image {
__u32 dx;
__u32 dy;
__u32 width;
__u32 height;
__u32 fg_color;
__u32 bg_color;
__u8 depth;
const char *data;
struct fb_cmap cmap;
};
struct fbcurpos {
__u16 x;
__u16 y;
};
struct fb_cursor {
__u16 set;
__u16 enable;
__u16 rop;
const char *mask;
struct fbcurpos hot;
struct fb_image image;
};
struct fb_chroma {
__u32 redx;
__u32 greenx;
__u32 bluex;
__u32 whitex;
__u32 redy;
__u32 greeny;
__u32 bluey;
__u32 whitey;
};
struct fb_monspecs {
struct fb_chroma chroma;
struct fb_videomode *modedb;
__u8 manufacturer[4];
__u8 monitor[14];
__u8 serial_no[14];
__u8 ascii[14];
__u32 modedb_len;
__u32 model;
__u32 serial;
__u32 year;
__u32 week;
__u32 hfmin;
__u32 hfmax;
__u32 dclkmin;
__u32 dclkmax;
__u16 input;
__u16 dpms;
__u16 signal;
__u16 vfmin;
__u16 vfmax;
__u16 gamma;
__u16 gtf: 1;
__u16 misc;
__u8 version;
__u8 revision;
__u8 max_x;
__u8 max_y;
};
struct fb_info;
struct fb_pixmap {
u8 *addr;
u32 size;
u32 offset;
u32 buf_align;
u32 scan_align;
u32 access_align;
u32 flags;
u32 blit_x;
u32 blit_y;
void (*writeio)(struct fb_info *, void *, void *, unsigned int);
void (*readio)(struct fb_info *, void *, void *, unsigned int);
};
struct fb_ops;
struct apertures_struct;
struct fb_info {
refcount_t count;
int node;
int flags;
int fbcon_rotate_hint;
struct mutex lock;
struct mutex mm_lock;
struct fb_var_screeninfo var;
struct fb_fix_screeninfo fix;
struct fb_monspecs monspecs;
struct fb_pixmap pixmap;
struct fb_pixmap sprite;
struct fb_cmap cmap;
struct list_head modelist;
struct fb_videomode *mode;
const struct fb_ops *fbops;
struct device *device;
struct device *dev;
int class_flag;
union {
char *screen_base;
char *screen_buffer;
};
long unsigned int screen_size;
void *pseudo_palette;
u32 state;
void *fbcon_par;
void *par;
struct apertures_struct *apertures;
bool skip_vt_switch;
};
struct fb_blit_caps {
u32 x;
u32 y;
u32 len;
u32 flags;
};
struct fb_ops {
struct module *owner;
int (*fb_open)(struct fb_info *, int);
int (*fb_release)(struct fb_info *, int);
ssize_t (*fb_read)(struct fb_info *, char *, size_t, loff_t *);
ssize_t (*fb_write)(struct fb_info *, const char *, size_t, loff_t *);
int (*fb_check_var)(struct fb_var_screeninfo *, struct fb_info *);
int (*fb_set_par)(struct fb_info *);
int (*fb_setcolreg)(unsigned int, unsigned int, unsigned int, unsigned int, unsigned int, struct fb_info *);
int (*fb_setcmap)(struct fb_cmap *, struct fb_info *);
int (*fb_blank)(int, struct fb_info *);
int (*fb_pan_display)(struct fb_var_screeninfo *, struct fb_info *);
void (*fb_fillrect)(struct fb_info *, const struct fb_fillrect *);
void (*fb_copyarea)(struct fb_info *, const struct fb_copyarea *);
void (*fb_imageblit)(struct fb_info *, const struct fb_image *);
int (*fb_cursor)(struct fb_info *, struct fb_cursor *);
int (*fb_sync)(struct fb_info *);
int (*fb_ioctl)(struct fb_info *, unsigned int, long unsigned int);
int (*fb_compat_ioctl)(struct fb_info *, unsigned int, long unsigned int);
int (*fb_mmap)(struct fb_info *, struct vm_area_struct *);
void (*fb_get_caps)(struct fb_info *, struct fb_blit_caps *, struct fb_var_screeninfo *);
void (*fb_destroy)(struct fb_info *);
int (*fb_debug_enter)(struct fb_info *);
int (*fb_debug_leave)(struct fb_info *);
};
struct aperture {
resource_size_t base;
resource_size_t size;
};
struct apertures_struct {
unsigned int count;
struct aperture ranges[0];
};
struct vcs_poll_data {
struct notifier_block notifier;
unsigned int cons_num;
int event;
wait_queue_head_t waitq;
struct fasync_struct *fasync;
};
struct timer_rand_state {
long unsigned int last_time;
long int last_delta;
long int last_delta2;
};
enum chacha_constants {
CHACHA_CONSTANT_EXPA = 1634760805,
CHACHA_CONSTANT_ND_3 = 857760878,
CHACHA_CONSTANT_2_BY = 2036477234,
CHACHA_CONSTANT_TE_K = 1797285236,
};
enum {
CRNG_EMPTY = 0,
CRNG_EARLY = 1,
CRNG_READY = 2,
};
enum {
CRNG_RESEED_START_INTERVAL = 100,
CRNG_RESEED_INTERVAL = 6000,
};
struct crng {
u8 key[32];
long unsigned int generation;
local_lock_t lock;
};
struct batch_u8 {
u8 entropy[96];
local_lock_t lock;
long unsigned int generation;
unsigned int position;
};
struct batch_u16 {
u16 entropy[48];
local_lock_t lock;
long unsigned int generation;
unsigned int position;
};
struct batch_u32 {
u32 entropy[24];
local_lock_t lock;
long unsigned int generation;
unsigned int position;
};
struct batch_u64 {
u64 entropy[12];
local_lock_t lock;
long unsigned int generation;
unsigned int position;
};
enum {
POOL_BITS = 256,
POOL_READY_BITS = 256,
POOL_EARLY_BITS = 128,
};
struct fast_pool {
long unsigned int pool[4];
long unsigned int last;
unsigned int count;
struct timer_list mix;
};
struct entropy_timer_state {
long unsigned int entropy;
struct timer_list timer;
unsigned int samples;
unsigned int samples_per_bit;
};
enum {
NUM_TRIAL_SAMPLES = 8192,
MAX_SAMPLES_PER_BIT = 6,
};
enum {
MIX_INFLIGHT = 2147483648,
};
struct reg_sequence {
unsigned int reg;
unsigned int def;
unsigned int delay_us;
};
typedef int (*regmap_hw_write)(void *, const void *, size_t);
typedef int (*regmap_hw_gather_write)(void *, const void *, size_t, const void *, size_t);
struct regmap_async;
typedef int (*regmap_hw_async_write)(void *, const void *, size_t, const void *, size_t, struct regmap_async *);
struct regmap_async {
struct list_head list;
struct regmap *map;
void *work_buf;
};
typedef int (*regmap_hw_read)(void *, const void *, size_t, void *, size_t);
typedef int (*regmap_hw_reg_read)(void *, unsigned int, unsigned int *);
typedef int (*regmap_hw_reg_noinc_read)(void *, unsigned int, void *, size_t);
typedef int (*regmap_hw_reg_write)(void *, unsigned int, unsigned int);
typedef int (*regmap_hw_reg_noinc_write)(void *, unsigned int, const void *, size_t);
typedef int (*regmap_hw_reg_update_bits)(void *, unsigned int, unsigned int, unsigned int);
typedef struct regmap_async * (*regmap_hw_async_alloc)();
typedef void (*regmap_hw_free_context)(void *);
struct regmap_bus {
bool fast_io;
regmap_hw_write write;
regmap_hw_gather_write gather_write;
regmap_hw_async_write async_write;
regmap_hw_reg_write reg_write;
regmap_hw_reg_noinc_write reg_noinc_write;
regmap_hw_reg_update_bits reg_update_bits;
regmap_hw_read read;
regmap_hw_reg_read reg_read;
regmap_hw_reg_noinc_read reg_noinc_read;
regmap_hw_free_context free_context;
regmap_hw_async_alloc async_alloc;
u8 read_flag_mask;
enum regmap_endian reg_format_endian_default;
enum regmap_endian val_format_endian_default;
size_t max_raw_read;
size_t max_raw_write;
bool free_on_exit;
};
struct regmap_format {
size_t buf_size;
size_t reg_bytes;
size_t pad_bytes;
size_t reg_downshift;
size_t val_bytes;
void (*format_write)(struct regmap *, unsigned int, unsigned int);
void (*format_reg)(void *, unsigned int, unsigned int);
void (*format_val)(void *, unsigned int, unsigned int);
unsigned int (*parse_val)(const void *);
void (*parse_inplace)(void *);
};
struct hwspinlock;
struct regcache_ops;
struct regmap {
union {
struct mutex mutex;
struct {
spinlock_t spinlock;
long unsigned int spinlock_flags;
};
struct {
raw_spinlock_t raw_spinlock;
long unsigned int raw_spinlock_flags;
};
};
regmap_lock lock;
regmap_unlock unlock;
void *lock_arg;
gfp_t alloc_flags;
unsigned int reg_base;
struct device *dev;
void *work_buf;
struct regmap_format format;
const struct regmap_bus *bus;
void *bus_context;
const char *name;
bool async;
spinlock_t async_lock;
wait_queue_head_t async_waitq;
struct list_head async_list;
struct list_head async_free;
int async_ret;
bool debugfs_disable;
struct dentry *debugfs;
const char *debugfs_name;
unsigned int debugfs_reg_len;
unsigned int debugfs_val_len;
unsigned int debugfs_tot_len;
struct list_head debugfs_off_cache;
struct mutex cache_lock;
unsigned int max_register;
bool (*writeable_reg)(struct device *, unsigned int);
bool (*readable_reg)(struct device *, unsigned int);
bool (*volatile_reg)(struct device *, unsigned int);
bool (*precious_reg)(struct device *, unsigned int);
bool (*writeable_noinc_reg)(struct device *, unsigned int);
bool (*readable_noinc_reg)(struct device *, unsigned int);
const struct regmap_access_table *wr_table;
const struct regmap_access_table *rd_table;
const struct regmap_access_table *volatile_table;
const struct regmap_access_table *precious_table;
const struct regmap_access_table *wr_noinc_table;
const struct regmap_access_table *rd_noinc_table;
int (*reg_read)(void *, unsigned int, unsigned int *);
int (*reg_write)(void *, unsigned int, unsigned int);
int (*reg_update_bits)(void *, unsigned int, unsigned int, unsigned int);
int (*read)(void *, const void *, size_t, void *, size_t);
int (*write)(void *, const void *, size_t);
bool defer_caching;
long unsigned int read_flag_mask;
long unsigned int write_flag_mask;
int reg_shift;
int reg_stride;
int reg_stride_order;
const struct regcache_ops *cache_ops;
enum regcache_type cache_type;
unsigned int cache_size_raw;
unsigned int cache_word_size;
unsigned int num_reg_defaults;
unsigned int num_reg_defaults_raw;
bool cache_only;
bool cache_bypass;
bool cache_free;
struct reg_default *reg_defaults;
const void *reg_defaults_raw;
void *cache;
bool cache_dirty;
bool no_sync_defaults;
struct reg_sequence *patch;
int patch_regs;
bool use_single_read;
bool use_single_write;
bool can_multi_write;
size_t max_raw_read;
size_t max_raw_write;
struct rb_root range_tree;
void *selector_work_buf;
struct hwspinlock *hwlock;
bool can_sleep;
};
struct regcache_ops {
const char *name;
enum regcache_type type;
int (*init)(struct regmap *);
int (*exit)(struct regmap *);
void (*debugfs_init)(struct regmap *);
int (*read)(struct regmap *, unsigned int, unsigned int *);
int (*write)(struct regmap *, unsigned int, unsigned int);
int (*sync)(struct regmap *, unsigned int, unsigned int);
int (*drop)(struct regmap *, unsigned int, unsigned int);
};
struct regmap_mmio_context {
void *regs;
unsigned int val_bytes;
bool big_endian;
bool attached_clk;
struct clk *clk;
void (*reg_write)(struct regmap_mmio_context *, unsigned int, unsigned int);
unsigned int (*reg_read)(struct regmap_mmio_context *, unsigned int);
};
enum bip_flags {
BIP_BLOCK_INTEGRITY = 1,
BIP_MAPPED_INTEGRITY = 2,
BIP_CTRL_NOCHECK = 4,
BIP_DISK_NOCHECK = 8,
BIP_IP_CHECKSUM = 16,
};
enum {
GENHD_FL_REMOVABLE = 1,
GENHD_FL_HIDDEN = 2,
GENHD_FL_NO_PART = 4,
};
enum {
DISK_EVENT_MEDIA_CHANGE = 1,
DISK_EVENT_EJECT_REQUEST = 2,
};
enum {
DISK_EVENT_FLAG_POLL = 1,
DISK_EVENT_FLAG_UEVENT = 2,
DISK_EVENT_FLAG_BLOCK_ON_EXCL_WRITE = 4,
};
enum blk_default_limits {
BLK_MAX_SEGMENTS = 128,
BLK_SAFE_MAX_SECTORS = 255,
BLK_DEF_MAX_SECTORS = 2560,
BLK_MAX_SEGMENT_SIZE = 65536,
BLK_SEG_BOUNDARY_MASK = 4294967295,
};
enum string_size_units {
STRING_UNITS_10 = 0,
STRING_UNITS_2 = 1,
};
enum t10_dif_type {
T10_PI_TYPE0_PROTECTION = 0,
T10_PI_TYPE1_PROTECTION = 1,
T10_PI_TYPE2_PROTECTION = 2,
T10_PI_TYPE3_PROTECTION = 3,
};
enum scsi_host_status {
DID_OK = 0,
DID_NO_CONNECT = 1,
DID_BUS_BUSY = 2,
DID_TIME_OUT = 3,
DID_BAD_TARGET = 4,
DID_ABORT = 5,
DID_PARITY = 6,
DID_ERROR = 7,
DID_RESET = 8,
DID_BAD_INTR = 9,
DID_PASSTHROUGH = 10,
DID_SOFT_ERROR = 11,
DID_IMM_RETRY = 12,
DID_REQUEUE = 13,
DID_TRANSPORT_DISRUPTED = 14,
DID_TRANSPORT_FAILFAST = 15,
DID_TRANSPORT_MARGINAL = 20,
};
enum scsi_disposition {
NEEDS_RETRY = 8193,
SUCCESS = 8194,
FAILED = 8195,
QUEUED = 8196,
SOFT_ERROR = 8197,
ADD_TO_MLQUEUE = 8198,
TIMEOUT_ERROR = 8199,
SCSI_RETURN_NOT_HANDLED = 8200,
FAST_IO_FAIL = 8201,
};
struct scsi_mode_data {
__u32 length;
__u16 block_descriptor_length;
__u8 medium_type;
__u8 device_specific;
__u8 header_length;
__u8 longlba: 1;
};
enum scsi_device_event {
SDEV_EVT_MEDIA_CHANGE = 1,
SDEV_EVT_INQUIRY_CHANGE_REPORTED = 2,
SDEV_EVT_CAPACITY_CHANGE_REPORTED = 3,
SDEV_EVT_SOFT_THRESHOLD_REACHED_REPORTED = 4,
SDEV_EVT_MODE_PARAMETER_CHANGE_REPORTED = 5,
SDEV_EVT_LUN_CHANGE_REPORTED = 6,
SDEV_EVT_ALUA_STATE_CHANGE_REPORTED = 7,
SDEV_EVT_POWER_ON_RESET_OCCURRED = 8,
SDEV_EVT_FIRST = 1,
SDEV_EVT_LAST = 8,
SDEV_EVT_MAXBITS = 9,
};
enum scsi_host_state {
SHOST_CREATED = 1,
SHOST_RUNNING = 2,
SHOST_CANCEL = 3,
SHOST_DEL = 4,
SHOST_RECOVERY = 5,
SHOST_CANCEL_RECOVERY = 6,
SHOST_DEL_RECOVERY = 7,
};
struct scsi_host_template;
struct scsi_transport_template;
struct Scsi_Host {
struct list_head __devices;
struct list_head __targets;
struct list_head starved_list;
spinlock_t default_lock;
spinlock_t *host_lock;
struct mutex scan_mutex;
struct list_head eh_abort_list;
struct list_head eh_cmd_q;
struct task_struct *ehandler;
struct completion *eh_action;
wait_queue_head_t host_wait;
struct scsi_host_template *hostt;
struct scsi_transport_template *transportt;
struct kref tagset_refcnt;
struct completion tagset_freed;
struct blk_mq_tag_set tag_set;
atomic_t host_blocked;
unsigned int host_failed;
unsigned int host_eh_scheduled;
unsigned int host_no;
int eh_deadline;
long unsigned int last_reset;
unsigned int max_channel;
unsigned int max_id;
long: 32;
u64 max_lun;
unsigned int unique_id;
short unsigned int max_cmd_len;
int this_id;
int can_queue;
short int cmd_per_lun;
short unsigned int sg_tablesize;
short unsigned int sg_prot_tablesize;
unsigned int max_sectors;
unsigned int opt_sectors;
unsigned int max_segment_size;
long unsigned int dma_boundary;
long unsigned int virt_boundary_mask;
unsigned int nr_hw_queues;
unsigned int nr_maps;
unsigned int active_mode: 2;
unsigned int host_self_blocked: 1;
unsigned int reverse_ordering: 1;
unsigned int tmf_in_progress: 1;
unsigned int async_scan: 1;
unsigned int eh_noresume: 1;
unsigned int no_write_same: 1;
unsigned int host_tagset: 1;
unsigned int short_inquiry: 1;
unsigned int no_scsi2_lun_in_cdb: 1;
char work_q_name[20];
struct workqueue_struct *work_q;
struct workqueue_struct *tmf_work_q;
unsigned int max_host_blocked;
unsigned int prot_capabilities;
unsigned char prot_guard_type;
long unsigned int base;
long unsigned int io_port;
unsigned char n_io_port;
unsigned char dma_channel;
unsigned int irq;
enum scsi_host_state shost_state;
long: 32;
struct device shost_gendev;
struct device shost_dev;
void *shost_data;
struct device *dma_dev;
long unsigned int hostdata[0];
};
enum scsi_prot_operations {
SCSI_PROT_NORMAL = 0,
SCSI_PROT_READ_INSERT = 1,
SCSI_PROT_WRITE_STRIP = 2,
SCSI_PROT_READ_STRIP = 3,
SCSI_PROT_WRITE_INSERT = 4,
SCSI_PROT_READ_PASS = 5,
SCSI_PROT_WRITE_PASS = 6,
};
enum scsi_prot_flags {
SCSI_PROT_TRANSFER_PI = 1,
SCSI_PROT_GUARD_CHECK = 2,
SCSI_PROT_REF_CHECK = 4,
SCSI_PROT_REF_INCREMENT = 8,
SCSI_PROT_IP_CHECKSUM = 16,
};
struct scsi_driver {
struct device_driver gendrv;
void (*rescan)(struct device *);
blk_status_t (*init_command)(struct scsi_cmnd *);
void (*uninit_command)(struct scsi_cmnd *);
int (*done)(struct scsi_cmnd *);
int (*eh_action)(struct scsi_cmnd *, int);
void (*eh_reset)(struct scsi_cmnd *);
};
struct scsi_host_template {
unsigned int cmd_size;
int (*queuecommand)(struct Scsi_Host *, struct scsi_cmnd *);
void (*commit_rqs)(struct Scsi_Host *, u16);
struct module *module;
const char *name;
const char * (*info)(struct Scsi_Host *);
int (*ioctl)(struct scsi_device *, unsigned int, void *);
int (*init_cmd_priv)(struct Scsi_Host *, struct scsi_cmnd *);
int (*exit_cmd_priv)(struct Scsi_Host *, struct scsi_cmnd *);
int (*eh_abort_handler)(struct scsi_cmnd *);
int (*eh_device_reset_handler)(struct scsi_cmnd *);
int (*eh_target_reset_handler)(struct scsi_cmnd *);
int (*eh_bus_reset_handler)(struct scsi_cmnd *);
int (*eh_host_reset_handler)(struct scsi_cmnd *);
int (*slave_alloc)(struct scsi_device *);
int (*slave_configure)(struct scsi_device *);
void (*slave_destroy)(struct scsi_device *);
int (*target_alloc)(struct scsi_target *);
void (*target_destroy)(struct scsi_target *);
int (*scan_finished)(struct Scsi_Host *, long unsigned int);
void (*scan_start)(struct Scsi_Host *);
int (*change_queue_depth)(struct scsi_device *, int);
void (*map_queues)(struct Scsi_Host *);
int (*mq_poll)(struct Scsi_Host *, unsigned int);
bool (*dma_need_drain)(struct request *);
int (*bios_param)(struct scsi_device *, struct block_device *, sector_t, int *);
void (*unlock_native_capacity)(struct scsi_device *);
int (*show_info)(struct seq_file *, struct Scsi_Host *);
int (*write_info)(struct Scsi_Host *, char *, int);
enum blk_eh_timer_return (*eh_timed_out)(struct scsi_cmnd *);
bool (*eh_should_retry_cmd)(struct scsi_cmnd *);
int (*host_reset)(struct Scsi_Host *, int);
const char *proc_name;
struct proc_dir_entry *proc_dir;
int can_queue;
int this_id;
short unsigned int sg_tablesize;
short unsigned int sg_prot_tablesize;
unsigned int max_sectors;
unsigned int max_segment_size;
long unsigned int dma_boundary;
long unsigned int virt_boundary_mask;
short int cmd_per_lun;
unsigned char present;
int tag_alloc_policy;
unsigned int track_queue_depth: 1;
unsigned int supported_mode: 2;
unsigned int emulated: 1;
unsigned int skip_settle_delay: 1;
unsigned int no_write_same: 1;
unsigned int host_tagset: 1;
unsigned int max_host_blocked;
const struct attribute_group **shost_groups;
const struct attribute_group **sdev_groups;
long: 32;
u64 vendor_id;
int rpm_autosuspend_delay;
long: 32;
};
enum scsi_host_prot_capabilities {
SHOST_DIF_TYPE1_PROTECTION = 1,
SHOST_DIF_TYPE2_PROTECTION = 2,
SHOST_DIF_TYPE3_PROTECTION = 4,
SHOST_DIX_TYPE0_PROTECTION = 8,
SHOST_DIX_TYPE1_PROTECTION = 16,
SHOST_DIX_TYPE2_PROTECTION = 32,
SHOST_DIX_TYPE3_PROTECTION = 64,
};
enum {
SD_EXT_CDB_SIZE = 32,
SD_MEMPOOL_SIZE = 2,
};
enum {
SD_DEF_XFER_BLOCKS = 65535,
SD_MAX_XFER_BLOCKS = 4294967295,
SD_MAX_WS10_BLOCKS = 65535,
SD_MAX_WS16_BLOCKS = 8388607,
};
enum {
SD_LBP_FULL = 0,
SD_LBP_UNMAP = 1,
SD_LBP_WS16 = 2,
SD_LBP_WS10 = 3,
SD_LBP_ZERO = 4,
SD_LBP_DISABLE = 5,
};
enum {
SD_ZERO_WRITE = 0,
SD_ZERO_WS = 1,
SD_ZERO_WS16_UNMAP = 2,
SD_ZERO_WS10_UNMAP = 3,
};
struct opal_dev;
struct scsi_disk {
struct scsi_device *device;
long: 32;
struct device disk_dev;
struct gendisk *disk;
struct opal_dev *opal_dev;
atomic_t openers;
long: 32;
sector_t capacity;
int max_retries;
u32 min_xfer_blocks;
u32 max_xfer_blocks;
u32 opt_xfer_blocks;
u32 max_ws_blocks;
u32 max_unmap_blocks;
u32 unmap_granularity;
u32 unmap_alignment;
u32 index;
unsigned int physical_block_size;
unsigned int max_medium_access_timeouts;
unsigned int medium_access_timed_out;
u8 media_present;
u8 write_prot;
u8 protection_type;
u8 provisioning_mode;
u8 zeroing_mode;
u8 nr_actuators;
unsigned int ATO: 1;
unsigned int cache_override: 1;
unsigned int WCE: 1;
unsigned int RCD: 1;
unsigned int DPOFUA: 1;
unsigned int first_scan: 1;
unsigned int lbpme: 1;
unsigned int lbprz: 1;
unsigned int lbpu: 1;
unsigned int lbpws: 1;
unsigned int lbpws10: 1;
unsigned int lbpvpd: 1;
unsigned int ws10: 1;
unsigned int ws16: 1;
unsigned int rc_basis: 2;
unsigned int zoned: 2;
unsigned int urswrz: 1;
unsigned int security: 1;
unsigned int ignore_medium_access_errors: 1;
long: 32;
};
struct mii_ioctl_data {
__u16 phy_id;
__u16 reg_num;
__u16 val_in;
__u16 val_out;
};
struct mii_if_info {
int phy_id;
int advertising;
int phy_id_mask;
int reg_num_mask;
unsigned int full_duplex: 1;
unsigned int force_media: 1;
unsigned int supports_gmii: 1;
struct net_device *dev;
int (*mdio_read)(struct net_device *, int, int);
void (*mdio_write)(struct net_device *, int, int, int);
};
struct ixgbe_hic_hdr {
u8 cmd;
u8 buf_len;
union {
u8 cmd_resv;
u8 ret_status;
} cmd_or_resp;
u8 checksum;
};
struct ixgbe_hic_hdr2_req {
u8 cmd;
u8 buf_lenh;
u8 buf_lenl;
u8 checksum;
};
struct ixgbe_hic_hdr2_rsp {
u8 cmd;
u8 buf_lenl;
u8 buf_lenh_status;
u8 checksum;
};
union ixgbe_hic_hdr2 {
struct ixgbe_hic_hdr2_req req;
struct ixgbe_hic_hdr2_rsp rsp;
};
struct ixgbe_hic_drv_info2 {
struct ixgbe_hic_hdr hdr;
u8 port_num;
u8 ver_sub;
u8 ver_build;
u8 ver_min;
u8 ver_maj;
char driver_string[39];
};
struct ixgbe_hic_read_shadow_ram {
union ixgbe_hic_hdr2 hdr;
u32 address;
u16 length;
u16 pad2;
u16 data;
u16 pad3;
};
struct ixgbe_hic_write_shadow_ram {
union ixgbe_hic_hdr2 hdr;
__be32 address;
__be16 length;
u16 pad2;
u16 data;
u16 pad3;
};
struct ixgbe_hic_disable_rxen {
struct ixgbe_hic_hdr hdr;
u8 port_number;
u8 pad2;
u16 pad3;
};
struct ixgbe_hic_phy_token_req {
struct ixgbe_hic_hdr hdr;
u8 port_number;
u8 command_type;
u16 pad;
};
struct ixgbe_hic_internal_phy_req {
struct ixgbe_hic_hdr hdr;
u8 port_number;
u8 command_type;
__be16 address;
u16 rsv1;
__be32 write_data;
u16 pad;
} __attribute__((packed));
struct ixgbe_hic_internal_phy_resp {
struct ixgbe_hic_hdr hdr;
__be32 read_data;
};
struct ixgbe_hic_phy_activity_req {
struct ixgbe_hic_hdr hdr;
u8 port_number;
u8 pad;
__le16 activity_id;
__be32 data[4];
};
struct ixgbe_hic_phy_activity_resp {
struct ixgbe_hic_hdr hdr;
__be32 data[4];
};
struct pps_ktime {
__s64 sec;
__s32 nsec;
__u32 flags;
};
struct pps_kparams {
int api_version;
int mode;
struct pps_ktime assert_off_tu;
struct pps_ktime clear_off_tu;
};
struct pps_device;
struct pps_source_info {
char name[32];
char path[32];
int mode;
void (*echo)(struct pps_device *, int, void *);
struct module *owner;
struct device *dev;
};
struct pps_device {
struct pps_source_info info;
struct pps_kparams params;
__u32 assert_sequence;
__u32 clear_sequence;
struct pps_ktime assert_tu;
struct pps_ktime clear_tu;
int current_mode;
unsigned int last_ev;
wait_queue_head_t queue;
unsigned int id;
const void *lookup_cookie;
struct cdev cdev;
struct device *dev;
struct fasync_struct *async_queue;
spinlock_t lock;
long: 32;
};
struct net_device_devres {
struct net_device *ndev;
};
enum {
NDA_UNSPEC = 0,
NDA_DST = 1,
NDA_LLADDR = 2,
NDA_CACHEINFO = 3,
NDA_PROBES = 4,
NDA_VLAN = 5,
NDA_PORT = 6,
NDA_VNI = 7,
NDA_IFINDEX = 8,
NDA_MASTER = 9,
NDA_LINK_NETNSID = 10,
NDA_SRC_VNI = 11,
NDA_PROTOCOL = 12,
NDA_NH_ID = 13,
NDA_FDB_EXT_ATTRS = 14,
NDA_FLAGS_EXT = 15,
NDA_NDM_STATE_MASK = 16,
NDA_NDM_FLAGS_MASK = 17,
__NDA_MAX = 18,
};
struct nda_cacheinfo {
__u32 ndm_confirmed;
__u32 ndm_used;
__u32 ndm_updated;
__u32 ndm_refcnt;
};
struct ndt_stats {
__u64 ndts_allocs;
__u64 ndts_destroys;
__u64 ndts_hash_grows;
__u64 ndts_res_failed;
__u64 ndts_lookups;
__u64 ndts_hits;
__u64 ndts_rcv_probes_mcast;
__u64 ndts_rcv_probes_ucast;
__u64 ndts_periodic_gc_runs;
__u64 ndts_forced_gc_runs;
__u64 ndts_table_fulls;
};
enum {
NDTPA_UNSPEC = 0,
NDTPA_IFINDEX = 1,
NDTPA_REFCNT = 2,
NDTPA_REACHABLE_TIME = 3,
NDTPA_BASE_REACHABLE_TIME = 4,
NDTPA_RETRANS_TIME = 5,
NDTPA_GC_STALETIME = 6,
NDTPA_DELAY_PROBE_TIME = 7,
NDTPA_QUEUE_LEN = 8,
NDTPA_APP_PROBES = 9,
NDTPA_UCAST_PROBES = 10,
NDTPA_MCAST_PROBES = 11,
NDTPA_ANYCAST_DELAY = 12,
NDTPA_PROXY_DELAY = 13,
NDTPA_PROXY_QLEN = 14,
NDTPA_LOCKTIME = 15,
NDTPA_QUEUE_LENBYTES = 16,
NDTPA_MCAST_REPROBES = 17,
NDTPA_PAD = 18,
NDTPA_INTERVAL_PROBE_TIME_MS = 19,
__NDTPA_MAX = 20,
};
struct ndtmsg {
__u8 ndtm_family;
__u8 ndtm_pad1;
__u16 ndtm_pad2;
};
struct ndt_config {
__u16 ndtc_key_len;
__u16 ndtc_entry_size;
__u32 ndtc_entries;
__u32 ndtc_last_flush;
__u32 ndtc_last_rand;
__u32 ndtc_hash_rnd;
__u32 ndtc_hash_mask;
__u32 ndtc_hash_chain_gc;
__u32 ndtc_proxy_qlen;
};
enum {
NDTA_UNSPEC = 0,
NDTA_NAME = 1,
NDTA_THRESH1 = 2,
NDTA_THRESH2 = 3,
NDTA_THRESH3 = 4,
NDTA_CONFIG = 5,
NDTA_PARMS = 6,
NDTA_STATS = 7,
NDTA_GC_INTERVAL = 8,
NDTA_PAD = 9,
__NDTA_MAX = 10,
};
enum {
NEIGH_ARP_TABLE = 0,
NEIGH_ND_TABLE = 1,
NEIGH_DN_TABLE = 2,
NEIGH_NR_TABLES = 3,
NEIGH_LINK_TABLE = 3,
};
struct neigh_seq_state {
struct seq_net_private p;
struct neigh_table *tbl;
struct neigh_hash_table *nht;
void * (*neigh_sub_iter)(struct neigh_seq_state *, struct neighbour *, loff_t *);
unsigned int bucket;
unsigned int flags;
};
struct neighbour_cb {
long unsigned int sched_next;
unsigned int flags;
};
struct neigh_dump_filter {
int master_idx;
int dev_idx;
};
struct neigh_sysctl_table {
struct ctl_table_header *sysctl_header;
struct ctl_table neigh_vars[22];
};
enum ethtool_stringset {
ETH_SS_TEST = 0,
ETH_SS_STATS = 1,
ETH_SS_PRIV_FLAGS = 2,
ETH_SS_NTUPLE_FILTERS = 3,
ETH_SS_FEATURES = 4,
ETH_SS_RSS_HASH_FUNCS = 5,
ETH_SS_TUNABLES = 6,
ETH_SS_PHY_STATS = 7,
ETH_SS_PHY_TUNABLES = 8,
ETH_SS_LINK_MODES = 9,
ETH_SS_MSG_CLASSES = 10,
ETH_SS_WOL_MODES = 11,
ETH_SS_SOF_TIMESTAMPING = 12,
ETH_SS_TS_TX_TYPES = 13,
ETH_SS_TS_RX_FILTERS = 14,
ETH_SS_UDP_TUNNEL_TYPES = 15,
ETH_SS_STATS_STD = 16,
ETH_SS_STATS_ETH_PHY = 17,
ETH_SS_STATS_ETH_MAC = 18,
ETH_SS_STATS_ETH_CTRL = 19,
ETH_SS_STATS_RMON = 20,
ETH_SS_COUNT = 21,
};
enum {
ETHTOOL_A_STATS_GRP_UNSPEC = 0,
ETHTOOL_A_STATS_GRP_PAD = 1,
ETHTOOL_A_STATS_GRP_ID = 2,
ETHTOOL_A_STATS_GRP_SS_ID = 3,
ETHTOOL_A_STATS_GRP_STAT = 4,
ETHTOOL_A_STATS_GRP_HIST_RX = 5,
ETHTOOL_A_STATS_GRP_HIST_TX = 6,
ETHTOOL_A_STATS_GRP_HIST_BKT_LOW = 7,
ETHTOOL_A_STATS_GRP_HIST_BKT_HI = 8,
ETHTOOL_A_STATS_GRP_HIST_VAL = 9,
__ETHTOOL_A_STATS_GRP_CNT = 10,
ETHTOOL_A_STATS_GRP_MAX = 4,
};
struct stats_req_info {
struct ethnl_req_info base;
long unsigned int stat_mask[1];
};
struct stats_reply_data {
struct ethnl_reply_data base;
long: 32;
union {
struct {
struct ethtool_eth_phy_stats phy_stats;
struct ethtool_eth_mac_stats mac_stats;
struct ethtool_eth_ctrl_stats ctrl_stats;
struct ethtool_rmon_stats rmon_stats;
};
struct {
struct ethtool_eth_phy_stats phy_stats;
struct ethtool_eth_mac_stats mac_stats;
struct ethtool_eth_ctrl_stats ctrl_stats;
struct ethtool_rmon_stats rmon_stats;
} stats;
};
const struct ethtool_rmon_hist_range *rmon_ranges;
long: 32;
};
struct udp_hslot;
struct udp_table {
struct udp_hslot *hash;
struct udp_hslot *hash2;
unsigned int mask;
unsigned int log;
};
struct udp_hslot {
struct hlist_head head;
int count;
spinlock_t lock;
long: 32;
};
enum inet_csk_ack_state_t {
ICSK_ACK_SCHED = 1,
ICSK_ACK_TIMER = 2,
ICSK_ACK_PUSHED = 4,
ICSK_ACK_PUSHED2 = 8,
ICSK_ACK_NOW = 16,
};
enum tcp_ca_state {
TCP_CA_Open = 0,
TCP_CA_Disorder = 1,
TCP_CA_CWR = 2,
TCP_CA_Recovery = 3,
TCP_CA_Loss = 4,
};
enum tcp_queue {
TCP_FRAG_IN_WRITE_QUEUE = 0,
TCP_FRAG_IN_RTX_QUEUE = 1,
};
struct tcp_skb_cb {
__u32 seq;
__u32 end_seq;
union {
__u32 tcp_tw_isn;
struct {
u16 tcp_gso_segs;
u16 tcp_gso_size;
};
};
__u8 tcp_flags;
__u8 sacked;
__u8 ip_dsfield;
__u8 txstamp_ack: 1;
__u8 eor: 1;
__u8 has_rxtstamp: 1;
__u8 unused: 5;
__u32 ack_seq;
long: 32;
union {
struct {
__u32 is_app_limited: 1;
__u32 delivered_ce: 20;
__u32 unused: 11;
__u32 delivered;
u64 first_tx_mstamp;
u64 delivered_mstamp;
} tx;
union {
struct inet_skb_parm h4;
struct inet6_skb_parm h6;
} header;
};
};
struct fib_config {
u8 fc_dst_len;
dscp_t fc_dscp;
u8 fc_protocol;
u8 fc_scope;
u8 fc_type;
u8 fc_gw_family;
u32 fc_table;
__be32 fc_dst;
union {
__be32 fc_gw4;
struct in6_addr fc_gw6;
};
int fc_oif;
u32 fc_flags;
u32 fc_priority;
__be32 fc_prefsrc;
u32 fc_nh_id;
struct nlattr *fc_mx;
struct rtnexthop *fc_mp;
int fc_mx_len;
int fc_mp_len;
u32 fc_flow;
u32 fc_nlflags;
struct nl_info fc_nlinfo;
struct nlattr *fc_encap;
u16 fc_encap_type;
};
struct fib_nh_notifier_info {
struct fib_notifier_info info;
struct fib_nh *fib_nh;
};
struct packet_type {
__be16 type;
bool ignore_outgoing;
struct net_device *dev;
netdevice_tracker dev_tracker;
int (*func)(struct sk_buff *, struct net_device *, struct packet_type *, struct net_device *);
void (*list_func)(struct list_head *, struct packet_type *, struct net_device *);
bool (*id_match)(struct packet_type *, struct sock *);
struct net *af_packet_net;
void *af_packet_priv;
struct list_head list;
};
struct rtentry {
long unsigned int rt_pad1;
struct sockaddr rt_dst;
struct sockaddr rt_gateway;
struct sockaddr rt_genmask;
short unsigned int rt_flags;
short int rt_pad2;
long unsigned int rt_pad3;
void *rt_pad4;
short int rt_metric;
char *rt_dev;
long unsigned int rt_mtu;
long unsigned int rt_window;
short unsigned int rt_irtt;
};
struct ic_device {
struct ic_device *next;
struct net_device *dev;
short unsigned int flags;
short int able;
__be32 xid;
};
struct bootp_pkt {
struct iphdr iph;
struct udphdr udph;
u8 op;
u8 htype;
u8 hlen;
u8 hops;
__be32 xid;
__be16 secs;
__be16 flags;
__be32 client_ip;
__be32 your_ip;
__be32 server_ip;
__be32 relay_ip;
u8 hw_addr[16];
u8 serv_name[64];
u8 boot_file[128];
u8 exten[312];
};
struct ip_beet_phdr {
__u8 nexthdr;
__u8 hdrlen;
__u8 padlen;
__u8 reserved;
};
struct gro_cell;
struct gro_cells {
struct gro_cell *cells;
};
enum {
XFRM_MODE_FLAG_TUNNEL = 1,
};
enum {
XFRM_STATE_VOID = 0,
XFRM_STATE_ACQ = 1,
XFRM_STATE_VALID = 2,
XFRM_STATE_ERROR = 3,
XFRM_STATE_EXPIRED = 4,
XFRM_STATE_DEAD = 5,
};
struct xfrm_state_afinfo {
u8 family;
u8 proto;
const struct xfrm_type_offload *type_offload_esp;
const struct xfrm_type *type_esp;
const struct xfrm_type *type_ipip;
const struct xfrm_type *type_ipip6;
const struct xfrm_type *type_comp;
const struct xfrm_type *type_ah;
const struct xfrm_type *type_routing;
const struct xfrm_type *type_dstopts;
int (*output)(struct net *, struct sock *, struct sk_buff *);
int (*transport_finish)(struct sk_buff *, int);
void (*local_error)(struct sk_buff *, u32);
};
struct xfrm_input_afinfo {
u8 family;
bool is_ipip;
int (*callback)(struct sk_buff *, u8, int);
};
struct ip_tunnel_encap {
u16 type;
u16 flags;
__be16 sport;
__be16 dport;
};
struct ip_tunnel_prl_entry;
struct ip_tunnel {
struct ip_tunnel *next;
struct hlist_node hash_node;
struct net_device *dev;
netdevice_tracker dev_tracker;
struct net *net;
long unsigned int err_time;
int err_count;
u32 i_seqno;
atomic_t o_seqno;
int tun_hlen;
u32 index;
u8 erspan_ver;
u8 dir;
u16 hwid;
struct dst_cache dst_cache;
struct ip_tunnel_parm parms;
int mlink;
int encap_hlen;
int hlen;
struct ip_tunnel_encap encap;
struct ip_tunnel_prl_entry *prl;
unsigned int prl_count;
unsigned int ip_tnl_net_id;
struct gro_cells gro_cells;
__u32 fwmark;
bool collect_md;
bool ignore_df;
};
struct __ip6_tnl_parm {
char name[16];
int link;
__u8 proto;
__u8 encap_limit;
__u8 hop_limit;
bool collect_md;
__be32 flowinfo;
__u32 flags;
struct in6_addr laddr;
struct in6_addr raddr;
__be16 i_flags;
__be16 o_flags;
__be32 i_key;
__be32 o_key;
__u32 fwmark;
__u32 index;
__u8 erspan_ver;
__u8 dir;
__u16 hwid;
};
struct ip6_tnl {
struct ip6_tnl *next;
struct net_device *dev;
netdevice_tracker dev_tracker;
struct net *net;
struct __ip6_tnl_parm parms;
long: 32;
struct flowi fl;
struct dst_cache dst_cache;
struct gro_cells gro_cells;
int err_count;
long unsigned int err_time;
__u32 i_seqno;
atomic_t o_seqno;
int hlen;
int tun_hlen;
int encap_hlen;
struct ip_tunnel_encap encap;
int mlink;
long: 32;
};
struct xfrm_tunnel_skb_cb {
union {
struct inet_skb_parm h4;
struct inet6_skb_parm h6;
} header;
union {
struct ip_tunnel *ip4;
struct ip6_tnl *ip6;
} tunnel;
};
struct xfrm_skb_cb {
struct xfrm_tunnel_skb_cb header;
union {
struct {
__u32 low;
__u32 hi;
} output;
struct {
__be32 low;
__be32 hi;
} input;
} seq;
};
struct xfrm_mode_skb_cb {
struct xfrm_tunnel_skb_cb header;
__be16 id;
__be16 frag_off;
u8 ihl;
u8 tos;
u8 ttl;
u8 protocol;
u8 optlen;
u8 flow_lbl[3];
};
struct xfrm_spi_skb_cb {
struct xfrm_tunnel_skb_cb header;
unsigned int daddroff;
unsigned int family;
__be32 seq;
};
enum {
INET_ECN_NOT_ECT = 0,
INET_ECN_ECT_1 = 1,
INET_ECN_ECT_0 = 2,
INET_ECN_CE = 3,
INET_ECN_MASK = 3,
};
struct ip_tunnel_prl_entry {
struct ip_tunnel_prl_entry *next;
__be32 addr;
u16 flags;
struct callback_head callback_head;
};
struct xfrm_trans_tasklet {
struct work_struct work;
spinlock_t queue_lock;
struct sk_buff_head queue;
};
struct xfrm_trans_cb {
union {
struct inet_skb_parm h4;
struct inet6_skb_parm h6;
} header;
int (*finish)(struct net *, struct sock *, struct sk_buff *);
struct net *net;
};
enum {
SKB_GSO_TCPV4 = 1,
SKB_GSO_DODGY = 2,
SKB_GSO_TCP_ECN = 4,
SKB_GSO_TCP_FIXEDID = 8,
SKB_GSO_TCPV6 = 16,
SKB_GSO_FCOE = 32,
SKB_GSO_GRE = 64,
SKB_GSO_GRE_CSUM = 128,
SKB_GSO_IPXIP4 = 256,
SKB_GSO_IPXIP6 = 512,
SKB_GSO_UDP_TUNNEL = 1024,
SKB_GSO_UDP_TUNNEL_CSUM = 2048,
SKB_GSO_PARTIAL = 4096,
SKB_GSO_TUNNEL_REMCSUM = 8192,
SKB_GSO_SCTP = 16384,
SKB_GSO_ESP = 32768,
SKB_GSO_UDP = 65536,
SKB_GSO_UDP_L4 = 131072,
SKB_GSO_FRAGLIST = 262144,
};
struct skb_gso_cb {
union {
int mac_offset;
int data_offset;
};
int encap_level;
__wsum csum;
__u16 csum_start;
};
struct offload_callbacks {
struct sk_buff * (*gso_segment)(struct sk_buff *, netdev_features_t);
struct sk_buff * (*gro_receive)(struct list_head *, struct sk_buff *);
int (*gro_complete)(struct sk_buff *, int);
};
struct net_offload {
struct offload_callbacks callbacks;
unsigned int flags;
};
typedef struct sock * (*udp_lookup_t)(const struct sk_buff *, __be16, __be16);
struct napi_gro_cb {
void *frag0;
unsigned int frag0_len;
int data_offset;
u16 flush;
u16 flush_id;
u16 count;
u16 proto;
long unsigned int age;
union {
struct {
u16 gro_remcsum_start;
u8 same_flow: 1;
u8 encap_mark: 1;
u8 csum_valid: 1;
u8 csum_cnt: 3;
u8 free: 2;
u8 is_ipv6: 1;
u8 is_fou: 1;
u8 is_atomic: 1;
u8 recursion_counter: 4;
u8 is_flist: 1;
};
struct {
u16 gro_remcsum_start;
u8 same_flow: 1;
u8 encap_mark: 1;
u8 csum_valid: 1;
u8 csum_cnt: 3;
u8 free: 2;
u8 is_ipv6: 1;
u8 is_fou: 1;
u8 is_atomic: 1;
u8 recursion_counter: 4;
u8 is_flist: 1;
} zeroed;
};
__wsum csum;
struct sk_buff *last;
};
enum {
IP6_FH_F_FRAG = 1,
IP6_FH_F_AUTH = 2,
IP6_FH_F_SKIP_RH = 4,
};
enum sock_shutdown_cmd {
SHUT_RD = 0,
SHUT_WR = 1,
SHUT_RDWR = 2,
};
struct sockaddr_un {
__kernel_sa_family_t sun_family;
char sun_path[108];
};
enum rpc_msg_type {
RPC_CALL = 0,
RPC_REPLY = 1,
};
typedef __be32 rpc_fraghdr;
struct svc_sock {
struct svc_xprt sk_xprt;
struct socket *sk_sock;
struct sock *sk_sk;
void (*sk_ostate)(struct sock *);
void (*sk_odata)(struct sock *);
void (*sk_owspace)(struct sock *);
__be32 sk_marker;
u32 sk_tcplen;
u32 sk_datalen;
atomic_t sk_sendqlen;
struct page *sk_pages[67];
};
struct sock_xprt {
struct rpc_xprt xprt;
struct socket *sock;
struct sock *inet;
struct file *file;
struct {
struct {
__be32 fraghdr;
__be32 xid;
__be32 calldir;
};
u32 offset;
u32 len;
long unsigned int copied;
} recv;
struct {
u32 offset;
} xmit;
long unsigned int sock_state;
struct delayed_work connect_worker;
struct work_struct error_worker;
struct work_struct recv_worker;
struct mutex recv_mutex;
struct __kernel_sockaddr_storage srcaddr;
short unsigned int srcport;
int xprt_err;
size_t rcvsize;
size_t sndsize;
struct rpc_timeout tcp_timeout;
void (*old_data_ready)(struct sock *);
void (*old_state_change)(struct sock *);
void (*old_write_space)(struct sock *);
void (*old_error_report)(struct sock *);
long: 32;
};
struct rpc_buffer {
size_t len;
char data[0];
};
struct pci_host_bridge {
struct device dev;
struct pci_bus *bus;
struct pci_ops *ops;
struct pci_ops *child_ops;
void *sysdata;
int busnr;
int domain_nr;
struct list_head windows;
struct list_head dma_ranges;
u8 (*swizzle_irq)(struct pci_dev *, u8 *);
int (*map_irq)(const struct pci_dev *, u8, u8);
void (*release_fn)(struct pci_host_bridge *);
void *release_data;
unsigned int ignore_reset_delay: 1;
unsigned int no_ext_tags: 1;
unsigned int native_aer: 1;
unsigned int native_pcie_hotplug: 1;
unsigned int native_shpc_hotplug: 1;
unsigned int native_pme: 1;
unsigned int native_ltr: 1;
unsigned int native_dpc: 1;
unsigned int preserve_config: 1;
unsigned int size_windows: 1;
unsigned int msi_domain: 1;
resource_size_t (*align_resource)(struct pci_dev *, const struct resource *, resource_size_t, resource_size_t, resource_size_t);
long: 32;
long: 32;
long unsigned int private[0];
};
enum {
PCI_REASSIGN_ALL_RSRC = 1,
PCI_REASSIGN_ALL_BUS = 2,
PCI_PROBE_ONLY = 4,
PCI_CAN_SKIP_ISA_ALIGN = 8,
PCI_ENABLE_PROC_DOMAINS = 16,
PCI_COMPAT_DOMAIN_0 = 32,
PCI_SCAN_ALL_PCIE_DEVS = 64,
};
struct of_bus;
struct of_pci_range_parser {
struct device_node *node;
struct of_bus *bus;
const __be32 *range;
const __be32 *end;
int na;
int ns;
int pna;
bool dma;
};
struct of_pci_range {
union {
u64 pci_addr;
u64 bus_addr;
};
u64 cpu_addr;
u64 size;
u32 flags;
long: 32;
};
struct cpio_data {
void *data;
size_t size;
char name[18];
};
enum cpio_fields {
C_MAGIC = 0,
C_INO = 1,
C_MODE = 2,
C_UID = 3,
C_GID = 4,
C_NLINK = 5,
C_MTIME = 6,
C_FILESIZE = 7,
C_MAJ = 8,
C_MIN = 9,
C_RMAJ = 10,
C_RMIN = 11,
C_NAMESIZE = 12,
C_CHKSUM = 13,
C_NFIELDS = 14,
};
typedef __be32 fdt32_t;
struct fdt_header {
fdt32_t magic;
fdt32_t totalsize;
fdt32_t off_dt_struct;
fdt32_t off_dt_strings;
fdt32_t off_mem_rsvmap;
fdt32_t version;
fdt32_t last_comp_version;
fdt32_t boot_cpuid_phys;
fdt32_t size_dt_strings;
fdt32_t size_dt_struct;
};
enum {
ASSUME_PERFECT = 255,
ASSUME_VALID_DTB = 1,
ASSUME_VALID_INPUT = 2,
ASSUME_LATEST = 4,
ASSUME_NO_ROLLBACK = 8,
ASSUME_LIBFDT_ORDER = 16,
ASSUME_LIBFDT_FLAWLESS = 32,
};
typedef __be64 fdt64_t;
struct fdt_reserve_entry {
fdt64_t address;
fdt64_t size;
};
struct fdt_node_header {
fdt32_t tag;
char name[0];
};
struct fdt_property {
fdt32_t tag;
fdt32_t len;
fdt32_t nameoff;
char data[0];
};
struct uuidcmp {
const char *uuid;
int len;
};
enum {
IRQ_DOMAIN_FLAG_HIERARCHY = 1,
IRQ_DOMAIN_NAME_ALLOCATED = 2,
IRQ_DOMAIN_FLAG_IPI_PER_CPU = 4,
IRQ_DOMAIN_FLAG_IPI_SINGLE = 8,
IRQ_DOMAIN_FLAG_MSI = 16,
IRQ_DOMAIN_FLAG_MSI_REMAP = 32,
IRQ_DOMAIN_MSI_NOMASK_QUIRK = 64,
IRQ_DOMAIN_FLAG_NO_MAP = 128,
IRQ_DOMAIN_FLAG_NONCORE = 65536,
};
enum {
IRQCHIP_FWNODE_REAL = 0,
IRQCHIP_FWNODE_NAMED = 1,
IRQCHIP_FWNODE_NAMED_ID = 2,
};
struct irqchip_fwid {
struct fwnode_handle fwnode;
unsigned int type;
char *name;
phys_addr_t *pa;
};
typedef struct elf32_hdr Elf32_Ehdr;
struct elf32_shdr {
Elf32_Word sh_name;
Elf32_Word sh_type;
Elf32_Word sh_flags;
Elf32_Addr sh_addr;
Elf32_Off sh_offset;
Elf32_Word sh_size;
Elf32_Word sh_link;
Elf32_Word sh_info;
Elf32_Word sh_addralign;
Elf32_Word sh_entsize;
};
typedef struct elf32_shdr Elf32_Shdr;
struct modversion_info {
long unsigned int crc;
char name[60];
};
struct _ddebug {
const char *modname;
const char *function;
const char *filename;
const char *format;
unsigned int lineno: 18;
unsigned int class_id: 6;
unsigned int flags: 8;
long: 32;
};
enum class_map_type {
DD_CLASS_TYPE_DISJOINT_BITS = 0,
DD_CLASS_TYPE_LEVEL_NUM = 1,
DD_CLASS_TYPE_DISJOINT_NAMES = 2,
DD_CLASS_TYPE_LEVEL_NAMES = 3,
};
struct ddebug_class_map {
struct list_head link;
struct module *mod;
const char *mod_name;
const char **class_names;
const int length;
const int base;
enum class_map_type map_type;
};
struct _ddebug_info {
struct _ddebug *descs;
struct ddebug_class_map *classes;
unsigned int num_descs;
unsigned int num_classes;
};
struct load_info {
const char *name;
struct module *mod;
Elf32_Ehdr *hdr;
long unsigned int len;
Elf32_Shdr *sechdrs;
char *secstrings;
char *strtab;
long unsigned int symoffs;
long unsigned int stroffs;
long unsigned int init_typeoffs;
long unsigned int core_typeoffs;
struct _ddebug_info dyndbg;
bool sig_ok;
long unsigned int mod_kallsyms_init_off;
struct {
unsigned int sym;
unsigned int str;
unsigned int mod;
unsigned int vers;
unsigned int info;
unsigned int pcpu;
} index;
};
enum mod_license {
NOT_GPL_ONLY = 0,
GPL_ONLY = 1,
};
struct find_symbol_arg {
const char *name;
bool gplok;
bool warn;
struct module *owner;
const s32 *crc;
const struct kernel_symbol *sym;
enum mod_license license;
};
struct class_interface {
struct list_head node;
struct class *class;
int (*add_dev)(struct device *, struct class_interface *);
void (*remove_dev)(struct device *, struct class_interface *);
};
struct property_entry;
struct platform_device_info {
struct device *parent;
struct fwnode_handle *fwnode;
bool of_node_reused;
const char *name;
int id;
const struct resource *res;
unsigned int num_res;
const void *data;
size_t size_data;
long: 32;
u64 dma_mask;
const struct property_entry *properties;
long: 32;
};
enum dev_prop_type {
DEV_PROP_U8 = 0,
DEV_PROP_U16 = 1,
DEV_PROP_U32 = 2,
DEV_PROP_U64 = 3,
DEV_PROP_STRING = 4,
DEV_PROP_REF = 5,
};
struct property_entry {
const char *name;
size_t length;
bool is_inline;
enum dev_prop_type type;
union {
const void *pointer;
union {
u8 u8_data[8];
u16 u16_data[4];
u32 u32_data[2];
u64 u64_data[1];
const char *str[2];
} value;
};
};
struct trace_event_raw_alarmtimer_suspend {
struct trace_entry ent;
s64 expires;
unsigned char alarm_type;
char __data[0];
long: 32;
};
struct trace_event_raw_alarm_class {
struct trace_entry ent;
void *alarm;
unsigned char alarm_type;
s64 expires;
s64 now;
char __data[0];
};
struct trace_event_data_offsets_alarmtimer_suspend {};
struct trace_event_data_offsets_alarm_class {};
typedef void (*btf_trace_alarmtimer_suspend)(void *, ktime_t, int);
typedef void (*btf_trace_alarmtimer_fired)(void *, struct alarm *, ktime_t);
typedef void (*btf_trace_alarmtimer_start)(void *, struct alarm *, ktime_t);
typedef void (*btf_trace_alarmtimer_cancel)(void *, struct alarm *, ktime_t);
struct alarm_base {
spinlock_t lock;
struct timerqueue_head timerqueue;
ktime_t (*get_ktime)();
void (*get_timespec)(struct timespec64 *);
clockid_t base_clockid;
};
enum {
CSD_FLAG_LOCK = 1,
IRQ_WORK_PENDING = 1,
IRQ_WORK_BUSY = 2,
IRQ_WORK_LAZY = 4,
IRQ_WORK_HARD_IRQ = 8,
IRQ_WORK_CLAIMED = 3,
CSD_TYPE_ASYNC = 0,
CSD_TYPE_SYNC = 16,
CSD_TYPE_IRQ_WORK = 32,
CSD_TYPE_TTWU = 48,
CSD_FLAG_TYPE_MASK = 240,
};
typedef bool (*smp_cond_func_t)(int, void *);
typedef struct __call_single_data call_single_data_t;
typedef struct {
unsigned int __softirq_pending;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
} irq_cpustat_t;
struct cfd_percpu {
call_single_data_t csd;
};
struct call_function_data {
struct cfd_percpu *pcpu;
cpumask_var_t cpumask;
cpumask_var_t cpumask_ipi;
};
struct smp_call_on_cpu_struct {
struct work_struct work;
struct completion done;
int (*func)(void *);
void *data;
int ret;
int cpu;
};
typedef void *va_list;
struct trace_print_flags_u64 {
long long unsigned int mask;
const char *name;
long: 32;
};
enum trace_iter_flags {
TRACE_FILE_LAT_FMT = 1,
TRACE_FILE_ANNOTATE = 2,
TRACE_FILE_TIME_IN_NS = 4,
};
enum trace_type {
__TRACE_FIRST_TYPE = 0,
TRACE_FN = 1,
TRACE_CTX = 2,
TRACE_WAKE = 3,
TRACE_STACK = 4,
TRACE_PRINT = 5,
TRACE_BPRINT = 6,
TRACE_MMIO_RW = 7,
TRACE_MMIO_MAP = 8,
TRACE_BRANCH = 9,
TRACE_GRAPH_RET = 10,
TRACE_GRAPH_ENT = 11,
TRACE_USER_STACK = 12,
TRACE_BLK = 13,
TRACE_BPUTS = 14,
TRACE_HWLAT = 15,
TRACE_OSNOISE = 16,
TRACE_TIMERLAT = 17,
TRACE_RAW_DATA = 18,
TRACE_FUNC_REPEATS = 19,
__TRACE_LAST_TYPE = 20,
};
struct ftrace_entry {
struct trace_entry ent;
long unsigned int ip;
long unsigned int parent_ip;
};
struct ctx_switch_entry {
struct trace_entry ent;
unsigned int prev_pid;
unsigned int next_pid;
unsigned int next_cpu;
unsigned char prev_prio;
unsigned char prev_state;
unsigned char next_prio;
unsigned char next_state;
};
struct stack_entry {
struct trace_entry ent;
int size;
long unsigned int caller[8];
};
struct userstack_entry {
struct trace_entry ent;
unsigned int tgid;
long unsigned int caller[8];
};
struct bprint_entry {
struct trace_entry ent;
long unsigned int ip;
const char *fmt;
u32 buf[0];
};
struct print_entry {
struct trace_entry ent;
long unsigned int ip;
char buf[0];
};
struct raw_data_entry {
struct trace_entry ent;
unsigned int id;
char buf[0];
};
struct bputs_entry {
struct trace_entry ent;
long unsigned int ip;
const char *str;
};
struct hwlat_entry {
struct trace_entry ent;
u64 duration;
u64 outer_duration;
u64 nmi_total_ts;
struct timespec64 timestamp;
unsigned int nmi_count;
unsigned int seqnum;
unsigned int count;
long: 32;
};
struct func_repeats_entry {
struct trace_entry ent;
long unsigned int ip;
long unsigned int parent_ip;
u16 count;
u16 top_delta_ts;
u32 bottom_delta_ts;
};
struct osnoise_entry {
struct trace_entry ent;
u64 noise;
u64 runtime;
u64 max_sample;
unsigned int hw_count;
unsigned int nmi_count;
unsigned int irq_count;
unsigned int softirq_count;
unsigned int thread_count;
long: 32;
};
struct timerlat_entry {
struct trace_entry ent;
unsigned int seqnum;
int context;
u64 timer_latency;
};
enum trace_iterator_flags {
TRACE_ITER_PRINT_PARENT = 1,
TRACE_ITER_SYM_OFFSET = 2,
TRACE_ITER_SYM_ADDR = 4,
TRACE_ITER_VERBOSE = 8,
TRACE_ITER_RAW = 16,
TRACE_ITER_HEX = 32,
TRACE_ITER_BIN = 64,
TRACE_ITER_BLOCK = 128,
TRACE_ITER_PRINTK = 256,
TRACE_ITER_ANNOTATE = 512,
TRACE_ITER_USERSTACKTRACE = 1024,
TRACE_ITER_SYM_USEROBJ = 2048,
TRACE_ITER_PRINTK_MSGONLY = 4096,
TRACE_ITER_CONTEXT_INFO = 8192,
TRACE_ITER_LATENCY_FMT = 16384,
TRACE_ITER_RECORD_CMD = 32768,
TRACE_ITER_RECORD_TGID = 65536,
TRACE_ITER_OVERWRITE = 131072,
TRACE_ITER_STOP_ON_FREE = 262144,
TRACE_ITER_IRQ_INFO = 524288,
TRACE_ITER_MARKERS = 1048576,
TRACE_ITER_EVENT_FORK = 2097152,
TRACE_ITER_PAUSE_ON_TRACE = 4194304,
TRACE_ITER_HASH_PTR = 8388608,
TRACE_ITER_FUNCTION = 16777216,
TRACE_ITER_FUNC_FORK = 33554432,
TRACE_ITER_DISPLAY_GRAPH = 67108864,
TRACE_ITER_STACKTRACE = 134217728,
};
struct trace_mark {
long long unsigned int val;
char sym;
long: 32;
};
struct ftrace_event_field {
struct list_head link;
const char *name;
const char *type;
int filter_type;
int offset;
int size;
int is_signed;
};
struct filter_pred;
struct prog_entry {
int target;
int when_to_branch;
struct filter_pred *pred;
};
struct regex;
typedef int (*regex_match_func)(char *, struct regex *, int);
struct regex {
char pattern[256];
int len;
int field_len;
regex_match_func match;
};
enum regex_type {
MATCH_FULL = 0,
MATCH_FRONT_ONLY = 1,
MATCH_MIDDLE_ONLY = 2,
MATCH_END_ONLY = 3,
MATCH_GLOB = 4,
MATCH_INDEX = 5,
};
enum filter_op_ids {
OP_GLOB = 0,
OP_NE = 1,
OP_EQ = 2,
OP_LE = 3,
OP_LT = 4,
OP_GE = 5,
OP_GT = 6,
OP_BAND = 7,
OP_MAX = 8,
};
enum filter_pred_fn {
FILTER_PRED_FN_NOP = 0,
FILTER_PRED_FN_64 = 1,
FILTER_PRED_FN_S64 = 2,
FILTER_PRED_FN_U64 = 3,
FILTER_PRED_FN_32 = 4,
FILTER_PRED_FN_S32 = 5,
FILTER_PRED_FN_U32 = 6,
FILTER_PRED_FN_16 = 7,
FILTER_PRED_FN_S16 = 8,
FILTER_PRED_FN_U16 = 9,
FILTER_PRED_FN_8 = 10,
FILTER_PRED_FN_S8 = 11,
FILTER_PRED_FN_U8 = 12,
FILTER_PRED_FN_COMM = 13,
FILTER_PRED_FN_STRING = 14,
FILTER_PRED_FN_STRLOC = 15,
FILTER_PRED_FN_STRRELLOC = 16,
FILTER_PRED_FN_PCHAR_USER = 17,
FILTER_PRED_FN_PCHAR = 18,
FILTER_PRED_FN_CPU = 19,
FILTER_PRED_FN_ = 20,
FILTER_PRED_TEST_VISITED = 21,
};
struct filter_pred {
enum filter_pred_fn fn_num;
long: 32;
u64 val;
struct regex regex;
short unsigned int *ops;
struct ftrace_event_field *field;
int offset;
int not;
int op;
};
enum {
FILT_ERR_NONE = 0,
FILT_ERR_INVALID_OP = 1,
FILT_ERR_TOO_MANY_OPEN = 2,
FILT_ERR_TOO_MANY_CLOSE = 3,
FILT_ERR_MISSING_QUOTE = 4,
FILT_ERR_OPERAND_TOO_LONG = 5,
FILT_ERR_EXPECT_STRING = 6,
FILT_ERR_EXPECT_DIGIT = 7,
FILT_ERR_ILLEGAL_FIELD_OP = 8,
FILT_ERR_FIELD_NOT_FOUND = 9,
FILT_ERR_ILLEGAL_INTVAL = 10,
FILT_ERR_BAD_SUBSYS_FILTER = 11,
FILT_ERR_TOO_MANY_PREDS = 12,
FILT_ERR_INVALID_FILTER = 13,
FILT_ERR_IP_FIELD_ONLY = 14,
FILT_ERR_INVALID_VALUE = 15,
FILT_ERR_ERRNO = 16,
FILT_ERR_NO_FILTER = 17,
};
struct filter_parse_error {
int lasterr;
int lasterr_pos;
};
typedef int (*parse_pred_fn)(const char *, void *, int, struct filter_parse_error *, struct filter_pred **);
enum {
INVERT = 1,
PROCESS_AND = 2,
PROCESS_OR = 4,
};
struct ustring_buffer {
char buffer[1024];
};
enum {
TOO_MANY_CLOSE = -1,
TOO_MANY_OPEN = -2,
MISSING_QUOTE = -3,
};
struct filter_list {
struct list_head list;
struct event_filter *filter;
};
struct function_filter_data {
struct ftrace_ops *ops;
int first_filter;
int first_notrace;
};
enum {
BPF_ANY = 0,
BPF_NOEXIST = 1,
BPF_EXIST = 2,
BPF_F_LOCK = 4,
};
enum {
BPF_F_NO_PREALLOC = 1,
BPF_F_NO_COMMON_LRU = 2,
BPF_F_NUMA_NODE = 4,
BPF_F_RDONLY = 8,
BPF_F_WRONLY = 16,
BPF_F_STACK_BUILD_ID = 32,
BPF_F_ZERO_SEED = 64,
BPF_F_RDONLY_PROG = 128,
BPF_F_WRONLY_PROG = 256,
BPF_F_CLONE = 512,
BPF_F_MMAPABLE = 1024,
BPF_F_PRESERVE_ELEMS = 2048,
BPF_F_INNER_MAP = 4096,
};
struct bpf_queue_stack {
struct bpf_map map;
raw_spinlock_t lock;
u32 head;
u32 tail;
u32 size;
char elements[0];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct fdtable {
unsigned int max_fds;
struct file **fd;
long unsigned int *close_on_exec;
long unsigned int *open_fds;
long unsigned int *full_fds_bits;
struct callback_head rcu;
};
struct files_struct {
atomic_t count;
bool resize_in_progress;
wait_queue_head_t resize_wait;
struct fdtable *fdt;
struct fdtable fdtab;
long: 32;
long: 32;
long: 32;
spinlock_t file_lock;
unsigned int next_fd;
long unsigned int close_on_exec_init[1];
long unsigned int open_fds_init[1];
long unsigned int full_fds_bits_init[1];
struct file *fd_array[32];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum {
BPF_LOCAL_STORAGE_GET_F_CREATE = 1,
BPF_SK_STORAGE_GET_F_CREATE = 1,
};
struct bpf_local_storage_elem {
struct hlist_node map_node;
struct hlist_node snode;
struct bpf_local_storage *local_storage;
struct callback_head rcu;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct bpf_local_storage_data sdata;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_local_storage_cache {
spinlock_t idx_lock;
long: 32;
u64 idx_usage_counts[16];
};
enum {
BTF_TRACING_TYPE_TASK = 0,
BTF_TRACING_TYPE_FILE = 1,
BTF_TRACING_TYPE_VMA = 2,
MAX_BTF_TRACING_TYPE = 3,
};
typedef u64 (*btf_bpf_task_storage_get)(struct bpf_map *, struct task_struct *, void *, u64, gfp_t);
typedef u64 (*btf_bpf_task_storage_delete)(struct bpf_map *, struct task_struct *);
struct reuseport_array {
struct bpf_map map;
struct sock *ptrs[0];
};
struct anon_vma_chain {
struct vm_area_struct *vma;
struct anon_vma *anon_vma;
struct list_head same_vma;
struct rb_node rb;
long unsigned int rb_subtree_last;
};
struct rb_augment_callbacks {
void (*propagate)(struct rb_node *, struct rb_node *);
void (*copy)(struct rb_node *, struct rb_node *);
void (*rotate)(struct rb_node *, struct rb_node *);
};
struct maple_alloc {
long unsigned int total;
unsigned char node_count;
unsigned int request_count;
struct maple_alloc *slot[61];
};
struct maple_enode;
struct ma_state {
struct maple_tree *tree;
long unsigned int index;
long unsigned int last;
struct maple_enode *node;
long unsigned int min;
long unsigned int max;
struct maple_alloc *alloc;
unsigned char depth;
unsigned char offset;
unsigned char mas_flags;
};
struct mmu_notifier_range {
long unsigned int start;
long unsigned int end;
};
struct mempolicy {};
enum pgt_entry {
NORMAL_PMD = 0,
HPAGE_PMD = 1,
NORMAL_PUD = 2,
HPAGE_PUD = 3,
};
struct file_dedupe_range_info {
__s64 dest_fd;
__u64 dest_offset;
__u64 bytes_deduped;
__s32 status;
__u32 reserved;
};
struct file_dedupe_range {
__u64 src_offset;
__u64 src_length;
__u16 dest_count;
__u16 reserved1;
__u32 reserved2;
struct file_dedupe_range_info info[0];
};
struct file_handle {
__u32 handle_bytes;
int handle_type;
unsigned char f_handle[0];
};
enum fid_type {
FILEID_ROOT = 0,
FILEID_INO32_GEN = 1,
FILEID_INO32_GEN_PARENT = 2,
FILEID_BTRFS_WITHOUT_PARENT = 77,
FILEID_BTRFS_WITH_PARENT = 78,
FILEID_BTRFS_WITH_PARENT_ROOT = 79,
FILEID_UDF_WITHOUT_PARENT = 81,
FILEID_UDF_WITH_PARENT = 82,
FILEID_NILFS_WITHOUT_PARENT = 97,
FILEID_NILFS_WITH_PARENT = 98,
FILEID_FAT_WITHOUT_PARENT = 113,
FILEID_FAT_WITH_PARENT = 114,
FILEID_LUSTRE = 151,
FILEID_KERNFS = 254,
FILEID_INVALID = 255,
};
struct mmp_struct {
__le32 mmp_magic;
__le32 mmp_seq;
__le64 mmp_time;
char mmp_nodename[64];
char mmp_bdevname[32];
__le16 mmp_check_interval;
__le16 mmp_pad1;
__le32 mmp_pad2[226];
__le32 mmp_checksum;
};
struct pnfs_layout_range {
u32 iomode;
long: 32;
u64 offset;
u64 length;
};
struct pnfs_layout_hdr;
struct pnfs_layout_segment {
struct list_head pls_list;
struct list_head pls_lc_list;
struct list_head pls_commits;
struct pnfs_layout_range pls_range;
refcount_t pls_refcount;
u32 pls_seq;
long unsigned int pls_flags;
struct pnfs_layout_hdr *pls_layout;
};
enum {
NFS_IOHDR_ERROR = 0,
NFS_IOHDR_EOF = 1,
NFS_IOHDR_REDO = 2,
NFS_IOHDR_STAT = 3,
NFS_IOHDR_RESEND_PNFS = 4,
NFS_IOHDR_RESEND_MDS = 5,
NFS_IOHDR_UNSTABLE_WRITES = 6,
};
enum {
PG_BUSY = 0,
PG_MAPPED = 1,
PG_CLEAN = 2,
PG_COMMIT_TO_DS = 3,
PG_INODE_REF = 4,
PG_HEADLOCK = 5,
PG_TEARDOWN = 6,
PG_UNLOCKPAGE = 7,
PG_UPTODATE = 8,
PG_WB_END = 9,
PG_REMOVE = 10,
PG_CONTENDED1 = 11,
PG_CONTENDED2 = 12,
};
struct nfs_pageio_descriptor;
struct nfs_pgio_mirror;
struct nfs_pageio_ops {
void (*pg_init)(struct nfs_pageio_descriptor *, struct nfs_page *);
size_t (*pg_test)(struct nfs_pageio_descriptor *, struct nfs_page *, struct nfs_page *);
int (*pg_doio)(struct nfs_pageio_descriptor *);
unsigned int (*pg_get_mirror_count)(struct nfs_pageio_descriptor *, struct nfs_page *);
void (*pg_cleanup)(struct nfs_pageio_descriptor *);
struct nfs_pgio_mirror * (*pg_get_mirror)(struct nfs_pageio_descriptor *, u32);
u32 (*pg_set_mirror)(struct nfs_pageio_descriptor *, u32);
};
struct nfs_pgio_mirror {
struct list_head pg_list;
long unsigned int pg_bytes_written;
size_t pg_count;
size_t pg_bsize;
unsigned int pg_base;
unsigned char pg_recoalesce: 1;
};
struct nfs_pageio_descriptor {
struct inode *pg_inode;
const struct nfs_pageio_ops *pg_ops;
const struct nfs_rw_ops *pg_rw_ops;
int pg_ioflags;
int pg_error;
const struct rpc_call_ops *pg_rpc_callops;
const struct nfs_pgio_completion_ops *pg_completion_ops;
struct pnfs_layout_segment *pg_lseg;
struct nfs_io_completion *pg_io_completion;
struct nfs_direct_req *pg_dreq;
unsigned int pg_bsize;
u32 pg_mirror_count;
struct nfs_pgio_mirror *pg_mirrors;
struct nfs_pgio_mirror pg_mirrors_static[1];
struct nfs_pgio_mirror *pg_mirrors_dynamic;
u32 pg_mirror_idx;
short unsigned int pg_maxretrans;
unsigned char pg_moreio: 1;
};
struct nfs_readdesc {
struct nfs_pageio_descriptor pgio;
struct nfs_open_context *ctx;
};
enum rpc_accept_stat {
RPC_SUCCESS = 0,
RPC_PROG_UNAVAIL = 1,
RPC_PROG_MISMATCH = 2,
RPC_PROC_UNAVAIL = 3,
RPC_GARBAGE_ARGS = 4,
RPC_SYSTEM_ERR = 5,
RPC_DROP_REPLY = 60000,
};
struct svc_cacherep {
struct {
__be32 k_xid;
__wsum k_csum;
u32 k_proc;
u32 k_prot;
u32 k_vers;
unsigned int k_len;
struct sockaddr_in6 k_addr;
} c_key;
struct rb_node c_node;
struct list_head c_lru;
unsigned char c_state;
unsigned char c_type;
unsigned char c_secure: 1;
long unsigned int c_timestamp;
union {
struct kvec u_vec;
__be32 u_status;
} c_u;
};
enum {
RC_NOCACHE = 0,
RC_REPLSTAT = 1,
RC_REPLBUFF = 2,
};
enum nfs_stat {
NFS_OK = 0,
NFSERR_PERM = 1,
NFSERR_NOENT = 2,
NFSERR_IO = 5,
NFSERR_NXIO = 6,
NFSERR_EAGAIN = 11,
NFSERR_ACCES = 13,
NFSERR_EXIST = 17,
NFSERR_XDEV = 18,
NFSERR_NODEV = 19,
NFSERR_NOTDIR = 20,
NFSERR_ISDIR = 21,
NFSERR_INVAL = 22,
NFSERR_FBIG = 27,
NFSERR_NOSPC = 28,
NFSERR_ROFS = 30,
NFSERR_MLINK = 31,
NFSERR_OPNOTSUPP = 45,
NFSERR_NAMETOOLONG = 63,
NFSERR_NOTEMPTY = 66,
NFSERR_DQUOT = 69,
NFSERR_STALE = 70,
NFSERR_REMOTE = 71,
NFSERR_WFLUSH = 99,
NFSERR_BADHANDLE = 10001,
NFSERR_NOT_SYNC = 10002,
NFSERR_BAD_COOKIE = 10003,
NFSERR_NOTSUPP = 10004,
NFSERR_TOOSMALL = 10005,
NFSERR_SERVERFAULT = 10006,
NFSERR_BADTYPE = 10007,
NFSERR_JUKEBOX = 10008,
NFSERR_SAME = 10009,
NFSERR_DENIED = 10010,
NFSERR_EXPIRED = 10011,
NFSERR_LOCKED = 10012,
NFSERR_GRACE = 10013,
NFSERR_FHEXPIRED = 10014,
NFSERR_SHARE_DENIED = 10015,
NFSERR_WRONGSEC = 10016,
NFSERR_CLID_INUSE = 10017,
NFSERR_RESOURCE = 10018,
NFSERR_MOVED = 10019,
NFSERR_NOFILEHANDLE = 10020,
NFSERR_MINOR_VERS_MISMATCH = 10021,
NFSERR_STALE_CLIENTID = 10022,
NFSERR_STALE_STATEID = 10023,
NFSERR_OLD_STATEID = 10024,
NFSERR_BAD_STATEID = 10025,
NFSERR_BAD_SEQID = 10026,
NFSERR_NOT_SAME = 10027,
NFSERR_LOCK_RANGE = 10028,
NFSERR_SYMLINK = 10029,
NFSERR_RESTOREFH = 10030,
NFSERR_LEASE_MOVED = 10031,
NFSERR_ATTRNOTSUPP = 10032,
NFSERR_NO_GRACE = 10033,
NFSERR_RECLAIM_BAD = 10034,
NFSERR_RECLAIM_CONFLICT = 10035,
NFSERR_BAD_XDR = 10036,
NFSERR_LOCKS_HELD = 10037,
NFSERR_OPENMODE = 10038,
NFSERR_BADOWNER = 10039,
NFSERR_BADCHAR = 10040,
NFSERR_BADNAME = 10041,
NFSERR_BAD_RANGE = 10042,
NFSERR_LOCK_NOTSUPP = 10043,
NFSERR_OP_ILLEGAL = 10044,
NFSERR_DEADLOCK = 10045,
NFSERR_FILE_OPEN = 10046,
NFSERR_ADMIN_REVOKED = 10047,
NFSERR_CB_PATH_DOWN = 10048,
};
enum {
EXP_STATS_FH_STALE = 0,
EXP_STATS_IO_READ = 1,
EXP_STATS_IO_WRITE = 2,
EXP_STATS_COUNTERS_NUM = 3,
};
enum {
NFSD_STATS_RC_HITS = 0,
NFSD_STATS_RC_MISSES = 1,
NFSD_STATS_RC_NOCACHE = 2,
NFSD_STATS_FH_STALE = 3,
NFSD_STATS_IO_READ = 4,
NFSD_STATS_IO_WRITE = 5,
NFSD_STATS_COUNTERS_NUM = 6,
};
struct readdir_cd {
__be32 err;
};
struct knfsd_fh {
unsigned int fh_size;
union {
char fh_raw[128];
struct {
u8 fh_version;
u8 fh_auth_type;
u8 fh_fsid_type;
u8 fh_fileid_type;
u32 fh_fsid[0];
};
};
};
struct svc_fh {
struct knfsd_fh fh_handle;
int fh_maxsize;
struct dentry *fh_dentry;
struct svc_export *fh_export;
bool fh_want_write;
bool fh_no_wcc;
bool fh_no_atomic_attr;
int fh_flags;
bool fh_post_saved;
bool fh_pre_saved;
long: 32;
__u64 fh_pre_size;
struct timespec64 fh_pre_mtime;
struct timespec64 fh_pre_ctime;
u64 fh_pre_change;
struct kstat fh_post_attr;
u64 fh_post_change;
};
typedef struct svc_fh svc_fh;
struct nfsd_fhandle {
struct svc_fh fh;
};
struct nfsd3_sattrargs {
struct svc_fh fh;
struct iattr attrs;
int check_guard;
long: 32;
time64_t guardtime;
};
struct nfsd3_diropargs {
struct svc_fh fh;
char *name;
unsigned int len;
};
struct nfsd3_accessargs {
struct svc_fh fh;
__u32 access;
long: 32;
};
struct nfsd3_readargs {
struct svc_fh fh;
__u64 offset;
__u32 count;
long: 32;
};
struct nfsd3_writeargs {
svc_fh fh;
__u64 offset;
__u32 count;
int stable;
__u32 len;
struct xdr_buf payload;
};
struct nfsd3_createargs {
struct svc_fh fh;
char *name;
unsigned int len;
int createmode;
long: 32;
struct iattr attrs;
__be32 *verf;
long: 32;
};
struct nfsd3_mknodargs {
struct svc_fh fh;
char *name;
unsigned int len;
__u32 ftype;
__u32 major;
__u32 minor;
long: 32;
struct iattr attrs;
};
struct nfsd3_renameargs {
struct svc_fh ffh;
char *fname;
unsigned int flen;
struct svc_fh tfh;
char *tname;
unsigned int tlen;
};
struct nfsd3_linkargs {
struct svc_fh ffh;
struct svc_fh tfh;
char *tname;
unsigned int tlen;
};
struct nfsd3_symlinkargs {
struct svc_fh ffh;
char *fname;
unsigned int flen;
char *tname;
unsigned int tlen;
struct iattr attrs;
struct kvec first;
};
struct nfsd3_readdirargs {
struct svc_fh fh;
__u64 cookie;
__u32 count;
__be32 *verf;
};
struct nfsd3_commitargs {
struct svc_fh fh;
__u64 offset;
__u32 count;
long: 32;
};
struct nfsd3_attrstat {
__be32 status;
long: 32;
struct svc_fh fh;
struct kstat stat;
};
struct nfsd3_diropres {
__be32 status;
long: 32;
struct svc_fh dirfh;
struct svc_fh fh;
};
struct nfsd3_accessres {
__be32 status;
long: 32;
struct svc_fh fh;
__u32 access;
long: 32;
struct kstat stat;
};
struct nfsd3_readlinkres {
__be32 status;
long: 32;
struct svc_fh fh;
__u32 len;
struct page **pages;
};
struct nfsd3_readres {
__be32 status;
long: 32;
struct svc_fh fh;
long unsigned int count;
__u32 eof;
struct page **pages;
long: 32;
};
struct nfsd3_writeres {
__be32 status;
long: 32;
struct svc_fh fh;
long unsigned int count;
int committed;
__be32 verf[2];
};
struct nfsd3_renameres {
__be32 status;
long: 32;
struct svc_fh ffh;
struct svc_fh tfh;
};
struct nfsd3_linkres {
__be32 status;
long: 32;
struct svc_fh tfh;
struct svc_fh fh;
};
struct nfsd3_readdirres {
__be32 status;
long: 32;
struct svc_fh fh;
__be32 verf[2];
struct xdr_stream xdr;
struct xdr_buf dirlist;
struct svc_fh scratch;
struct readdir_cd common;
unsigned int cookie_offset;
struct svc_rqst *rqstp;
long: 32;
};
struct nfsd3_fsstatres {
__be32 status;
long: 32;
struct kstatfs stats;
__u32 invarsec;
long: 32;
};
struct nfsd3_fsinfores {
__be32 status;
__u32 f_rtmax;
__u32 f_rtpref;
__u32 f_rtmult;
__u32 f_wtmax;
__u32 f_wtpref;
__u32 f_wtmult;
__u32 f_dtpref;
__u64 f_maxfilesize;
__u32 f_properties;
long: 32;
};
struct nfsd3_pathconfres {
__be32 status;
__u32 p_link_max;
__u32 p_name_max;
__u32 p_no_trunc;
__u32 p_chown_restricted;
__u32 p_case_insensitive;
__u32 p_case_preserving;
};
struct nfsd3_commitres {
__be32 status;
long: 32;
struct svc_fh fh;
__be32 verf[2];
};
typedef int (*nfsd_filldir_t)(void *, const char *, int, loff_t, u64, unsigned int);
struct nfsd_attrs {
struct iattr *na_iattr;
struct xdr_netobj *na_seclabel;
struct posix_acl *na_pacl;
struct posix_acl *na_dpacl;
int na_labelerr;
int na_aclerr;
};
struct autofs_packet_missing {
struct autofs_packet_hdr hdr;
autofs_wqt_t wait_queue_token;
int len;
char name[256];
};
struct autofs_packet_expire_multi {
struct autofs_packet_hdr hdr;
autofs_wqt_t wait_queue_token;
int len;
char name[256];
};
union autofs_packet_union {
struct autofs_packet_hdr hdr;
struct autofs_packet_missing missing;
struct autofs_packet_expire expire;
struct autofs_packet_expire_multi expire_multi;
};
struct autofs_v5_packet {
struct autofs_packet_hdr hdr;
autofs_wqt_t wait_queue_token;
__u32 dev;
__u64 ino;
__u32 uid;
__u32 gid;
__u32 pid;
__u32 tgid;
__u32 len;
char name[256];
long: 32;
};
typedef struct autofs_v5_packet autofs_packet_missing_indirect_t;
typedef struct autofs_v5_packet autofs_packet_expire_indirect_t;
typedef struct autofs_v5_packet autofs_packet_missing_direct_t;
typedef struct autofs_v5_packet autofs_packet_expire_direct_t;
union autofs_v5_packet_union {
struct autofs_packet_hdr hdr;
struct autofs_v5_packet v5_packet;
autofs_packet_missing_indirect_t missing_indirect;
autofs_packet_expire_indirect_t expire_indirect;
autofs_packet_missing_direct_t missing_direct;
autofs_packet_expire_direct_t expire_direct;
};
typedef unsigned int __kernel_mode_t;
typedef int __kernel_ipc_pid_t;
typedef __kernel_long_t __kernel_old_time_t;
struct vma_iterator {
struct ma_state mas;
};
struct ipc_perm {
__kernel_key_t key;
__kernel_uid_t uid;
__kernel_gid_t gid;
__kernel_uid_t cuid;
__kernel_gid_t cgid;
__kernel_mode_t mode;
short unsigned int seq;
};
struct ipc64_perm {
__kernel_key_t key;
__kernel_uid32_t uid;
__kernel_gid32_t gid;
__kernel_uid32_t cuid;
__kernel_gid32_t cgid;
__kernel_mode_t mode;
unsigned char __pad1[0];
short unsigned int seq;
short unsigned int __pad2;
__kernel_ulong_t __unused1;
__kernel_ulong_t __unused2;
};
struct shmid_ds {
struct ipc_perm shm_perm;
int shm_segsz;
__kernel_old_time_t shm_atime;
__kernel_old_time_t shm_dtime;
__kernel_old_time_t shm_ctime;
__kernel_ipc_pid_t shm_cpid;
__kernel_ipc_pid_t shm_lpid;
short unsigned int shm_nattch;
short unsigned int shm_unused;
void *shm_unused2;
void *shm_unused3;
};
struct shmid64_ds {
struct ipc64_perm shm_perm;
__kernel_size_t shm_segsz;
long unsigned int shm_atime;
long unsigned int shm_dtime;
long unsigned int shm_ctime;
__kernel_pid_t shm_cpid;
__kernel_pid_t shm_lpid;
long unsigned int shm_nattch;
short unsigned int shm_atime_high;
short unsigned int shm_dtime_high;
short unsigned int shm_ctime_high;
short unsigned int __unused1;
};
struct shminfo64 {
long unsigned int shmmax;
long unsigned int shmmin;
long unsigned int shmmni;
long unsigned int shmseg;
long unsigned int shmall;
long unsigned int __unused1;
long unsigned int __unused2;
long unsigned int __unused3;
long unsigned int __unused4;
};
struct shminfo {
int shmmax;
int shmmin;
int shmmni;
int shmseg;
int shmall;
};
struct shm_info {
int used_ids;
__kernel_ulong_t shm_tot;
__kernel_ulong_t shm_rss;
__kernel_ulong_t shm_swp;
__kernel_ulong_t swap_attempts;
__kernel_ulong_t swap_successes;
};
struct ipc_params {
key_t key;
int flg;
union {
size_t size;
int nsems;
} u;
};
struct ipc_ops {
int (*getnew)(struct ipc_namespace *, struct ipc_params *);
int (*associate)(struct kern_ipc_perm *, int);
int (*more_checks)(struct kern_ipc_perm *, struct ipc_params *);
};
struct shmid_kernel {
struct kern_ipc_perm shm_perm;
struct file *shm_file;
long unsigned int shm_nattch;
long unsigned int shm_segsz;
long: 32;
time64_t shm_atim;
time64_t shm_dtim;
time64_t shm_ctim;
struct pid *shm_cprid;
struct pid *shm_lprid;
struct ucounts *mlock_ucounts;
struct task_struct *shm_creator;
struct list_head shm_clist;
struct ipc_namespace *ns;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct shm_file_data {
int id;
struct ipc_namespace *ns;
struct file *file;
const struct vm_operations_struct *vm_ops;
};
struct aead_request {
struct crypto_async_request base;
unsigned int assoclen;
unsigned int cryptlen;
u8 *iv;
struct scatterlist *src;
struct scatterlist *dst;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__ctx[0];
};
struct aead_alg {
int (*setkey)(struct crypto_aead *, const u8 *, unsigned int);
int (*setauthsize)(struct crypto_aead *, unsigned int);
int (*encrypt)(struct aead_request *);
int (*decrypt)(struct aead_request *);
int (*init)(struct crypto_aead *);
void (*exit)(struct crypto_aead *);
unsigned int ivsize;
unsigned int maxauthsize;
unsigned int chunksize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct crypto_aead {
unsigned int authsize;
unsigned int reqsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_tfm base;
};
struct rtattr {
short unsigned int rta_len;
short unsigned int rta_type;
};
struct scatter_walk {
struct scatterlist *sg;
unsigned int offset;
};
struct crypto_cipher {
struct crypto_tfm base;
};
struct crypto_cipher_spawn {
struct crypto_spawn base;
};
struct skcipher_request {
unsigned int cryptlen;
u8 *iv;
struct scatterlist *src;
struct scatterlist *dst;
struct crypto_async_request base;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__ctx[0];
};
struct crypto_skcipher {
unsigned int reqsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_tfm base;
};
struct crypto_sync_skcipher {
struct crypto_skcipher base;
};
struct skcipher_alg {
int (*setkey)(struct crypto_skcipher *, const u8 *, unsigned int);
int (*encrypt)(struct skcipher_request *);
int (*decrypt)(struct skcipher_request *);
int (*init)(struct crypto_skcipher *);
void (*exit)(struct crypto_skcipher *);
unsigned int min_keysize;
unsigned int max_keysize;
unsigned int ivsize;
unsigned int chunksize;
unsigned int walksize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct skcipher_instance {
void (*free)(struct skcipher_instance *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
union {
struct {
char head[128];
struct crypto_instance base;
} s;
struct skcipher_alg alg;
};
};
struct crypto_skcipher_spawn {
struct crypto_spawn base;
};
struct skcipher_walk {
union {
struct {
struct page *page;
long unsigned int offset;
} phys;
struct {
u8 *page;
void *addr;
} virt;
} src;
union {
struct {
struct page *page;
long unsigned int offset;
} phys;
struct {
u8 *page;
void *addr;
} virt;
} dst;
struct scatter_walk in;
unsigned int nbytes;
struct scatter_walk out;
unsigned int total;
struct list_head buffers;
u8 *page;
u8 *buffer;
u8 *oiv;
void *iv;
unsigned int ivsize;
int flags;
unsigned int blocksize;
unsigned int stride;
unsigned int alignmask;
};
struct skcipher_ctx_simple {
struct crypto_cipher *cipher;
};
struct crypto_report_blkcipher {
char type[64];
char geniv[64];
unsigned int blocksize;
unsigned int min_keysize;
unsigned int max_keysize;
unsigned int ivsize;
};
enum {
SKCIPHER_WALK_PHYS = 1,
SKCIPHER_WALK_SLOW = 2,
SKCIPHER_WALK_COPY = 4,
SKCIPHER_WALK_DIFF = 8,
SKCIPHER_WALK_SLEEP = 16,
};
struct skcipher_walk_buffer {
struct list_head entry;
struct scatter_walk dst;
unsigned int len;
u8 *data;
u8 buffer[0];
};
struct bsg_device {
struct request_queue *queue;
long: 32;
struct device device;
struct cdev cdev;
int max_queue;
unsigned int timeout;
unsigned int reserved_size;
bsg_sg_io_fn *sg_io_fn;
long: 32;
};
struct user_msghdr {
void *msg_name;
int msg_namelen;
struct iovec *msg_iov;
__kernel_size_t msg_iovlen;
void *msg_control;
__kernel_size_t msg_controllen;
unsigned int msg_flags;
};
typedef u32 compat_size_t;
typedef s32 compat_int_t;
typedef u32 compat_uint_t;
typedef u32 compat_uptr_t;
struct compat_msghdr {
compat_uptr_t msg_name;
compat_int_t msg_namelen;
compat_uptr_t msg_iov;
compat_size_t msg_iovlen;
compat_uptr_t msg_control;
compat_size_t msg_controllen;
compat_uint_t msg_flags;
};
struct io_uring_buf {
__u64 addr;
__u32 len;
__u16 bid;
__u16 resv;
};
struct io_uring_buf_ring {
union {
struct {
__u64 resv1;
__u32 resv2;
__u16 resv3;
__u16 tail;
};
struct io_uring_buf bufs[0];
};
};
struct io_uring_recvmsg_out {
__u32 namelen;
__u32 controllen;
__u32 payloadlen;
__u32 flags;
};
struct io_buffer_list {
union {
struct list_head buf_list;
struct {
struct page **buf_pages;
struct io_uring_buf_ring *buf_ring;
};
};
__u16 bgid;
__u16 buf_nr_pages;
__u16 nr_entries;
__u16 head;
__u16 mask;
};
struct io_buffer {
struct list_head list;
__u64 addr;
__u32 len;
__u16 bid;
__u16 bgid;
};
struct io_cache_entry {
struct hlist_node node;
};
struct io_async_msghdr {
union {
struct iovec fast_iov[8];
struct {
struct iovec fast_iov_one;
__kernel_size_t controllen;
int namelen;
__kernel_size_t payloadlen;
};
struct io_cache_entry cache;
};
struct iovec *free_iov;
struct sockaddr *uaddr;
struct msghdr msg;
struct __kernel_sockaddr_storage addr;
};
struct io_async_connect {
struct __kernel_sockaddr_storage address;
};
struct io_shutdown {
struct file *file;
int how;
};
struct io_accept {
struct file *file;
struct sockaddr *addr;
int *addr_len;
int flags;
u32 file_slot;
long unsigned int nofile;
};
struct io_socket {
struct file *file;
int domain;
int type;
int protocol;
int flags;
u32 file_slot;
long unsigned int nofile;
};
struct io_connect {
struct file *file;
struct sockaddr *addr;
int addr_len;
bool in_progress;
};
struct io_sr_msg {
struct file *file;
union {
struct compat_msghdr *umsg_compat;
struct user_msghdr *umsg;
void *buf;
};
unsigned int len;
unsigned int done_io;
unsigned int msg_flags;
u16 flags;
u16 addr_len;
void *addr;
struct io_kiocb *notif;
};
struct io_recvmsg_multishot_hdr {
struct io_uring_recvmsg_out msg;
struct __kernel_sockaddr_storage addr;
};
struct barrett_ctx_s;
typedef struct barrett_ctx_s *mpi_barrett_t;
struct barrett_ctx_s {
MPI m;
int m_copied;
int k;
MPI y;
MPI r1;
MPI r2;
MPI r3;
};
enum mips_gic_local_interrupt {
GIC_LOCAL_INT_WD = 0,
GIC_LOCAL_INT_COMPARE = 1,
GIC_LOCAL_INT_TIMER = 2,
GIC_LOCAL_INT_PERFCTR = 3,
GIC_LOCAL_INT_SWINT0 = 4,
GIC_LOCAL_INT_SWINT1 = 5,
GIC_LOCAL_INT_FDC = 6,
GIC_NUM_LOCAL_INTRS = 7,
};
typedef int (*of_init_fn_2)(struct device_node *, struct device_node *);
typedef int (*of_irq_init_cb_t)(struct device_node *, struct device_node *);
typedef void (*vi_handler_t)();
struct gic_all_vpes_chip_data {
u32 map;
bool mask;
};
struct fb_modelist {
struct list_head list;
struct fb_videomode mode;
};
struct unipair {
short unsigned int unicode;
short unsigned int fontpos;
};
struct unimapdesc {
short unsigned int entry_ct;
struct unipair *entries;
};
struct kbentry {
unsigned char kb_table;
unsigned char kb_index;
short unsigned int kb_value;
};
struct kbsentry {
unsigned char kb_func;
unsigned char kb_string[512];
};
struct kbkeycode {
unsigned int scancode;
unsigned int keycode;
};
struct kbd_repeat {
int delay;
int period;
};
struct vt_stat {
short unsigned int v_active;
short unsigned int v_signal;
short unsigned int v_state;
};
struct vt_sizes {
short unsigned int v_rows;
short unsigned int v_cols;
short unsigned int v_scrollsize;
};
struct vt_consize {
short unsigned int v_rows;
short unsigned int v_cols;
short unsigned int v_vlin;
short unsigned int v_clin;
short unsigned int v_vcol;
short unsigned int v_ccol;
};
struct vt_event {
unsigned int event;
unsigned int oldev;
unsigned int newev;
unsigned int pad[4];
};
struct vt_setactivate {
unsigned int console;
struct vt_mode mode;
};
struct vt_spawn_console {
spinlock_t lock;
struct pid *pid;
int sig;
};
struct vt_event_wait {
struct list_head list;
struct vt_event event;
int done;
};
struct klist_iter {
struct klist *i_klist;
struct klist_node *i_cur;
};
enum pm_qos_type {
PM_QOS_UNITIALIZED = 0,
PM_QOS_MAX = 1,
PM_QOS_MIN = 2,
};
struct pm_qos_constraints {
struct plist_head list;
s32 target_value;
s32 default_value;
s32 no_constraint_value;
enum pm_qos_type type;
struct blocking_notifier_head *notifiers;
};
struct freq_constraints {
struct pm_qos_constraints min_freq;
struct blocking_notifier_head min_freq_notifiers;
struct pm_qos_constraints max_freq;
struct blocking_notifier_head max_freq_notifiers;
};
struct pm_qos_flags {
struct list_head list;
s32 effective_flags;
};
struct dev_pm_qos_request;
struct dev_pm_qos {
struct pm_qos_constraints resume_latency;
struct pm_qos_constraints latency_tolerance;
struct freq_constraints freq;
struct pm_qos_flags flags;
struct dev_pm_qos_request *resume_latency_req;
struct dev_pm_qos_request *latency_tolerance_req;
struct dev_pm_qos_request *flags_req;
};
struct bus_attribute {
struct attribute attr;
ssize_t (*show)(struct bus_type *, char *);
ssize_t (*store)(struct bus_type *, const char *, size_t);
};
struct subsys_dev_iter {
struct klist_iter ki;
const struct device_type *type;
};
struct subsys_interface {
const char *name;
struct bus_type *subsys;
struct list_head node;
int (*add_dev)(struct device *, struct subsys_interface *);
void (*remove_dev)(struct device *, struct subsys_interface *);
};
struct pm_qos_flags_request {
struct list_head node;
s32 flags;
};
enum freq_qos_req_type {
FREQ_QOS_MIN = 1,
FREQ_QOS_MAX = 2,
};
struct freq_qos_request {
enum freq_qos_req_type type;
struct plist_node pnode;
struct freq_constraints *qos;
};
enum dev_pm_qos_req_type {
DEV_PM_QOS_RESUME_LATENCY = 1,
DEV_PM_QOS_LATENCY_TOLERANCE = 2,
DEV_PM_QOS_MIN_FREQUENCY = 3,
DEV_PM_QOS_MAX_FREQUENCY = 4,
DEV_PM_QOS_FLAGS = 5,
};
struct dev_pm_qos_request {
enum dev_pm_qos_req_type type;
union {
struct plist_node pnode;
struct pm_qos_flags_request flr;
struct freq_qos_request freq;
} data;
struct device *dev;
};
struct pm_clk_notifier_block {
struct notifier_block nb;
struct dev_pm_domain *pm_domain;
char *con_ids[0];
};
enum {
ATA_MAX_DEVICES = 2,
ATA_MAX_PRD = 256,
ATA_SECT_SIZE = 512,
ATA_MAX_SECTORS_128 = 128,
ATA_MAX_SECTORS = 256,
ATA_MAX_SECTORS_1024 = 1024,
ATA_MAX_SECTORS_LBA48 = 65535,
ATA_MAX_SECTORS_TAPE = 65535,
ATA_MAX_TRIM_RNUM = 64,
ATA_ID_WORDS = 256,
ATA_ID_CONFIG = 0,
ATA_ID_CYLS = 1,
ATA_ID_HEADS = 3,
ATA_ID_SECTORS = 6,
ATA_ID_SERNO = 10,
ATA_ID_BUF_SIZE = 21,
ATA_ID_FW_REV = 23,
ATA_ID_PROD = 27,
ATA_ID_MAX_MULTSECT = 47,
ATA_ID_DWORD_IO = 48,
ATA_ID_TRUSTED = 48,
ATA_ID_CAPABILITY = 49,
ATA_ID_OLD_PIO_MODES = 51,
ATA_ID_OLD_DMA_MODES = 52,
ATA_ID_FIELD_VALID = 53,
ATA_ID_CUR_CYLS = 54,
ATA_ID_CUR_HEADS = 55,
ATA_ID_CUR_SECTORS = 56,
ATA_ID_MULTSECT = 59,
ATA_ID_LBA_CAPACITY = 60,
ATA_ID_SWDMA_MODES = 62,
ATA_ID_MWDMA_MODES = 63,
ATA_ID_PIO_MODES = 64,
ATA_ID_EIDE_DMA_MIN = 65,
ATA_ID_EIDE_DMA_TIME = 66,
ATA_ID_EIDE_PIO = 67,
ATA_ID_EIDE_PIO_IORDY = 68,
ATA_ID_ADDITIONAL_SUPP = 69,
ATA_ID_QUEUE_DEPTH = 75,
ATA_ID_SATA_CAPABILITY = 76,
ATA_ID_SATA_CAPABILITY_2 = 77,
ATA_ID_FEATURE_SUPP = 78,
ATA_ID_MAJOR_VER = 80,
ATA_ID_COMMAND_SET_1 = 82,
ATA_ID_COMMAND_SET_2 = 83,
ATA_ID_CFSSE = 84,
ATA_ID_CFS_ENABLE_1 = 85,
ATA_ID_CFS_ENABLE_2 = 86,
ATA_ID_CSF_DEFAULT = 87,
ATA_ID_UDMA_MODES = 88,
ATA_ID_HW_CONFIG = 93,
ATA_ID_SPG = 98,
ATA_ID_LBA_CAPACITY_2 = 100,
ATA_ID_SECTOR_SIZE = 106,
ATA_ID_WWN = 108,
ATA_ID_LOGICAL_SECTOR_SIZE = 117,
ATA_ID_COMMAND_SET_3 = 119,
ATA_ID_COMMAND_SET_4 = 120,
ATA_ID_LAST_LUN = 126,
ATA_ID_DLF = 128,
ATA_ID_CSFO = 129,
ATA_ID_CFA_POWER = 160,
ATA_ID_CFA_KEY_MGMT = 162,
ATA_ID_CFA_MODES = 163,
ATA_ID_DATA_SET_MGMT = 169,
ATA_ID_SCT_CMD_XPORT = 206,
ATA_ID_ROT_SPEED = 217,
ATA_ID_PIO4 = 2,
ATA_ID_SERNO_LEN = 20,
ATA_ID_FW_REV_LEN = 8,
ATA_ID_PROD_LEN = 40,
ATA_ID_WWN_LEN = 8,
ATA_PCI_CTL_OFS = 2,
ATA_PIO0 = 1,
ATA_PIO1 = 3,
ATA_PIO2 = 7,
ATA_PIO3 = 15,
ATA_PIO4 = 31,
ATA_PIO5 = 63,
ATA_PIO6 = 127,
ATA_PIO4_ONLY = 16,
ATA_SWDMA0 = 1,
ATA_SWDMA1 = 3,
ATA_SWDMA2 = 7,
ATA_SWDMA2_ONLY = 4,
ATA_MWDMA0 = 1,
ATA_MWDMA1 = 3,
ATA_MWDMA2 = 7,
ATA_MWDMA3 = 15,
ATA_MWDMA4 = 31,
ATA_MWDMA12_ONLY = 6,
ATA_MWDMA2_ONLY = 4,
ATA_UDMA0 = 1,
ATA_UDMA1 = 3,
ATA_UDMA2 = 7,
ATA_UDMA3 = 15,
ATA_UDMA4 = 31,
ATA_UDMA5 = 63,
ATA_UDMA6 = 127,
ATA_UDMA7 = 255,
ATA_UDMA24_ONLY = 20,
ATA_UDMA_MASK_40C = 7,
ATA_PRD_SZ = 8,
ATA_PRD_TBL_SZ = 2048,
ATA_PRD_EOT = -2147483648,
ATA_DMA_TABLE_OFS = 4,
ATA_DMA_STATUS = 2,
ATA_DMA_CMD = 0,
ATA_DMA_WR = 8,
ATA_DMA_START = 1,
ATA_DMA_INTR = 4,
ATA_DMA_ERR = 2,
ATA_DMA_ACTIVE = 1,
ATA_HOB = 128,
ATA_NIEN = 2,
ATA_LBA = 64,
ATA_DEV1 = 16,
ATA_DEVICE_OBS = 160,
ATA_DEVCTL_OBS = 8,
ATA_BUSY = 128,
ATA_DRDY = 64,
ATA_DF = 32,
ATA_DSC = 16,
ATA_DRQ = 8,
ATA_CORR = 4,
ATA_SENSE = 2,
ATA_ERR = 1,
ATA_SRST = 4,
ATA_ICRC = 128,
ATA_BBK = 128,
ATA_UNC = 64,
ATA_MC = 32,
ATA_IDNF = 16,
ATA_MCR = 8,
ATA_ABORTED = 4,
ATA_TRK0NF = 2,
ATA_AMNF = 1,
ATAPI_LFS = 240,
ATAPI_EOM = 2,
ATAPI_ILI = 1,
ATAPI_IO = 2,
ATAPI_COD = 1,
ATA_REG_DATA = 0,
ATA_REG_ERR = 1,
ATA_REG_NSECT = 2,
ATA_REG_LBAL = 3,
ATA_REG_LBAM = 4,
ATA_REG_LBAH = 5,
ATA_REG_DEVICE = 6,
ATA_REG_STATUS = 7,
ATA_REG_FEATURE = 1,
ATA_REG_CMD = 7,
ATA_REG_BYTEL = 4,
ATA_REG_BYTEH = 5,
ATA_REG_DEVSEL = 6,
ATA_REG_IRQ = 2,
ATA_CMD_DEV_RESET = 8,
ATA_CMD_CHK_POWER = 229,
ATA_CMD_STANDBY = 226,
ATA_CMD_IDLE = 227,
ATA_CMD_EDD = 144,
ATA_CMD_DOWNLOAD_MICRO = 146,
ATA_CMD_DOWNLOAD_MICRO_DMA = 147,
ATA_CMD_NOP = 0,
ATA_CMD_FLUSH = 231,
ATA_CMD_FLUSH_EXT = 234,
ATA_CMD_ID_ATA = 236,
ATA_CMD_ID_ATAPI = 161,
ATA_CMD_SERVICE = 162,
ATA_CMD_READ = 200,
ATA_CMD_READ_EXT = 37,
ATA_CMD_READ_QUEUED = 38,
ATA_CMD_READ_STREAM_EXT = 43,
ATA_CMD_READ_STREAM_DMA_EXT = 42,
ATA_CMD_WRITE = 202,
ATA_CMD_WRITE_EXT = 53,
ATA_CMD_WRITE_QUEUED = 54,
ATA_CMD_WRITE_STREAM_EXT = 59,
ATA_CMD_WRITE_STREAM_DMA_EXT = 58,
ATA_CMD_WRITE_FUA_EXT = 61,
ATA_CMD_WRITE_QUEUED_FUA_EXT = 62,
ATA_CMD_FPDMA_READ = 96,
ATA_CMD_FPDMA_WRITE = 97,
ATA_CMD_NCQ_NON_DATA = 99,
ATA_CMD_FPDMA_SEND = 100,
ATA_CMD_FPDMA_RECV = 101,
ATA_CMD_PIO_READ = 32,
ATA_CMD_PIO_READ_EXT = 36,
ATA_CMD_PIO_WRITE = 48,
ATA_CMD_PIO_WRITE_EXT = 52,
ATA_CMD_READ_MULTI = 196,
ATA_CMD_READ_MULTI_EXT = 41,
ATA_CMD_WRITE_MULTI = 197,
ATA_CMD_WRITE_MULTI_EXT = 57,
ATA_CMD_WRITE_MULTI_FUA_EXT = 206,
ATA_CMD_SET_FEATURES = 239,
ATA_CMD_SET_MULTI = 198,
ATA_CMD_PACKET = 160,
ATA_CMD_VERIFY = 64,
ATA_CMD_VERIFY_EXT = 66,
ATA_CMD_WRITE_UNCORR_EXT = 69,
ATA_CMD_STANDBYNOW1 = 224,
ATA_CMD_IDLEIMMEDIATE = 225,
ATA_CMD_SLEEP = 230,
ATA_CMD_INIT_DEV_PARAMS = 145,
ATA_CMD_READ_NATIVE_MAX = 248,
ATA_CMD_READ_NATIVE_MAX_EXT = 39,
ATA_CMD_SET_MAX = 249,
ATA_CMD_SET_MAX_EXT = 55,
ATA_CMD_READ_LOG_EXT = 47,
ATA_CMD_WRITE_LOG_EXT = 63,
ATA_CMD_READ_LOG_DMA_EXT = 71,
ATA_CMD_WRITE_LOG_DMA_EXT = 87,
ATA_CMD_TRUSTED_NONDATA = 91,
ATA_CMD_TRUSTED_RCV = 92,
ATA_CMD_TRUSTED_RCV_DMA = 93,
ATA_CMD_TRUSTED_SND = 94,
ATA_CMD_TRUSTED_SND_DMA = 95,
ATA_CMD_PMP_READ = 228,
ATA_CMD_PMP_READ_DMA = 233,
ATA_CMD_PMP_WRITE = 232,
ATA_CMD_PMP_WRITE_DMA = 235,
ATA_CMD_CONF_OVERLAY = 177,
ATA_CMD_SEC_SET_PASS = 241,
ATA_CMD_SEC_UNLOCK = 242,
ATA_CMD_SEC_ERASE_PREP = 243,
ATA_CMD_SEC_ERASE_UNIT = 244,
ATA_CMD_SEC_FREEZE_LOCK = 245,
ATA_CMD_SEC_DISABLE_PASS = 246,
ATA_CMD_CONFIG_STREAM = 81,
ATA_CMD_SMART = 176,
ATA_CMD_MEDIA_LOCK = 222,
ATA_CMD_MEDIA_UNLOCK = 223,
ATA_CMD_DSM = 6,
ATA_CMD_CHK_MED_CRD_TYP = 209,
ATA_CMD_CFA_REQ_EXT_ERR = 3,
ATA_CMD_CFA_WRITE_NE = 56,
ATA_CMD_CFA_TRANS_SECT = 135,
ATA_CMD_CFA_ERASE = 192,
ATA_CMD_CFA_WRITE_MULT_NE = 205,
ATA_CMD_REQ_SENSE_DATA = 11,
ATA_CMD_SANITIZE_DEVICE = 180,
ATA_CMD_ZAC_MGMT_IN = 74,
ATA_CMD_ZAC_MGMT_OUT = 159,
ATA_CMD_RESTORE = 16,
ATA_SUBCMD_FPDMA_RECV_RD_LOG_DMA_EXT = 1,
ATA_SUBCMD_FPDMA_RECV_ZAC_MGMT_IN = 2,
ATA_SUBCMD_FPDMA_SEND_DSM = 0,
ATA_SUBCMD_FPDMA_SEND_WR_LOG_DMA_EXT = 2,
ATA_SUBCMD_NCQ_NON_DATA_ABORT_QUEUE = 0,
ATA_SUBCMD_NCQ_NON_DATA_SET_FEATURES = 5,
ATA_SUBCMD_NCQ_NON_DATA_ZERO_EXT = 6,
ATA_SUBCMD_NCQ_NON_DATA_ZAC_MGMT_OUT = 7,
ATA_SUBCMD_ZAC_MGMT_IN_REPORT_ZONES = 0,
ATA_SUBCMD_ZAC_MGMT_OUT_CLOSE_ZONE = 1,
ATA_SUBCMD_ZAC_MGMT_OUT_FINISH_ZONE = 2,
ATA_SUBCMD_ZAC_MGMT_OUT_OPEN_ZONE = 3,
ATA_SUBCMD_ZAC_MGMT_OUT_RESET_WRITE_POINTER = 4,
ATA_LOG_DIRECTORY = 0,
ATA_LOG_SATA_NCQ = 16,
ATA_LOG_NCQ_NON_DATA = 18,
ATA_LOG_NCQ_SEND_RECV = 19,
ATA_LOG_IDENTIFY_DEVICE = 48,
ATA_LOG_CONCURRENT_POSITIONING_RANGES = 71,
ATA_LOG_SECURITY = 6,
ATA_LOG_SATA_SETTINGS = 8,
ATA_LOG_ZONED_INFORMATION = 9,
ATA_LOG_DEVSLP_OFFSET = 48,
ATA_LOG_DEVSLP_SIZE = 8,
ATA_LOG_DEVSLP_MDAT = 0,
ATA_LOG_DEVSLP_MDAT_MASK = 31,
ATA_LOG_DEVSLP_DETO = 1,
ATA_LOG_DEVSLP_VALID = 7,
ATA_LOG_DEVSLP_VALID_MASK = 128,
ATA_LOG_NCQ_PRIO_OFFSET = 9,
ATA_LOG_NCQ_SEND_RECV_SUBCMDS_OFFSET = 0,
ATA_LOG_NCQ_SEND_RECV_SUBCMDS_DSM = 1,
ATA_LOG_NCQ_SEND_RECV_DSM_OFFSET = 4,
ATA_LOG_NCQ_SEND_RECV_DSM_TRIM = 1,
ATA_LOG_NCQ_SEND_RECV_RD_LOG_OFFSET = 8,
ATA_LOG_NCQ_SEND_RECV_RD_LOG_SUPPORTED = 1,
ATA_LOG_NCQ_SEND_RECV_WR_LOG_OFFSET = 12,
ATA_LOG_NCQ_SEND_RECV_WR_LOG_SUPPORTED = 1,
ATA_LOG_NCQ_SEND_RECV_ZAC_MGMT_OFFSET = 16,
ATA_LOG_NCQ_SEND_RECV_ZAC_MGMT_OUT_SUPPORTED = 1,
ATA_LOG_NCQ_SEND_RECV_ZAC_MGMT_IN_SUPPORTED = 2,
ATA_LOG_NCQ_SEND_RECV_SIZE = 20,
ATA_LOG_NCQ_NON_DATA_SUBCMDS_OFFSET = 0,
ATA_LOG_NCQ_NON_DATA_ABORT_OFFSET = 0,
ATA_LOG_NCQ_NON_DATA_ABORT_NCQ = 1,
ATA_LOG_NCQ_NON_DATA_ABORT_ALL = 2,
ATA_LOG_NCQ_NON_DATA_ABORT_STREAMING = 4,
ATA_LOG_NCQ_NON_DATA_ABORT_NON_STREAMING = 8,
ATA_LOG_NCQ_NON_DATA_ABORT_SELECTED = 16,
ATA_LOG_NCQ_NON_DATA_ZAC_MGMT_OFFSET = 28,
ATA_LOG_NCQ_NON_DATA_ZAC_MGMT_OUT = 1,
ATA_LOG_NCQ_NON_DATA_SIZE = 64,
ATA_CMD_READ_LONG = 34,
ATA_CMD_READ_LONG_ONCE = 35,
ATA_CMD_WRITE_LONG = 50,
ATA_CMD_WRITE_LONG_ONCE = 51,
SETFEATURES_XFER = 3,
XFER_UDMA_7 = 71,
XFER_UDMA_6 = 70,
XFER_UDMA_5 = 69,
XFER_UDMA_4 = 68,
XFER_UDMA_3 = 67,
XFER_UDMA_2 = 66,
XFER_UDMA_1 = 65,
XFER_UDMA_0 = 64,
XFER_MW_DMA_4 = 36,
XFER_MW_DMA_3 = 35,
XFER_MW_DMA_2 = 34,
XFER_MW_DMA_1 = 33,
XFER_MW_DMA_0 = 32,
XFER_SW_DMA_2 = 18,
XFER_SW_DMA_1 = 17,
XFER_SW_DMA_0 = 16,
XFER_PIO_6 = 14,
XFER_PIO_5 = 13,
XFER_PIO_4 = 12,
XFER_PIO_3 = 11,
XFER_PIO_2 = 10,
XFER_PIO_1 = 9,
XFER_PIO_0 = 8,
XFER_PIO_SLOW = 0,
SETFEATURES_WC_ON = 2,
SETFEATURES_WC_OFF = 130,
SETFEATURES_RA_ON = 170,
SETFEATURES_RA_OFF = 85,
SETFEATURES_AAM_ON = 66,
SETFEATURES_AAM_OFF = 194,
SETFEATURES_SPINUP = 7,
SETFEATURES_SPINUP_TIMEOUT = 30000,
SETFEATURES_SATA_ENABLE = 16,
SETFEATURES_SATA_DISABLE = 144,
SATA_FPDMA_OFFSET = 1,
SATA_FPDMA_AA = 2,
SATA_DIPM = 3,
SATA_FPDMA_IN_ORDER = 4,
SATA_AN = 5,
SATA_SSP = 6,
SATA_DEVSLP = 9,
SETFEATURE_SENSE_DATA = 195,
ATA_SET_MAX_ADDR = 0,
ATA_SET_MAX_PASSWD = 1,
ATA_SET_MAX_LOCK = 2,
ATA_SET_MAX_UNLOCK = 3,
ATA_SET_MAX_FREEZE_LOCK = 4,
ATA_SET_MAX_PASSWD_DMA = 5,
ATA_SET_MAX_UNLOCK_DMA = 6,
ATA_DCO_RESTORE = 192,
ATA_DCO_FREEZE_LOCK = 193,
ATA_DCO_IDENTIFY = 194,
ATA_DCO_SET = 195,
ATA_SMART_ENABLE = 216,
ATA_SMART_READ_VALUES = 208,
ATA_SMART_READ_THRESHOLDS = 209,
ATA_DSM_TRIM = 1,
ATA_SMART_LBAM_PASS = 79,
ATA_SMART_LBAH_PASS = 194,
ATAPI_PKT_DMA = 1,
ATAPI_DMADIR = 4,
ATAPI_CDB_LEN = 16,
SATA_PMP_MAX_PORTS = 15,
SATA_PMP_CTRL_PORT = 15,
SATA_PMP_GSCR_DWORDS = 128,
SATA_PMP_GSCR_PROD_ID = 0,
SATA_PMP_GSCR_REV = 1,
SATA_PMP_GSCR_PORT_INFO = 2,
SATA_PMP_GSCR_ERROR = 32,
SATA_PMP_GSCR_ERROR_EN = 33,
SATA_PMP_GSCR_FEAT = 64,
SATA_PMP_GSCR_FEAT_EN = 96,
SATA_PMP_PSCR_STATUS = 0,
SATA_PMP_PSCR_ERROR = 1,
SATA_PMP_PSCR_CONTROL = 2,
SATA_PMP_FEAT_BIST = 1,
SATA_PMP_FEAT_PMREQ = 2,
SATA_PMP_FEAT_DYNSSC = 4,
SATA_PMP_FEAT_NOTIFY = 8,
ATA_CBL_NONE = 0,
ATA_CBL_PATA40 = 1,
ATA_CBL_PATA80 = 2,
ATA_CBL_PATA40_SHORT = 3,
ATA_CBL_PATA_UNK = 4,
ATA_CBL_PATA_IGN = 5,
ATA_CBL_SATA = 6,
SCR_STATUS = 0,
SCR_ERROR = 1,
SCR_CONTROL = 2,
SCR_ACTIVE = 3,
SCR_NOTIFICATION = 4,
SERR_DATA_RECOVERED = 1,
SERR_COMM_RECOVERED = 2,
SERR_DATA = 256,
SERR_PERSISTENT = 512,
SERR_PROTOCOL = 1024,
SERR_INTERNAL = 2048,
SERR_PHYRDY_CHG = 65536,
SERR_PHY_INT_ERR = 131072,
SERR_COMM_WAKE = 262144,
SERR_10B_8B_ERR = 524288,
SERR_DISPARITY = 1048576,
SERR_CRC = 2097152,
SERR_HANDSHAKE = 4194304,
SERR_LINK_SEQ_ERR = 8388608,
SERR_TRANS_ST_ERROR = 16777216,
SERR_UNRECOG_FIS = 33554432,
SERR_DEV_XCHG = 67108864,
};
struct cdrom_device_ops;
struct cdrom_device_info {
const struct cdrom_device_ops *ops;
struct list_head list;
struct gendisk *disk;
void *handle;
int mask;
int speed;
int capacity;
unsigned int options: 30;
unsigned int mc_flags: 2;
unsigned int vfs_events;
unsigned int ioctl_events;
int use_count;
char name[20];
__u8 sanyo_slot: 2;
__u8 keeplocked: 1;
__u8 reserved: 5;
int cdda_method;
__u8 last_sense;
__u8 media_written;
short unsigned int mmc3_profile;
int for_data;
int (*exit)(struct cdrom_device_info *);
int mrw_mode_page;
long: 32;
__s64 last_media_change_ms;
};
struct cdrom_msf0 {
__u8 minute;
__u8 second;
__u8 frame;
};
union cdrom_addr {
struct cdrom_msf0 msf;
int lba;
};
struct cdrom_multisession {
union cdrom_addr addr;
__u8 xa_flag;
__u8 addr_format;
};
struct cdrom_mcn {
__u8 medium_catalog_number[14];
};
struct packet_command {
unsigned char cmd[12];
unsigned char *buffer;
unsigned int buflen;
int stat;
struct scsi_sense_hdr *sshdr;
unsigned char data_direction;
int quiet;
int timeout;
void *reserved[1];
};
struct cdrom_device_ops {
int (*open)(struct cdrom_device_info *, int);
void (*release)(struct cdrom_device_info *);
int (*drive_status)(struct cdrom_device_info *, int);
unsigned int (*check_events)(struct cdrom_device_info *, unsigned int, int);
int (*tray_move)(struct cdrom_device_info *, int);
int (*lock_door)(struct cdrom_device_info *, int);
int (*select_speed)(struct cdrom_device_info *, int);
int (*get_last_session)(struct cdrom_device_info *, struct cdrom_multisession *);
int (*get_mcn)(struct cdrom_device_info *, struct cdrom_mcn *);
int (*reset)(struct cdrom_device_info *);
int (*audio_ioctl)(struct cdrom_device_info *, unsigned int, void *);
int (*generic_packet)(struct cdrom_device_info *, struct packet_command *);
int (*read_cdda_bpc)(struct cdrom_device_info *, void *, u32, u32, u8 *);
const int capability;
};
enum {
LIBATA_MAX_PRD = 128,
LIBATA_DUMB_MAX_PRD = 64,
ATA_DEF_QUEUE = 1,
ATA_MAX_QUEUE = 32,
ATA_TAG_INTERNAL = 32,
ATA_SHORT_PAUSE = 16,
ATAPI_MAX_DRAIN = 16384,
ATA_ALL_DEVICES = 3,
ATA_SHT_EMULATED = 1,
ATA_SHT_THIS_ID = -1,
ATA_TFLAG_LBA48 = 1,
ATA_TFLAG_ISADDR = 2,
ATA_TFLAG_DEVICE = 4,
ATA_TFLAG_WRITE = 8,
ATA_TFLAG_LBA = 16,
ATA_TFLAG_FUA = 32,
ATA_TFLAG_POLLING = 64,
ATA_DFLAG_LBA = 1,
ATA_DFLAG_LBA48 = 2,
ATA_DFLAG_CDB_INTR = 4,
ATA_DFLAG_NCQ = 8,
ATA_DFLAG_FLUSH_EXT = 16,
ATA_DFLAG_ACPI_PENDING = 32,
ATA_DFLAG_ACPI_FAILED = 64,
ATA_DFLAG_AN = 128,
ATA_DFLAG_TRUSTED = 256,
ATA_DFLAG_DMADIR = 1024,
ATA_DFLAG_CFG_MASK = 4095,
ATA_DFLAG_PIO = 4096,
ATA_DFLAG_NCQ_OFF = 8192,
ATA_DFLAG_SLEEPING = 32768,
ATA_DFLAG_DUBIOUS_XFER = 65536,
ATA_DFLAG_NO_UNLOAD = 131072,
ATA_DFLAG_UNLOCK_HPA = 262144,
ATA_DFLAG_NCQ_SEND_RECV = 524288,
ATA_DFLAG_NCQ_PRIO = 1048576,
ATA_DFLAG_NCQ_PRIO_ENABLED = 2097152,
ATA_DFLAG_INIT_MASK = 16777215,
ATA_DFLAG_DETACH = 16777216,
ATA_DFLAG_DETACHED = 33554432,
ATA_DFLAG_DA = 67108864,
ATA_DFLAG_DEVSLP = 134217728,
ATA_DFLAG_ACPI_DISABLED = 268435456,
ATA_DFLAG_D_SENSE = 536870912,
ATA_DFLAG_ZAC = 1073741824,
ATA_DFLAG_FEATURES_MASK = 202899712,
ATA_DEV_UNKNOWN = 0,
ATA_DEV_ATA = 1,
ATA_DEV_ATA_UNSUP = 2,
ATA_DEV_ATAPI = 3,
ATA_DEV_ATAPI_UNSUP = 4,
ATA_DEV_PMP = 5,
ATA_DEV_PMP_UNSUP = 6,
ATA_DEV_SEMB = 7,
ATA_DEV_SEMB_UNSUP = 8,
ATA_DEV_ZAC = 9,
ATA_DEV_ZAC_UNSUP = 10,
ATA_DEV_NONE = 11,
ATA_LFLAG_NO_HRST = 2,
ATA_LFLAG_NO_SRST = 4,
ATA_LFLAG_ASSUME_ATA = 8,
ATA_LFLAG_ASSUME_SEMB = 16,
ATA_LFLAG_ASSUME_CLASS = 24,
ATA_LFLAG_NO_RETRY = 32,
ATA_LFLAG_DISABLED = 64,
ATA_LFLAG_SW_ACTIVITY = 128,
ATA_LFLAG_NO_LPM = 256,
ATA_LFLAG_RST_ONCE = 512,
ATA_LFLAG_CHANGED = 1024,
ATA_LFLAG_NO_DEBOUNCE_DELAY = 2048,
ATA_FLAG_SLAVE_POSS = 1,
ATA_FLAG_SATA = 2,
ATA_FLAG_NO_LPM = 4,
ATA_FLAG_NO_LOG_PAGE = 32,
ATA_FLAG_NO_ATAPI = 64,
ATA_FLAG_PIO_DMA = 128,
ATA_FLAG_PIO_LBA48 = 256,
ATA_FLAG_PIO_POLLING = 512,
ATA_FLAG_NCQ = 1024,
ATA_FLAG_NO_POWEROFF_SPINDOWN = 2048,
ATA_FLAG_NO_HIBERNATE_SPINDOWN = 4096,
ATA_FLAG_DEBUGMSG = 8192,
ATA_FLAG_FPDMA_AA = 16384,
ATA_FLAG_IGN_SIMPLEX = 32768,
ATA_FLAG_NO_IORDY = 65536,
ATA_FLAG_ACPI_SATA = 131072,
ATA_FLAG_AN = 262144,
ATA_FLAG_PMP = 524288,
ATA_FLAG_FPDMA_AUX = 1048576,
ATA_FLAG_EM = 2097152,
ATA_FLAG_SW_ACTIVITY = 4194304,
ATA_FLAG_NO_DIPM = 8388608,
ATA_FLAG_SAS_HOST = 16777216,
ATA_PFLAG_EH_PENDING = 1,
ATA_PFLAG_EH_IN_PROGRESS = 2,
ATA_PFLAG_FROZEN = 4,
ATA_PFLAG_RECOVERED = 8,
ATA_PFLAG_LOADING = 16,
ATA_PFLAG_SCSI_HOTPLUG = 64,
ATA_PFLAG_INITIALIZING = 128,
ATA_PFLAG_RESETTING = 256,
ATA_PFLAG_UNLOADING = 512,
ATA_PFLAG_UNLOADED = 1024,
ATA_PFLAG_SUSPENDED = 131072,
ATA_PFLAG_PM_PENDING = 262144,
ATA_PFLAG_INIT_GTM_VALID = 524288,
ATA_PFLAG_PIO32 = 1048576,
ATA_PFLAG_PIO32CHANGE = 2097152,
ATA_PFLAG_EXTERNAL = 4194304,
ATA_QCFLAG_ACTIVE = 1,
ATA_QCFLAG_DMAMAP = 2,
ATA_QCFLAG_IO = 8,
ATA_QCFLAG_RESULT_TF = 16,
ATA_QCFLAG_CLEAR_EXCL = 32,
ATA_QCFLAG_QUIET = 64,
ATA_QCFLAG_RETRY = 128,
ATA_QCFLAG_FAILED = 65536,
ATA_QCFLAG_SENSE_VALID = 131072,
ATA_QCFLAG_EH_SCHEDULED = 262144,
ATA_HOST_SIMPLEX = 1,
ATA_HOST_STARTED = 2,
ATA_HOST_PARALLEL_SCAN = 4,
ATA_HOST_IGNORE_ATA = 8,
ATA_TMOUT_BOOT = 30000,
ATA_TMOUT_BOOT_QUICK = 7000,
ATA_TMOUT_INTERNAL_QUICK = 5000,
ATA_TMOUT_MAX_PARK = 30000,
ATA_TMOUT_FF_WAIT_LONG = 2000,
ATA_TMOUT_FF_WAIT = 800,
ATA_WAIT_AFTER_RESET = 150,
ATA_TMOUT_PMP_SRST_WAIT = 5000,
ATA_TMOUT_SPURIOUS_PHY = 10000,
BUS_UNKNOWN = 0,
BUS_DMA = 1,
BUS_IDLE = 2,
BUS_NOINTR = 3,
BUS_NODATA = 4,
BUS_TIMER = 5,
BUS_PIO = 6,
BUS_EDD = 7,
BUS_IDENTIFY = 8,
BUS_PACKET = 9,
PORT_UNKNOWN = 0,
PORT_ENABLED = 1,
PORT_DISABLED = 2,
ATA_NR_PIO_MODES = 7,
ATA_NR_MWDMA_MODES = 5,
ATA_NR_UDMA_MODES = 8,
ATA_SHIFT_PIO = 0,
ATA_SHIFT_MWDMA = 7,
ATA_SHIFT_UDMA = 12,
ATA_SHIFT_PRIO = 6,
ATA_PRIO_HIGH = 2,
ATA_DMA_PAD_SZ = 4,
ATA_ERING_SIZE = 32,
ATA_DEFER_LINK = 1,
ATA_DEFER_PORT = 2,
ATA_EH_DESC_LEN = 80,
ATA_EH_REVALIDATE = 1,
ATA_EH_SOFTRESET = 2,
ATA_EH_HARDRESET = 4,
ATA_EH_RESET = 6,
ATA_EH_ENABLE_LINK = 8,
ATA_EH_PARK = 32,
ATA_EH_PERDEV_MASK = 33,
ATA_EH_ALL_ACTIONS = 15,
ATA_EHI_HOTPLUGGED = 1,
ATA_EHI_NO_AUTOPSY = 4,
ATA_EHI_QUIET = 8,
ATA_EHI_NO_RECOVERY = 16,
ATA_EHI_DID_SOFTRESET = 65536,
ATA_EHI_DID_HARDRESET = 131072,
ATA_EHI_PRINTINFO = 262144,
ATA_EHI_SETMODE = 524288,
ATA_EHI_POST_SETMODE = 1048576,
ATA_EHI_DID_RESET = 196608,
ATA_EHI_TO_SLAVE_MASK = 12,
ATA_EH_MAX_TRIES = 5,
ATA_LINK_RESUME_TRIES = 5,
ATA_PROBE_MAX_TRIES = 3,
ATA_EH_DEV_TRIES = 3,
ATA_EH_PMP_TRIES = 5,
ATA_EH_PMP_LINK_TRIES = 3,
SATA_PMP_RW_TIMEOUT = 3000,
ATA_EH_CMD_TIMEOUT_TABLE_SIZE = 7,
ATA_HORKAGE_DIAGNOSTIC = 1,
ATA_HORKAGE_NODMA = 2,
ATA_HORKAGE_NONCQ = 4,
ATA_HORKAGE_MAX_SEC_128 = 8,
ATA_HORKAGE_BROKEN_HPA = 16,
ATA_HORKAGE_DISABLE = 32,
ATA_HORKAGE_HPA_SIZE = 64,
ATA_HORKAGE_IVB = 256,
ATA_HORKAGE_STUCK_ERR = 512,
ATA_HORKAGE_BRIDGE_OK = 1024,
ATA_HORKAGE_ATAPI_MOD16_DMA = 2048,
ATA_HORKAGE_FIRMWARE_WARN = 4096,
ATA_HORKAGE_1_5_GBPS = 8192,
ATA_HORKAGE_NOSETXFER = 16384,
ATA_HORKAGE_BROKEN_FPDMA_AA = 32768,
ATA_HORKAGE_DUMP_ID = 65536,
ATA_HORKAGE_MAX_SEC_LBA48 = 131072,
ATA_HORKAGE_ATAPI_DMADIR = 262144,
ATA_HORKAGE_NO_NCQ_TRIM = 524288,
ATA_HORKAGE_NOLPM = 1048576,
ATA_HORKAGE_WD_BROKEN_LPM = 2097152,
ATA_HORKAGE_ZERO_AFTER_TRIM = 4194304,
ATA_HORKAGE_NO_DMA_LOG = 8388608,
ATA_HORKAGE_NOTRIM = 16777216,
ATA_HORKAGE_MAX_SEC_1024 = 33554432,
ATA_HORKAGE_MAX_TRIM_128M = 67108864,
ATA_HORKAGE_NO_NCQ_ON_ATI = 134217728,
ATA_HORKAGE_NO_ID_DEV_LOG = 268435456,
ATA_HORKAGE_NO_LOG_DIR = 536870912,
ATA_DMA_MASK_ATA = 1,
ATA_DMA_MASK_ATAPI = 2,
ATA_DMA_MASK_CFA = 4,
ATAPI_READ = 0,
ATAPI_WRITE = 1,
ATAPI_READ_CD = 2,
ATAPI_PASS_THRU = 3,
ATAPI_MISC = 4,
ATA_TIMING_SETUP = 1,
ATA_TIMING_ACT8B = 2,
ATA_TIMING_REC8B = 4,
ATA_TIMING_CYC8B = 8,
ATA_TIMING_8BIT = 14,
ATA_TIMING_ACTIVE = 16,
ATA_TIMING_RECOVER = 32,
ATA_TIMING_DMACK_HOLD = 64,
ATA_TIMING_CYCLE = 128,
ATA_TIMING_UDMA = 256,
ATA_TIMING_ALL = 511,
ATA_ACPI_FILTER_SETXFER = 1,
ATA_ACPI_FILTER_LOCK = 2,
ATA_ACPI_FILTER_DIPM = 4,
ATA_ACPI_FILTER_FPDMA_OFFSET = 8,
ATA_ACPI_FILTER_FPDMA_AA = 16,
ATA_ACPI_FILTER_DEFAULT = 7,
};
enum ata_completion_errors {
AC_ERR_OK = 0,
AC_ERR_DEV = 1,
AC_ERR_HSM = 2,
AC_ERR_TIMEOUT = 4,
AC_ERR_MEDIA = 8,
AC_ERR_ATA_BUS = 16,
AC_ERR_HOST_BUS = 32,
AC_ERR_SYSTEM = 64,
AC_ERR_INVALID = 128,
AC_ERR_OTHER = 256,
AC_ERR_NODEV_HINT = 512,
AC_ERR_NCQ = 1024,
};
struct mdiobus_devres {
struct mii_bus *mii;
};
enum dmi_field {
DMI_NONE = 0,
DMI_BIOS_VENDOR = 1,
DMI_BIOS_VERSION = 2,
DMI_BIOS_DATE = 3,
DMI_BIOS_RELEASE = 4,
DMI_EC_FIRMWARE_RELEASE = 5,
DMI_SYS_VENDOR = 6,
DMI_PRODUCT_NAME = 7,
DMI_PRODUCT_VERSION = 8,
DMI_PRODUCT_SERIAL = 9,
DMI_PRODUCT_UUID = 10,
DMI_PRODUCT_SKU = 11,
DMI_PRODUCT_FAMILY = 12,
DMI_BOARD_VENDOR = 13,
DMI_BOARD_NAME = 14,
DMI_BOARD_VERSION = 15,
DMI_BOARD_SERIAL = 16,
DMI_BOARD_ASSET_TAG = 17,
DMI_CHASSIS_VENDOR = 18,
DMI_CHASSIS_TYPE = 19,
DMI_CHASSIS_VERSION = 20,
DMI_CHASSIS_SERIAL = 21,
DMI_CHASSIS_ASSET_TAG = 22,
DMI_STRING_MAX = 23,
DMI_OEM_STRING = 24,
};
struct dmi_strmatch {
unsigned char slot: 7;
unsigned char exact_match: 1;
char substr[79];
};
struct dmi_system_id {
int (*callback)(const struct dmi_system_id *);
const char *ident;
struct dmi_strmatch matches[4];
void *driver_data;
};
struct pci_fixup {
u16 vendor;
u16 device;
u32 class;
unsigned int class_shift;
void (*hook)(struct pci_dev *);
};
enum amd_chipset_gen {
NOT_AMD_CHIPSET = 0,
AMD_CHIPSET_SB600 = 1,
AMD_CHIPSET_SB700 = 2,
AMD_CHIPSET_SB800 = 3,
AMD_CHIPSET_HUDSON2 = 4,
AMD_CHIPSET_BOLTON = 5,
AMD_CHIPSET_YANGTZE = 6,
AMD_CHIPSET_TAISHAN = 7,
AMD_CHIPSET_UNKNOWN = 8,
};
struct amd_chipset_type {
enum amd_chipset_gen gen;
u8 rev;
};
struct amd_chipset_info {
struct pci_dev *nb_dev;
struct pci_dev *smbus_dev;
int nb_type;
struct amd_chipset_type sb_type;
int isoc_reqs;
int probe_count;
bool need_pll_quirk;
};
struct vivaldi_data {
u32 function_row_physmap[24];
unsigned int num_function_row_keys;
};
struct csum_state {
__wsum csum;
size_t off;
};
struct rhashtable_walker {
struct list_head list;
struct bucket_table *tbl;
};
struct rhashtable_iter {
struct rhashtable *ht;
struct rhash_head *p;
struct rhlist_head *list;
struct rhashtable_walker walker;
unsigned int slot;
unsigned int skip;
bool end_of_table;
};
enum xdp_buff_flags {
XDP_FLAGS_HAS_FRAGS = 1,
XDP_FLAGS_FRAGS_PF_MEMALLOC = 2,
};
struct xdp_frame_bulk {
int count;
void *xa;
void *q[16];
};
struct xdp_attachment_info {
struct bpf_prog *prog;
u32 flags;
};
struct xsk_queue;
struct xdp_umem;
struct xdp_buff_xsk;
struct xdp_desc;
struct xsk_buff_pool {
struct device *dev;
struct net_device *netdev;
struct list_head xsk_tx_list;
spinlock_t xsk_tx_list_lock;
refcount_t users;
struct xdp_umem *umem;
struct work_struct work;
struct list_head free_list;
u32 heads_cnt;
u16 queue_id;
long: 32;
struct xsk_queue *fq;
struct xsk_queue *cq;
dma_addr_t *dma_pages;
struct xdp_buff_xsk *heads;
struct xdp_desc *tx_descs;
long: 32;
u64 chunk_mask;
u64 addrs_cnt;
u32 free_list_cnt;
u32 dma_pages_cnt;
u32 free_heads_cnt;
u32 headroom;
u32 chunk_size;
u32 chunk_shift;
u32 frame_len;
u8 cached_need_wakeup;
bool uses_need_wakeup;
bool dma_need_sync;
bool unaligned;
void *addrs;
spinlock_t cq_lock;
struct xdp_buff_xsk *free_heads[0];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_nh_params {
u32 nh_family;
union {
u32 ipv4_nh;
struct in6_addr ipv6_nh;
};
};
struct bpf_redirect_info {
u32 flags;
u32 tgt_index;
void *tgt_value;
struct bpf_map *map;
u32 map_id;
enum bpf_map_type map_type;
u32 kern_flags;
struct bpf_nh_params nh;
};
struct xdp_desc {
__u64 addr;
__u32 len;
__u32 options;
};
struct xdp_umem {
void *addrs;
long: 32;
u64 size;
u32 headroom;
u32 chunk_size;
u32 chunks;
u32 npgs;
struct user_struct *user;
refcount_t users;
u8 flags;
bool zc;
struct page **pgs;
int id;
struct list_head xsk_dma_list;
struct work_struct work;
long: 32;
};
struct xdp_buff_xsk {
struct xdp_buff xdp;
dma_addr_t dma;
dma_addr_t frame_dma;
struct xsk_buff_pool *pool;
long: 32;
u64 orig_addr;
struct list_head free_list_node;
};
enum netlink_attribute_type {
NL_ATTR_TYPE_INVALID = 0,
NL_ATTR_TYPE_FLAG = 1,
NL_ATTR_TYPE_U8 = 2,
NL_ATTR_TYPE_U16 = 3,
NL_ATTR_TYPE_U32 = 4,
NL_ATTR_TYPE_U64 = 5,
NL_ATTR_TYPE_S8 = 6,
NL_ATTR_TYPE_S16 = 7,
NL_ATTR_TYPE_S32 = 8,
NL_ATTR_TYPE_S64 = 9,
NL_ATTR_TYPE_BINARY = 10,
NL_ATTR_TYPE_STRING = 11,
NL_ATTR_TYPE_NUL_STRING = 12,
NL_ATTR_TYPE_NESTED = 13,
NL_ATTR_TYPE_NESTED_ARRAY = 14,
NL_ATTR_TYPE_BITFIELD32 = 15,
};
enum netlink_policy_type_attr {
NL_POLICY_TYPE_ATTR_UNSPEC = 0,
NL_POLICY_TYPE_ATTR_TYPE = 1,
NL_POLICY_TYPE_ATTR_MIN_VALUE_S = 2,
NL_POLICY_TYPE_ATTR_MAX_VALUE_S = 3,
NL_POLICY_TYPE_ATTR_MIN_VALUE_U = 4,
NL_POLICY_TYPE_ATTR_MAX_VALUE_U = 5,
NL_POLICY_TYPE_ATTR_MIN_LENGTH = 6,
NL_POLICY_TYPE_ATTR_MAX_LENGTH = 7,
NL_POLICY_TYPE_ATTR_POLICY_IDX = 8,
NL_POLICY_TYPE_ATTR_POLICY_MAXTYPE = 9,
NL_POLICY_TYPE_ATTR_BITFIELD32_MASK = 10,
NL_POLICY_TYPE_ATTR_PAD = 11,
NL_POLICY_TYPE_ATTR_MASK = 12,
__NL_POLICY_TYPE_ATTR_MAX = 13,
NL_POLICY_TYPE_ATTR_MAX = 12,
};
struct netlink_policy_dump_state {
unsigned int policy_idx;
unsigned int attr_idx;
unsigned int n_alloc;
struct {
const struct nla_policy *policy;
unsigned int maxtype;
} policies[0];
};
struct linkstate_reply_data {
struct ethnl_reply_data base;
int link;
int sqi;
int sqi_max;
bool link_ext_state_provided;
struct ethtool_link_ext_state_info ethtool_link_ext_state_info;
};
enum {
ETHTOOL_A_CABLE_PAIR_A = 0,
ETHTOOL_A_CABLE_PAIR_B = 1,
ETHTOOL_A_CABLE_PAIR_C = 2,
ETHTOOL_A_CABLE_PAIR_D = 3,
};
enum {
ETHTOOL_A_CABLE_RESULT_UNSPEC = 0,
ETHTOOL_A_CABLE_RESULT_PAIR = 1,
ETHTOOL_A_CABLE_RESULT_CODE = 2,
__ETHTOOL_A_CABLE_RESULT_CNT = 3,
ETHTOOL_A_CABLE_RESULT_MAX = 2,
};
enum {
ETHTOOL_A_CABLE_FAULT_LENGTH_UNSPEC = 0,
ETHTOOL_A_CABLE_FAULT_LENGTH_PAIR = 1,
ETHTOOL_A_CABLE_FAULT_LENGTH_CM = 2,
__ETHTOOL_A_CABLE_FAULT_LENGTH_CNT = 3,
ETHTOOL_A_CABLE_FAULT_LENGTH_MAX = 2,
};
enum {
ETHTOOL_A_CABLE_TEST_NTF_STATUS_UNSPEC = 0,
ETHTOOL_A_CABLE_TEST_NTF_STATUS_STARTED = 1,
ETHTOOL_A_CABLE_TEST_NTF_STATUS_COMPLETED = 2,
};
enum {
ETHTOOL_A_CABLE_NEST_UNSPEC = 0,
ETHTOOL_A_CABLE_NEST_RESULT = 1,
ETHTOOL_A_CABLE_NEST_FAULT_LENGTH = 2,
__ETHTOOL_A_CABLE_NEST_CNT = 3,
ETHTOOL_A_CABLE_NEST_MAX = 2,
};
enum {
ETHTOOL_A_CABLE_TEST_NTF_UNSPEC = 0,
ETHTOOL_A_CABLE_TEST_NTF_HEADER = 1,
ETHTOOL_A_CABLE_TEST_NTF_STATUS = 2,
ETHTOOL_A_CABLE_TEST_NTF_NEST = 3,
__ETHTOOL_A_CABLE_TEST_NTF_CNT = 4,
ETHTOOL_A_CABLE_TEST_NTF_MAX = 3,
};
enum {
ETHTOOL_A_CABLE_TEST_TDR_CFG_UNSPEC = 0,
ETHTOOL_A_CABLE_TEST_TDR_CFG_FIRST = 1,
ETHTOOL_A_CABLE_TEST_TDR_CFG_LAST = 2,
ETHTOOL_A_CABLE_TEST_TDR_CFG_STEP = 3,
ETHTOOL_A_CABLE_TEST_TDR_CFG_PAIR = 4,
__ETHTOOL_A_CABLE_TEST_TDR_CFG_CNT = 5,
ETHTOOL_A_CABLE_TEST_TDR_CFG_MAX = 4,
};
enum {
ETHTOOL_A_CABLE_AMPLITUDE_UNSPEC = 0,
ETHTOOL_A_CABLE_AMPLITUDE_PAIR = 1,
ETHTOOL_A_CABLE_AMPLITUDE_mV = 2,
__ETHTOOL_A_CABLE_AMPLITUDE_CNT = 3,
ETHTOOL_A_CABLE_AMPLITUDE_MAX = 2,
};
enum {
ETHTOOL_A_CABLE_PULSE_UNSPEC = 0,
ETHTOOL_A_CABLE_PULSE_mV = 1,
__ETHTOOL_A_CABLE_PULSE_CNT = 2,
ETHTOOL_A_CABLE_PULSE_MAX = 1,
};
enum {
ETHTOOL_A_CABLE_STEP_UNSPEC = 0,
ETHTOOL_A_CABLE_STEP_FIRST_DISTANCE = 1,
ETHTOOL_A_CABLE_STEP_LAST_DISTANCE = 2,
ETHTOOL_A_CABLE_STEP_STEP_DISTANCE = 3,
__ETHTOOL_A_CABLE_STEP_CNT = 4,
ETHTOOL_A_CABLE_STEP_MAX = 3,
};
enum {
ETHTOOL_A_CABLE_TDR_NEST_UNSPEC = 0,
ETHTOOL_A_CABLE_TDR_NEST_STEP = 1,
ETHTOOL_A_CABLE_TDR_NEST_AMPLITUDE = 2,
ETHTOOL_A_CABLE_TDR_NEST_PULSE = 3,
__ETHTOOL_A_CABLE_TDR_NEST_CNT = 4,
ETHTOOL_A_CABLE_TDR_NEST_MAX = 3,
};
enum {
INET_FRAG_FIRST_IN = 1,
INET_FRAG_LAST_IN = 2,
INET_FRAG_COMPLETE = 4,
INET_FRAG_HASH_DEAD = 8,
};
enum ip_defrag_users {
IP_DEFRAG_LOCAL_DELIVER = 0,
IP_DEFRAG_CALL_RA_CHAIN = 1,
IP_DEFRAG_CONNTRACK_IN = 2,
__IP_DEFRAG_CONNTRACK_IN_END = 65537,
IP_DEFRAG_CONNTRACK_OUT = 65538,
__IP_DEFRAG_CONNTRACK_OUT_END = 131073,
IP_DEFRAG_CONNTRACK_BRIDGE_IN = 131074,
__IP_DEFRAG_CONNTRACK_BRIDGE_IN = 196609,
IP_DEFRAG_VS_IN = 196610,
IP_DEFRAG_VS_OUT = 196611,
IP_DEFRAG_VS_FWD = 196612,
IP_DEFRAG_AF_PACKET = 196613,
IP_DEFRAG_MACVLAN = 196614,
};
struct ipq {
struct inet_frag_queue q;
u8 ecn;
u16 max_df_size;
int iif;
unsigned int rid;
struct inet_peer *peer;
};
struct nhmsg {
unsigned char nh_family;
unsigned char nh_scope;
unsigned char nh_protocol;
unsigned char resvd;
unsigned int nh_flags;
};
struct nexthop_grp {
__u32 id;
__u8 weight;
__u8 resvd1;
__u16 resvd2;
};
enum {
NEXTHOP_GRP_TYPE_MPATH = 0,
NEXTHOP_GRP_TYPE_RES = 1,
__NEXTHOP_GRP_TYPE_MAX = 2,
};
enum {
NHA_UNSPEC = 0,
NHA_ID = 1,
NHA_GROUP = 2,
NHA_GROUP_TYPE = 3,
NHA_BLACKHOLE = 4,
NHA_OIF = 5,
NHA_GATEWAY = 6,
NHA_ENCAP_TYPE = 7,
NHA_ENCAP = 8,
NHA_GROUPS = 9,
NHA_MASTER = 10,
NHA_FDB = 11,
NHA_RES_GROUP = 12,
NHA_RES_BUCKET = 13,
__NHA_MAX = 14,
};
enum {
NHA_RES_GROUP_UNSPEC = 0,
NHA_RES_GROUP_PAD = 0,
NHA_RES_GROUP_BUCKETS = 1,
NHA_RES_GROUP_IDLE_TIMER = 2,
NHA_RES_GROUP_UNBALANCED_TIMER = 3,
NHA_RES_GROUP_UNBALANCED_TIME = 4,
__NHA_RES_GROUP_MAX = 5,
};
enum {
NHA_RES_BUCKET_UNSPEC = 0,
NHA_RES_BUCKET_PAD = 0,
NHA_RES_BUCKET_INDEX = 1,
NHA_RES_BUCKET_IDLE_TIME = 2,
NHA_RES_BUCKET_NH_ID = 3,
__NHA_RES_BUCKET_MAX = 4,
};
struct netdev_notifier_info_ext {
struct netdev_notifier_info info;
union {
u32 mtu;
} ext;
};
struct nh_config {
u32 nh_id;
u8 nh_family;
u8 nh_protocol;
u8 nh_blackhole;
u8 nh_fdb;
u32 nh_flags;
int nh_ifindex;
struct net_device *dev;
union {
__be32 ipv4;
struct in6_addr ipv6;
} gw;
struct nlattr *nh_grp;
u16 nh_grp_type;
u16 nh_grp_res_num_buckets;
long unsigned int nh_grp_res_idle_timer;
long unsigned int nh_grp_res_unbalanced_timer;
bool nh_grp_res_has_num_buckets;
bool nh_grp_res_has_idle_timer;
bool nh_grp_res_has_unbalanced_timer;
struct nlattr *nh_encap;
u16 nh_encap_type;
u32 nlflags;
struct nl_info nlinfo;
};
enum nexthop_event_type {
NEXTHOP_EVENT_DEL = 0,
NEXTHOP_EVENT_REPLACE = 1,
NEXTHOP_EVENT_RES_TABLE_PRE_REPLACE = 2,
NEXTHOP_EVENT_BUCKET_REPLACE = 3,
};
enum nh_notifier_info_type {
NH_NOTIFIER_INFO_TYPE_SINGLE = 0,
NH_NOTIFIER_INFO_TYPE_GRP = 1,
NH_NOTIFIER_INFO_TYPE_RES_TABLE = 2,
NH_NOTIFIER_INFO_TYPE_RES_BUCKET = 3,
};
struct nh_notifier_single_info {
struct net_device *dev;
u8 gw_family;
union {
__be32 ipv4;
struct in6_addr ipv6;
};
u8 is_reject: 1;
u8 is_fdb: 1;
u8 has_encap: 1;
};
struct nh_notifier_grp_entry_info {
u8 weight;
u32 id;
struct nh_notifier_single_info nh;
};
struct nh_notifier_grp_info {
u16 num_nh;
bool is_fdb;
struct nh_notifier_grp_entry_info nh_entries[0];
};
struct nh_notifier_res_bucket_info {
u16 bucket_index;
unsigned int idle_timer_ms;
bool force;
struct nh_notifier_single_info old_nh;
struct nh_notifier_single_info new_nh;
};
struct nh_notifier_res_table_info {
u16 num_nh_buckets;
struct nh_notifier_single_info nhs[0];
};
struct nh_notifier_info {
struct net *net;
struct netlink_ext_ack *extack;
u32 id;
enum nh_notifier_info_type type;
union {
struct nh_notifier_single_info *nh;
struct nh_notifier_grp_info *nh_grp;
struct nh_notifier_res_table_info *nh_res_table;
struct nh_notifier_res_bucket_info *nh_res_bucket;
};
};
struct nh_dump_filter {
u32 nh_id;
int dev_idx;
int master_idx;
bool group_filter;
bool fdb_filter;
u32 res_bucket_nh_id;
};
struct rtm_dump_nh_ctx {
u32 idx;
};
struct rtm_dump_res_bucket_ctx {
struct rtm_dump_nh_ctx nh;
u16 bucket_index;
u32 done_nh_idx;
};
struct rtm_dump_nexthop_bucket_data {
struct rtm_dump_res_bucket_ctx *ctx;
struct nh_dump_filter filter;
};
enum {
WQ_UNBOUND = 2,
WQ_FREEZABLE = 4,
WQ_MEM_RECLAIM = 8,
WQ_HIGHPRI = 16,
WQ_CPU_INTENSIVE = 32,
WQ_SYSFS = 64,
WQ_POWER_EFFICIENT = 128,
__WQ_DRAINING = 65536,
__WQ_ORDERED = 131072,
__WQ_LEGACY = 262144,
__WQ_ORDERED_EXPLICIT = 524288,
WQ_MAX_ACTIVE = 512,
WQ_MAX_UNBOUND_PER_CPU = 4,
WQ_DFL_ACTIVE = 256,
};
enum {
IF_OPER_UNKNOWN = 0,
IF_OPER_NOTPRESENT = 1,
IF_OPER_DOWN = 2,
IF_OPER_LOWERLAYERDOWN = 3,
IF_OPER_TESTING = 4,
IF_OPER_DORMANT = 5,
IF_OPER_UP = 6,
};
enum {
IFLA_UNSPEC = 0,
IFLA_ADDRESS = 1,
IFLA_BROADCAST = 2,
IFLA_IFNAME = 3,
IFLA_MTU = 4,
IFLA_LINK = 5,
IFLA_QDISC = 6,
IFLA_STATS = 7,
IFLA_COST = 8,
IFLA_PRIORITY = 9,
IFLA_MASTER = 10,
IFLA_WIRELESS = 11,
IFLA_PROTINFO = 12,
IFLA_TXQLEN = 13,
IFLA_MAP = 14,
IFLA_WEIGHT = 15,
IFLA_OPERSTATE = 16,
IFLA_LINKMODE = 17,
IFLA_LINKINFO = 18,
IFLA_NET_NS_PID = 19,
IFLA_IFALIAS = 20,
IFLA_NUM_VF = 21,
IFLA_VFINFO_LIST = 22,
IFLA_STATS64 = 23,
IFLA_VF_PORTS = 24,
IFLA_PORT_SELF = 25,
IFLA_AF_SPEC = 26,
IFLA_GROUP = 27,
IFLA_NET_NS_FD = 28,
IFLA_EXT_MASK = 29,
IFLA_PROMISCUITY = 30,
IFLA_NUM_TX_QUEUES = 31,
IFLA_NUM_RX_QUEUES = 32,
IFLA_CARRIER = 33,
IFLA_PHYS_PORT_ID = 34,
IFLA_CARRIER_CHANGES = 35,
IFLA_PHYS_SWITCH_ID = 36,
IFLA_LINK_NETNSID = 37,
IFLA_PHYS_PORT_NAME = 38,
IFLA_PROTO_DOWN = 39,
IFLA_GSO_MAX_SEGS = 40,
IFLA_GSO_MAX_SIZE = 41,
IFLA_PAD = 42,
IFLA_XDP = 43,
IFLA_EVENT = 44,
IFLA_NEW_NETNSID = 45,
IFLA_IF_NETNSID = 46,
IFLA_TARGET_NETNSID = 46,
IFLA_CARRIER_UP_COUNT = 47,
IFLA_CARRIER_DOWN_COUNT = 48,
IFLA_NEW_IFINDEX = 49,
IFLA_MIN_MTU = 50,
IFLA_MAX_MTU = 51,
IFLA_PROP_LIST = 52,
IFLA_ALT_IFNAME = 53,
IFLA_PERM_ADDRESS = 54,
IFLA_PROTO_DOWN_REASON = 55,
IFLA_PARENT_DEV_NAME = 56,
IFLA_PARENT_DEV_BUS_NAME = 57,
IFLA_GRO_MAX_SIZE = 58,
IFLA_TSO_MAX_SIZE = 59,
IFLA_TSO_MAX_SEGS = 60,
IFLA_ALLMULTI = 61,
__IFLA_MAX = 62,
};
enum {
IFLA_INET6_UNSPEC = 0,
IFLA_INET6_FLAGS = 1,
IFLA_INET6_CONF = 2,
IFLA_INET6_STATS = 3,
IFLA_INET6_MCAST = 4,
IFLA_INET6_CACHEINFO = 5,
IFLA_INET6_ICMP6STATS = 6,
IFLA_INET6_TOKEN = 7,
IFLA_INET6_ADDR_GEN_MODE = 8,
IFLA_INET6_RA_MTU = 9,
__IFLA_INET6_MAX = 10,
};
enum in6_addr_gen_mode {
IN6_ADDR_GEN_MODE_EUI64 = 0,
IN6_ADDR_GEN_MODE_NONE = 1,
IN6_ADDR_GEN_MODE_STABLE_PRIVACY = 2,
IN6_ADDR_GEN_MODE_RANDOM = 3,
};
struct ifla_cacheinfo {
__u32 max_reasm_len;
__u32 tstamp;
__u32 reachable_time;
__u32 retrans_time;
};
struct netdev_notifier_change_info {
struct netdev_notifier_info info;
unsigned int flags_changed;
};
struct netdev_notifier_changeupper_info {
struct netdev_notifier_info info;
struct net_device *upper_dev;
bool master;
bool linking;
void *upper_info;
};
struct ifaddrmsg {
__u8 ifa_family;
__u8 ifa_prefixlen;
__u8 ifa_flags;
__u8 ifa_scope;
__u32 ifa_index;
};
enum {
IFA_UNSPEC = 0,
IFA_ADDRESS = 1,
IFA_LOCAL = 2,
IFA_LABEL = 3,
IFA_BROADCAST = 4,
IFA_ANYCAST = 5,
IFA_CACHEINFO = 6,
IFA_MULTICAST = 7,
IFA_FLAGS = 8,
IFA_RT_PRIORITY = 9,
IFA_TARGET_NETNSID = 10,
IFA_PROTO = 11,
__IFA_MAX = 12,
};
struct ifa_cacheinfo {
__u32 ifa_prefered;
__u32 ifa_valid;
__u32 cstamp;
__u32 tstamp;
};
struct ifinfomsg {
unsigned char ifi_family;
unsigned char __ifi_pad;
short unsigned int ifi_type;
int ifi_index;
unsigned int ifi_flags;
unsigned int ifi_change;
};
struct prefixmsg {
unsigned char prefix_family;
unsigned char prefix_pad1;
short unsigned int prefix_pad2;
int prefix_ifindex;
unsigned char prefix_type;
unsigned char prefix_len;
unsigned char prefix_flags;
unsigned char prefix_pad3;
};
enum {
PREFIX_UNSPEC = 0,
PREFIX_ADDRESS = 1,
PREFIX_CACHEINFO = 2,
__PREFIX_MAX = 3,
};
struct prefix_cacheinfo {
__u32 preferred_time;
__u32 valid_time;
};
struct rtnl_af_ops {
struct list_head list;
int family;
int (*fill_link_af)(struct sk_buff *, const struct net_device *, u32);
size_t (*get_link_af_size)(const struct net_device *, u32);
int (*validate_link_af)(const struct net_device *, const struct nlattr *, struct netlink_ext_ack *);
int (*set_link_af)(struct net_device *, const struct nlattr *, struct netlink_ext_ack *);
int (*fill_stats_af)(struct sk_buff *, const struct net_device *);
size_t (*get_stats_af_size)(const struct net_device *);
};
struct in6_ifreq {
struct in6_addr ifr6_addr;
__u32 ifr6_prefixlen;
int ifr6_ifindex;
};
enum {
DEVCONF_FORWARDING = 0,
DEVCONF_HOPLIMIT = 1,
DEVCONF_MTU6 = 2,
DEVCONF_ACCEPT_RA = 3,
DEVCONF_ACCEPT_REDIRECTS = 4,
DEVCONF_AUTOCONF = 5,
DEVCONF_DAD_TRANSMITS = 6,
DEVCONF_RTR_SOLICITS = 7,
DEVCONF_RTR_SOLICIT_INTERVAL = 8,
DEVCONF_RTR_SOLICIT_DELAY = 9,
DEVCONF_USE_TEMPADDR = 10,
DEVCONF_TEMP_VALID_LFT = 11,
DEVCONF_TEMP_PREFERED_LFT = 12,
DEVCONF_REGEN_MAX_RETRY = 13,
DEVCONF_MAX_DESYNC_FACTOR = 14,
DEVCONF_MAX_ADDRESSES = 15,
DEVCONF_FORCE_MLD_VERSION = 16,
DEVCONF_ACCEPT_RA_DEFRTR = 17,
DEVCONF_ACCEPT_RA_PINFO = 18,
DEVCONF_ACCEPT_RA_RTR_PREF = 19,
DEVCONF_RTR_PROBE_INTERVAL = 20,
DEVCONF_ACCEPT_RA_RT_INFO_MAX_PLEN = 21,
DEVCONF_PROXY_NDP = 22,
DEVCONF_OPTIMISTIC_DAD = 23,
DEVCONF_ACCEPT_SOURCE_ROUTE = 24,
DEVCONF_MC_FORWARDING = 25,
DEVCONF_DISABLE_IPV6 = 26,
DEVCONF_ACCEPT_DAD = 27,
DEVCONF_FORCE_TLLAO = 28,
DEVCONF_NDISC_NOTIFY = 29,
DEVCONF_MLDV1_UNSOLICITED_REPORT_INTERVAL = 30,
DEVCONF_MLDV2_UNSOLICITED_REPORT_INTERVAL = 31,
DEVCONF_SUPPRESS_FRAG_NDISC = 32,
DEVCONF_ACCEPT_RA_FROM_LOCAL = 33,
DEVCONF_USE_OPTIMISTIC = 34,
DEVCONF_ACCEPT_RA_MTU = 35,
DEVCONF_STABLE_SECRET = 36,
DEVCONF_USE_OIF_ADDRS_ONLY = 37,
DEVCONF_ACCEPT_RA_MIN_HOP_LIMIT = 38,
DEVCONF_IGNORE_ROUTES_WITH_LINKDOWN = 39,
DEVCONF_DROP_UNICAST_IN_L2_MULTICAST = 40,
DEVCONF_DROP_UNSOLICITED_NA = 41,
DEVCONF_KEEP_ADDR_ON_DOWN = 42,
DEVCONF_RTR_SOLICIT_MAX_INTERVAL = 43,
DEVCONF_SEG6_ENABLED = 44,
DEVCONF_SEG6_REQUIRE_HMAC = 45,
DEVCONF_ENHANCED_DAD = 46,
DEVCONF_ADDR_GEN_MODE = 47,
DEVCONF_DISABLE_POLICY = 48,
DEVCONF_ACCEPT_RA_RT_INFO_MIN_PLEN = 49,
DEVCONF_NDISC_TCLASS = 50,
DEVCONF_RPL_SEG_ENABLED = 51,
DEVCONF_RA_DEFRTR_METRIC = 52,
DEVCONF_IOAM6_ENABLED = 53,
DEVCONF_IOAM6_ID = 54,
DEVCONF_IOAM6_ID_WIDE = 55,
DEVCONF_NDISC_EVICT_NOCARRIER = 56,
DEVCONF_ACCEPT_UNTRACKED_NA = 57,
DEVCONF_MAX = 58,
};
struct ipv6_params {
__s32 disable_ipv6;
__s32 autoconf;
};
enum {
INET6_IFADDR_STATE_PREDAD = 0,
INET6_IFADDR_STATE_DAD = 1,
INET6_IFADDR_STATE_POSTDAD = 2,
INET6_IFADDR_STATE_ERRDAD = 3,
INET6_IFADDR_STATE_DEAD = 4,
};
union fwnet_hwaddr {
u8 u[16];
struct {
__be64 uniq_id;
u8 max_rec;
u8 sspd;
u8 fifo[6];
} uc;
};
struct in6_validator_info {
struct in6_addr i6vi_addr;
struct inet6_dev *i6vi_dev;
struct netlink_ext_ack *extack;
};
struct ifa6_config {
const struct in6_addr *pfx;
unsigned int plen;
u8 ifa_proto;
const struct in6_addr *peer_pfx;
u32 rt_priority;
u32 ifa_flags;
u32 preferred_lft;
u32 valid_lft;
u16 scope;
};
struct netconfmsg {
__u8 ncm_family;
};
enum cleanup_prefix_rt_t {
CLEANUP_PREFIX_RT_NOP = 0,
CLEANUP_PREFIX_RT_DEL = 1,
CLEANUP_PREFIX_RT_EXPIRE = 2,
};
enum {
IPV6_SADDR_RULE_INIT = 0,
IPV6_SADDR_RULE_LOCAL = 1,
IPV6_SADDR_RULE_SCOPE = 2,
IPV6_SADDR_RULE_PREFERRED = 3,
IPV6_SADDR_RULE_OIF = 4,
IPV6_SADDR_RULE_LABEL = 5,
IPV6_SADDR_RULE_PRIVACY = 6,
IPV6_SADDR_RULE_ORCHID = 7,
IPV6_SADDR_RULE_PREFIX = 8,
IPV6_SADDR_RULE_NOT_OPTIMISTIC = 9,
IPV6_SADDR_RULE_MAX = 10,
};
struct ipv6_saddr_score {
int rule;
int addr_type;
struct inet6_ifaddr *ifa;
long unsigned int scorebits[1];
int scopedist;
int matchlen;
};
struct ipv6_saddr_dst {
const struct in6_addr *addr;
int ifindex;
int scope;
int label;
unsigned int prefs;
};
struct if6_iter_state {
struct seq_net_private p;
int bucket;
int offset;
};
enum addr_type_t {
UNICAST_ADDR = 0,
MULTICAST_ADDR = 1,
ANYCAST_ADDR = 2,
};
struct inet6_fill_args {
u32 portid;
u32 seq;
int event;
unsigned int flags;
int netnsid;
int ifindex;
enum addr_type_t type;
};
enum {
DAD_PROCESS = 0,
DAD_BEGIN = 1,
DAD_ABORT = 2,
};
enum mem_map {
MEM_MAP_V1 = 0,
MEM_MAP_V2 = 1,
};
struct stack_trace {
unsigned int nr_entries;
unsigned int max_entries;
long unsigned int *entries;
unsigned int skip;
};
struct dyn_arch_ftrace {};
struct dyn_ftrace {
long unsigned int ip;
long unsigned int flags;
struct dyn_arch_ftrace arch;
};
struct srcu_notifier_head {
struct mutex mutex;
struct srcu_struct srcu;
struct notifier_block *head;
};
enum die_val {
DIE_OOPS = 1,
DIE_FP = 2,
DIE_TRAP = 3,
DIE_RI = 4,
DIE_PAGE_FAULT = 5,
DIE_BREAK = 6,
DIE_SSTEPBP = 7,
DIE_MSAFP = 8,
DIE_UPROBE = 9,
DIE_UPROBE_XOL = 10,
};
struct die_args {
struct pt_regs *regs;
const char *str;
long int err;
int trapnr;
int signr;
};
struct kernel_stat {
long unsigned int irqs_sum;
unsigned int softirqs[10];
};
typedef s64 int64_t;
enum wd_read_status {
WD_READ_SUCCESS = 0,
WD_READ_UNSTABLE = 1,
WD_READ_SKIP = 2,
};
struct tp_module {
struct list_head list;
struct module *mod;
};
enum tp_func_state {
TP_FUNC_0 = 0,
TP_FUNC_1 = 1,
TP_FUNC_2 = 2,
TP_FUNC_N = 3,
};
enum tp_transition_sync {
TP_TRANSITION_SYNC_1_0_1 = 0,
TP_TRANSITION_SYNC_N_2_1 = 1,
_NR_TP_TRANSITION_SYNC = 2,
};
struct tp_transition_snapshot {
long unsigned int rcu;
long unsigned int srcu;
bool ongoing;
};
struct tp_probes {
struct callback_head rcu;
struct tracepoint_func probes[0];
};
enum blktrace_cat {
BLK_TC_READ = 1,
BLK_TC_WRITE = 2,
BLK_TC_FLUSH = 4,
BLK_TC_SYNC = 8,
BLK_TC_SYNCIO = 8,
BLK_TC_QUEUE = 16,
BLK_TC_REQUEUE = 32,
BLK_TC_ISSUE = 64,
BLK_TC_COMPLETE = 128,
BLK_TC_FS = 256,
BLK_TC_PC = 512,
BLK_TC_NOTIFY = 1024,
BLK_TC_AHEAD = 2048,
BLK_TC_META = 4096,
BLK_TC_DISCARD = 8192,
BLK_TC_DRV_DATA = 16384,
BLK_TC_FUA = 32768,
BLK_TC_END = 32768,
};
enum blktrace_notify {
__BLK_TN_PROCESS = 0,
__BLK_TN_TIMESTAMP = 1,
__BLK_TN_MESSAGE = 2,
__BLK_TN_CGROUP = 256,
};
struct blk_io_trace {
__u32 magic;
__u32 sequence;
__u64 time;
__u64 sector;
__u32 bytes;
__u32 action;
__u32 pid;
__u32 device;
__u32 cpu;
__u16 error;
__u16 pdu_len;
};
struct blk_io_trace_remap {
__be32 device_from;
__be32 device_to;
__be64 sector_from;
};
enum {
Blktrace_setup = 1,
Blktrace_running = 2,
Blktrace_stopped = 3,
};
struct blk_user_trace_setup {
char name[32];
__u16 act_mask;
__u32 buf_size;
__u32 buf_nr;
long: 32;
__u64 start_lba;
__u64 end_lba;
__u32 pid;
long: 32;
};
typedef void blk_log_action_t(struct trace_iterator *, const char *, bool);
enum bpf_iter_feature {
BPF_ITER_RESCHED = 1,
};
struct bpf_iter__cgroup {
union {
struct bpf_iter_meta *meta;
};
union {
struct cgroup *cgroup;
};
};
struct cgroup_iter_priv {
struct cgroup_subsys_state *start_css;
bool visited_all;
bool terminate;
int order;
};
enum {
MEMREMAP_WB = 1,
MEMREMAP_WT = 2,
MEMREMAP_WC = 4,
MEMREMAP_ENC = 8,
MEMREMAP_DEC = 16,
};
enum {
IORES_DESC_NONE = 0,
IORES_DESC_CRASH_KERNEL = 1,
IORES_DESC_ACPI_TABLES = 2,
IORES_DESC_ACPI_NV_STORAGE = 3,
IORES_DESC_PERSISTENT_MEMORY = 4,
IORES_DESC_PERSISTENT_MEMORY_LEGACY = 5,
IORES_DESC_DEVICE_PRIVATE_MEMORY = 6,
IORES_DESC_RESERVED = 7,
IORES_DESC_SOFT_RESERVED = 8,
IORES_DESC_CXL = 9,
};
enum {
REGION_INTERSECTS = 0,
REGION_DISJOINT = 1,
REGION_MIXED = 2,
};
enum mapping_flags {
AS_EIO = 0,
AS_ENOSPC = 1,
AS_MM_ALL_LOCKS = 2,
AS_UNEVICTABLE = 3,
AS_EXITING = 4,
AS_NO_WRITEBACK_TAGS = 5,
AS_LARGE_FOLIO_SUPPORT = 6,
};
struct reciprocal_value {
u32 m;
u8 sh1;
u8 sh2;
};
struct array_cache;
struct kmem_cache_node;
struct kmem_cache {
struct array_cache *cpu_cache;
unsigned int batchcount;
unsigned int limit;
unsigned int shared;
unsigned int size;
struct reciprocal_value reciprocal_buffer_size;
slab_flags_t flags;
unsigned int num;
unsigned int gfporder;
gfp_t allocflags;
size_t colour;
unsigned int colour_off;
unsigned int freelist_size;
void (*ctor)(void *);
const char *name;
struct list_head list;
int refcount;
int object_size;
int align;
unsigned int useroffset;
unsigned int usersize;
struct kmem_cache_node *node[1];
};
struct alien_cache;
struct kmem_cache_node {
spinlock_t list_lock;
struct list_head slabs_partial;
struct list_head slabs_full;
struct list_head slabs_free;
long unsigned int total_slabs;
long unsigned int free_slabs;
long unsigned int free_objects;
unsigned int free_limit;
unsigned int colour_next;
struct array_cache *shared;
struct alien_cache **alien;
long unsigned int next_reap;
int free_touched;
};
struct mm_walk;
struct mm_walk_ops {
int (*pgd_entry)(pgd_t *, long unsigned int, long unsigned int, struct mm_walk *);
int (*p4d_entry)(p4d_t *, long unsigned int, long unsigned int, struct mm_walk *);
int (*pud_entry)(pud_t *, long unsigned int, long unsigned int, struct mm_walk *);
int (*pmd_entry)(pmd_t *, long unsigned int, long unsigned int, struct mm_walk *);
int (*pte_entry)(pte_t *, long unsigned int, long unsigned int, struct mm_walk *);
int (*pte_hole)(long unsigned int, long unsigned int, int, struct mm_walk *);
int (*hugetlb_entry)(pte_t *, long unsigned int, long unsigned int, long unsigned int, struct mm_walk *);
int (*test_walk)(long unsigned int, long unsigned int, struct mm_walk *);
int (*pre_vma)(long unsigned int, long unsigned int, struct mm_walk *);
void (*post_vma)(struct mm_walk *);
};
enum page_walk_action {
ACTION_SUBTREE = 0,
ACTION_CONTINUE = 1,
ACTION_AGAIN = 2,
};
struct mm_walk {
const struct mm_walk_ops *ops;
struct mm_struct *mm;
pgd_t *pgd;
struct vm_area_struct *vma;
enum page_walk_action action;
bool no_vma;
void *private;
};
struct mmu_gather_batch {
struct mmu_gather_batch *next;
unsigned int nr;
unsigned int max;
struct page *pages[0];
};
struct mmu_gather {
struct mm_struct *mm;
long unsigned int start;
long unsigned int end;
unsigned int fullmm: 1;
unsigned int need_flush_all: 1;
unsigned int freed_tables: 1;
unsigned int cleared_ptes: 1;
unsigned int cleared_pmds: 1;
unsigned int cleared_puds: 1;
unsigned int cleared_p4ds: 1;
unsigned int vma_exec: 1;
unsigned int vma_huge: 1;
unsigned int vma_pfn: 1;
unsigned int batch_count;
struct mmu_gather_batch *active;
struct mmu_gather_batch local;
struct page *__pages[8];
};
enum vfs_get_super_keying {
vfs_get_single_super = 0,
vfs_get_single_reconf_super = 1,
vfs_get_keyed_super = 2,
vfs_get_independent_super = 3,
};
struct fprop_global {
struct percpu_counter events;
unsigned int period;
seqcount_t sequence;
};
enum wb_state {
WB_registered = 0,
WB_writeback_running = 1,
WB_has_dirty_io = 2,
WB_start_all = 3,
};
struct wb_completion {
atomic_t cnt;
wait_queue_head_t *waitq;
};
struct wb_domain {
spinlock_t lock;
long: 32;
struct fprop_global completions;
struct timer_list period_timer;
long unsigned int period_time;
long unsigned int dirty_limit_tstamp;
long unsigned int dirty_limit;
};
struct wb_writeback_work {
long int nr_pages;
struct super_block *sb;
enum writeback_sync_modes sync_mode;
unsigned int tagged_writepages: 1;
unsigned int for_kupdate: 1;
unsigned int range_cyclic: 1;
unsigned int for_background: 1;
unsigned int for_sync: 1;
unsigned int auto_free: 1;
enum wb_reason reason;
struct list_head list;
struct wb_completion *done;
};
struct trace_event_raw_writeback_folio_template {
struct trace_entry ent;
char name[32];
ino_t ino;
long unsigned int index;
char __data[0];
};
struct trace_event_raw_writeback_dirty_inode_template {
struct trace_entry ent;
char name[32];
ino_t ino;
long unsigned int state;
long unsigned int flags;
char __data[0];
};
struct trace_event_raw_writeback_write_inode_template {
struct trace_entry ent;
char name[32];
ino_t ino;
int sync_mode;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_writeback_work_class {
struct trace_entry ent;
char name[32];
long int nr_pages;
dev_t sb_dev;
int sync_mode;
int for_kupdate;
int range_cyclic;
int for_background;
int reason;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_writeback_pages_written {
struct trace_entry ent;
long int pages;
char __data[0];
};
struct trace_event_raw_writeback_class {
struct trace_entry ent;
char name[32];
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_writeback_bdi_register {
struct trace_entry ent;
char name[32];
char __data[0];
};
struct trace_event_raw_wbc_class {
struct trace_entry ent;
char name[32];
long int nr_to_write;
long int pages_skipped;
int sync_mode;
int for_kupdate;
int for_background;
int for_reclaim;
int range_cyclic;
long int range_start;
long int range_end;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_writeback_queue_io {
struct trace_entry ent;
char name[32];
long unsigned int older;
long int age;
int moved;
int reason;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_global_dirty_state {
struct trace_entry ent;
long unsigned int nr_dirty;
long unsigned int nr_writeback;
long unsigned int background_thresh;
long unsigned int dirty_thresh;
long unsigned int dirty_limit;
long unsigned int nr_dirtied;
long unsigned int nr_written;
char __data[0];
};
struct trace_event_raw_bdi_dirty_ratelimit {
struct trace_entry ent;
char bdi[32];
long unsigned int write_bw;
long unsigned int avg_write_bw;
long unsigned int dirty_rate;
long unsigned int dirty_ratelimit;
long unsigned int task_ratelimit;
long unsigned int balanced_dirty_ratelimit;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_balance_dirty_pages {
struct trace_entry ent;
char bdi[32];
long unsigned int limit;
long unsigned int setpoint;
long unsigned int dirty;
long unsigned int bdi_setpoint;
long unsigned int bdi_dirty;
long unsigned int dirty_ratelimit;
long unsigned int task_ratelimit;
unsigned int dirtied;
unsigned int dirtied_pause;
long unsigned int paused;
long int pause;
long unsigned int period;
long int think;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_writeback_sb_inodes_requeue {
struct trace_entry ent;
char name[32];
ino_t ino;
long unsigned int state;
long unsigned int dirtied_when;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_writeback_single_inode_template {
struct trace_entry ent;
char name[32];
ino_t ino;
long unsigned int state;
long unsigned int dirtied_when;
long unsigned int writeback_index;
long int nr_to_write;
long unsigned int wrote;
ino_t cgroup_ino;
char __data[0];
};
struct trace_event_raw_writeback_inode_template {
struct trace_entry ent;
dev_t dev;
ino_t ino;
long unsigned int state;
__u16 mode;
long unsigned int dirtied_when;
char __data[0];
};
struct trace_event_data_offsets_writeback_folio_template {};
struct trace_event_data_offsets_writeback_dirty_inode_template {};
struct trace_event_data_offsets_writeback_write_inode_template {};
struct trace_event_data_offsets_writeback_work_class {};
struct trace_event_data_offsets_writeback_pages_written {};
struct trace_event_data_offsets_writeback_class {};
struct trace_event_data_offsets_writeback_bdi_register {};
struct trace_event_data_offsets_wbc_class {};
struct trace_event_data_offsets_writeback_queue_io {};
struct trace_event_data_offsets_global_dirty_state {};
struct trace_event_data_offsets_bdi_dirty_ratelimit {};
struct trace_event_data_offsets_balance_dirty_pages {};
struct trace_event_data_offsets_writeback_sb_inodes_requeue {};
struct trace_event_data_offsets_writeback_single_inode_template {};
struct trace_event_data_offsets_writeback_inode_template {};
typedef void (*btf_trace_writeback_dirty_folio)(void *, struct folio *, struct address_space *);
typedef void (*btf_trace_folio_wait_writeback)(void *, struct folio *, struct address_space *);
typedef void (*btf_trace_writeback_mark_inode_dirty)(void *, struct inode *, int);
typedef void (*btf_trace_writeback_dirty_inode_start)(void *, struct inode *, int);
typedef void (*btf_trace_writeback_dirty_inode)(void *, struct inode *, int);
typedef void (*btf_trace_writeback_write_inode_start)(void *, struct inode *, struct writeback_control *);
typedef void (*btf_trace_writeback_write_inode)(void *, struct inode *, struct writeback_control *);
typedef void (*btf_trace_writeback_queue)(void *, struct bdi_writeback *, struct wb_writeback_work *);
typedef void (*btf_trace_writeback_exec)(void *, struct bdi_writeback *, struct wb_writeback_work *);
typedef void (*btf_trace_writeback_start)(void *, struct bdi_writeback *, struct wb_writeback_work *);
typedef void (*btf_trace_writeback_written)(void *, struct bdi_writeback *, struct wb_writeback_work *);
typedef void (*btf_trace_writeback_wait)(void *, struct bdi_writeback *, struct wb_writeback_work *);
typedef void (*btf_trace_writeback_pages_written)(void *, long int);
typedef void (*btf_trace_writeback_wake_background)(void *, struct bdi_writeback *);
typedef void (*btf_trace_writeback_bdi_register)(void *, struct backing_dev_info *);
typedef void (*btf_trace_wbc_writepage)(void *, struct writeback_control *, struct backing_dev_info *);
typedef void (*btf_trace_writeback_queue_io)(void *, struct bdi_writeback *, struct wb_writeback_work *, long unsigned int, int);
typedef void (*btf_trace_global_dirty_state)(void *, long unsigned int, long unsigned int);
typedef void (*btf_trace_bdi_dirty_ratelimit)(void *, struct bdi_writeback *, long unsigned int, long unsigned int);
typedef void (*btf_trace_balance_dirty_pages)(void *, struct bdi_writeback *, long unsigned int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, long int, long unsigned int);
typedef void (*btf_trace_writeback_sb_inodes_requeue)(void *, struct inode *);
typedef void (*btf_trace_writeback_single_inode_start)(void *, struct inode *, struct writeback_control *, long unsigned int);
typedef void (*btf_trace_writeback_single_inode)(void *, struct inode *, struct writeback_control *, long unsigned int);
typedef void (*btf_trace_writeback_lazytime)(void *, struct inode *);
typedef void (*btf_trace_writeback_lazytime_iput)(void *, struct inode *);
typedef void (*btf_trace_writeback_dirty_inode_enqueue)(void *, struct inode *);
typedef void (*btf_trace_sb_mark_inode_writeback)(void *, struct inode *);
typedef void (*btf_trace_sb_clear_inode_writeback)(void *, struct inode *);
enum proc_hidepid {
HIDEPID_OFF = 0,
HIDEPID_NO_ACCESS = 1,
HIDEPID_INVISIBLE = 2,
HIDEPID_NOT_PTRACEABLE = 4,
};
enum proc_pidonly {
PROC_PIDONLY_OFF = 0,
PROC_PIDONLY_ON = 1,
};
struct proc_fs_info {
struct pid_namespace *pid_ns;
struct dentry *proc_self;
struct dentry *proc_thread_self;
kgid_t pid_gid;
enum proc_hidepid hide_pid;
enum proc_pidonly pidonly;
};
struct genradix_root;
struct __genradix {
struct genradix_root *root;
};
struct syscall_info {
__u64 sp;
struct seccomp_data data;
};
enum resctrl_conf_type {
CDP_NONE = 0,
CDP_CODE = 1,
CDP_DATA = 2,
};
union proc_op {
int (*proc_get_link)(struct dentry *, struct path *);
int (*proc_show)(struct seq_file *, struct pid_namespace *, struct pid *, struct task_struct *);
const char *lsm;
};
struct proc_inode {
struct pid *pid;
unsigned int fd;
union proc_op op;
struct proc_dir_entry *pde;
struct ctl_table_header *sysctl;
struct ctl_table *sysctl_entry;
struct hlist_node sibling_inodes;
const struct proc_ns_operations *ns_ops;
long: 32;
struct inode vfs_inode;
};
typedef struct dentry *instantiate_t(struct dentry *, struct task_struct *, const void *);
struct pid_entry {
const char *name;
unsigned int len;
umode_t mode;
const struct inode_operations *iop;
const struct file_operations *fop;
union proc_op op;
};
struct limit_names {
const char *name;
const char *unit;
};
struct map_files_info {
long unsigned int start;
long unsigned int end;
fmode_t mode;
};
struct tgid_iter {
unsigned int tgid;
struct task_struct *task;
};
enum {
ES_WRITTEN_B = 0,
ES_UNWRITTEN_B = 1,
ES_DELAYED_B = 2,
ES_HOLE_B = 3,
ES_REFERENCED_B = 4,
ES_FLAGS = 5,
};
struct pending_reservation {
struct rb_node rb_node;
ext4_lblk_t lclu;
};
struct rsvd_count {
int ndelonly;
bool first_do_lblk_found;
ext4_lblk_t first_do_lblk;
ext4_lblk_t last_do_lblk;
struct extent_status *left_es;
bool partial;
ext4_lblk_t lclu;
};
typedef short unsigned int __kernel_uid16_t;
typedef short unsigned int __kernel_gid16_t;
typedef __kernel_uid16_t uid16_t;
typedef __kernel_gid16_t gid16_t;
typedef int dio_iodone_t(struct kiocb *, loff_t, ssize_t, void *);
typedef void dio_submit_t(struct bio *, struct inode *, loff_t);
enum {
DIO_LOCKING = 1,
DIO_SKIP_HOLES = 2,
};
struct ext2_group_desc {
__le32 bg_block_bitmap;
__le32 bg_inode_bitmap;
__le32 bg_inode_table;
__le16 bg_free_blocks_count;
__le16 bg_free_inodes_count;
__le16 bg_used_dirs_count;
__le16 bg_pad;
__le32 bg_reserved[3];
};
struct ext2_inode {
__le16 i_mode;
__le16 i_uid;
__le32 i_size;
__le32 i_atime;
__le32 i_ctime;
__le32 i_mtime;
__le32 i_dtime;
__le16 i_gid;
__le16 i_links_count;
__le32 i_blocks;
__le32 i_flags;
union {
struct {
__le32 l_i_reserved1;
} linux1;
struct {
__le32 h_i_translator;
} hurd1;
struct {
__le32 m_i_reserved1;
} masix1;
} osd1;
__le32 i_block[15];
__le32 i_generation;
__le32 i_file_acl;
__le32 i_dir_acl;
__le32 i_faddr;
union {
struct {
__u8 l_i_frag;
__u8 l_i_fsize;
__u16 i_pad1;
__le16 l_i_uid_high;
__le16 l_i_gid_high;
__u32 l_i_reserved2;
} linux2;
struct {
__u8 h_i_frag;
__u8 h_i_fsize;
__le16 h_i_mode_high;
__le16 h_i_uid_high;
__le16 h_i_gid_high;
__le32 h_i_author;
} hurd2;
struct {
__u8 m_i_frag;
__u8 m_i_fsize;
__u16 m_pad1;
__u32 m_i_reserved2[2];
} masix2;
} osd2;
};
typedef struct {
__le32 *p;
__le32 key;
struct buffer_head *bh;
} Indirect;
enum rpc_auth_flavors {
RPC_AUTH_NULL = 0,
RPC_AUTH_UNIX = 1,
RPC_AUTH_SHORT = 2,
RPC_AUTH_DES = 3,
RPC_AUTH_KRB = 4,
RPC_AUTH_GSS = 6,
RPC_AUTH_TLS = 7,
RPC_AUTH_MAXFLAVOR = 8,
RPC_AUTH_GSS_KRB5 = 390003,
RPC_AUTH_GSS_KRB5I = 390004,
RPC_AUTH_GSS_KRB5P = 390005,
RPC_AUTH_GSS_LKEY = 390006,
RPC_AUTH_GSS_LKEYI = 390007,
RPC_AUTH_GSS_LKEYP = 390008,
RPC_AUTH_GSS_SPKM = 390009,
RPC_AUTH_GSS_SPKMI = 390010,
RPC_AUTH_GSS_SPKMP = 390011,
};
struct nfsd_stats {
struct percpu_counter counter[6];
atomic_t th_cnt;
long: 32;
};
enum nfsd_fsid {
FSID_DEV = 0,
FSID_NUM = 1,
FSID_MAJOR_MINOR = 2,
FSID_ENCODE_DEV = 3,
FSID_UUID4_INUM = 4,
FSID_UUID8 = 5,
FSID_UUID16 = 6,
FSID_UUID16_INUM = 7,
};
enum fsid_source {
FSIDSOURCE_DEV = 0,
FSIDSOURCE_FSID = 1,
FSIDSOURCE_UUID = 2,
};
struct debugfs_blob_wrapper {
void *data;
long unsigned int size;
};
struct debugfs_reg32 {
char *name;
long unsigned int offset;
};
struct debugfs_regset32 {
const struct debugfs_reg32 *regs;
int nregs;
void *base;
struct device *dev;
};
struct debugfs_u32_array {
u32 *array;
u32 n_elements;
};
struct debugfs_fsdata {
const struct file_operations *real_fops;
refcount_t active_users;
struct completion active_users_drained;
};
struct debugfs_devm_entry {
int (*read)(struct seq_file *, void *);
struct device *dev;
};
enum lsm_event {
LSM_POLICY_CHANGE = 0,
};
struct xattr;
typedef int (*initxattrs)(struct inode *, const struct xattr *, void *);
struct xattr {
const char *name;
void *value;
size_t value_len;
};
struct public_key {
void *key;
u32 keylen;
enum OID algo;
void *params;
u32 paramlen;
bool key_is_private;
const char *id_type;
const char *pkey_algo;
};
struct crypto_wait {
struct completion completion;
int err;
};
struct blk_mq_hw_ctx_sysfs_entry {
struct attribute attr;
ssize_t (*show)(struct blk_mq_hw_ctx *, char *);
ssize_t (*store)(struct blk_mq_hw_ctx *, const char *, size_t);
};
struct io_uring_sync_cancel_reg {
__u64 addr;
__s32 fd;
__u32 flags;
struct __kernel_timespec timeout;
__u64 pad[4];
};
struct io_poll {
struct file *file;
struct wait_queue_head *head;
__poll_t events;
struct wait_queue_entry wait;
};
struct async_poll {
union {
struct io_poll poll;
struct io_cache_entry cache;
};
struct io_poll *double_poll;
};
enum io_wq_cancel {
IO_WQ_CANCEL_OK = 0,
IO_WQ_CANCEL_RUNNING = 1,
IO_WQ_CANCEL_NOTFOUND = 2,
};
typedef bool work_cancel_fn(struct io_wq_work *, void *);
struct io_tctx_node {
struct list_head ctx_node;
struct task_struct *task;
struct io_ring_ctx *ctx;
};
struct io_cancel_data {
struct io_ring_ctx *ctx;
long: 32;
union {
u64 data;
struct file *file;
};
u32 flags;
int seq;
};
struct io_cancel {
struct file *file;
long: 32;
u64 addr;
u32 flags;
s32 fd;
};
union nested_table {
union nested_table *table;
struct rhash_lock_head *bucket;
};
enum mm_major_op {
mm_pool32a_op = 0,
mm_pool16a_op = 1,
mm_lbu16_op = 2,
mm_move16_op = 3,
mm_addi32_op = 4,
mm_lbu32_op = 5,
mm_sb32_op = 6,
mm_lb32_op = 7,
mm_pool32b_op = 8,
mm_pool16b_op = 9,
mm_lhu16_op = 10,
mm_andi16_op = 11,
mm_addiu32_op = 12,
mm_lhu32_op = 13,
mm_sh32_op = 14,
mm_lh32_op = 15,
mm_pool32i_op = 16,
mm_pool16c_op = 17,
mm_lwsp16_op = 18,
mm_pool16d_op = 19,
mm_ori32_op = 20,
mm_pool32f_op = 21,
mm_pool32s_op = 22,
mm_reserved2_op = 23,
mm_pool32c_op = 24,
mm_lwgp16_op = 25,
mm_lw16_op = 26,
mm_pool16e_op = 27,
mm_xori32_op = 28,
mm_jals32_op = 29,
mm_addiupc_op = 30,
mm_reserved3_op = 31,
mm_reserved4_op = 32,
mm_pool16f_op = 33,
mm_sb16_op = 34,
mm_beqz16_op = 35,
mm_slti32_op = 36,
mm_beq32_op = 37,
mm_swc132_op = 38,
mm_lwc132_op = 39,
mm_reserved5_op = 40,
mm_reserved6_op = 41,
mm_sh16_op = 42,
mm_bnez16_op = 43,
mm_sltiu32_op = 44,
mm_bne32_op = 45,
mm_sdc132_op = 46,
mm_ldc132_op = 47,
mm_reserved7_op = 48,
mm_reserved8_op = 49,
mm_swsp16_op = 50,
mm_b16_op = 51,
mm_andi32_op = 52,
mm_j32_op = 53,
mm_sd32_op = 54,
mm_ld32_op = 55,
mm_reserved11_op = 56,
mm_reserved12_op = 57,
mm_sw16_op = 58,
mm_li16_op = 59,
mm_jalx32_op = 60,
mm_jal32_op = 61,
mm_sw32_op = 62,
mm_lw32_op = 63,
};
struct j_format {
unsigned int target: 26;
unsigned int opcode: 6;
};
struct i_format {
int simmediate: 16;
unsigned int rt: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct u_format {
unsigned int uimmediate: 16;
unsigned int rt: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct c_format {
unsigned int simmediate: 16;
unsigned int cache: 2;
unsigned int c_op: 3;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct r_format {
unsigned int func: 6;
unsigned int re: 5;
unsigned int rd: 5;
unsigned int rt: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct c0r_format {
unsigned int sel: 3;
unsigned int z: 8;
unsigned int rd: 5;
unsigned int rt: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct mfmc0_format {
unsigned int sel: 3;
char: 2;
unsigned int sc: 1;
unsigned int re: 5;
unsigned int rd: 5;
unsigned int rt: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct co_format {
unsigned int func: 6;
unsigned int code: 19;
unsigned int co: 1;
unsigned int opcode: 6;
};
struct p_format {
unsigned int func: 6;
unsigned int re: 5;
unsigned int rd: 5;
unsigned int rt: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct f_format {
unsigned int func: 6;
unsigned int re: 5;
unsigned int rd: 5;
unsigned int rt: 5;
unsigned int fmt: 4;
char: 1;
unsigned int opcode: 6;
};
struct ma_format {
unsigned int fmt: 2;
unsigned int func: 4;
unsigned int fd: 5;
unsigned int fs: 5;
unsigned int ft: 5;
unsigned int fr: 5;
unsigned int opcode: 6;
};
struct b_format {
unsigned int func: 6;
unsigned int code: 20;
unsigned int opcode: 6;
};
struct ps_format {
unsigned int func: 6;
unsigned int fd: 5;
unsigned int fs: 5;
unsigned int ft: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct v_format {
unsigned int func: 6;
unsigned int vd: 5;
unsigned int vs: 5;
unsigned int vt: 5;
unsigned int fmt: 1;
unsigned int sel: 4;
unsigned int opcode: 6;
};
struct msa_mi10_format {
unsigned int df: 2;
unsigned int func: 4;
unsigned int wd: 5;
unsigned int rs: 5;
int s10: 10;
unsigned int opcode: 6;
};
struct dsp_format {
unsigned int func: 6;
unsigned int op: 5;
unsigned int rd: 5;
unsigned int index: 5;
unsigned int base: 5;
unsigned int opcode: 6;
};
struct spec3_format {
unsigned int func: 7;
int simmediate: 9;
unsigned int rt: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
struct fb_format {
int simmediate: 16;
unsigned int flag: 2;
unsigned int cc: 3;
unsigned int bc: 5;
unsigned int opcode: 6;
};
struct fp0_format {
unsigned int func: 6;
unsigned int fd: 5;
unsigned int fs: 5;
unsigned int ft: 5;
unsigned int fmt: 5;
unsigned int opcode: 6;
};
struct mm_fp0_format {
unsigned int func: 6;
unsigned int op: 2;
unsigned int fmt: 3;
unsigned int fd: 5;
unsigned int fs: 5;
unsigned int ft: 5;
unsigned int opcode: 6;
};
struct fp1_format {
unsigned int func: 6;
unsigned int fd: 5;
unsigned int fs: 5;
unsigned int rt: 5;
unsigned int op: 5;
unsigned int opcode: 6;
};
struct mm_fp1_format {
unsigned int func: 6;
unsigned int op: 8;
unsigned int fmt: 2;
unsigned int fs: 5;
unsigned int rt: 5;
unsigned int opcode: 6;
};
struct mm_fp2_format {
unsigned int func: 6;
unsigned int op: 3;
unsigned int fmt: 2;
unsigned int zero: 2;
unsigned int cc: 3;
unsigned int fs: 5;
unsigned int fd: 5;
unsigned int opcode: 6;
};
struct mm_fp3_format {
unsigned int func: 6;
unsigned int op: 7;
unsigned int fmt: 3;
unsigned int fs: 5;
unsigned int rt: 5;
unsigned int opcode: 6;
};
struct mm_fp4_format {
unsigned int func: 6;
unsigned int cond: 4;
unsigned int fmt: 3;
unsigned int cc: 3;
unsigned int fs: 5;
unsigned int rt: 5;
unsigned int opcode: 6;
};
struct mm_fp5_format {
unsigned int func: 6;
unsigned int op: 5;
unsigned int fd: 5;
unsigned int base: 5;
unsigned int index: 5;
unsigned int opcode: 6;
};
struct fp6_format {
unsigned int func: 6;
unsigned int fd: 5;
unsigned int fs: 5;
unsigned int ft: 5;
unsigned int fr: 5;
unsigned int opcode: 6;
};
struct mm_fp6_format {
unsigned int func: 6;
unsigned int fr: 5;
unsigned int fd: 5;
unsigned int fs: 5;
unsigned int ft: 5;
unsigned int opcode: 6;
};
struct mm_i_format {
int simmediate: 16;
unsigned int rs: 5;
unsigned int rt: 5;
unsigned int opcode: 6;
};
struct mm_m_format {
int simmediate: 12;
unsigned int func: 4;
unsigned int base: 5;
unsigned int rd: 5;
unsigned int opcode: 6;
};
struct mm_x_format {
unsigned int func: 11;
unsigned int rd: 5;
unsigned int base: 5;
unsigned int index: 5;
unsigned int opcode: 6;
};
struct mm_a_format {
int simmediate: 23;
unsigned int rs: 3;
unsigned int opcode: 6;
};
struct mm_b0_format {
short: 16;
int simmediate: 10;
unsigned int opcode: 6;
};
struct mm_b1_format {
short: 16;
int simmediate: 7;
unsigned int rs: 3;
unsigned int opcode: 6;
};
struct mm16_m_format {
short: 16;
unsigned int imm: 4;
unsigned int rlist: 2;
unsigned int func: 4;
unsigned int opcode: 6;
};
struct mm16_rb_format {
short: 16;
int simmediate: 4;
unsigned int base: 3;
unsigned int rt: 3;
unsigned int opcode: 6;
};
struct mm16_r3_format {
short: 16;
int simmediate: 7;
unsigned int rt: 3;
unsigned int opcode: 6;
};
struct mm16_r5_format {
short: 16;
unsigned int imm: 5;
unsigned int rt: 5;
unsigned int opcode: 6;
};
struct loongson3_lswc2_format {
unsigned int rq: 5;
unsigned int ls: 1;
unsigned int offset: 9;
unsigned int fr: 1;
unsigned int rt: 5;
unsigned int base: 5;
unsigned int opcode: 6;
};
struct loongson3_lsdc2_format {
unsigned int opcode1: 3;
unsigned int offset: 8;
unsigned int index: 5;
unsigned int rt: 5;
unsigned int base: 5;
unsigned int opcode: 6;
};
struct loongson3_lscsr_format {
unsigned int func: 6;
unsigned int fd: 5;
unsigned int rd: 5;
unsigned int fr: 5;
unsigned int rs: 5;
unsigned int opcode: 6;
};
union mips_instruction {
unsigned int word;
short unsigned int halfword[2];
unsigned char byte[4];
struct j_format j_format;
struct i_format i_format;
struct u_format u_format;
struct c_format c_format;
struct r_format r_format;
struct c0r_format c0r_format;
struct mfmc0_format mfmc0_format;
struct co_format co_format;
struct p_format p_format;
struct f_format f_format;
struct ma_format ma_format;
struct msa_mi10_format msa_mi10_format;
struct b_format b_format;
struct ps_format ps_format;
struct v_format v_format;
struct dsp_format dsp_format;
struct spec3_format spec3_format;
struct fb_format fb_format;
struct fp0_format fp0_format;
struct mm_fp0_format mm_fp0_format;
struct fp1_format fp1_format;
struct mm_fp1_format mm_fp1_format;
struct mm_fp2_format mm_fp2_format;
struct mm_fp3_format mm_fp3_format;
struct mm_fp4_format mm_fp4_format;
struct mm_fp5_format mm_fp5_format;
struct fp6_format fp6_format;
struct mm_fp6_format mm_fp6_format;
struct mm_i_format mm_i_format;
struct mm_m_format mm_m_format;
struct mm_x_format mm_x_format;
struct mm_a_format mm_a_format;
struct mm_b0_format mm_b0_format;
struct mm_b1_format mm_b1_format;
struct mm16_m_format mm16_m_format;
struct mm16_rb_format mm16_rb_format;
struct mm16_r3_format mm16_r3_format;
struct mm16_r5_format mm16_r5_format;
struct loongson3_lswc2_format loongson3_lswc2_format;
struct loongson3_lsdc2_format loongson3_lsdc2_format;
struct loongson3_lscsr_format loongson3_lscsr_format;
};
typedef unsigned int mips_instruction;
struct mips_fpu_emulator_stats {
long unsigned int emulated;
long unsigned int loads;
long unsigned int stores;
long unsigned int branches;
long unsigned int cp1ops;
long unsigned int cp1xops;
long unsigned int errors;
long unsigned int ieee754_inexact;
long unsigned int ieee754_underflow;
long unsigned int ieee754_overflow;
long unsigned int ieee754_zerodiv;
long unsigned int ieee754_invalidop;
long unsigned int ds_emul;
long unsigned int abs_s;
long unsigned int abs_d;
long unsigned int add_s;
long unsigned int add_d;
long unsigned int bc1eqz;
long unsigned int bc1nez;
long unsigned int ceil_w_s;
long unsigned int ceil_w_d;
long unsigned int ceil_l_s;
long unsigned int ceil_l_d;
long unsigned int class_s;
long unsigned int class_d;
long unsigned int cmp_af_s;
long unsigned int cmp_af_d;
long unsigned int cmp_eq_s;
long unsigned int cmp_eq_d;
long unsigned int cmp_le_s;
long unsigned int cmp_le_d;
long unsigned int cmp_lt_s;
long unsigned int cmp_lt_d;
long unsigned int cmp_ne_s;
long unsigned int cmp_ne_d;
long unsigned int cmp_or_s;
long unsigned int cmp_or_d;
long unsigned int cmp_ueq_s;
long unsigned int cmp_ueq_d;
long unsigned int cmp_ule_s;
long unsigned int cmp_ule_d;
long unsigned int cmp_ult_s;
long unsigned int cmp_ult_d;
long unsigned int cmp_un_s;
long unsigned int cmp_un_d;
long unsigned int cmp_une_s;
long unsigned int cmp_une_d;
long unsigned int cmp_saf_s;
long unsigned int cmp_saf_d;
long unsigned int cmp_seq_s;
long unsigned int cmp_seq_d;
long unsigned int cmp_sle_s;
long unsigned int cmp_sle_d;
long unsigned int cmp_slt_s;
long unsigned int cmp_slt_d;
long unsigned int cmp_sne_s;
long unsigned int cmp_sne_d;
long unsigned int cmp_sor_s;
long unsigned int cmp_sor_d;
long unsigned int cmp_sueq_s;
long unsigned int cmp_sueq_d;
long unsigned int cmp_sule_s;
long unsigned int cmp_sule_d;
long unsigned int cmp_sult_s;
long unsigned int cmp_sult_d;
long unsigned int cmp_sun_s;
long unsigned int cmp_sun_d;
long unsigned int cmp_sune_s;
long unsigned int cmp_sune_d;
long unsigned int cvt_d_l;
long unsigned int cvt_d_s;
long unsigned int cvt_d_w;
long unsigned int cvt_l_s;
long unsigned int cvt_l_d;
long unsigned int cvt_s_d;
long unsigned int cvt_s_l;
long unsigned int cvt_s_w;
long unsigned int cvt_w_s;
long unsigned int cvt_w_d;
long unsigned int div_s;
long unsigned int div_d;
long unsigned int floor_w_s;
long unsigned int floor_w_d;
long unsigned int floor_l_s;
long unsigned int floor_l_d;
long unsigned int maddf_s;
long unsigned int maddf_d;
long unsigned int max_s;
long unsigned int max_d;
long unsigned int maxa_s;
long unsigned int maxa_d;
long unsigned int min_s;
long unsigned int min_d;
long unsigned int mina_s;
long unsigned int mina_d;
long unsigned int mov_s;
long unsigned int mov_d;
long unsigned int msubf_s;
long unsigned int msubf_d;
long unsigned int mul_s;
long unsigned int mul_d;
long unsigned int neg_s;
long unsigned int neg_d;
long unsigned int recip_s;
long unsigned int recip_d;
long unsigned int rint_s;
long unsigned int rint_d;
long unsigned int round_w_s;
long unsigned int round_w_d;
long unsigned int round_l_s;
long unsigned int round_l_d;
long unsigned int rsqrt_s;
long unsigned int rsqrt_d;
long unsigned int sel_s;
long unsigned int sel_d;
long unsigned int seleqz_s;
long unsigned int seleqz_d;
long unsigned int selnez_s;
long unsigned int selnez_d;
long unsigned int sqrt_s;
long unsigned int sqrt_d;
long unsigned int sub_s;
long unsigned int sub_d;
long unsigned int trunc_w_s;
long unsigned int trunc_w_d;
long unsigned int trunc_l_s;
long unsigned int trunc_l_d;
};
struct emuframe {
mips_instruction emul;
mips_instruction badinst;
};
typedef short unsigned int u_short;
struct fbcon_display {
const u_char *fontdata;
int userfont;
u_short inverse;
short int yscroll;
int vrows;
int cursor_shape;
int con_rotate;
u32 xres_virtual;
u32 yres_virtual;
u32 height;
u32 width;
u32 bits_per_pixel;
u32 grayscale;
u32 nonstd;
u32 accel_flags;
u32 rotate;
struct fb_bitfield red;
struct fb_bitfield green;
struct fb_bitfield blue;
struct fb_bitfield transp;
const struct fb_videomode *mode;
};
struct fbcon_ops {
void (*bmove)(struct vc_data *, struct fb_info *, int, int, int, int, int, int);
void (*clear)(struct vc_data *, struct fb_info *, int, int, int, int);
void (*putcs)(struct vc_data *, struct fb_info *, const short unsigned int *, int, int, int, int, int);
void (*clear_margins)(struct vc_data *, struct fb_info *, int, int);
void (*cursor)(struct vc_data *, struct fb_info *, int, int, int);
int (*update_start)(struct fb_info *);
int (*rotate_font)(struct fb_info *, struct vc_data *);
struct fb_var_screeninfo var;
struct delayed_work cursor_work;
struct fb_cursor cursor_state;
struct fbcon_display *p;
struct fb_info *info;
int currcon;
int cur_blink_jiffies;
int cursor_flash;
int cursor_reset;
int blank_state;
int graphics;
int save_graphics;
bool initialized;
int rotate;
int cur_rotate;
char *cursor_data;
u8 *fontbuffer;
u8 *fontdata;
u8 *cursor_src;
u32 cursor_size;
u32 fd_size;
};
struct va_format {
const char *fmt;
va_list *va;
};
typedef u64 async_cookie_t;
typedef void (*async_func_t)(void *, async_cookie_t);
struct device_attach_data {
struct device *dev;
bool check_async;
bool want_async;
bool have_async;
};
struct trace_event_raw_devres {
struct trace_entry ent;
u32 __data_loc_devname;
struct device *dev;
const char *op;
void *node;
const char *name;
size_t size;
char __data[0];
};
struct trace_event_data_offsets_devres {
u32 devname;
};
typedef void (*btf_trace_devres_log)(void *, struct device *, const char *, void *, const char *, size_t);
struct ccs_modesel_head {
__u8 _r1;
__u8 medium;
__u8 _r2;
__u8 block_desc_length;
__u8 density;
__u8 number_blocks_hi;
__u8 number_blocks_med;
__u8 number_blocks_lo;
__u8 _r3;
__u8 block_length_hi;
__u8 block_length_med;
__u8 block_length_lo;
};
struct scsi_cd {
unsigned int capacity;
struct scsi_device *device;
unsigned int vendor;
long unsigned int ms_offset;
unsigned int writeable: 1;
unsigned int use: 1;
unsigned int xa_flag: 1;
unsigned int readcd_known: 1;
unsigned int readcd_cdda: 1;
unsigned int media_present: 1;
int tur_mismatch;
bool tur_changed: 1;
bool get_event_changed: 1;
bool ignore_get_event: 1;
long: 32;
struct cdrom_device_info cdi;
struct mutex lock;
struct gendisk *disk;
long: 32;
};
typedef struct scsi_cd Scsi_CD;
enum {
SKBTX_HW_TSTAMP = 1,
SKBTX_SW_TSTAMP = 2,
SKBTX_IN_PROGRESS = 4,
SKBTX_HW_TSTAMP_USE_CYCLES = 8,
SKBTX_WIFI_STATUS = 16,
SKBTX_HW_TSTAMP_NETDEV = 32,
SKBTX_SCHED_TSTAMP = 64,
};
enum usb_phy_interface {
USBPHY_INTERFACE_MODE_UNKNOWN = 0,
USBPHY_INTERFACE_MODE_UTMI = 1,
USBPHY_INTERFACE_MODE_UTMIW = 2,
USBPHY_INTERFACE_MODE_ULPI = 3,
USBPHY_INTERFACE_MODE_SERIAL = 4,
USBPHY_INTERFACE_MODE_HSIC = 5,
};
struct input_id {
__u16 bustype;
__u16 vendor;
__u16 product;
__u16 version;
};
struct input_absinfo {
__s32 value;
__s32 minimum;
__s32 maximum;
__s32 fuzz;
__s32 flat;
__s32 resolution;
};
struct input_keymap_entry {
__u8 flags;
__u8 len;
__u16 index;
__u32 keycode;
__u8 scancode[32];
};
struct ff_replay {
__u16 length;
__u16 delay;
};
struct ff_trigger {
__u16 button;
__u16 interval;
};
struct ff_envelope {
__u16 attack_length;
__u16 attack_level;
__u16 fade_length;
__u16 fade_level;
};
struct ff_constant_effect {
__s16 level;
struct ff_envelope envelope;
};
struct ff_ramp_effect {
__s16 start_level;
__s16 end_level;
struct ff_envelope envelope;
};
struct ff_condition_effect {
__u16 right_saturation;
__u16 left_saturation;
__s16 right_coeff;
__s16 left_coeff;
__u16 deadband;
__s16 center;
};
struct ff_periodic_effect {
__u16 waveform;
__u16 period;
__s16 magnitude;
__s16 offset;
__u16 phase;
struct ff_envelope envelope;
__u32 custom_len;
__s16 *custom_data;
};
struct ff_rumble_effect {
__u16 strong_magnitude;
__u16 weak_magnitude;
};
struct ff_effect {
__u16 type;
__s16 id;
__u16 direction;
struct ff_trigger trigger;
struct ff_replay replay;
union {
struct ff_constant_effect constant;
struct ff_ramp_effect ramp;
struct ff_periodic_effect periodic;
struct ff_condition_effect condition[2];
struct ff_rumble_effect rumble;
} u;
};
struct input_device_id {
kernel_ulong_t flags;
__u16 bustype;
__u16 vendor;
__u16 product;
__u16 version;
kernel_ulong_t evbit[1];
kernel_ulong_t keybit[24];
kernel_ulong_t relbit[1];
kernel_ulong_t absbit[2];
kernel_ulong_t mscbit[1];
kernel_ulong_t ledbit[1];
kernel_ulong_t sndbit[1];
kernel_ulong_t ffbit[4];
kernel_ulong_t swbit[1];
kernel_ulong_t propbit[1];
kernel_ulong_t driver_info;
};
struct input_value {
__u16 type;
__u16 code;
__s32 value;
};
enum input_clock_type {
INPUT_CLK_REAL = 0,
INPUT_CLK_MONO = 1,
INPUT_CLK_BOOT = 2,
INPUT_CLK_MAX = 3,
};
struct ff_device;
struct input_dev_poller;
struct input_mt;
struct input_handle;
struct input_dev {
const char *name;
const char *phys;
const char *uniq;
struct input_id id;
long unsigned int propbit[1];
long unsigned int evbit[1];
long unsigned int keybit[24];
long unsigned int relbit[1];
long unsigned int absbit[2];
long unsigned int mscbit[1];
long unsigned int ledbit[1];
long unsigned int sndbit[1];
long unsigned int ffbit[4];
long unsigned int swbit[1];
unsigned int hint_events_per_packet;
unsigned int keycodemax;
unsigned int keycodesize;
void *keycode;
int (*setkeycode)(struct input_dev *, const struct input_keymap_entry *, unsigned int *);
int (*getkeycode)(struct input_dev *, struct input_keymap_entry *);
struct ff_device *ff;
struct input_dev_poller *poller;
unsigned int repeat_key;
struct timer_list timer;
int rep[2];
struct input_mt *mt;
struct input_absinfo *absinfo;
long unsigned int key[24];
long unsigned int led[1];
long unsigned int snd[1];
long unsigned int sw[1];
int (*open)(struct input_dev *);
void (*close)(struct input_dev *);
int (*flush)(struct input_dev *, struct file *);
int (*event)(struct input_dev *, unsigned int, unsigned int, int);
struct input_handle *grab;
spinlock_t event_lock;
struct mutex mutex;
unsigned int users;
bool going_away;
long: 32;
struct device dev;
struct list_head h_list;
struct list_head node;
unsigned int num_vals;
unsigned int max_vals;
struct input_value *vals;
bool devres_managed;
ktime_t timestamp[3];
bool inhibited;
long: 32;
};
struct ff_device {
int (*upload)(struct input_dev *, struct ff_effect *, struct ff_effect *);
int (*erase)(struct input_dev *, int);
int (*playback)(struct input_dev *, int, int);
void (*set_gain)(struct input_dev *, u16);
void (*set_autocenter)(struct input_dev *, u16);
void (*destroy)(struct ff_device *);
void *private;
long unsigned int ffbit[4];
struct mutex mutex;
int max_effects;
struct ff_effect *effects;
struct file *effect_owners[0];
};
struct input_mt_slot {
int abs[14];
unsigned int frame;
unsigned int key;
};
struct input_mt {
int trkid;
int num_slots;
int slot;
unsigned int flags;
unsigned int frame;
int *red;
struct input_mt_slot slots[0];
};
struct input_handler;
struct input_handle {
void *private;
int open;
const char *name;
struct input_dev *dev;
struct input_handler *handler;
struct list_head d_node;
struct list_head h_node;
};
struct input_handler {
void *private;
void (*event)(struct input_handle *, unsigned int, unsigned int, int);
void (*events)(struct input_handle *, const struct input_value *, unsigned int);
bool (*filter)(struct input_handle *, unsigned int, unsigned int, int);
bool (*match)(struct input_handler *, struct input_dev *);
int (*connect)(struct input_handler *, struct input_dev *, const struct input_device_id *);
void (*disconnect)(struct input_handle *);
void (*start)(struct input_handle *);
bool legacy_minors;
int minor;
const char *name;
const struct input_device_id *id_table;
struct list_head h_list;
struct list_head node;
};
struct input_mt_pos {
s16 x;
s16 y;
};
struct touchscreen_properties {
unsigned int max_x;
unsigned int max_y;
bool invert_x;
bool invert_y;
bool swap_x_y;
};
struct of_phandle_iterator {
const char *cells_name;
int cell_count;
const struct device_node *parent;
const __be32 *list_end;
const __be32 *phandle_end;
const __be32 *cur;
uint32_t cur_count;
phandle phandle;
struct device_node *node;
};
struct alias_prop {
struct list_head link;
const char *alias;
struct device_node *np;
int id;
char stem[0];
};
struct netpoll;
struct netpoll_info {
refcount_t refcnt;
struct semaphore dev_lock;
struct sk_buff_head txq;
struct delayed_work tx_work;
struct netpoll *netpoll;
struct callback_head rcu;
};
union inet_addr {
__u32 all[4];
__be32 ip;
__be32 ip6[4];
struct in_addr in;
struct in6_addr in6;
};
struct netpoll {
struct net_device *dev;
netdevice_tracker dev_tracker;
char dev_name[16];
const char *name;
union inet_addr local_ip;
union inet_addr remote_ip;
bool ipv6;
u16 local_port;
u16 remote_port;
u8 remote_mac[6];
};
struct trace_event_raw_kfree_skb {
struct trace_entry ent;
void *skbaddr;
void *location;
short unsigned int protocol;
enum skb_drop_reason reason;
char __data[0];
};
struct trace_event_raw_consume_skb {
struct trace_entry ent;
void *skbaddr;
char __data[0];
};
struct trace_event_raw_skb_copy_datagram_iovec {
struct trace_entry ent;
const void *skbaddr;
int len;
char __data[0];
};
struct trace_event_data_offsets_kfree_skb {};
struct trace_event_data_offsets_consume_skb {};
struct trace_event_data_offsets_skb_copy_datagram_iovec {};
typedef void (*btf_trace_kfree_skb)(void *, struct sk_buff *, void *, enum skb_drop_reason);
typedef void (*btf_trace_consume_skb)(void *, struct sk_buff *);
typedef void (*btf_trace_skb_copy_datagram_iovec)(void *, const struct sk_buff *, int);
struct trace_event_raw_net_dev_start_xmit {
struct trace_entry ent;
u32 __data_loc_name;
u16 queue_mapping;
const void *skbaddr;
bool vlan_tagged;
u16 vlan_proto;
u16 vlan_tci;
u16 protocol;
u8 ip_summed;
unsigned int len;
unsigned int data_len;
int network_offset;
bool transport_offset_valid;
int transport_offset;
u8 tx_flags;
u16 gso_size;
u16 gso_segs;
u16 gso_type;
char __data[0];
};
struct trace_event_raw_net_dev_xmit {
struct trace_entry ent;
void *skbaddr;
unsigned int len;
int rc;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_net_dev_xmit_timeout {
struct trace_entry ent;
u32 __data_loc_name;
u32 __data_loc_driver;
int queue_index;
char __data[0];
};
struct trace_event_raw_net_dev_template {
struct trace_entry ent;
void *skbaddr;
unsigned int len;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_net_dev_rx_verbose_template {
struct trace_entry ent;
u32 __data_loc_name;
unsigned int napi_id;
u16 queue_mapping;
const void *skbaddr;
bool vlan_tagged;
u16 vlan_proto;
u16 vlan_tci;
u16 protocol;
u8 ip_summed;
u32 hash;
bool l4_hash;
unsigned int len;
unsigned int data_len;
unsigned int truesize;
bool mac_header_valid;
int mac_header;
unsigned char nr_frags;
u16 gso_size;
u16 gso_type;
char __data[0];
};
struct trace_event_raw_net_dev_rx_exit_template {
struct trace_entry ent;
int ret;
char __data[0];
};
struct trace_event_data_offsets_net_dev_start_xmit {
u32 name;
};
struct trace_event_data_offsets_net_dev_xmit {
u32 name;
};
struct trace_event_data_offsets_net_dev_xmit_timeout {
u32 name;
u32 driver;
};
struct trace_event_data_offsets_net_dev_template {
u32 name;
};
struct trace_event_data_offsets_net_dev_rx_verbose_template {
u32 name;
};
struct trace_event_data_offsets_net_dev_rx_exit_template {};
typedef void (*btf_trace_net_dev_start_xmit)(void *, const struct sk_buff *, const struct net_device *);
typedef void (*btf_trace_net_dev_xmit)(void *, struct sk_buff *, int, struct net_device *, unsigned int);
typedef void (*btf_trace_net_dev_xmit_timeout)(void *, struct net_device *, int);
typedef void (*btf_trace_net_dev_queue)(void *, struct sk_buff *);
typedef void (*btf_trace_netif_receive_skb)(void *, struct sk_buff *);
typedef void (*btf_trace_netif_rx)(void *, struct sk_buff *);
typedef void (*btf_trace_napi_gro_frags_entry)(void *, const struct sk_buff *);
typedef void (*btf_trace_napi_gro_receive_entry)(void *, const struct sk_buff *);
typedef void (*btf_trace_netif_receive_skb_entry)(void *, const struct sk_buff *);
typedef void (*btf_trace_netif_receive_skb_list_entry)(void *, const struct sk_buff *);
typedef void (*btf_trace_netif_rx_entry)(void *, const struct sk_buff *);
typedef void (*btf_trace_napi_gro_frags_exit)(void *, int);
typedef void (*btf_trace_napi_gro_receive_exit)(void *, int);
typedef void (*btf_trace_netif_receive_skb_exit)(void *, int);
typedef void (*btf_trace_netif_rx_exit)(void *, int);
typedef void (*btf_trace_netif_receive_skb_list_exit)(void *, int);
struct trace_event_raw_napi_poll {
struct trace_entry ent;
struct napi_struct *napi;
u32 __data_loc_dev_name;
int work;
int budget;
char __data[0];
};
struct trace_event_data_offsets_napi_poll {
u32 dev_name;
};
typedef void (*btf_trace_napi_poll)(void *, struct napi_struct *, int, int);
struct inet_request_sock {
struct request_sock req;
u16 snd_wscale: 4;
u16 rcv_wscale: 4;
u16 tstamp_ok: 1;
u16 sack_ok: 1;
u16 wscale_ok: 1;
u16 ecn_ok: 1;
u16 acked: 1;
u16 no_srccheck: 1;
u16 smc_ok: 1;
u32 ir_mark;
union {
struct ip_options_rcu *ireq_opt;
struct {
struct ipv6_txoptions *ipv6_opt;
struct sk_buff *pktopts;
};
};
};
struct trace_event_raw_sock_rcvqueue_full {
struct trace_entry ent;
int rmem_alloc;
unsigned int truesize;
int sk_rcvbuf;
char __data[0];
};
struct trace_event_raw_sock_exceed_buf_limit {
struct trace_entry ent;
char name[32];
long int sysctl_mem[3];
long int allocated;
int sysctl_rmem;
int rmem_alloc;
int sysctl_wmem;
int wmem_alloc;
int wmem_queued;
int kind;
char __data[0];
};
struct trace_event_raw_inet_sock_set_state {
struct trace_entry ent;
const void *skaddr;
int oldstate;
int newstate;
__u16 sport;
__u16 dport;
__u16 family;
__u16 protocol;
__u8 saddr[4];
__u8 daddr[4];
__u8 saddr_v6[16];
__u8 daddr_v6[16];
char __data[0];
};
struct trace_event_raw_inet_sk_error_report {
struct trace_entry ent;
int error;
__u16 sport;
__u16 dport;
__u16 family;
__u16 protocol;
__u8 saddr[4];
__u8 daddr[4];
__u8 saddr_v6[16];
__u8 daddr_v6[16];
char __data[0];
};
struct trace_event_data_offsets_sock_rcvqueue_full {};
struct trace_event_data_offsets_sock_exceed_buf_limit {};
struct trace_event_data_offsets_inet_sock_set_state {};
struct trace_event_data_offsets_inet_sk_error_report {};
typedef void (*btf_trace_sock_rcvqueue_full)(void *, struct sock *, struct sk_buff *);
typedef void (*btf_trace_sock_exceed_buf_limit)(void *, struct sock *, struct proto *, long int, int);
typedef void (*btf_trace_inet_sock_set_state)(void *, const struct sock *, const int, const int);
typedef void (*btf_trace_inet_sk_error_report)(void *, const struct sock *);
struct trace_event_raw_udp_fail_queue_rcv_skb {
struct trace_entry ent;
int rc;
__u16 lport;
char __data[0];
};
struct trace_event_data_offsets_udp_fail_queue_rcv_skb {};
typedef void (*btf_trace_udp_fail_queue_rcv_skb)(void *, int, struct sock *);
struct trace_event_raw_tcp_event_sk_skb {
struct trace_entry ent;
const void *skbaddr;
const void *skaddr;
int state;
__u16 sport;
__u16 dport;
__u16 family;
__u8 saddr[4];
__u8 daddr[4];
__u8 saddr_v6[16];
__u8 daddr_v6[16];
char __data[0];
};
struct trace_event_raw_tcp_event_sk {
struct trace_entry ent;
const void *skaddr;
__u16 sport;
__u16 dport;
__u16 family;
__u8 saddr[4];
__u8 daddr[4];
__u8 saddr_v6[16];
__u8 daddr_v6[16];
long: 32;
__u64 sock_cookie;
char __data[0];
};
struct trace_event_raw_tcp_retransmit_synack {
struct trace_entry ent;
const void *skaddr;
const void *req;
__u16 sport;
__u16 dport;
__u16 family;
__u8 saddr[4];
__u8 daddr[4];
__u8 saddr_v6[16];
__u8 daddr_v6[16];
char __data[0];
};
struct trace_event_raw_tcp_probe {
struct trace_entry ent;
__u8 saddr[28];
__u8 daddr[28];
__u16 sport;
__u16 dport;
__u16 family;
__u32 mark;
__u16 data_len;
__u32 snd_nxt;
__u32 snd_una;
__u32 snd_cwnd;
__u32 ssthresh;
__u32 snd_wnd;
__u32 srtt;
__u32 rcv_wnd;
long: 32;
__u64 sock_cookie;
char __data[0];
};
struct trace_event_raw_tcp_event_skb {
struct trace_entry ent;
const void *skbaddr;
__u8 saddr[28];
__u8 daddr[28];
char __data[0];
};
struct trace_event_raw_tcp_cong_state_set {
struct trace_entry ent;
const void *skaddr;
__u16 sport;
__u16 dport;
__u8 saddr[4];
__u8 daddr[4];
__u8 saddr_v6[16];
__u8 daddr_v6[16];
__u8 cong_state;
char __data[0];
};
struct trace_event_data_offsets_tcp_event_sk_skb {};
struct trace_event_data_offsets_tcp_event_sk {};
struct trace_event_data_offsets_tcp_retransmit_synack {};
struct trace_event_data_offsets_tcp_probe {};
struct trace_event_data_offsets_tcp_event_skb {};
struct trace_event_data_offsets_tcp_cong_state_set {};
typedef void (*btf_trace_tcp_retransmit_skb)(void *, const struct sock *, const struct sk_buff *);
typedef void (*btf_trace_tcp_send_reset)(void *, const struct sock *, const struct sk_buff *);
typedef void (*btf_trace_tcp_receive_reset)(void *, struct sock *);
typedef void (*btf_trace_tcp_destroy_sock)(void *, struct sock *);
typedef void (*btf_trace_tcp_rcv_space_adjust)(void *, struct sock *);
typedef void (*btf_trace_tcp_retransmit_synack)(void *, const struct sock *, const struct request_sock *);
typedef void (*btf_trace_tcp_probe)(void *, struct sock *, struct sk_buff *);
typedef void (*btf_trace_tcp_bad_csum)(void *, const struct sk_buff *);
typedef void (*btf_trace_tcp_cong_state_set)(void *, struct sock *, const u8);
struct trace_event_raw_fib_table_lookup {
struct trace_entry ent;
u32 tb_id;
int err;
int oif;
int iif;
u8 proto;
__u8 tos;
__u8 scope;
__u8 flags;
__u8 src[4];
__u8 dst[4];
__u8 gw4[4];
__u8 gw6[16];
u16 sport;
u16 dport;
char name[16];
char __data[0];
};
struct trace_event_data_offsets_fib_table_lookup {};
typedef void (*btf_trace_fib_table_lookup)(void *, u32, const struct flowi4 *, const struct fib_nh_common *, int);
struct trace_event_raw_qdisc_dequeue {
struct trace_entry ent;
struct Qdisc *qdisc;
const struct netdev_queue *txq;
int packets;
void *skbaddr;
int ifindex;
u32 handle;
u32 parent;
long unsigned int txq_state;
char __data[0];
};
struct trace_event_raw_qdisc_enqueue {
struct trace_entry ent;
struct Qdisc *qdisc;
const struct netdev_queue *txq;
void *skbaddr;
int ifindex;
u32 handle;
u32 parent;
char __data[0];
};
struct trace_event_raw_qdisc_reset {
struct trace_entry ent;
u32 __data_loc_dev;
u32 __data_loc_kind;
u32 parent;
u32 handle;
char __data[0];
};
struct trace_event_raw_qdisc_destroy {
struct trace_entry ent;
u32 __data_loc_dev;
u32 __data_loc_kind;
u32 parent;
u32 handle;
char __data[0];
};
struct trace_event_raw_qdisc_create {
struct trace_entry ent;
u32 __data_loc_dev;
u32 __data_loc_kind;
u32 parent;
char __data[0];
};
struct trace_event_data_offsets_qdisc_dequeue {};
struct trace_event_data_offsets_qdisc_enqueue {};
struct trace_event_data_offsets_qdisc_reset {
u32 dev;
u32 kind;
};
struct trace_event_data_offsets_qdisc_destroy {
u32 dev;
u32 kind;
};
struct trace_event_data_offsets_qdisc_create {
u32 dev;
u32 kind;
};
typedef void (*btf_trace_qdisc_dequeue)(void *, struct Qdisc *, const struct netdev_queue *, int, struct sk_buff *);
typedef void (*btf_trace_qdisc_enqueue)(void *, struct Qdisc *, const struct netdev_queue *, struct sk_buff *);
typedef void (*btf_trace_qdisc_reset)(void *, struct Qdisc *);
typedef void (*btf_trace_qdisc_destroy)(void *, struct Qdisc *);
typedef void (*btf_trace_qdisc_create)(void *, const struct Qdisc_ops *, struct net_device *, u32);
struct bridge_stp_xstats {
__u64 transition_blk;
__u64 transition_fwd;
__u64 rx_bpdu;
__u64 tx_bpdu;
__u64 rx_tcn;
__u64 tx_tcn;
};
enum {
BR_MCAST_DIR_RX = 0,
BR_MCAST_DIR_TX = 1,
BR_MCAST_DIR_SIZE = 2,
};
struct br_mcast_stats {
__u64 igmp_v1queries[2];
__u64 igmp_v2queries[2];
__u64 igmp_v3queries[2];
__u64 igmp_leaves[2];
__u64 igmp_v1reports[2];
__u64 igmp_v2reports[2];
__u64 igmp_v3reports[2];
__u64 igmp_parse_errors;
__u64 mld_v1queries[2];
__u64 mld_v2queries[2];
__u64 mld_leaves[2];
__u64 mld_v1reports[2];
__u64 mld_v2reports[2];
__u64 mld_parse_errors;
__u64 mcast_bytes[2];
__u64 mcast_packets[2];
};
struct br_ip {
union {
__be32 ip4;
struct in6_addr ip6;
} src;
union {
__be32 ip4;
struct in6_addr ip6;
unsigned char mac_addr[6];
} dst;
__be16 proto;
__u16 vid;
};
struct bridge_id {
unsigned char prio[2];
unsigned char addr[6];
};
typedef struct bridge_id bridge_id;
struct mac_addr {
unsigned char addr[6];
};
typedef struct mac_addr mac_addr;
typedef __u16 port_id;
struct bridge_mcast_own_query {
struct timer_list timer;
u32 startup_sent;
};
struct bridge_mcast_other_query {
struct timer_list timer;
long unsigned int delay_time;
};
struct bridge_mcast_querier {
struct br_ip addr;
int port_ifidx;
seqcount_spinlock_t seq;
};
struct bridge_mcast_stats {
struct br_mcast_stats mstats;
struct u64_stats_sync syncp;
long: 32;
};
struct net_bridge_port;
struct net_bridge_vlan;
struct net_bridge_mcast_port {
struct net_bridge_port *port;
struct net_bridge_vlan *vlan;
struct bridge_mcast_own_query ip4_own_query;
struct timer_list ip4_mc_router_timer;
struct hlist_node ip4_rlist;
struct bridge_mcast_own_query ip6_own_query;
struct timer_list ip6_mc_router_timer;
struct hlist_node ip6_rlist;
unsigned char multicast_router;
};
struct net_bridge;
struct net_bridge_port {
struct net_bridge *br;
struct net_device *dev;
netdevice_tracker dev_tracker;
struct list_head list;
long unsigned int flags;
struct net_bridge_port *backup_port;
u8 priority;
u8 state;
u16 port_no;
unsigned char topology_change_ack;
unsigned char config_pending;
port_id port_id;
port_id designated_port;
bridge_id designated_root;
bridge_id designated_bridge;
u32 path_cost;
u32 designated_cost;
long unsigned int designated_age;
struct timer_list forward_delay_timer;
struct timer_list hold_timer;
struct timer_list message_age_timer;
struct kobject kobj;
struct callback_head rcu;
struct net_bridge_mcast_port multicast_ctx;
struct bridge_mcast_stats *mcast_stats;
u32 multicast_eht_hosts_limit;
u32 multicast_eht_hosts_cnt;
struct hlist_head mglist;
char sysfs_name[16];
struct netpoll *np;
u16 group_fwd_mask;
u16 backup_redirected_cnt;
long: 32;
struct bridge_stp_xstats stp_xstats;
};
struct br_tunnel_info {
__be64 tunnel_id;
struct metadata_dst *tunnel_dst;
long: 32;
};
struct net_bridge_mcast {
struct net_bridge *br;
struct net_bridge_vlan *vlan;
u32 multicast_last_member_count;
u32 multicast_startup_query_count;
u8 multicast_querier;
u8 multicast_igmp_version;
u8 multicast_router;
u8 multicast_mld_version;
long unsigned int multicast_last_member_interval;
long unsigned int multicast_membership_interval;
long unsigned int multicast_querier_interval;
long unsigned int multicast_query_interval;
long unsigned int multicast_query_response_interval;
long unsigned int multicast_startup_query_interval;
struct hlist_head ip4_mc_router_list;
struct timer_list ip4_mc_router_timer;
struct bridge_mcast_other_query ip4_other_query;
struct bridge_mcast_own_query ip4_own_query;
struct bridge_mcast_querier ip4_querier;
struct hlist_head ip6_mc_router_list;
struct timer_list ip6_mc_router_timer;
struct bridge_mcast_other_query ip6_other_query;
struct bridge_mcast_own_query ip6_own_query;
struct bridge_mcast_querier ip6_querier;
};
struct net_bridge_vlan {
struct rhash_head vnode;
struct rhash_head tnode;
u16 vid;
u16 flags;
u16 priv_flags;
u8 state;
struct pcpu_sw_netstats *stats;
union {
struct net_bridge *br;
struct net_bridge_port *port;
};
union {
refcount_t refcnt;
struct net_bridge_vlan *brvlan;
};
long: 32;
struct br_tunnel_info tinfo;
union {
struct net_bridge_mcast br_mcast_ctx;
struct net_bridge_mcast_port port_mcast_ctx;
};
u16 msti;
struct list_head vlist;
struct callback_head rcu;
};
struct net_bridge {
spinlock_t lock;
spinlock_t hash_lock;
struct hlist_head frame_type_list;
struct net_device *dev;
long unsigned int options;
struct rhashtable fdb_hash_tbl;
struct list_head port_list;
u16 group_fwd_mask;
u16 group_fwd_mask_required;
bridge_id designated_root;
bridge_id bridge_id;
unsigned char topology_change;
unsigned char topology_change_detected;
u16 root_port;
long unsigned int max_age;
long unsigned int hello_time;
long unsigned int forward_delay;
long unsigned int ageing_time;
long unsigned int bridge_max_age;
long unsigned int bridge_hello_time;
long unsigned int bridge_forward_delay;
long unsigned int bridge_ageing_time;
u32 root_path_cost;
u8 group_addr[6];
enum {
BR_NO_STP = 0,
BR_KERNEL_STP = 1,
BR_USER_STP = 2,
} stp_enabled;
struct net_bridge_mcast multicast_ctx;
struct bridge_mcast_stats *mcast_stats;
u32 hash_max;
spinlock_t multicast_lock;
struct rhashtable mdb_hash_tbl;
struct rhashtable sg_port_tbl;
struct hlist_head mcast_gc_list;
struct hlist_head mdb_list;
struct work_struct mcast_gc_work;
struct timer_list hello_timer;
struct timer_list tcn_timer;
struct timer_list topology_change_timer;
struct delayed_work gc_work;
struct kobject *ifobj;
u32 auto_cnt;
struct hlist_head fdb_list;
};
struct net_bridge_fdb_key {
mac_addr addr;
u16 vlan_id;
};
struct net_bridge_fdb_entry {
struct rhash_head rhnode;
struct net_bridge_port *dst;
struct net_bridge_fdb_key key;
struct hlist_node fdb_node;
long unsigned int flags;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long unsigned int updated;
long unsigned int used;
struct callback_head rcu;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct trace_event_raw_br_fdb_add {
struct trace_entry ent;
u8 ndm_flags;
u32 __data_loc_dev;
unsigned char addr[6];
u16 vid;
u16 nlh_flags;
char __data[0];
};
struct trace_event_raw_br_fdb_external_learn_add {
struct trace_entry ent;
u32 __data_loc_br_dev;
u32 __data_loc_dev;
unsigned char addr[6];
u16 vid;
char __data[0];
};
struct trace_event_raw_fdb_delete {
struct trace_entry ent;
u32 __data_loc_br_dev;
u32 __data_loc_dev;
unsigned char addr[6];
u16 vid;
char __data[0];
};
struct trace_event_raw_br_fdb_update {
struct trace_entry ent;
u32 __data_loc_br_dev;
u32 __data_loc_dev;
unsigned char addr[6];
u16 vid;
long unsigned int flags;
char __data[0];
};
struct trace_event_data_offsets_br_fdb_add {
u32 dev;
};
struct trace_event_data_offsets_br_fdb_external_learn_add {
u32 br_dev;
u32 dev;
};
struct trace_event_data_offsets_fdb_delete {
u32 br_dev;
u32 dev;
};
struct trace_event_data_offsets_br_fdb_update {
u32 br_dev;
u32 dev;
};
typedef void (*btf_trace_br_fdb_add)(void *, struct ndmsg *, struct net_device *, const unsigned char *, u16, u16);
typedef void (*btf_trace_br_fdb_external_learn_add)(void *, struct net_bridge *, struct net_bridge_port *, const unsigned char *, u16);
typedef void (*btf_trace_fdb_delete)(void *, struct net_bridge *, struct net_bridge_fdb_entry *);
typedef void (*btf_trace_br_fdb_update)(void *, struct net_bridge *, struct net_bridge_port *, const unsigned char *, u16, long unsigned int);
struct trace_event_raw_page_pool_release {
struct trace_entry ent;
const struct page_pool *pool;
s32 inflight;
u32 hold;
u32 release;
u64 cnt;
char __data[0];
};
struct trace_event_raw_page_pool_state_release {
struct trace_entry ent;
const struct page_pool *pool;
const struct page *page;
u32 release;
long unsigned int pfn;
char __data[0];
};
struct trace_event_raw_page_pool_state_hold {
struct trace_entry ent;
const struct page_pool *pool;
const struct page *page;
u32 hold;
long unsigned int pfn;
char __data[0];
};
struct trace_event_raw_page_pool_update_nid {
struct trace_entry ent;
const struct page_pool *pool;
int pool_nid;
int new_nid;
char __data[0];
};
struct trace_event_data_offsets_page_pool_release {};
struct trace_event_data_offsets_page_pool_state_release {};
struct trace_event_data_offsets_page_pool_state_hold {};
struct trace_event_data_offsets_page_pool_update_nid {};
typedef void (*btf_trace_page_pool_release)(void *, const struct page_pool *, s32, u32, u32);
typedef void (*btf_trace_page_pool_state_release)(void *, const struct page_pool *, const struct page *, u32);
typedef void (*btf_trace_page_pool_state_hold)(void *, const struct page_pool *, const struct page *, u32);
typedef void (*btf_trace_page_pool_update_nid)(void *, const struct page_pool *, int);
struct trace_event_raw_neigh_create {
struct trace_entry ent;
u32 family;
u32 __data_loc_dev;
int entries;
u8 created;
u8 gc_exempt;
u8 primary_key4[4];
u8 primary_key6[16];
char __data[0];
};
struct trace_event_raw_neigh_update {
struct trace_entry ent;
u32 family;
u32 __data_loc_dev;
u8 lladdr[32];
u8 lladdr_len;
u8 flags;
u8 nud_state;
u8 type;
u8 dead;
int refcnt;
__u8 primary_key4[4];
__u8 primary_key6[16];
long unsigned int confirmed;
long unsigned int updated;
long unsigned int used;
u8 new_lladdr[32];
u8 new_state;
u32 update_flags;
u32 pid;
char __data[0];
};
struct trace_event_raw_neigh__update {
struct trace_entry ent;
u32 family;
u32 __data_loc_dev;
u8 lladdr[32];
u8 lladdr_len;
u8 flags;
u8 nud_state;
u8 type;
u8 dead;
int refcnt;
__u8 primary_key4[4];
__u8 primary_key6[16];
long unsigned int confirmed;
long unsigned int updated;
long unsigned int used;
u32 err;
char __data[0];
};
struct trace_event_data_offsets_neigh_create {
u32 dev;
};
struct trace_event_data_offsets_neigh_update {
u32 dev;
};
struct trace_event_data_offsets_neigh__update {
u32 dev;
};
typedef void (*btf_trace_neigh_create)(void *, struct neigh_table *, struct net_device *, const void *, const struct neighbour *, bool);
typedef void (*btf_trace_neigh_update)(void *, struct neighbour *, const u8 *, u8, u32, u32);
typedef void (*btf_trace_neigh_update_done)(void *, struct neighbour *, int);
typedef void (*btf_trace_neigh_timer_handler)(void *, struct neighbour *, int);
typedef void (*btf_trace_neigh_event_send_done)(void *, struct neighbour *, int);
typedef void (*btf_trace_neigh_event_send_dead)(void *, struct neighbour *, int);
typedef void (*btf_trace_neigh_cleanup_and_release)(void *, struct neighbour *, int);
enum lwtunnel_ip_t {
LWTUNNEL_IP_UNSPEC = 0,
LWTUNNEL_IP_ID = 1,
LWTUNNEL_IP_DST = 2,
LWTUNNEL_IP_SRC = 3,
LWTUNNEL_IP_TTL = 4,
LWTUNNEL_IP_TOS = 5,
LWTUNNEL_IP_FLAGS = 6,
LWTUNNEL_IP_PAD = 7,
LWTUNNEL_IP_OPTS = 8,
__LWTUNNEL_IP_MAX = 9,
};
enum lwtunnel_ip6_t {
LWTUNNEL_IP6_UNSPEC = 0,
LWTUNNEL_IP6_ID = 1,
LWTUNNEL_IP6_DST = 2,
LWTUNNEL_IP6_SRC = 3,
LWTUNNEL_IP6_HOPLIMIT = 4,
LWTUNNEL_IP6_TC = 5,
LWTUNNEL_IP6_FLAGS = 6,
LWTUNNEL_IP6_PAD = 7,
LWTUNNEL_IP6_OPTS = 8,
__LWTUNNEL_IP6_MAX = 9,
};
enum {
LWTUNNEL_IP_OPTS_UNSPEC = 0,
LWTUNNEL_IP_OPTS_GENEVE = 1,
LWTUNNEL_IP_OPTS_VXLAN = 2,
LWTUNNEL_IP_OPTS_ERSPAN = 3,
__LWTUNNEL_IP_OPTS_MAX = 4,
};
enum {
LWTUNNEL_IP_OPT_GENEVE_UNSPEC = 0,
LWTUNNEL_IP_OPT_GENEVE_CLASS = 1,
LWTUNNEL_IP_OPT_GENEVE_TYPE = 2,
LWTUNNEL_IP_OPT_GENEVE_DATA = 3,
__LWTUNNEL_IP_OPT_GENEVE_MAX = 4,
};
enum {
LWTUNNEL_IP_OPT_VXLAN_UNSPEC = 0,
LWTUNNEL_IP_OPT_VXLAN_GBP = 1,
__LWTUNNEL_IP_OPT_VXLAN_MAX = 2,
};
enum {
LWTUNNEL_IP_OPT_ERSPAN_UNSPEC = 0,
LWTUNNEL_IP_OPT_ERSPAN_VER = 1,
LWTUNNEL_IP_OPT_ERSPAN_INDEX = 2,
LWTUNNEL_IP_OPT_ERSPAN_DIR = 3,
LWTUNNEL_IP_OPT_ERSPAN_HWID = 4,
__LWTUNNEL_IP_OPT_ERSPAN_MAX = 5,
};
struct lwtunnel_encap_ops {
int (*build_state)(struct net *, struct nlattr *, unsigned int, const void *, struct lwtunnel_state **, struct netlink_ext_ack *);
void (*destroy_state)(struct lwtunnel_state *);
int (*output)(struct net *, struct sock *, struct sk_buff *);
int (*input)(struct sk_buff *);
int (*fill_encap)(struct sk_buff *, struct lwtunnel_state *);
int (*get_encap_size)(struct lwtunnel_state *);
int (*cmp_encap)(struct lwtunnel_state *, struct lwtunnel_state *);
int (*xmit)(struct sk_buff *);
struct module *owner;
};
enum {
IFLA_IPTUN_UNSPEC = 0,
IFLA_IPTUN_LINK = 1,
IFLA_IPTUN_LOCAL = 2,
IFLA_IPTUN_REMOTE = 3,
IFLA_IPTUN_TTL = 4,
IFLA_IPTUN_TOS = 5,
IFLA_IPTUN_ENCAP_LIMIT = 6,
IFLA_IPTUN_FLOWINFO = 7,
IFLA_IPTUN_FLAGS = 8,
IFLA_IPTUN_PROTO = 9,
IFLA_IPTUN_PMTUDISC = 10,
IFLA_IPTUN_6RD_PREFIX = 11,
IFLA_IPTUN_6RD_RELAY_PREFIX = 12,
IFLA_IPTUN_6RD_PREFIXLEN = 13,
IFLA_IPTUN_6RD_RELAY_PREFIXLEN = 14,
IFLA_IPTUN_ENCAP_TYPE = 15,
IFLA_IPTUN_ENCAP_FLAGS = 16,
IFLA_IPTUN_ENCAP_SPORT = 17,
IFLA_IPTUN_ENCAP_DPORT = 18,
IFLA_IPTUN_COLLECT_METADATA = 19,
IFLA_IPTUN_FWMARK = 20,
__IFLA_IPTUN_MAX = 21,
};
struct ip_tunnel_encap_ops {
size_t (*encap_hlen)(struct ip_tunnel_encap *);
int (*build_header)(struct sk_buff *, struct ip_tunnel_encap *, u8 *, struct flowi4 *);
int (*err_handler)(struct sk_buff *, u32);
};
struct ip6_tnl_encap_ops {
size_t (*encap_hlen)(struct ip_tunnel_encap *);
int (*build_header)(struct sk_buff *, struct ip_tunnel_encap *, u8 *, struct flowi6 *);
int (*err_handler)(struct sk_buff *, struct inet6_skb_parm *, u8, u8, int, __be32);
};
struct udp_tunnel_info {
short unsigned int type;
sa_family_t sa_family;
__be16 port;
u8 hw_priv;
};
struct udp_tunnel_nic_shared {
struct udp_tunnel_nic *udp_tunnel_nic_info;
struct list_head devices;
};
struct geneve_opt {
__be16 opt_class;
u8 type;
u8 length: 5;
u8 r3: 1;
u8 r2: 1;
u8 r1: 1;
u8 opt_data[0];
};
struct vxlan_metadata {
u32 gbp;
};
struct erspan_md2 {
__be32 timestamp;
__be16 sgt;
__u8 hwid_upper: 2;
__u8 ft: 5;
__u8 p: 1;
__u8 o: 1;
__u8 gra: 2;
__u8 dir: 1;
__u8 hwid: 4;
};
struct erspan_metadata {
int version;
union {
__be32 index;
struct erspan_md2 md2;
} u;
};
struct sk_psock_progs {
struct bpf_prog *msg_parser;
struct bpf_prog *stream_parser;
struct bpf_prog *stream_verdict;
struct bpf_prog *skb_verdict;
};
struct sk_psock_work_state {
struct sk_buff *skb;
u32 len;
u32 off;
};
struct sk_msg;
struct sk_psock {
struct sock *sk;
struct sock *sk_redir;
u32 apply_bytes;
u32 cork_bytes;
u32 eval;
struct sk_msg *cork;
struct sk_psock_progs progs;
struct sk_buff_head ingress_skb;
struct list_head ingress_msg;
spinlock_t ingress_lock;
long unsigned int state;
struct list_head link;
spinlock_t link_lock;
refcount_t refcnt;
void (*saved_unhash)(struct sock *);
void (*saved_destroy)(struct sock *);
void (*saved_close)(struct sock *, long int);
void (*saved_write_space)(struct sock *);
void (*saved_data_ready)(struct sock *);
int (*psock_update_sk_prot)(struct sock *, struct sk_psock *, bool);
struct proto *sk_proto;
struct mutex work_mutex;
struct sk_psock_work_state work_state;
struct work_struct work;
struct rcu_work rwork;
};
struct udp_sock {
struct inet_sock inet;
int pending;
unsigned int corkflag;
__u8 encap_type;
unsigned char no_check6_tx: 1;
unsigned char no_check6_rx: 1;
unsigned char encap_enabled: 1;
unsigned char gro_enabled: 1;
unsigned char accept_udp_l4: 1;
unsigned char accept_udp_fraglist: 1;
__u16 len;
__u16 gso_size;
__u16 pcslen;
__u16 pcrlen;
__u8 pcflag;
__u8 unused[3];
int (*encap_rcv)(struct sock *, struct sk_buff *);
void (*encap_err_rcv)(struct sock *, struct sk_buff *, unsigned int);
int (*encap_err_lookup)(struct sock *, struct sk_buff *);
void (*encap_destroy)(struct sock *);
struct sk_buff * (*gro_receive)(struct sock *, struct list_head *, struct sk_buff *);
int (*gro_complete)(struct sock *, struct sk_buff *, int);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct sk_buff_head reader_queue;
int forward_deficit;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct sk_msg_sg {
u32 start;
u32 curr;
u32 end;
u32 size;
u32 copybreak;
long unsigned int copy[1];
struct scatterlist data[18];
};
struct sk_msg {
struct sk_msg_sg sg;
void *data;
void *data_end;
u32 apply_bytes;
u32 cork_bytes;
u32 flags;
struct sk_buff *skb;
struct sock *sk_redir;
struct sock *sk;
struct list_head list;
};
enum {
UDP_BPF_IPV4 = 0,
UDP_BPF_IPV6 = 1,
UDP_BPF_NUM_PROTS = 2,
};
struct ifaddrlblmsg {
__u8 ifal_family;
__u8 __ifal_reserved;
__u8 ifal_prefixlen;
__u8 ifal_flags;
__u32 ifal_index;
__u32 ifal_seq;
};
enum {
IFAL_ADDRESS = 1,
IFAL_LABEL = 2,
__IFAL_MAX = 3,
};
struct ip6addrlbl_entry {
struct in6_addr prefix;
int prefixlen;
int ifindex;
int addrtype;
u32 label;
struct hlist_node list;
struct callback_head rcu;
};
struct ip6addrlbl_init_table {
const struct in6_addr *prefix;
int prefixlen;
u32 label;
};
struct in6_flowlabel_req {
struct in6_addr flr_dst;
__be32 flr_label;
__u8 flr_action;
__u8 flr_share;
__u16 flr_flags;
__u16 flr_expires;
__u16 flr_linger;
__u32 __flr_pad;
};
struct static_key_false_deferred {
struct static_key_false key;
};
struct sockcm_cookie {
u64 transmit_time;
u32 mark;
u16 tsflags;
};
struct ipcm6_cookie {
struct sockcm_cookie sockc;
__s16 hlimit;
__s16 tclass;
__u16 gso_size;
__s8 dontfrag;
struct ipv6_txoptions *opt;
long: 32;
};
struct ip6fl_iter_state {
struct seq_net_private p;
struct pid_namespace *pid_ns;
int bucket;
};
enum rpc_auth_stat {
RPC_AUTH_OK = 0,
RPC_AUTH_BADCRED = 1,
RPC_AUTH_REJECTEDCRED = 2,
RPC_AUTH_BADVERF = 3,
RPC_AUTH_REJECTEDVERF = 4,
RPC_AUTH_TOOWEAK = 5,
RPCSEC_GSS_CREDPROBLEM = 13,
RPCSEC_GSS_CTXPROBLEM = 14,
};
enum {
SVC_POOL_AUTO = -1,
SVC_POOL_GLOBAL = 0,
SVC_POOL_PERCPU = 1,
SVC_POOL_PERNODE = 2,
};
struct svc_pool_map {
int count;
int mode;
unsigned int npools;
unsigned int *pool_to;
unsigned int *to_pool;
};
struct subprocess_info {
struct work_struct work;
struct completion *complete;
const char *path;
char **argv;
char **envp;
int wait;
int retval;
int (*init)(struct subprocess_info *, struct cred *);
void (*cleanup)(struct subprocess_info *);
void *data;
};
struct softirq_action {
void (*action)(struct softirq_action *);
};
struct tasklet_struct {
struct tasklet_struct *next;
long unsigned int state;
atomic_t count;
bool use_callback;
union {
void (*func)(long unsigned int);
void (*callback)(struct tasklet_struct *);
};
long unsigned int data;
};
enum {
TASKLET_STATE_SCHED = 0,
TASKLET_STATE_RUN = 1,
};
struct smp_hotplug_thread {
struct task_struct **store;
struct list_head list;
int (*thread_should_run)(unsigned int);
void (*thread_fn)(unsigned int);
void (*create)(unsigned int);
void (*setup)(unsigned int);
void (*cleanup)(unsigned int, bool);
void (*park)(unsigned int);
void (*unpark)(unsigned int);
bool selfparking;
const char *thread_comm;
};
struct trace_event_raw_irq_handler_entry {
struct trace_entry ent;
int irq;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_irq_handler_exit {
struct trace_entry ent;
int irq;
int ret;
char __data[0];
};
struct trace_event_raw_softirq {
struct trace_entry ent;
unsigned int vec;
char __data[0];
};
struct trace_event_data_offsets_irq_handler_entry {
u32 name;
};
struct trace_event_data_offsets_irq_handler_exit {};
struct trace_event_data_offsets_softirq {};
typedef void (*btf_trace_irq_handler_entry)(void *, int, struct irqaction *);
typedef void (*btf_trace_irq_handler_exit)(void *, int, struct irqaction *, int);
typedef void (*btf_trace_softirq_entry)(void *, unsigned int);
typedef void (*btf_trace_softirq_exit)(void *, unsigned int);
typedef void (*btf_trace_softirq_raise)(void *, unsigned int);
struct tasklet_head {
struct tasklet_struct *head;
struct tasklet_struct **tail;
};
struct pin_cookie {};
struct dl_bw {
raw_spinlock_t lock;
long: 32;
u64 bw;
u64 total_bw;
};
struct cpudl_item;
struct cpudl {
raw_spinlock_t lock;
int size;
cpumask_var_t free_cpus;
struct cpudl_item *elements;
};
struct cpupri_vec {
atomic_t count;
cpumask_var_t mask;
};
struct cpupri {
struct cpupri_vec pri_to_cpu[101];
int *cpu_to_pri;
};
struct perf_domain;
struct root_domain {
atomic_t refcount;
atomic_t rto_count;
struct callback_head rcu;
cpumask_var_t span;
cpumask_var_t online;
int overload;
int overutilized;
cpumask_var_t dlo_mask;
atomic_t dlo_count;
struct dl_bw dl_bw;
struct cpudl cpudl;
u64 visit_gen;
struct irq_work rto_push_work;
raw_spinlock_t rto_lock;
int rto_loop;
int rto_cpu;
atomic_t rto_loop_next;
atomic_t rto_loop_start;
cpumask_var_t rto_mask;
struct cpupri cpupri;
long unsigned int max_cpu_capacity;
struct perf_domain *pd;
long: 32;
};
struct swait_queue {
struct task_struct *task;
struct list_head task_list;
};
enum {
MEMBARRIER_STATE_PRIVATE_EXPEDITED_READY = 1,
MEMBARRIER_STATE_PRIVATE_EXPEDITED = 2,
MEMBARRIER_STATE_GLOBAL_EXPEDITED_READY = 4,
MEMBARRIER_STATE_GLOBAL_EXPEDITED = 8,
MEMBARRIER_STATE_PRIVATE_EXPEDITED_SYNC_CORE_READY = 16,
MEMBARRIER_STATE_PRIVATE_EXPEDITED_SYNC_CORE = 32,
MEMBARRIER_STATE_PRIVATE_EXPEDITED_RSEQ_READY = 64,
MEMBARRIER_STATE_PRIVATE_EXPEDITED_RSEQ = 128,
};
enum {
MEMBARRIER_FLAG_SYNC_CORE = 1,
MEMBARRIER_FLAG_RSEQ = 2,
};
enum {
SD_BALANCE_NEWIDLE = 1,
SD_BALANCE_EXEC = 2,
SD_BALANCE_FORK = 4,
SD_BALANCE_WAKE = 8,
SD_WAKE_AFFINE = 16,
SD_ASYM_CPUCAPACITY = 32,
SD_ASYM_CPUCAPACITY_FULL = 64,
SD_SHARE_CPUCAPACITY = 128,
SD_SHARE_PKG_RESOURCES = 256,
SD_SERIALIZE = 512,
SD_ASYM_PACKING = 1024,
SD_PREFER_SIBLING = 2048,
SD_OVERLAP = 4096,
SD_NUMA = 8192,
};
struct sd_flag_debug {
unsigned int meta_flags;
char *name;
};
struct sched_domain_attr {
int relax_domain_level;
};
struct sched_domain_shared {
atomic_t ref;
atomic_t nr_busy_cpus;
int has_idle_cores;
int nr_idle_scan;
};
struct sched_group;
struct sched_domain {
struct sched_domain *parent;
struct sched_domain *child;
struct sched_group *groups;
long unsigned int min_interval;
long unsigned int max_interval;
unsigned int busy_factor;
unsigned int imbalance_pct;
unsigned int cache_nice_tries;
unsigned int imb_numa_nr;
int nohz_idle;
int flags;
int level;
long unsigned int last_balance;
unsigned int balance_interval;
unsigned int nr_balance_failed;
long: 32;
u64 max_newidle_lb_cost;
long unsigned int last_decay_max_lb_cost;
long: 32;
u64 avg_scan_cost;
char *name;
union {
void *private;
struct callback_head rcu;
};
struct sched_domain_shared *shared;
unsigned int span_weight;
long unsigned int span[0];
long: 32;
};
struct sched_group_capacity;
struct sched_group {
struct sched_group *next;
atomic_t ref;
unsigned int group_weight;
struct sched_group_capacity *sgc;
int asym_prefer_cpu;
int flags;
long unsigned int cpumask[0];
};
typedef const struct cpumask * (*sched_domain_mask_f)(int);
typedef int (*sched_domain_flags_f)();
struct sd_data {
struct sched_domain **sd;
struct sched_domain_shared **sds;
struct sched_group **sg;
struct sched_group_capacity **sgc;
};
struct sched_group_capacity {
atomic_t ref;
long unsigned int capacity;
long unsigned int min_capacity;
long unsigned int max_capacity;
long unsigned int next_update;
int imbalance;
int id;
long unsigned int cpumask[0];
};
struct sched_domain_topology_level {
sched_domain_mask_f mask;
sched_domain_flags_f sd_flags;
int flags;
int numa_level;
struct sd_data data;
char *name;
};
struct em_perf_state {
long unsigned int frequency;
long unsigned int power;
long unsigned int cost;
long unsigned int flags;
};
struct em_perf_domain {
struct em_perf_state *table;
int nr_perf_states;
long unsigned int flags;
long unsigned int cpus[0];
};
enum membarrier_cmd {
MEMBARRIER_CMD_QUERY = 0,
MEMBARRIER_CMD_GLOBAL = 1,
MEMBARRIER_CMD_GLOBAL_EXPEDITED = 2,
MEMBARRIER_CMD_REGISTER_GLOBAL_EXPEDITED = 4,
MEMBARRIER_CMD_PRIVATE_EXPEDITED = 8,
MEMBARRIER_CMD_REGISTER_PRIVATE_EXPEDITED = 16,
MEMBARRIER_CMD_PRIVATE_EXPEDITED_SYNC_CORE = 32,
MEMBARRIER_CMD_REGISTER_PRIVATE_EXPEDITED_SYNC_CORE = 64,
MEMBARRIER_CMD_PRIVATE_EXPEDITED_RSEQ = 128,
MEMBARRIER_CMD_REGISTER_PRIVATE_EXPEDITED_RSEQ = 256,
MEMBARRIER_CMD_SHARED = 1,
};
enum membarrier_cmd_flag {
MEMBARRIER_CMD_FLAG_CPU = 1,
};
enum sched_tunable_scaling {
SCHED_TUNABLESCALING_NONE = 0,
SCHED_TUNABLESCALING_LOG = 1,
SCHED_TUNABLESCALING_LINEAR = 2,
SCHED_TUNABLESCALING_END = 3,
};
struct cpu_stop_done;
struct cpu_stop_work {
struct list_head list;
cpu_stop_fn_t fn;
long unsigned int caller;
void *arg;
struct cpu_stop_done *done;
};
struct cpudl_item {
u64 dl;
int cpu;
int idx;
};
struct rt_prio_array {
long unsigned int bitmap[4];
struct list_head queue[100];
};
struct cfs_rq {
struct load_weight load;
unsigned int nr_running;
unsigned int h_nr_running;
unsigned int idle_nr_running;
unsigned int idle_h_nr_running;
u64 exec_clock;
u64 min_vruntime;
u64 min_vruntime_copy;
struct rb_root_cached tasks_timeline;
struct sched_entity *curr;
struct sched_entity *next;
struct sched_entity *last;
struct sched_entity *skip;
unsigned int nr_spread_over;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct sched_avg avg;
u64 last_update_time_copy;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct {
raw_spinlock_t lock;
int nr;
long unsigned int load_avg;
long unsigned int util_avg;
long unsigned int runnable_avg;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
} removed;
};
struct rt_rq {
struct rt_prio_array active;
unsigned int rt_nr_running;
unsigned int rr_nr_running;
struct {
int curr;
int next;
} highest_prio;
unsigned int rt_nr_migratory;
unsigned int rt_nr_total;
int overloaded;
struct plist_head pushable_tasks;
int rt_queued;
int rt_throttled;
long: 32;
u64 rt_time;
u64 rt_runtime;
raw_spinlock_t rt_runtime_lock;
long: 32;
};
struct dl_rq {
struct rb_root_cached root;
unsigned int dl_nr_running;
long: 32;
struct {
u64 curr;
u64 next;
} earliest_dl;
unsigned int dl_nr_migratory;
int overloaded;
struct rb_root_cached pushable_dl_tasks_root;
u64 running_bw;
u64 this_bw;
u64 extra_bw;
u64 bw_ratio;
};
struct perf_domain {
struct em_perf_domain *em_pd;
struct perf_domain *next;
struct callback_head rcu;
};
struct balance_callback {
struct balance_callback *next;
void (*func)(struct rq *);
};
struct rq {
raw_spinlock_t __lock;
unsigned int nr_running;
long unsigned int last_blocked_load_update_tick;
unsigned int has_blocked_load;
call_single_data_t nohz_csd;
unsigned int nohz_tick_stopped;
atomic_t nohz_flags;
unsigned int ttwu_pending;
long: 32;
u64 nr_switches;
long: 32;
long: 32;
struct cfs_rq cfs;
struct rt_rq rt;
struct dl_rq dl;
unsigned int nr_uninterruptible;
struct task_struct *curr;
struct task_struct *idle;
struct task_struct *stop;
long unsigned int next_balance;
struct mm_struct *prev_mm;
unsigned int clock_update_flags;
long: 32;
u64 clock;
long: 32;
long: 32;
long: 32;
long: 32;
u64 clock_task;
u64 clock_pelt;
long unsigned int lost_idle_time;
long: 32;
u64 clock_pelt_idle;
u64 clock_idle;
u64 clock_pelt_idle_copy;
u64 clock_idle_copy;
atomic_t nr_iowait;
long: 32;
u64 last_seen_need_resched_ns;
int ticks_without_resched;
int membarrier_state;
struct root_domain *rd;
struct sched_domain *sd;
long unsigned int cpu_capacity;
long unsigned int cpu_capacity_orig;
struct balance_callback *balance_callback;
unsigned char nohz_idle_balance;
unsigned char idle_balance;
long unsigned int misfit_task_load;
int active_balance;
int push_cpu;
struct cpu_stop_work active_balance_work;
int cpu;
int online;
struct list_head cfs_tasks;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct sched_avg avg_rt;
struct sched_avg avg_dl;
u64 idle_stamp;
u64 avg_idle;
long unsigned int wake_stamp;
long: 32;
u64 wake_avg_idle;
u64 max_idle_balance_cost;
long unsigned int calc_load_update;
long int calc_load_active;
call_single_data_t hrtick_csd;
struct hrtimer hrtick_timer;
ktime_t hrtick_time;
unsigned int nr_pinned;
unsigned int push_busy;
struct cpu_stop_work push_work;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct rq_flags {
long unsigned int flags;
struct pin_cookie cookie;
unsigned int clock_update_flags;
};
enum {
__SCHED_FEAT_GENTLE_FAIR_SLEEPERS = 0,
__SCHED_FEAT_START_DEBIT = 1,
__SCHED_FEAT_NEXT_BUDDY = 2,
__SCHED_FEAT_LAST_BUDDY = 3,
__SCHED_FEAT_CACHE_HOT_BUDDY = 4,
__SCHED_FEAT_WAKEUP_PREEMPTION = 5,
__SCHED_FEAT_HRTICK = 6,
__SCHED_FEAT_HRTICK_DL = 7,
__SCHED_FEAT_DOUBLE_TICK = 8,
__SCHED_FEAT_NONTASK_CAPACITY = 9,
__SCHED_FEAT_TTWU_QUEUE = 10,
__SCHED_FEAT_SIS_PROP = 11,
__SCHED_FEAT_SIS_UTIL = 12,
__SCHED_FEAT_WARN_DOUBLE_CLOCK = 13,
__SCHED_FEAT_RT_PUSH_IPI = 14,
__SCHED_FEAT_RT_RUNTIME_SHARE = 15,
__SCHED_FEAT_LB_MIN = 16,
__SCHED_FEAT_ATTACH_AGE_LOAD = 17,
__SCHED_FEAT_WA_IDLE = 18,
__SCHED_FEAT_WA_WEIGHT = 19,
__SCHED_FEAT_WA_BIAS = 20,
__SCHED_FEAT_UTIL_EST = 21,
__SCHED_FEAT_UTIL_EST_FASTUP = 22,
__SCHED_FEAT_LATENCY_WARN = 23,
__SCHED_FEAT_ALT_PERIOD = 24,
__SCHED_FEAT_BASE_SLICE = 25,
__SCHED_FEAT_NR = 26,
};
struct s_data {
struct sched_domain **sd;
struct root_domain *rd;
};
enum s_alloc {
sa_rootdomain = 0,
sa_sd = 1,
sa_sd_storage = 2,
sa_none = 3,
};
struct asym_cap_data {
struct list_head link;
long unsigned int capacity;
long unsigned int cpus[0];
};
enum hk_flags {
HK_FLAG_TIMER = 1,
HK_FLAG_RCU = 2,
HK_FLAG_MISC = 4,
HK_FLAG_SCHED = 8,
HK_FLAG_TICK = 16,
HK_FLAG_DOMAIN = 32,
HK_FLAG_WQ = 64,
HK_FLAG_MANAGED_IRQ = 128,
HK_FLAG_KTHREAD = 256,
};
struct housekeeping {
struct cpumask cpumasks[9];
long unsigned int flags;
};
enum {
TRACE_PIDS = 1,
TRACE_NO_PIDS = 2,
};
struct trace_parser {
bool cont;
char *buffer;
unsigned int idx;
unsigned int size;
};
struct module_string {
struct list_head next;
struct module *module;
char *str;
};
enum {
FORMAT_HEADER = 1,
FORMAT_FIELD_SEPERATOR = 2,
FORMAT_PRINTFMT = 3,
};
struct event_probe_data {
struct trace_event_file *file;
long unsigned int count;
int ref;
bool enable;
};
struct bpf_iter_seq_prog_info {
u32 prog_id;
};
struct bpf_iter__bpf_prog {
union {
struct bpf_iter_meta *meta;
};
union {
struct bpf_prog *prog;
};
};
struct btf_enum {
__u32 name_off;
__s32 val;
};
struct btf_array {
__u32 type;
__u32 index_type;
__u32 nelems;
};
struct btf_param {
__u32 name_off;
__u32 type;
};
enum {
BTF_VAR_STATIC = 0,
BTF_VAR_GLOBAL_ALLOCATED = 1,
BTF_VAR_GLOBAL_EXTERN = 2,
};
enum btf_func_linkage {
BTF_FUNC_STATIC = 0,
BTF_FUNC_GLOBAL = 1,
BTF_FUNC_EXTERN = 2,
};
struct btf_var {
__u32 linkage;
};
struct btf_var_secinfo {
__u32 type;
__u32 offset;
__u32 size;
};
struct btf_decl_tag {
__s32 component_idx;
};
struct btf_enum64 {
__u32 name_off;
__u32 val_lo32;
__u32 val_hi32;
};
struct bpf_sock {
__u32 bound_dev_if;
__u32 family;
__u32 type;
__u32 protocol;
__u32 mark;
__u32 priority;
__u32 src_ip4;
__u32 src_ip6[4];
__u32 src_port;
__be16 dst_port;
__u32 dst_ip4;
__u32 dst_ip6[4];
__u32 state;
__s32 rx_queue_mapping;
};
struct __sk_buff {
__u32 len;
__u32 pkt_type;
__u32 mark;
__u32 queue_mapping;
__u32 protocol;
__u32 vlan_present;
__u32 vlan_tci;
__u32 vlan_proto;
__u32 priority;
__u32 ingress_ifindex;
__u32 ifindex;
__u32 tc_index;
__u32 cb[5];
__u32 hash;
__u32 tc_classid;
__u32 data;
__u32 data_end;
__u32 napi_id;
__u32 family;
__u32 remote_ip4;
__u32 local_ip4;
__u32 remote_ip6[4];
__u32 local_ip6[4];
__u32 remote_port;
__u32 local_port;
__u32 data_meta;
union {
struct bpf_flow_keys *flow_keys;
};
__u64 tstamp;
__u32 wire_len;
__u32 gso_segs;
union {
struct bpf_sock *sk;
};
__u32 gso_size;
__u8 tstamp_type;
__u64 hwtstamp;
};
struct xdp_md {
__u32 data;
__u32 data_end;
__u32 data_meta;
__u32 ingress_ifindex;
__u32 rx_queue_index;
__u32 egress_ifindex;
};
struct sk_msg_md {
union {
void *data;
};
union {
void *data_end;
};
__u32 family;
__u32 remote_ip4;
__u32 local_ip4;
__u32 remote_ip6[4];
__u32 local_ip6[4];
__u32 remote_port;
__u32 local_port;
__u32 size;
union {
struct bpf_sock *sk;
};
};
struct sk_reuseport_md {
union {
void *data;
};
union {
void *data_end;
};
__u32 len;
__u32 eth_protocol;
__u32 ip_protocol;
__u32 bind_inany;
__u32 hash;
long: 32;
union {
struct bpf_sock *sk;
};
union {
struct bpf_sock *migrating_sk;
};
};
struct bpf_btf_info {
__u64 btf;
__u32 btf_size;
__u32 id;
__u64 name;
__u32 name_len;
__u32 kernel_btf;
};
struct bpf_sock_ops {
__u32 op;
union {
__u32 args[4];
__u32 reply;
__u32 replylong[4];
};
__u32 family;
__u32 remote_ip4;
__u32 local_ip4;
__u32 remote_ip6[4];
__u32 local_ip6[4];
__u32 remote_port;
__u32 local_port;
__u32 is_fullsock;
__u32 snd_cwnd;
__u32 srtt_us;
__u32 bpf_sock_ops_cb_flags;
__u32 state;
__u32 rtt_min;
__u32 snd_ssthresh;
__u32 rcv_nxt;
__u32 snd_nxt;
__u32 snd_una;
__u32 mss_cache;
__u32 ecn_flags;
__u32 rate_delivered;
__u32 rate_interval_us;
__u32 packets_out;
__u32 retrans_out;
__u32 total_retrans;
__u32 segs_in;
__u32 data_segs_in;
__u32 segs_out;
__u32 data_segs_out;
__u32 lost_out;
__u32 sacked_out;
__u32 sk_txhash;
__u64 bytes_received;
__u64 bytes_acked;
union {
struct bpf_sock *sk;
};
union {
void *skb_data;
};
union {
void *skb_data_end;
};
__u32 skb_len;
__u32 skb_tcp_flags;
};
struct bpf_raw_tracepoint_args {
__u64 args[0];
};
struct bpf_sk_lookup {
union {
union {
struct bpf_sock *sk;
};
__u64 cookie;
};
__u32 family;
__u32 protocol;
__u32 remote_ip4;
__u32 remote_ip6[4];
__be16 remote_port;
__u32 local_ip4;
__u32 local_ip6[4];
__u32 local_port;
__u32 ingress_ifindex;
long: 32;
};
enum {
BTF_F_COMPACT = 1,
BTF_F_NONAME = 2,
BTF_F_PTR_RAW = 4,
BTF_F_ZERO = 8,
};
enum bpf_core_relo_kind {
BPF_CORE_FIELD_BYTE_OFFSET = 0,
BPF_CORE_FIELD_BYTE_SIZE = 1,
BPF_CORE_FIELD_EXISTS = 2,
BPF_CORE_FIELD_SIGNED = 3,
BPF_CORE_FIELD_LSHIFT_U64 = 4,
BPF_CORE_FIELD_RSHIFT_U64 = 5,
BPF_CORE_TYPE_ID_LOCAL = 6,
BPF_CORE_TYPE_ID_TARGET = 7,
BPF_CORE_TYPE_EXISTS = 8,
BPF_CORE_TYPE_SIZE = 9,
BPF_CORE_ENUMVAL_EXISTS = 10,
BPF_CORE_ENUMVAL_VALUE = 11,
BPF_CORE_TYPE_MATCHES = 12,
};
struct bpf_core_relo {
__u32 insn_off;
__u32 type_id;
__u32 access_str_off;
enum bpf_core_relo_kind kind;
};
typedef struct pt_regs bpf_user_pt_regs_t;
struct bpf_perf_event_data {
bpf_user_pt_regs_t regs;
__u64 sample_period;
__u64 addr;
};
struct btf_id_dtor_kfunc {
u32 btf_id;
u32 kfunc_btf_id;
};
struct bpf_kfunc_arg_meta {
u64 r0_size;
bool r0_rdonly;
int ref_obj_id;
u32 flags;
long: 32;
};
struct bpf_core_ctx {
struct bpf_verifier_log *log;
const struct btf *btf;
};
struct sk_reuseport_kern {
struct sk_buff *skb;
struct sock *sk;
struct sock *selected_sk;
struct sock *migrating_sk;
void *data_end;
u32 hash;
u32 reuseport_id;
bool bind_inany;
};
struct bpf_sock_ops_kern {
struct sock *sk;
union {
u32 args[4];
u32 reply;
u32 replylong[4];
};
struct sk_buff *syn_skb;
struct sk_buff *skb;
void *skb_data_end;
u8 op;
u8 is_fullsock;
u8 remaining_opt_len;
long: 32;
u64 temp;
};
struct bpf_sk_lookup_kern {
u16 family;
u16 protocol;
__be16 sport;
u16 dport;
struct {
__be32 saddr;
__be32 daddr;
} v4;
struct {
const struct in6_addr *saddr;
const struct in6_addr *daddr;
} v6;
struct sock *selected_sk;
u32 ingress_ifindex;
bool no_reuseport;
};
struct btf_id_set {
u32 cnt;
u32 ids[0];
};
enum {
BTF_SOCK_TYPE_INET = 0,
BTF_SOCK_TYPE_INET_CONN = 1,
BTF_SOCK_TYPE_INET_REQ = 2,
BTF_SOCK_TYPE_INET_TW = 3,
BTF_SOCK_TYPE_REQ = 4,
BTF_SOCK_TYPE_SOCK = 5,
BTF_SOCK_TYPE_SOCK_COMMON = 6,
BTF_SOCK_TYPE_TCP = 7,
BTF_SOCK_TYPE_TCP_REQ = 8,
BTF_SOCK_TYPE_TCP_TW = 9,
BTF_SOCK_TYPE_TCP6 = 10,
BTF_SOCK_TYPE_UDP = 11,
BTF_SOCK_TYPE_UDP6 = 12,
BTF_SOCK_TYPE_UNIX = 13,
BTF_SOCK_TYPE_MPTCP = 14,
BTF_SOCK_TYPE_SOCKET = 15,
MAX_BTF_SOCK_TYPE = 16,
};
struct bpf_perf_event_data_kern {
bpf_user_pt_regs_t *regs;
struct perf_sample_data *data;
struct perf_event *event;
};
struct bpf_core_cand {
const struct btf *btf;
__u32 id;
};
struct bpf_core_cand_list {
struct bpf_core_cand *cands;
int len;
};
struct bpf_core_accessor {
__u32 type_id;
__u32 idx;
const char *name;
};
struct bpf_core_spec {
const struct btf *btf;
struct bpf_core_accessor spec[64];
__u32 root_type_id;
enum bpf_core_relo_kind relo_kind;
int len;
int raw_spec[64];
int raw_len;
__u32 bit_offset;
};
struct bpf_core_relo_res {
__u64 orig_val;
__u64 new_val;
bool poison;
bool validate;
bool fail_memsz_adjust;
__u32 orig_sz;
__u32 orig_type_id;
__u32 new_sz;
__u32 new_type_id;
long: 32;
};
enum btf_kfunc_hook {
BTF_KFUNC_HOOK_XDP = 0,
BTF_KFUNC_HOOK_TC = 1,
BTF_KFUNC_HOOK_STRUCT_OPS = 2,
BTF_KFUNC_HOOK_TRACING = 3,
BTF_KFUNC_HOOK_SYSCALL = 4,
BTF_KFUNC_HOOK_MAX = 5,
};
enum {
BTF_KFUNC_SET_MAX_CNT = 256,
BTF_DTOR_KFUNC_MAX_CNT = 256,
};
struct btf_kfunc_set_tab {
struct btf_id_set8 *sets[5];
};
struct btf_id_dtor_kfunc_tab {
u32 cnt;
struct btf_id_dtor_kfunc dtors[0];
};
enum verifier_phase {
CHECK_META = 0,
CHECK_TYPE = 1,
};
struct resolve_vertex {
const struct btf_type *t;
u32 type_id;
u16 next_member;
};
enum visit_state {
NOT_VISITED = 0,
VISITED = 1,
RESOLVED = 2,
};
enum resolve_mode {
RESOLVE_TBD = 0,
RESOLVE_PTR = 1,
RESOLVE_STRUCT_OR_ARRAY = 2,
};
struct btf_sec_info {
u32 off;
u32 len;
};
struct btf_verifier_env {
struct btf *btf;
u8 *visit_states;
struct resolve_vertex stack[32];
struct bpf_verifier_log log;
u32 log_type_id;
u32 top_stack;
enum verifier_phase phase;
enum resolve_mode resolve_mode;
};
struct btf_show {
u64 flags;
void *target;
void (*showfn)(struct btf_show *, const char *, va_list);
const struct btf *btf;
struct {
u8 depth;
u8 depth_to_show;
u8 depth_check;
u8 array_member: 1;
u8 array_terminated: 1;
u16 array_encoding;
u32 type_id;
int status;
const struct btf_type *type;
const struct btf_member *member;
char name[80];
} state;
struct {
u32 size;
void *head;
void *data;
u8 safe[32];
} obj;
};
struct btf_kind_operations {
s32 (*check_meta)(struct btf_verifier_env *, const struct btf_type *, u32);
int (*resolve)(struct btf_verifier_env *, const struct resolve_vertex *);
int (*check_member)(struct btf_verifier_env *, const struct btf_type *, const struct btf_member *, const struct btf_type *);
int (*check_kflag_member)(struct btf_verifier_env *, const struct btf_type *, const struct btf_member *, const struct btf_type *);
void (*log_details)(struct btf_verifier_env *, const struct btf_type *);
void (*show)(const struct btf *, const struct btf_type *, u32, void *, u8, struct btf_show *);
};
enum btf_field_type {
BTF_FIELD_SPIN_LOCK = 0,
BTF_FIELD_TIMER = 1,
BTF_FIELD_KPTR = 2,
};
enum {
BTF_FIELD_IGNORE = 0,
BTF_FIELD_FOUND = 1,
};
struct btf_field_info {
u32 type_id;
u32 off;
enum bpf_kptr_type type;
};
struct bpf_ctx_convert {
struct __sk_buff BPF_PROG_TYPE_SOCKET_FILTER_prog;
struct sk_buff BPF_PROG_TYPE_SOCKET_FILTER_kern;
struct __sk_buff BPF_PROG_TYPE_SCHED_CLS_prog;
struct sk_buff BPF_PROG_TYPE_SCHED_CLS_kern;
struct __sk_buff BPF_PROG_TYPE_SCHED_ACT_prog;
struct sk_buff BPF_PROG_TYPE_SCHED_ACT_kern;
struct xdp_md BPF_PROG_TYPE_XDP_prog;
struct xdp_buff BPF_PROG_TYPE_XDP_kern;
struct __sk_buff BPF_PROG_TYPE_LWT_IN_prog;
struct sk_buff BPF_PROG_TYPE_LWT_IN_kern;
struct __sk_buff BPF_PROG_TYPE_LWT_OUT_prog;
struct sk_buff BPF_PROG_TYPE_LWT_OUT_kern;
struct __sk_buff BPF_PROG_TYPE_LWT_XMIT_prog;
struct sk_buff BPF_PROG_TYPE_LWT_XMIT_kern;
struct __sk_buff BPF_PROG_TYPE_LWT_SEG6LOCAL_prog;
struct sk_buff BPF_PROG_TYPE_LWT_SEG6LOCAL_kern;
struct bpf_sock_ops BPF_PROG_TYPE_SOCK_OPS_prog;
struct bpf_sock_ops_kern BPF_PROG_TYPE_SOCK_OPS_kern;
struct __sk_buff BPF_PROG_TYPE_SK_SKB_prog;
struct sk_buff BPF_PROG_TYPE_SK_SKB_kern;
struct sk_msg_md BPF_PROG_TYPE_SK_MSG_prog;
struct sk_msg BPF_PROG_TYPE_SK_MSG_kern;
struct __sk_buff BPF_PROG_TYPE_FLOW_DISSECTOR_prog;
struct bpf_flow_dissector BPF_PROG_TYPE_FLOW_DISSECTOR_kern;
bpf_user_pt_regs_t BPF_PROG_TYPE_KPROBE_prog;
struct pt_regs BPF_PROG_TYPE_KPROBE_kern;
__u64 BPF_PROG_TYPE_TRACEPOINT_prog;
u64 BPF_PROG_TYPE_TRACEPOINT_kern;
struct bpf_perf_event_data BPF_PROG_TYPE_PERF_EVENT_prog;
struct bpf_perf_event_data_kern BPF_PROG_TYPE_PERF_EVENT_kern;
long: 32;
struct bpf_raw_tracepoint_args BPF_PROG_TYPE_RAW_TRACEPOINT_prog;
u64 BPF_PROG_TYPE_RAW_TRACEPOINT_kern;
struct bpf_raw_tracepoint_args BPF_PROG_TYPE_RAW_TRACEPOINT_WRITABLE_prog;
u64 BPF_PROG_TYPE_RAW_TRACEPOINT_WRITABLE_kern;
void *BPF_PROG_TYPE_TRACING_prog;
void *BPF_PROG_TYPE_TRACING_kern;
struct sk_reuseport_md BPF_PROG_TYPE_SK_REUSEPORT_prog;
struct sk_reuseport_kern BPF_PROG_TYPE_SK_REUSEPORT_kern;
struct bpf_sk_lookup BPF_PROG_TYPE_SK_LOOKUP_prog;
struct bpf_sk_lookup_kern BPF_PROG_TYPE_SK_LOOKUP_kern;
void *BPF_PROG_TYPE_STRUCT_OPS_prog;
void *BPF_PROG_TYPE_STRUCT_OPS_kern;
void *BPF_PROG_TYPE_EXT_prog;
void *BPF_PROG_TYPE_EXT_kern;
void *BPF_PROG_TYPE_SYSCALL_prog;
void *BPF_PROG_TYPE_SYSCALL_kern;
long: 32;
};
enum {
__ctx_convertBPF_PROG_TYPE_SOCKET_FILTER = 0,
__ctx_convertBPF_PROG_TYPE_SCHED_CLS = 1,
__ctx_convertBPF_PROG_TYPE_SCHED_ACT = 2,
__ctx_convertBPF_PROG_TYPE_XDP = 3,
__ctx_convertBPF_PROG_TYPE_LWT_IN = 4,
__ctx_convertBPF_PROG_TYPE_LWT_OUT = 5,
__ctx_convertBPF_PROG_TYPE_LWT_XMIT = 6,
__ctx_convertBPF_PROG_TYPE_LWT_SEG6LOCAL = 7,
__ctx_convertBPF_PROG_TYPE_SOCK_OPS = 8,
__ctx_convertBPF_PROG_TYPE_SK_SKB = 9,
__ctx_convertBPF_PROG_TYPE_SK_MSG = 10,
__ctx_convertBPF_PROG_TYPE_FLOW_DISSECTOR = 11,
__ctx_convertBPF_PROG_TYPE_KPROBE = 12,
__ctx_convertBPF_PROG_TYPE_TRACEPOINT = 13,
__ctx_convertBPF_PROG_TYPE_PERF_EVENT = 14,
__ctx_convertBPF_PROG_TYPE_RAW_TRACEPOINT = 15,
__ctx_convertBPF_PROG_TYPE_RAW_TRACEPOINT_WRITABLE = 16,
__ctx_convertBPF_PROG_TYPE_TRACING = 17,
__ctx_convertBPF_PROG_TYPE_SK_REUSEPORT = 18,
__ctx_convertBPF_PROG_TYPE_SK_LOOKUP = 19,
__ctx_convertBPF_PROG_TYPE_STRUCT_OPS = 20,
__ctx_convertBPF_PROG_TYPE_EXT = 21,
__ctx_convertBPF_PROG_TYPE_SYSCALL = 22,
__ctx_convert_unused = 23,
};
enum bpf_struct_walk_result {
WALK_SCALAR = 0,
WALK_PTR = 1,
WALK_STRUCT = 2,
};
struct btf_show_snprintf {
struct btf_show show;
int len_left;
int len;
};
enum {
BTF_MODULE_F_LIVE = 1,
};
struct btf_module {
struct list_head list;
struct module *module;
struct btf *btf;
struct bin_attribute *sysfs_attr;
int flags;
};
typedef u64 (*btf_bpf_btf_find_by_name_kind)(char *, int, u32, int);
struct bpf_cand_cache {
const char *name;
u32 name_len;
u16 kind;
u16 cnt;
struct {
const struct btf *btf;
u32 id;
} cands[0];
};
struct fs_pin {
wait_queue_head_t wait;
int done;
struct hlist_node s_list;
struct hlist_node m_list;
void (*kill)(struct fs_pin *);
};
enum {
IOPRIO_CLASS_NONE = 0,
IOPRIO_CLASS_RT = 1,
IOPRIO_CLASS_BE = 2,
IOPRIO_CLASS_IDLE = 3,
};
enum {
_DQUOT_USAGE_ENABLED = 0,
_DQUOT_LIMITS_ENABLED = 1,
_DQUOT_SUSPENDED = 2,
_DQUOT_STATE_FLAGS = 3,
};
typedef int (*writepage_t)(struct page *, struct writeback_control *, void *);
struct dax_holder_operations {
int (*notify_failure)(struct dax_device *, u64, u64, int);
};
struct fs_error_report {
int error;
struct inode *inode;
struct super_block *sb;
};
struct constant_table {
const char *name;
int value;
};
struct ext4_allocation_request {
struct inode *inode;
unsigned int len;
ext4_lblk_t logical;
ext4_lblk_t lleft;
ext4_lblk_t lright;
long: 32;
ext4_fsblk_t goal;
ext4_fsblk_t pleft;
ext4_fsblk_t pright;
unsigned int flags;
long: 32;
};
struct ext4_map_blocks {
ext4_fsblk_t m_pblk;
ext4_lblk_t m_lblk;
unsigned int m_len;
unsigned int m_flags;
long: 32;
};
struct ext4_inode {
__le16 i_mode;
__le16 i_uid;
__le32 i_size_lo;
__le32 i_atime;
__le32 i_ctime;
__le32 i_mtime;
__le32 i_dtime;
__le16 i_gid;
__le16 i_links_count;
__le32 i_blocks_lo;
__le32 i_flags;
union {
struct {
__le32 l_i_version;
} linux1;
struct {
__u32 h_i_translator;
} hurd1;
struct {
__u32 m_i_reserved1;
} masix1;
} osd1;
__le32 i_block[15];
__le32 i_generation;
__le32 i_file_acl_lo;
__le32 i_size_high;
__le32 i_obso_faddr;
union {
struct {
__le16 l_i_blocks_high;
__le16 l_i_file_acl_high;
__le16 l_i_uid_high;
__le16 l_i_gid_high;
__le16 l_i_checksum_lo;
__le16 l_i_reserved;
} linux2;
struct {
__le16 h_i_reserved1;
__u16 h_i_mode_high;
__u16 h_i_uid_high;
__u16 h_i_gid_high;
__u32 h_i_author;
} hurd2;
struct {
__le16 h_i_reserved1;
__le16 m_i_file_acl_high;
__u32 m_i_reserved2[2];
} masix2;
} osd2;
__le16 i_extra_isize;
__le16 i_checksum_hi;
__le32 i_ctime_extra;
__le32 i_mtime_extra;
__le32 i_atime_extra;
__le32 i_crtime;
__le32 i_crtime_extra;
__le32 i_version_hi;
__le32 i_projid;
};
enum {
EXT4_FC_REASON_XATTR = 0,
EXT4_FC_REASON_CROSS_RENAME = 1,
EXT4_FC_REASON_JOURNAL_FLAG_CHANGE = 2,
EXT4_FC_REASON_NOMEM = 3,
EXT4_FC_REASON_SWAP_BOOT = 4,
EXT4_FC_REASON_RESIZE = 5,
EXT4_FC_REASON_RENAME_DIR = 6,
EXT4_FC_REASON_FALLOC_RANGE = 7,
EXT4_FC_REASON_INODE_JOURNAL_DATA = 8,
EXT4_FC_REASON_MAX = 9,
};
enum {
I_DATA_SEM_NORMAL = 0,
I_DATA_SEM_OTHER = 1,
I_DATA_SEM_QUOTA = 2,
};
enum ext4_journal_trigger_type {
EXT4_JTR_ORPHAN_FILE = 0,
EXT4_JTR_NONE = 1,
};
struct ext4_lazy_init {
long unsigned int li_state;
struct list_head li_request_list;
struct mutex li_list_mtx;
};
typedef enum {
EXT4_IGET_NORMAL = 0,
EXT4_IGET_SPECIAL = 1,
EXT4_IGET_HANDLE = 2,
} ext4_iget_flags;
struct partial_cluster {
ext4_fsblk_t pclu;
ext4_lblk_t lblk;
enum {
initial = 0,
tofree = 1,
nofree = 2,
} state;
};
struct ext4_journal_cb_entry {
struct list_head jce_list;
void (*jce_func)(struct super_block *, struct ext4_journal_cb_entry *, int);
};
struct ext4_prealloc_space {
struct list_head pa_inode_list;
struct list_head pa_group_list;
union {
struct list_head pa_tmp_list;
struct callback_head pa_rcu;
} u;
spinlock_t pa_lock;
atomic_t pa_count;
unsigned int pa_deleted;
long: 32;
ext4_fsblk_t pa_pstart;
ext4_lblk_t pa_lstart;
ext4_grpblk_t pa_len;
ext4_grpblk_t pa_free;
short unsigned int pa_type;
spinlock_t *pa_obj_lock;
struct inode *pa_inode;
};
struct ext4_free_extent {
ext4_lblk_t fe_logical;
ext4_grpblk_t fe_start;
ext4_group_t fe_group;
ext4_grpblk_t fe_len;
};
struct ext4_allocation_context {
struct inode *ac_inode;
struct super_block *ac_sb;
struct ext4_free_extent ac_o_ex;
struct ext4_free_extent ac_g_ex;
struct ext4_free_extent ac_b_ex;
struct ext4_free_extent ac_f_ex;
__u32 ac_groups_considered;
__u32 ac_flags;
__u16 ac_groups_scanned;
__u16 ac_groups_linear_remaining;
__u16 ac_found;
__u16 ac_tail;
__u16 ac_buddy;
__u8 ac_status;
__u8 ac_criteria;
__u8 ac_2order;
__u8 ac_op;
struct page *ac_bitmap_page;
struct page *ac_buddy_page;
struct ext4_prealloc_space *ac_pa;
struct ext4_locality_group *ac_lg;
};
struct trace_event_raw_ext4_other_inode_update_time {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ino_t orig_ino;
uid_t uid;
gid_t gid;
__u16 mode;
char __data[0];
};
struct trace_event_raw_ext4_free_inode {
struct trace_entry ent;
dev_t dev;
ino_t ino;
uid_t uid;
gid_t gid;
__u64 blocks;
__u16 mode;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_request_inode {
struct trace_entry ent;
dev_t dev;
ino_t dir;
__u16 mode;
char __data[0];
};
struct trace_event_raw_ext4_allocate_inode {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ino_t dir;
__u16 mode;
char __data[0];
};
struct trace_event_raw_ext4_evict_inode {
struct trace_entry ent;
dev_t dev;
ino_t ino;
int nlink;
char __data[0];
};
struct trace_event_raw_ext4_drop_inode {
struct trace_entry ent;
dev_t dev;
ino_t ino;
int drop;
char __data[0];
};
struct trace_event_raw_ext4_nfs_commit_metadata {
struct trace_entry ent;
dev_t dev;
ino_t ino;
char __data[0];
};
struct trace_event_raw_ext4_mark_inode_dirty {
struct trace_entry ent;
dev_t dev;
ino_t ino;
long unsigned int ip;
char __data[0];
};
struct trace_event_raw_ext4_begin_ordered_truncate {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t new_size;
char __data[0];
};
struct trace_event_raw_ext4__write_begin {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t pos;
unsigned int len;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4__write_end {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t pos;
unsigned int len;
unsigned int copied;
char __data[0];
};
struct trace_event_raw_ext4_writepages {
struct trace_entry ent;
dev_t dev;
ino_t ino;
long int nr_to_write;
long int pages_skipped;
loff_t range_start;
loff_t range_end;
long unsigned int writeback_index;
int sync_mode;
char for_kupdate;
char range_cyclic;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_da_write_pages {
struct trace_entry ent;
dev_t dev;
ino_t ino;
long unsigned int first_page;
long int nr_to_write;
int sync_mode;
char __data[0];
};
struct trace_event_raw_ext4_da_write_pages_extent {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 lblk;
__u32 len;
__u32 flags;
char __data[0];
};
struct trace_event_raw_ext4_writepages_result {
struct trace_entry ent;
dev_t dev;
ino_t ino;
int ret;
int pages_written;
long int pages_skipped;
long unsigned int writeback_index;
int sync_mode;
char __data[0];
};
struct trace_event_raw_ext4__page_op {
struct trace_entry ent;
dev_t dev;
ino_t ino;
long unsigned int index;
char __data[0];
};
struct trace_event_raw_ext4_invalidate_folio_op {
struct trace_entry ent;
dev_t dev;
ino_t ino;
long unsigned int index;
size_t offset;
size_t length;
char __data[0];
};
struct trace_event_raw_ext4_discard_blocks {
struct trace_entry ent;
dev_t dev;
long: 32;
__u64 blk;
__u64 count;
char __data[0];
};
struct trace_event_raw_ext4__mb_new_pa {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 pa_pstart;
__u64 pa_lstart;
__u32 pa_len;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_mb_release_inode_pa {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 block;
__u32 count;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_mb_release_group_pa {
struct trace_entry ent;
dev_t dev;
long: 32;
__u64 pa_pstart;
__u32 pa_len;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_discard_preallocations {
struct trace_entry ent;
dev_t dev;
ino_t ino;
unsigned int len;
unsigned int needed;
char __data[0];
};
struct trace_event_raw_ext4_mb_discard_preallocations {
struct trace_entry ent;
dev_t dev;
int needed;
char __data[0];
};
struct trace_event_raw_ext4_request_blocks {
struct trace_entry ent;
dev_t dev;
ino_t ino;
unsigned int len;
__u32 logical;
__u32 lleft;
__u32 lright;
__u64 goal;
__u64 pleft;
__u64 pright;
unsigned int flags;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_allocate_blocks {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 block;
unsigned int len;
__u32 logical;
__u32 lleft;
__u32 lright;
__u64 goal;
__u64 pleft;
__u64 pright;
unsigned int flags;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_free_blocks {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 block;
long unsigned int count;
int flags;
__u16 mode;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_sync_file_enter {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ino_t parent;
int datasync;
char __data[0];
};
struct trace_event_raw_ext4_sync_file_exit {
struct trace_entry ent;
dev_t dev;
ino_t ino;
int ret;
char __data[0];
};
struct trace_event_raw_ext4_sync_fs {
struct trace_entry ent;
dev_t dev;
int wait;
char __data[0];
};
struct trace_event_raw_ext4_alloc_da_blocks {
struct trace_entry ent;
dev_t dev;
ino_t ino;
unsigned int data_blocks;
char __data[0];
};
struct trace_event_raw_ext4_mballoc_alloc {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u32 orig_logical;
int orig_start;
__u32 orig_group;
int orig_len;
__u32 goal_logical;
int goal_start;
__u32 goal_group;
int goal_len;
__u32 result_logical;
int result_start;
__u32 result_group;
int result_len;
__u16 found;
__u16 groups;
__u16 buddy;
__u16 flags;
__u16 tail;
__u8 cr;
char __data[0];
};
struct trace_event_raw_ext4_mballoc_prealloc {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u32 orig_logical;
int orig_start;
__u32 orig_group;
int orig_len;
__u32 result_logical;
int result_start;
__u32 result_group;
int result_len;
char __data[0];
};
struct trace_event_raw_ext4__mballoc {
struct trace_entry ent;
dev_t dev;
ino_t ino;
int result_start;
__u32 result_group;
int result_len;
char __data[0];
};
struct trace_event_raw_ext4_forget {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 block;
int is_metadata;
__u16 mode;
char __data[0];
};
struct trace_event_raw_ext4_da_update_reserve_space {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 i_blocks;
int used_blocks;
int reserved_data_blocks;
int quota_claim;
__u16 mode;
char __data[0];
};
struct trace_event_raw_ext4_da_reserve_space {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 i_blocks;
int reserved_data_blocks;
__u16 mode;
char __data[0];
};
struct trace_event_raw_ext4_da_release_space {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 i_blocks;
int freed_blocks;
int reserved_data_blocks;
__u16 mode;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4__bitmap_load {
struct trace_entry ent;
dev_t dev;
__u32 group;
char __data[0];
};
struct trace_event_raw_ext4_read_block_bitmap_load {
struct trace_entry ent;
dev_t dev;
__u32 group;
bool prefetch;
char __data[0];
};
struct trace_event_raw_ext4__fallocate_mode {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t offset;
loff_t len;
int mode;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_fallocate_exit {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t pos;
unsigned int blocks;
int ret;
char __data[0];
};
struct trace_event_raw_ext4_unlink_enter {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ino_t parent;
long: 32;
loff_t size;
char __data[0];
};
struct trace_event_raw_ext4_unlink_exit {
struct trace_entry ent;
dev_t dev;
ino_t ino;
int ret;
char __data[0];
};
struct trace_event_raw_ext4__truncate {
struct trace_entry ent;
dev_t dev;
ino_t ino;
__u64 blocks;
char __data[0];
};
struct trace_event_raw_ext4_ext_convert_to_initialized_enter {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t m_lblk;
unsigned int m_len;
ext4_lblk_t u_lblk;
unsigned int u_len;
ext4_fsblk_t u_pblk;
char __data[0];
};
struct trace_event_raw_ext4_ext_convert_to_initialized_fastpath {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t m_lblk;
unsigned int m_len;
ext4_lblk_t u_lblk;
unsigned int u_len;
ext4_fsblk_t u_pblk;
ext4_lblk_t i_lblk;
unsigned int i_len;
ext4_fsblk_t i_pblk;
char __data[0];
};
struct trace_event_raw_ext4__map_blocks_enter {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t lblk;
unsigned int len;
unsigned int flags;
char __data[0];
};
struct trace_event_raw_ext4__map_blocks_exit {
struct trace_entry ent;
dev_t dev;
ino_t ino;
unsigned int flags;
long: 32;
ext4_fsblk_t pblk;
ext4_lblk_t lblk;
unsigned int len;
unsigned int mflags;
int ret;
char __data[0];
};
struct trace_event_raw_ext4_ext_load_extent {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_fsblk_t pblk;
ext4_lblk_t lblk;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_load_inode {
struct trace_entry ent;
dev_t dev;
ino_t ino;
char __data[0];
};
struct trace_event_raw_ext4_journal_start {
struct trace_entry ent;
dev_t dev;
long unsigned int ip;
int blocks;
int rsv_blocks;
int revoke_creds;
char __data[0];
};
struct trace_event_raw_ext4_journal_start_reserved {
struct trace_entry ent;
dev_t dev;
long unsigned int ip;
int blocks;
char __data[0];
};
struct trace_event_raw_ext4__trim {
struct trace_entry ent;
int dev_major;
int dev_minor;
__u32 group;
int start;
int len;
char __data[0];
};
struct trace_event_raw_ext4_ext_handle_unwritten_extents {
struct trace_entry ent;
dev_t dev;
ino_t ino;
int flags;
ext4_lblk_t lblk;
ext4_fsblk_t pblk;
unsigned int len;
unsigned int allocated;
ext4_fsblk_t newblk;
char __data[0];
};
struct trace_event_raw_ext4_get_implied_cluster_alloc_exit {
struct trace_entry ent;
dev_t dev;
unsigned int flags;
ext4_lblk_t lblk;
long: 32;
ext4_fsblk_t pblk;
unsigned int len;
int ret;
char __data[0];
};
struct trace_event_raw_ext4_ext_show_extent {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_fsblk_t pblk;
ext4_lblk_t lblk;
short unsigned int len;
char __data[0];
};
struct trace_event_raw_ext4_remove_blocks {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t from;
ext4_lblk_t to;
ext4_fsblk_t ee_pblk;
ext4_lblk_t ee_lblk;
short unsigned int ee_len;
ext4_fsblk_t pc_pclu;
ext4_lblk_t pc_lblk;
int pc_state;
char __data[0];
};
struct trace_event_raw_ext4_ext_rm_leaf {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t start;
ext4_lblk_t ee_lblk;
ext4_fsblk_t ee_pblk;
short int ee_len;
long: 32;
ext4_fsblk_t pc_pclu;
ext4_lblk_t pc_lblk;
int pc_state;
char __data[0];
};
struct trace_event_raw_ext4_ext_rm_idx {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_fsblk_t pblk;
char __data[0];
};
struct trace_event_raw_ext4_ext_remove_space {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t start;
ext4_lblk_t end;
int depth;
char __data[0];
};
struct trace_event_raw_ext4_ext_remove_space_done {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t start;
ext4_lblk_t end;
int depth;
long: 32;
ext4_fsblk_t pc_pclu;
ext4_lblk_t pc_lblk;
int pc_state;
short unsigned int eh_entries;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4__es_extent {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t lblk;
ext4_lblk_t len;
ext4_fsblk_t pblk;
char status;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_es_remove_extent {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t lblk;
loff_t len;
char __data[0];
};
struct trace_event_raw_ext4_es_find_extent_range_enter {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t lblk;
char __data[0];
};
struct trace_event_raw_ext4_es_find_extent_range_exit {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t lblk;
ext4_lblk_t len;
ext4_fsblk_t pblk;
char status;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_es_lookup_extent_enter {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t lblk;
char __data[0];
};
struct trace_event_raw_ext4_es_lookup_extent_exit {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t lblk;
ext4_lblk_t len;
ext4_fsblk_t pblk;
char status;
int found;
char __data[0];
};
struct trace_event_raw_ext4__es_shrink_enter {
struct trace_entry ent;
dev_t dev;
int nr_to_scan;
int cache_cnt;
char __data[0];
};
struct trace_event_raw_ext4_es_shrink_scan_exit {
struct trace_entry ent;
dev_t dev;
int nr_shrunk;
int cache_cnt;
char __data[0];
};
struct trace_event_raw_ext4_collapse_range {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t offset;
loff_t len;
char __data[0];
};
struct trace_event_raw_ext4_insert_range {
struct trace_entry ent;
dev_t dev;
ino_t ino;
loff_t offset;
loff_t len;
char __data[0];
};
struct trace_event_raw_ext4_es_shrink {
struct trace_entry ent;
dev_t dev;
int nr_shrunk;
long long unsigned int scan_time;
int nr_skipped;
int retried;
char __data[0];
};
struct trace_event_raw_ext4_es_insert_delayed_block {
struct trace_entry ent;
dev_t dev;
ino_t ino;
ext4_lblk_t lblk;
ext4_lblk_t len;
ext4_fsblk_t pblk;
char status;
bool allocated;
char __data[0];
long: 32;
};
struct trace_event_raw_ext4_fsmap_class {
struct trace_entry ent;
dev_t dev;
dev_t keydev;
u32 agno;
long: 32;
u64 bno;
u64 len;
u64 owner;
char __data[0];
};
struct trace_event_raw_ext4_getfsmap_class {
struct trace_entry ent;
dev_t dev;
dev_t keydev;
u64 block;
u64 len;
u64 owner;
u64 flags;
char __data[0];
};
struct trace_event_raw_ext4_shutdown {
struct trace_entry ent;
dev_t dev;
unsigned int flags;
char __data[0];
};
struct trace_event_raw_ext4_error {
struct trace_entry ent;
dev_t dev;
const char *function;
unsigned int line;
char __data[0];
};
struct trace_event_raw_ext4_prefetch_bitmaps {
struct trace_entry ent;
dev_t dev;
__u32 group;
__u32 next;
__u32 ios;
char __data[0];
};
struct trace_event_raw_ext4_lazy_itable_init {
struct trace_entry ent;
dev_t dev;
__u32 group;
char __data[0];
};
struct trace_event_raw_ext4_fc_replay_scan {
struct trace_entry ent;
dev_t dev;
int error;
int off;
char __data[0];
};
struct trace_event_raw_ext4_fc_replay {
struct trace_entry ent;
dev_t dev;
int tag;
int ino;
int priv1;
int priv2;
char __data[0];
};
struct trace_event_raw_ext4_fc_commit_start {
struct trace_entry ent;
dev_t dev;
tid_t tid;
char __data[0];
};
struct trace_event_raw_ext4_fc_commit_stop {
struct trace_entry ent;
dev_t dev;
int nblks;
int reason;
int num_fc;
int num_fc_ineligible;
int nblks_agg;
tid_t tid;
char __data[0];
};
struct trace_event_raw_ext4_fc_stats {
struct trace_entry ent;
dev_t dev;
unsigned int fc_ineligible_rc[9];
long unsigned int fc_commits;
long unsigned int fc_ineligible_commits;
long unsigned int fc_numblks;
char __data[0];
};
struct trace_event_raw_ext4_fc_track_dentry {
struct trace_entry ent;
dev_t dev;
tid_t t_tid;
ino_t i_ino;
tid_t i_sync_tid;
int error;
char __data[0];
};
struct trace_event_raw_ext4_fc_track_inode {
struct trace_entry ent;
dev_t dev;
tid_t t_tid;
ino_t i_ino;
tid_t i_sync_tid;
int error;
char __data[0];
};
struct trace_event_raw_ext4_fc_track_range {
struct trace_entry ent;
dev_t dev;
tid_t t_tid;
ino_t i_ino;
tid_t i_sync_tid;
long int start;
long int end;
int error;
char __data[0];
};
struct trace_event_raw_ext4_fc_cleanup {
struct trace_entry ent;
dev_t dev;
int j_fc_off;
int full;
tid_t tid;
char __data[0];
};
struct trace_event_raw_ext4_update_sb {
struct trace_entry ent;
dev_t dev;
long: 32;
ext4_fsblk_t fsblk;
unsigned int flags;
char __data[0];
long: 32;
};
struct trace_event_data_offsets_ext4_other_inode_update_time {};
struct trace_event_data_offsets_ext4_free_inode {};
struct trace_event_data_offsets_ext4_request_inode {};
struct trace_event_data_offsets_ext4_allocate_inode {};
struct trace_event_data_offsets_ext4_evict_inode {};
struct trace_event_data_offsets_ext4_drop_inode {};
struct trace_event_data_offsets_ext4_nfs_commit_metadata {};
struct trace_event_data_offsets_ext4_mark_inode_dirty {};
struct trace_event_data_offsets_ext4_begin_ordered_truncate {};
struct trace_event_data_offsets_ext4__write_begin {};
struct trace_event_data_offsets_ext4__write_end {};
struct trace_event_data_offsets_ext4_writepages {};
struct trace_event_data_offsets_ext4_da_write_pages {};
struct trace_event_data_offsets_ext4_da_write_pages_extent {};
struct trace_event_data_offsets_ext4_writepages_result {};
struct trace_event_data_offsets_ext4__page_op {};
struct trace_event_data_offsets_ext4_invalidate_folio_op {};
struct trace_event_data_offsets_ext4_discard_blocks {};
struct trace_event_data_offsets_ext4__mb_new_pa {};
struct trace_event_data_offsets_ext4_mb_release_inode_pa {};
struct trace_event_data_offsets_ext4_mb_release_group_pa {};
struct trace_event_data_offsets_ext4_discard_preallocations {};
struct trace_event_data_offsets_ext4_mb_discard_preallocations {};
struct trace_event_data_offsets_ext4_request_blocks {};
struct trace_event_data_offsets_ext4_allocate_blocks {};
struct trace_event_data_offsets_ext4_free_blocks {};
struct trace_event_data_offsets_ext4_sync_file_enter {};
struct trace_event_data_offsets_ext4_sync_file_exit {};
struct trace_event_data_offsets_ext4_sync_fs {};
struct trace_event_data_offsets_ext4_alloc_da_blocks {};
struct trace_event_data_offsets_ext4_mballoc_alloc {};
struct trace_event_data_offsets_ext4_mballoc_prealloc {};
struct trace_event_data_offsets_ext4__mballoc {};
struct trace_event_data_offsets_ext4_forget {};
struct trace_event_data_offsets_ext4_da_update_reserve_space {};
struct trace_event_data_offsets_ext4_da_reserve_space {};
struct trace_event_data_offsets_ext4_da_release_space {};
struct trace_event_data_offsets_ext4__bitmap_load {};
struct trace_event_data_offsets_ext4_read_block_bitmap_load {};
struct trace_event_data_offsets_ext4__fallocate_mode {};
struct trace_event_data_offsets_ext4_fallocate_exit {};
struct trace_event_data_offsets_ext4_unlink_enter {};
struct trace_event_data_offsets_ext4_unlink_exit {};
struct trace_event_data_offsets_ext4__truncate {};
struct trace_event_data_offsets_ext4_ext_convert_to_initialized_enter {};
struct trace_event_data_offsets_ext4_ext_convert_to_initialized_fastpath {};
struct trace_event_data_offsets_ext4__map_blocks_enter {};
struct trace_event_data_offsets_ext4__map_blocks_exit {};
struct trace_event_data_offsets_ext4_ext_load_extent {};
struct trace_event_data_offsets_ext4_load_inode {};
struct trace_event_data_offsets_ext4_journal_start {};
struct trace_event_data_offsets_ext4_journal_start_reserved {};
struct trace_event_data_offsets_ext4__trim {};
struct trace_event_data_offsets_ext4_ext_handle_unwritten_extents {};
struct trace_event_data_offsets_ext4_get_implied_cluster_alloc_exit {};
struct trace_event_data_offsets_ext4_ext_show_extent {};
struct trace_event_data_offsets_ext4_remove_blocks {};
struct trace_event_data_offsets_ext4_ext_rm_leaf {};
struct trace_event_data_offsets_ext4_ext_rm_idx {};
struct trace_event_data_offsets_ext4_ext_remove_space {};
struct trace_event_data_offsets_ext4_ext_remove_space_done {};
struct trace_event_data_offsets_ext4__es_extent {};
struct trace_event_data_offsets_ext4_es_remove_extent {};
struct trace_event_data_offsets_ext4_es_find_extent_range_enter {};
struct trace_event_data_offsets_ext4_es_find_extent_range_exit {};
struct trace_event_data_offsets_ext4_es_lookup_extent_enter {};
struct trace_event_data_offsets_ext4_es_lookup_extent_exit {};
struct trace_event_data_offsets_ext4__es_shrink_enter {};
struct trace_event_data_offsets_ext4_es_shrink_scan_exit {};
struct trace_event_data_offsets_ext4_collapse_range {};
struct trace_event_data_offsets_ext4_insert_range {};
struct trace_event_data_offsets_ext4_es_shrink {};
struct trace_event_data_offsets_ext4_es_insert_delayed_block {};
struct trace_event_data_offsets_ext4_fsmap_class {};
struct trace_event_data_offsets_ext4_getfsmap_class {};
struct trace_event_data_offsets_ext4_shutdown {};
struct trace_event_data_offsets_ext4_error {};
struct trace_event_data_offsets_ext4_prefetch_bitmaps {};
struct trace_event_data_offsets_ext4_lazy_itable_init {};
struct trace_event_data_offsets_ext4_fc_replay_scan {};
struct trace_event_data_offsets_ext4_fc_replay {};
struct trace_event_data_offsets_ext4_fc_commit_start {};
struct trace_event_data_offsets_ext4_fc_commit_stop {};
struct trace_event_data_offsets_ext4_fc_stats {};
struct trace_event_data_offsets_ext4_fc_track_dentry {};
struct trace_event_data_offsets_ext4_fc_track_inode {};
struct trace_event_data_offsets_ext4_fc_track_range {};
struct trace_event_data_offsets_ext4_fc_cleanup {};
struct trace_event_data_offsets_ext4_update_sb {};
typedef void (*btf_trace_ext4_other_inode_update_time)(void *, struct inode *, ino_t);
typedef void (*btf_trace_ext4_free_inode)(void *, struct inode *);
typedef void (*btf_trace_ext4_request_inode)(void *, struct inode *, int);
typedef void (*btf_trace_ext4_allocate_inode)(void *, struct inode *, struct inode *, int);
typedef void (*btf_trace_ext4_evict_inode)(void *, struct inode *);
typedef void (*btf_trace_ext4_drop_inode)(void *, struct inode *, int);
typedef void (*btf_trace_ext4_nfs_commit_metadata)(void *, struct inode *);
typedef void (*btf_trace_ext4_mark_inode_dirty)(void *, struct inode *, long unsigned int);
typedef void (*btf_trace_ext4_begin_ordered_truncate)(void *, struct inode *, loff_t);
typedef void (*btf_trace_ext4_write_begin)(void *, struct inode *, loff_t, unsigned int);
typedef void (*btf_trace_ext4_da_write_begin)(void *, struct inode *, loff_t, unsigned int);
typedef void (*btf_trace_ext4_write_end)(void *, struct inode *, loff_t, unsigned int, unsigned int);
typedef void (*btf_trace_ext4_journalled_write_end)(void *, struct inode *, loff_t, unsigned int, unsigned int);
typedef void (*btf_trace_ext4_da_write_end)(void *, struct inode *, loff_t, unsigned int, unsigned int);
typedef void (*btf_trace_ext4_writepages)(void *, struct inode *, struct writeback_control *);
typedef void (*btf_trace_ext4_da_write_pages)(void *, struct inode *, long unsigned int, struct writeback_control *);
typedef void (*btf_trace_ext4_da_write_pages_extent)(void *, struct inode *, struct ext4_map_blocks *);
typedef void (*btf_trace_ext4_writepages_result)(void *, struct inode *, struct writeback_control *, int, int);
typedef void (*btf_trace_ext4_writepage)(void *, struct page *);
typedef void (*btf_trace_ext4_readpage)(void *, struct page *);
typedef void (*btf_trace_ext4_releasepage)(void *, struct page *);
typedef void (*btf_trace_ext4_invalidate_folio)(void *, struct folio *, size_t, size_t);
typedef void (*btf_trace_ext4_journalled_invalidate_folio)(void *, struct folio *, size_t, size_t);
typedef void (*btf_trace_ext4_discard_blocks)(void *, struct super_block *, long long unsigned int, long long unsigned int);
typedef void (*btf_trace_ext4_mb_new_inode_pa)(void *, struct ext4_allocation_context *, struct ext4_prealloc_space *);
typedef void (*btf_trace_ext4_mb_new_group_pa)(void *, struct ext4_allocation_context *, struct ext4_prealloc_space *);
typedef void (*btf_trace_ext4_mb_release_inode_pa)(void *, struct ext4_prealloc_space *, long long unsigned int, unsigned int);
typedef void (*btf_trace_ext4_mb_release_group_pa)(void *, struct super_block *, struct ext4_prealloc_space *);
typedef void (*btf_trace_ext4_discard_preallocations)(void *, struct inode *, unsigned int, unsigned int);
typedef void (*btf_trace_ext4_mb_discard_preallocations)(void *, struct super_block *, int);
typedef void (*btf_trace_ext4_request_blocks)(void *, struct ext4_allocation_request *);
typedef void (*btf_trace_ext4_allocate_blocks)(void *, struct ext4_allocation_request *, long long unsigned int);
typedef void (*btf_trace_ext4_free_blocks)(void *, struct inode *, __u64, long unsigned int, int);
typedef void (*btf_trace_ext4_sync_file_enter)(void *, struct file *, int);
typedef void (*btf_trace_ext4_sync_file_exit)(void *, struct inode *, int);
typedef void (*btf_trace_ext4_sync_fs)(void *, struct super_block *, int);
typedef void (*btf_trace_ext4_alloc_da_blocks)(void *, struct inode *);
typedef void (*btf_trace_ext4_mballoc_alloc)(void *, struct ext4_allocation_context *);
typedef void (*btf_trace_ext4_mballoc_prealloc)(void *, struct ext4_allocation_context *);
typedef void (*btf_trace_ext4_mballoc_discard)(void *, struct super_block *, struct inode *, ext4_group_t, ext4_grpblk_t, ext4_grpblk_t);
typedef void (*btf_trace_ext4_mballoc_free)(void *, struct super_block *, struct inode *, ext4_group_t, ext4_grpblk_t, ext4_grpblk_t);
typedef void (*btf_trace_ext4_forget)(void *, struct inode *, int, __u64);
typedef void (*btf_trace_ext4_da_update_reserve_space)(void *, struct inode *, int, int);
typedef void (*btf_trace_ext4_da_reserve_space)(void *, struct inode *);
typedef void (*btf_trace_ext4_da_release_space)(void *, struct inode *, int);
typedef void (*btf_trace_ext4_mb_bitmap_load)(void *, struct super_block *, long unsigned int);
typedef void (*btf_trace_ext4_mb_buddy_bitmap_load)(void *, struct super_block *, long unsigned int);
typedef void (*btf_trace_ext4_load_inode_bitmap)(void *, struct super_block *, long unsigned int);
typedef void (*btf_trace_ext4_read_block_bitmap_load)(void *, struct super_block *, long unsigned int, bool);
typedef void (*btf_trace_ext4_fallocate_enter)(void *, struct inode *, loff_t, loff_t, int);
typedef void (*btf_trace_ext4_punch_hole)(void *, struct inode *, loff_t, loff_t, int);
typedef void (*btf_trace_ext4_zero_range)(void *, struct inode *, loff_t, loff_t, int);
typedef void (*btf_trace_ext4_fallocate_exit)(void *, struct inode *, loff_t, unsigned int, int);
typedef void (*btf_trace_ext4_unlink_enter)(void *, struct inode *, struct dentry *);
typedef void (*btf_trace_ext4_unlink_exit)(void *, struct dentry *, int);
typedef void (*btf_trace_ext4_truncate_enter)(void *, struct inode *);
typedef void (*btf_trace_ext4_truncate_exit)(void *, struct inode *);
typedef void (*btf_trace_ext4_ext_convert_to_initialized_enter)(void *, struct inode *, struct ext4_map_blocks *, struct ext4_extent *);
typedef void (*btf_trace_ext4_ext_convert_to_initialized_fastpath)(void *, struct inode *, struct ext4_map_blocks *, struct ext4_extent *, struct ext4_extent *);
typedef void (*btf_trace_ext4_ext_map_blocks_enter)(void *, struct inode *, ext4_lblk_t, unsigned int, unsigned int);
typedef void (*btf_trace_ext4_ind_map_blocks_enter)(void *, struct inode *, ext4_lblk_t, unsigned int, unsigned int);
typedef void (*btf_trace_ext4_ext_map_blocks_exit)(void *, struct inode *, unsigned int, struct ext4_map_blocks *, int);
typedef void (*btf_trace_ext4_ind_map_blocks_exit)(void *, struct inode *, unsigned int, struct ext4_map_blocks *, int);
typedef void (*btf_trace_ext4_ext_load_extent)(void *, struct inode *, ext4_lblk_t, ext4_fsblk_t);
typedef void (*btf_trace_ext4_load_inode)(void *, struct super_block *, long unsigned int);
typedef void (*btf_trace_ext4_journal_start)(void *, struct super_block *, int, int, int, long unsigned int);
typedef void (*btf_trace_ext4_journal_start_reserved)(void *, struct super_block *, int, long unsigned int);
typedef void (*btf_trace_ext4_trim_extent)(void *, struct super_block *, ext4_group_t, ext4_grpblk_t, ext4_grpblk_t);
typedef void (*btf_trace_ext4_trim_all_free)(void *, struct super_block *, ext4_group_t, ext4_grpblk_t, ext4_grpblk_t);
typedef void (*btf_trace_ext4_ext_handle_unwritten_extents)(void *, struct inode *, struct ext4_map_blocks *, int, unsigned int, ext4_fsblk_t);
typedef void (*btf_trace_ext4_get_implied_cluster_alloc_exit)(void *, struct super_block *, struct ext4_map_blocks *, int);
typedef void (*btf_trace_ext4_ext_show_extent)(void *, struct inode *, ext4_lblk_t, ext4_fsblk_t, short unsigned int);
typedef void (*btf_trace_ext4_remove_blocks)(void *, struct inode *, struct ext4_extent *, ext4_lblk_t, ext4_fsblk_t, struct partial_cluster *);
typedef void (*btf_trace_ext4_ext_rm_leaf)(void *, struct inode *, ext4_lblk_t, struct ext4_extent *, struct partial_cluster *);
typedef void (*btf_trace_ext4_ext_rm_idx)(void *, struct inode *, ext4_fsblk_t);
typedef void (*btf_trace_ext4_ext_remove_space)(void *, struct inode *, ext4_lblk_t, ext4_lblk_t, int);
typedef void (*btf_trace_ext4_ext_remove_space_done)(void *, struct inode *, ext4_lblk_t, ext4_lblk_t, int, struct partial_cluster *, __le16);
typedef void (*btf_trace_ext4_es_insert_extent)(void *, struct inode *, struct extent_status *);
typedef void (*btf_trace_ext4_es_cache_extent)(void *, struct inode *, struct extent_status *);
typedef void (*btf_trace_ext4_es_remove_extent)(void *, struct inode *, ext4_lblk_t, ext4_lblk_t);
typedef void (*btf_trace_ext4_es_find_extent_range_enter)(void *, struct inode *, ext4_lblk_t);
typedef void (*btf_trace_ext4_es_find_extent_range_exit)(void *, struct inode *, struct extent_status *);
typedef void (*btf_trace_ext4_es_lookup_extent_enter)(void *, struct inode *, ext4_lblk_t);
typedef void (*btf_trace_ext4_es_lookup_extent_exit)(void *, struct inode *, struct extent_status *, int);
typedef void (*btf_trace_ext4_es_shrink_count)(void *, struct super_block *, int, int);
typedef void (*btf_trace_ext4_es_shrink_scan_enter)(void *, struct super_block *, int, int);
typedef void (*btf_trace_ext4_es_shrink_scan_exit)(void *, struct super_block *, int, int);
typedef void (*btf_trace_ext4_collapse_range)(void *, struct inode *, loff_t, loff_t);
typedef void (*btf_trace_ext4_insert_range)(void *, struct inode *, loff_t, loff_t);
typedef void (*btf_trace_ext4_es_shrink)(void *, struct super_block *, int, u64, int, int);
typedef void (*btf_trace_ext4_es_insert_delayed_block)(void *, struct inode *, struct extent_status *, bool);
typedef void (*btf_trace_ext4_fsmap_low_key)(void *, struct super_block *, u32, u32, u64, u64, u64);
typedef void (*btf_trace_ext4_fsmap_high_key)(void *, struct super_block *, u32, u32, u64, u64, u64);
typedef void (*btf_trace_ext4_fsmap_mapping)(void *, struct super_block *, u32, u32, u64, u64, u64);
typedef void (*btf_trace_ext4_getfsmap_low_key)(void *, struct super_block *, struct ext4_fsmap *);
typedef void (*btf_trace_ext4_getfsmap_high_key)(void *, struct super_block *, struct ext4_fsmap *);
typedef void (*btf_trace_ext4_getfsmap_mapping)(void *, struct super_block *, struct ext4_fsmap *);
typedef void (*btf_trace_ext4_shutdown)(void *, struct super_block *, long unsigned int);
typedef void (*btf_trace_ext4_error)(void *, struct super_block *, const char *, unsigned int);
typedef void (*btf_trace_ext4_prefetch_bitmaps)(void *, struct super_block *, ext4_group_t, ext4_group_t, unsigned int);
typedef void (*btf_trace_ext4_lazy_itable_init)(void *, struct super_block *, ext4_group_t);
typedef void (*btf_trace_ext4_fc_replay_scan)(void *, struct super_block *, int, int);
typedef void (*btf_trace_ext4_fc_replay)(void *, struct super_block *, int, int, int, int);
typedef void (*btf_trace_ext4_fc_commit_start)(void *, struct super_block *, tid_t);
typedef void (*btf_trace_ext4_fc_commit_stop)(void *, struct super_block *, int, int, tid_t);
typedef void (*btf_trace_ext4_fc_stats)(void *, struct super_block *);
typedef void (*btf_trace_ext4_fc_track_create)(void *, handle_t *, struct inode *, struct dentry *, int);
typedef void (*btf_trace_ext4_fc_track_link)(void *, handle_t *, struct inode *, struct dentry *, int);
typedef void (*btf_trace_ext4_fc_track_unlink)(void *, handle_t *, struct inode *, struct dentry *, int);
typedef void (*btf_trace_ext4_fc_track_inode)(void *, handle_t *, struct inode *, int);
typedef void (*btf_trace_ext4_fc_track_range)(void *, handle_t *, struct inode *, long int, long int, int);
typedef void (*btf_trace_ext4_fc_cleanup)(void *, journal_t *, int, tid_t);
typedef void (*btf_trace_ext4_update_sb)(void *, struct super_block *, ext4_fsblk_t, unsigned int);
struct ext4_err_translation {
int code;
int errno;
};
enum {
Opt_bsd_df = 0,
Opt_minix_df = 1,
Opt_grpid = 2,
Opt_nogrpid = 3,
Opt_resgid = 4,
Opt_resuid = 5,
Opt_sb = 6,
Opt_nouid32 = 7,
Opt_debug = 8,
Opt_removed = 9,
Opt_user_xattr = 10,
Opt_acl = 11,
Opt_auto_da_alloc = 12,
Opt_noauto_da_alloc = 13,
Opt_noload = 14,
Opt_commit = 15,
Opt_min_batch_time = 16,
Opt_max_batch_time = 17,
Opt_journal_dev = 18,
Opt_journal_path = 19,
Opt_journal_checksum = 20,
Opt_journal_async_commit = 21,
Opt_abort = 22,
Opt_data_journal = 23,
Opt_data_ordered = 24,
Opt_data_writeback = 25,
Opt_data_err_abort = 26,
Opt_data_err_ignore = 27,
Opt_test_dummy_encryption = 28,
Opt_inlinecrypt = 29,
Opt_usrjquota = 30,
Opt_grpjquota = 31,
Opt_quota = 32,
Opt_noquota = 33,
Opt_barrier = 34,
Opt_nobarrier = 35,
Opt_err = 36,
Opt_usrquota = 37,
Opt_grpquota = 38,
Opt_prjquota = 39,
Opt_dax = 40,
Opt_dax_always = 41,
Opt_dax_inode = 42,
Opt_dax_never = 43,
Opt_stripe = 44,
Opt_delalloc = 45,
Opt_nodelalloc = 46,
Opt_warn_on_error = 47,
Opt_nowarn_on_error = 48,
Opt_mblk_io_submit = 49,
Opt_debug_want_extra_isize = 50,
Opt_nomblk_io_submit = 51,
Opt_block_validity = 52,
Opt_noblock_validity = 53,
Opt_inode_readahead_blks = 54,
Opt_journal_ioprio = 55,
Opt_dioread_nolock = 56,
Opt_dioread_lock = 57,
Opt_discard = 58,
Opt_nodiscard = 59,
Opt_init_itable = 60,
Opt_noinit_itable = 61,
Opt_max_dir_size_kb = 62,
Opt_nojournal_checksum = 63,
Opt_nombcache = 64,
Opt_no_prefetch_block_bitmaps = 65,
Opt_mb_optimize_scan = 66,
Opt_errors = 67,
Opt_data = 68,
Opt_data_err = 69,
Opt_jqfmt = 70,
Opt_dax_type = 71,
};
struct mount_opts {
int token;
int mount_opt;
int flags;
};
struct ext4_fs_context {
char *s_qf_names[3];
struct fscrypt_dummy_policy dummy_enc_policy;
int s_jquota_fmt;
short unsigned int qname_spec;
long unsigned int vals_s_flags;
long unsigned int mask_s_flags;
long unsigned int journal_devnum;
long unsigned int s_commit_interval;
long unsigned int s_stripe;
unsigned int s_inode_readahead_blks;
unsigned int s_want_extra_isize;
unsigned int s_li_wait_mult;
unsigned int s_max_dir_size_kb;
unsigned int journal_ioprio;
unsigned int vals_s_mount_opt;
unsigned int mask_s_mount_opt;
unsigned int vals_s_mount_opt2;
unsigned int mask_s_mount_opt2;
long unsigned int vals_s_mount_flags;
long unsigned int mask_s_mount_flags;
unsigned int opt_flags;
unsigned int spec;
u32 s_max_batch_time;
u32 s_min_batch_time;
kuid_t s_resuid;
kgid_t s_resgid;
long: 32;
ext4_fsblk_t s_sb_block;
};
struct ext4_mount_options {
long unsigned int s_mount_opt;
long unsigned int s_mount_opt2;
kuid_t s_resuid;
kgid_t s_resgid;
long unsigned int s_commit_interval;
u32 s_min_batch_time;
u32 s_max_batch_time;
int s_jquota_fmt;
char *s_qf_names[3];
};
enum pci_dev_flags {
PCI_DEV_FLAGS_MSI_INTX_DISABLE_BUG = 1,
PCI_DEV_FLAGS_NO_D3 = 2,
PCI_DEV_FLAGS_ASSIGNED = 4,
PCI_DEV_FLAGS_ACS_ENABLED_QUIRK = 8,
PCI_DEV_FLAG_PCIE_BRIDGE_ALIAS = 32,
PCI_DEV_FLAGS_NO_BUS_RESET = 64,
PCI_DEV_FLAGS_NO_PM_RESET = 128,
PCI_DEV_FLAGS_VPD_REF_F0 = 256,
PCI_DEV_FLAGS_BRIDGE_XLATE_ROOT = 512,
PCI_DEV_FLAGS_NO_FLR_RESET = 1024,
PCI_DEV_FLAGS_NO_RELAXED_ORDERING = 2048,
PCI_DEV_FLAGS_HAS_MSI_MASKING = 4096,
};
enum {
KERNEL_PARAM_FL_UNSAFE = 1,
KERNEL_PARAM_FL_HWPARAM = 2,
};
struct fb_con2fbmap {
__u32 console;
__u32 framebuffer;
};
enum {
FB_BLANK_UNBLANK = 0,
FB_BLANK_NORMAL = 1,
FB_BLANK_VSYNC_SUSPEND = 2,
FB_BLANK_HSYNC_SUSPEND = 3,
FB_BLANK_POWERDOWN = 4,
};
struct font_desc {
int idx;
const char *name;
unsigned int width;
unsigned int height;
unsigned int charcount;
const void *data;
int pref;
};
enum {
FBCON_LOGO_CANSHOW = -1,
FBCON_LOGO_DRAW = -2,
FBCON_LOGO_DONTSHOW = -3,
};
struct serial_icounter_struct {
int cts;
int dsr;
int rng;
int dcd;
int rx;
int tx;
int frame;
int overrun;
int parity;
int brk;
int buf_overrun;
int reserved[9];
};
struct serial_struct {
int type;
int line;
unsigned int port;
int irq;
int flags;
int xmit_fifo_size;
int custom_divisor;
int baud_base;
short unsigned int close_delay;
char io_type;
char reserved_char[1];
int hub6;
short unsigned int closing_wait;
short unsigned int closing_wait2;
unsigned char *iomem_base;
short unsigned int iomem_reg_shift;
unsigned int port_high;
long unsigned int iomap_base;
};
struct serial_rs485 {
__u32 flags;
__u32 delay_rts_before_send;
__u32 delay_rts_after_send;
union {
__u32 padding[5];
struct {
__u8 addr_recv;
__u8 addr_dest;
__u8 padding0[2];
__u32 padding1[4];
};
};
};
struct serial_iso7816 {
__u32 flags;
__u32 tg;
__u32 sc_fi;
__u32 sc_di;
__u32 clk;
__u32 reserved[5];
};
struct circ_buf {
char *buf;
int head;
int tail;
};
struct uart_port;
struct uart_ops {
unsigned int (*tx_empty)(struct uart_port *);
void (*set_mctrl)(struct uart_port *, unsigned int);
unsigned int (*get_mctrl)(struct uart_port *);
void (*stop_tx)(struct uart_port *);
void (*start_tx)(struct uart_port *);
void (*throttle)(struct uart_port *);
void (*unthrottle)(struct uart_port *);
void (*send_xchar)(struct uart_port *, char);
void (*stop_rx)(struct uart_port *);
void (*start_rx)(struct uart_port *);
void (*enable_ms)(struct uart_port *);
void (*break_ctl)(struct uart_port *, int);
int (*startup)(struct uart_port *);
void (*shutdown)(struct uart_port *);
void (*flush_buffer)(struct uart_port *);
void (*set_termios)(struct uart_port *, struct ktermios *, const struct ktermios *);
void (*set_ldisc)(struct uart_port *, struct ktermios *);
void (*pm)(struct uart_port *, unsigned int, unsigned int);
const char * (*type)(struct uart_port *);
void (*release_port)(struct uart_port *);
int (*request_port)(struct uart_port *);
void (*config_port)(struct uart_port *, int);
int (*verify_port)(struct uart_port *, struct serial_struct *);
int (*ioctl)(struct uart_port *, unsigned int, long unsigned int);
};
struct uart_icount {
__u32 cts;
__u32 dsr;
__u32 rng;
__u32 dcd;
__u32 rx;
__u32 tx;
__u32 frame;
__u32 overrun;
__u32 parity;
__u32 brk;
__u32 buf_overrun;
};
typedef u64 upf_t;
typedef unsigned int upstat_t;
struct uart_state;
struct uart_port {
spinlock_t lock;
long unsigned int iobase;
unsigned char *membase;
unsigned int (*serial_in)(struct uart_port *, int);
void (*serial_out)(struct uart_port *, int, int);
void (*set_termios)(struct uart_port *, struct ktermios *, const struct ktermios *);
void (*set_ldisc)(struct uart_port *, struct ktermios *);
unsigned int (*get_mctrl)(struct uart_port *);
void (*set_mctrl)(struct uart_port *, unsigned int);
unsigned int (*get_divisor)(struct uart_port *, unsigned int, unsigned int *);
void (*set_divisor)(struct uart_port *, unsigned int, unsigned int, unsigned int);
int (*startup)(struct uart_port *);
void (*shutdown)(struct uart_port *);
void (*throttle)(struct uart_port *);
void (*unthrottle)(struct uart_port *);
int (*handle_irq)(struct uart_port *);
void (*pm)(struct uart_port *, unsigned int, unsigned int);
void (*handle_break)(struct uart_port *);
int (*rs485_config)(struct uart_port *, struct ktermios *, struct serial_rs485 *);
int (*iso7816_config)(struct uart_port *, struct serial_iso7816 *);
unsigned int irq;
long unsigned int irqflags;
unsigned int uartclk;
unsigned int fifosize;
unsigned char x_char;
unsigned char regshift;
unsigned char iotype;
unsigned char quirks;
unsigned int read_status_mask;
unsigned int ignore_status_mask;
struct uart_state *state;
struct uart_icount icount;
struct console *cons;
upf_t flags;
upstat_t status;
int hw_stopped;
unsigned int mctrl;
unsigned int frame_time;
unsigned int type;
const struct uart_ops *ops;
unsigned int custom_divisor;
unsigned int line;
unsigned int minor;
resource_size_t mapbase;
resource_size_t mapsize;
struct device *dev;
long unsigned int sysrq;
unsigned int sysrq_ch;
unsigned char has_sysrq;
unsigned char sysrq_seq;
unsigned char hub6;
unsigned char suspended;
unsigned char console_reinit;
const char *name;
struct attribute_group *attr_group;
const struct attribute_group **tty_groups;
struct serial_rs485 rs485;
struct serial_rs485 rs485_supported;
struct gpio_desc *rs485_term_gpio;
struct serial_iso7816 iso7816;
void *private_data;
long: 32;
};
enum uart_pm_state {
UART_PM_STATE_ON = 0,
UART_PM_STATE_OFF = 3,
UART_PM_STATE_UNDEFINED = 4,
};
struct uart_state {
struct tty_port port;
enum uart_pm_state pm_state;
struct circ_buf xmit;
atomic_t refcount;
wait_queue_head_t remove_wait;
struct uart_port *uart_port;
};
struct uart_driver {
struct module *owner;
const char *driver_name;
const char *dev_name;
int major;
int minor;
int nr;
struct console *cons;
struct uart_state *state;
struct tty_driver *tty_driver;
};
struct uart_match {
struct uart_port *port;
struct uart_driver *driver;
};
enum cache_type {
CACHE_TYPE_NOCACHE = 0,
CACHE_TYPE_INST = 1,
CACHE_TYPE_DATA = 2,
CACHE_TYPE_SEPARATE = 3,
CACHE_TYPE_UNIFIED = 4,
};
struct cacheinfo {
unsigned int id;
enum cache_type type;
unsigned int level;
unsigned int coherency_line_size;
unsigned int number_of_sets;
unsigned int ways_of_associativity;
unsigned int physical_line_partition;
unsigned int size;
cpumask_t shared_cpu_map;
unsigned int attributes;
void *fw_token;
bool disable_sysfs;
void *priv;
};
struct cpu_cacheinfo {
struct cacheinfo *info_list;
unsigned int num_levels;
unsigned int num_leaves;
bool cpu_map_populated;
};
struct cache_type_info {
const char *size_prop;
const char *line_size_props[2];
const char *nr_sets_prop;
};
struct netlink_kernel_cfg {
unsigned int groups;
unsigned int flags;
void (*input)(struct sk_buff *);
struct mutex *cb_mutex;
int (*bind)(struct net *, int);
void (*unbind)(struct net *, int);
bool (*compare)(struct net *, struct sock *);
};
struct scsi_nl_hdr {
__u8 version;
__u8 transport;
__u16 magic;
__u16 msgtype;
__u16 msglen;
};
struct fixed_phy_status {
int link;
int speed;
int duplex;
int pause;
int asym_pause;
};
struct swmii_regs {
u16 bmsr;
u16 lpa;
u16 lpagb;
u16 estat;
};
enum {
SWMII_SPEED_10 = 0,
SWMII_SPEED_100 = 1,
SWMII_SPEED_1000 = 2,
SWMII_DUPLEX_HALF = 0,
SWMII_DUPLEX_FULL = 1,
};
struct serio_device_id {
__u8 type;
__u8 extra;
__u8 id;
__u8 proto;
};
struct serio_driver;
struct serio {
void *port_data;
char name[32];
char phys[32];
char firmware_id[128];
bool manual_bind;
struct serio_device_id id;
spinlock_t lock;
int (*write)(struct serio *, unsigned char);
int (*open)(struct serio *);
void (*close)(struct serio *);
int (*start)(struct serio *);
void (*stop)(struct serio *);
struct serio *parent;
struct list_head child_node;
struct list_head children;
unsigned int depth;
struct serio_driver *drv;
struct mutex drv_mutex;
struct device dev;
struct list_head node;
struct mutex *ps2_cmd_mutex;
long: 32;
};
struct serio_driver {
const char *description;
const struct serio_device_id *id_table;
bool manual_bind;
void (*write_wakeup)(struct serio *);
irqreturn_t (*interrupt)(struct serio *, unsigned char, unsigned int);
int (*connect)(struct serio *, struct serio_driver *);
int (*reconnect)(struct serio *);
int (*fast_reconnect)(struct serio *);
void (*disconnect)(struct serio *);
void (*cleanup)(struct serio *);
struct device_driver driver;
};
enum serio_event_type {
SERIO_RESCAN_PORT = 0,
SERIO_RECONNECT_PORT = 1,
SERIO_RECONNECT_SUBTREE = 2,
SERIO_REGISTER_PORT = 3,
SERIO_ATTACH_DRIVER = 4,
};
struct serio_event {
enum serio_event_type type;
void *object;
struct module *owner;
struct list_head node;
};
struct mousedev_hw_data {
int dx;
int dy;
int dz;
int x;
int y;
int abs_event;
long unsigned int buttons;
};
struct mousedev {
int open;
struct input_handle handle;
wait_queue_head_t wait;
struct list_head client_list;
spinlock_t client_lock;
struct mutex mutex;
struct device dev;
struct cdev cdev;
bool exist;
struct list_head mixdev_node;
bool opened_by_mixdev;
struct mousedev_hw_data packet;
unsigned int pkt_count;
int old_x[4];
int old_y[4];
int frac_dx;
int frac_dy;
long unsigned int touch;
int (*open_device)(struct mousedev *);
void (*close_device)(struct mousedev *);
};
enum mousedev_emul {
MOUSEDEV_EMUL_PS2 = 0,
MOUSEDEV_EMUL_IMPS = 1,
MOUSEDEV_EMUL_EXPS = 2,
};
struct mousedev_motion {
int dx;
int dy;
int dz;
long unsigned int buttons;
};
struct mousedev_client {
struct fasync_struct *fasync;
struct mousedev *mousedev;
struct list_head node;
struct mousedev_motion packets[16];
unsigned int head;
unsigned int tail;
spinlock_t packet_lock;
int pos_x;
int pos_y;
u8 ps2[6];
unsigned char ready;
unsigned char buffer;
unsigned char bufsiz;
unsigned char imexseq;
unsigned char impsseq;
enum mousedev_emul mode;
long unsigned int last_buttons;
};
enum {
FRACTION_DENOM = 128,
};
struct pps_event_time {
struct timespec64 ts_real;
};
enum {
BPF_F_RECOMPUTE_CSUM = 1,
BPF_F_INVALIDATE_HASH = 2,
};
enum {
BPF_F_HDR_FIELD_MASK = 15,
};
enum {
BPF_F_PSEUDO_HDR = 16,
BPF_F_MARK_MANGLED_0 = 32,
BPF_F_MARK_ENFORCE = 64,
};
enum {
BPF_F_INGRESS = 1,
};
enum {
BPF_F_TUNINFO_IPV6 = 1,
};
enum {
BPF_F_ZERO_CSUM_TX = 2,
BPF_F_DONT_FRAGMENT = 4,
BPF_F_SEQ_NUMBER = 8,
};
enum {
BPF_F_TUNINFO_FLAGS = 16,
};
enum {
BPF_F_INDEX_MASK = 4294967295ULL,
BPF_F_CURRENT_CPU = 4294967295ULL,
BPF_F_CTXLEN_MASK = 4503595332403200ULL,
};
enum {
BPF_CSUM_LEVEL_QUERY = 0,
BPF_CSUM_LEVEL_INC = 1,
BPF_CSUM_LEVEL_DEC = 2,
BPF_CSUM_LEVEL_RESET = 3,
};
enum {
BPF_F_ADJ_ROOM_FIXED_GSO = 1,
BPF_F_ADJ_ROOM_ENCAP_L3_IPV4 = 2,
BPF_F_ADJ_ROOM_ENCAP_L3_IPV6 = 4,
BPF_F_ADJ_ROOM_ENCAP_L4_GRE = 8,
BPF_F_ADJ_ROOM_ENCAP_L4_UDP = 16,
BPF_F_ADJ_ROOM_NO_CSUM_RESET = 32,
BPF_F_ADJ_ROOM_ENCAP_L2_ETH = 64,
};
enum {
BPF_ADJ_ROOM_ENCAP_L2_MASK = 255,
BPF_ADJ_ROOM_ENCAP_L2_SHIFT = 56,
};
enum {
BPF_SK_LOOKUP_F_REPLACE = 1,
BPF_SK_LOOKUP_F_NO_REUSEPORT = 2,
};
enum bpf_adj_room_mode {
BPF_ADJ_ROOM_NET = 0,
BPF_ADJ_ROOM_MAC = 1,
};
enum bpf_hdr_start_off {
BPF_HDR_START_MAC = 0,
BPF_HDR_START_NET = 1,
};
enum {
BPF_F_BROADCAST = 8,
BPF_F_EXCLUDE_INGRESS = 16,
};
enum {
BPF_SKB_TSTAMP_UNSPEC = 0,
BPF_SKB_TSTAMP_DELIVERY_MONO = 1,
};
struct bpf_tunnel_key {
__u32 tunnel_id;
union {
__u32 remote_ipv4;
__u32 remote_ipv6[4];
};
__u8 tunnel_tos;
__u8 tunnel_ttl;
union {
__u16 tunnel_ext;
__be16 tunnel_flags;
};
__u32 tunnel_label;
union {
__u32 local_ipv4;
__u32 local_ipv6[4];
};
};
struct bpf_xfrm_state {
__u32 reqid;
__u32 spi;
__u16 family;
__u16 ext;
union {
__u32 remote_ipv4;
__u32 remote_ipv6[4];
};
};
struct bpf_tcp_sock {
__u32 snd_cwnd;
__u32 srtt_us;
__u32 rtt_min;
__u32 snd_ssthresh;
__u32 rcv_nxt;
__u32 snd_nxt;
__u32 snd_una;
__u32 mss_cache;
__u32 ecn_flags;
__u32 rate_delivered;
__u32 rate_interval_us;
__u32 packets_out;
__u32 retrans_out;
__u32 total_retrans;
__u32 segs_in;
__u32 data_segs_in;
__u32 segs_out;
__u32 data_segs_out;
__u32 lost_out;
__u32 sacked_out;
__u64 bytes_received;
__u64 bytes_acked;
__u32 dsack_dups;
__u32 delivered;
__u32 delivered_ce;
__u32 icsk_retransmits;
};
struct bpf_sock_tuple {
union {
struct {
__be32 saddr;
__be32 daddr;
__be16 sport;
__be16 dport;
} ipv4;
struct {
__be32 saddr[4];
__be32 daddr[4];
__be16 sport;
__be16 dport;
} ipv6;
};
};
struct bpf_xdp_sock {
__u32 queue_id;
};
enum sk_action {
SK_DROP = 0,
SK_PASS = 1,
};
struct bpf_sock_addr {
__u32 user_family;
__u32 user_ip4;
__u32 user_ip6[4];
__u32 user_port;
__u32 family;
__u32 type;
__u32 protocol;
__u32 msg_src_ip4;
__u32 msg_src_ip6[4];
long: 32;
union {
struct bpf_sock *sk;
};
};
enum {
BPF_SOCK_OPS_RTO_CB_FLAG = 1,
BPF_SOCK_OPS_RETRANS_CB_FLAG = 2,
BPF_SOCK_OPS_STATE_CB_FLAG = 4,
BPF_SOCK_OPS_RTT_CB_FLAG = 8,
BPF_SOCK_OPS_PARSE_ALL_HDR_OPT_CB_FLAG = 16,
BPF_SOCK_OPS_PARSE_UNKNOWN_HDR_OPT_CB_FLAG = 32,
BPF_SOCK_OPS_WRITE_HDR_OPT_CB_FLAG = 64,
BPF_SOCK_OPS_ALL_CB_FLAGS = 127,
};
enum {
BPF_SOCK_OPS_VOID = 0,
BPF_SOCK_OPS_TIMEOUT_INIT = 1,
BPF_SOCK_OPS_RWND_INIT = 2,
BPF_SOCK_OPS_TCP_CONNECT_CB = 3,
BPF_SOCK_OPS_ACTIVE_ESTABLISHED_CB = 4,
BPF_SOCK_OPS_PASSIVE_ESTABLISHED_CB = 5,
BPF_SOCK_OPS_NEEDS_ECN = 6,
BPF_SOCK_OPS_BASE_RTT = 7,
BPF_SOCK_OPS_RTO_CB = 8,
BPF_SOCK_OPS_RETRANS_CB = 9,
BPF_SOCK_OPS_STATE_CB = 10,
BPF_SOCK_OPS_TCP_LISTEN_CB = 11,
BPF_SOCK_OPS_RTT_CB = 12,
BPF_SOCK_OPS_PARSE_HDR_OPT_CB = 13,
BPF_SOCK_OPS_HDR_OPT_LEN_CB = 14,
BPF_SOCK_OPS_WRITE_HDR_OPT_CB = 15,
};
enum {
TCP_BPF_IW = 1001,
TCP_BPF_SNDCWND_CLAMP = 1002,
TCP_BPF_DELACK_MAX = 1003,
TCP_BPF_RTO_MIN = 1004,
TCP_BPF_SYN = 1005,
TCP_BPF_SYN_IP = 1006,
TCP_BPF_SYN_MAC = 1007,
};
enum {
BPF_LOAD_HDR_OPT_TCP_SYN = 1,
};
enum {
BPF_FIB_LOOKUP_DIRECT = 1,
BPF_FIB_LOOKUP_OUTPUT = 2,
};
enum {
BPF_FIB_LKUP_RET_SUCCESS = 0,
BPF_FIB_LKUP_RET_BLACKHOLE = 1,
BPF_FIB_LKUP_RET_UNREACHABLE = 2,
BPF_FIB_LKUP_RET_PROHIBIT = 3,
BPF_FIB_LKUP_RET_NOT_FWDED = 4,
BPF_FIB_LKUP_RET_FWD_DISABLED = 5,
BPF_FIB_LKUP_RET_UNSUPP_LWT = 6,
BPF_FIB_LKUP_RET_NO_NEIGH = 7,
BPF_FIB_LKUP_RET_FRAG_NEEDED = 8,
};
struct bpf_fib_lookup {
__u8 family;
__u8 l4_protocol;
__be16 sport;
__be16 dport;
union {
__u16 tot_len;
__u16 mtu_result;
};
__u32 ifindex;
union {
__u8 tos;
__be32 flowinfo;
__u32 rt_metric;
};
union {
__be32 ipv4_src;
__u32 ipv6_src[4];
};
union {
__be32 ipv4_dst;
__u32 ipv6_dst[4];
};
__be16 h_vlan_proto;
__be16 h_vlan_TCI;
__u8 smac[6];
__u8 dmac[6];
};
struct bpf_redir_neigh {
__u32 nh_family;
union {
__be32 ipv4_nh;
__u32 ipv6_nh[4];
};
};
enum bpf_check_mtu_flags {
BPF_MTU_CHK_SEGS = 1,
};
enum bpf_check_mtu_ret {
BPF_MTU_CHK_RET_SUCCESS = 0,
BPF_MTU_CHK_RET_FRAG_NEEDED = 1,
BPF_MTU_CHK_RET_SEGS_TOOBIG = 2,
};
struct bpf_dispatcher_prog {
struct bpf_prog *prog;
refcount_t users;
};
struct bpf_dispatcher {
struct mutex mutex;
void *func;
struct bpf_dispatcher_prog progs[48];
int num_progs;
void *image;
void *rw_image;
u32 image_off;
struct bpf_ksym ksym;
};
struct seg6_pernet_data {
struct mutex lock;
struct in6_addr *tun_src;
};
struct sd_flow_limit;
struct softnet_data {
struct list_head poll_list;
struct sk_buff_head process_queue;
unsigned int processed;
unsigned int time_squeeze;
unsigned int received_rps;
struct softnet_data *rps_ipi_list;
struct sd_flow_limit *flow_limit;
struct Qdisc *output_queue;
struct Qdisc **output_queue_tailp;
struct sk_buff *completion_queue;
struct {
u16 recursion;
u8 more;
u8 skip_txqueue;
} xmit;
long: 32;
unsigned int input_queue_head;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
call_single_data_t csd;
struct softnet_data *rps_ipi_next;
unsigned int cpu;
unsigned int input_queue_tail;
unsigned int dropped;
struct sk_buff_head input_pkt_queue;
struct napi_struct backlog;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
spinlock_t defer_lock;
int defer_count;
int defer_ipi_scheduled;
struct sk_buff *defer_list;
call_single_data_t defer_csd;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct compat_sock_fprog {
u16 len;
compat_uptr_t filter;
};
struct bpf_skb_data_end {
struct qdisc_skb_cb qdisc_cb;
void *data_meta;
void *data_end;
};
struct bpf_sock_addr_kern {
struct sock *sk;
struct sockaddr *uaddr;
u64 tmp_reg;
void *t_ctx;
long: 32;
};
struct tcp_timewait_sock {
struct inet_timewait_sock tw_sk;
u32 tw_rcv_wnd;
u32 tw_ts_offset;
u32 tw_ts_recent;
u32 tw_last_oow_ack_time;
int tw_ts_recent_stamp;
u32 tw_tx_delay;
struct tcp_md5sig_key *tw_md5_key;
long: 32;
};
struct udp6_sock {
struct udp_sock udp;
struct ipv6_pinfo inet6;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct tcp6_sock {
struct tcp_sock tcp;
struct ipv6_pinfo inet6;
long: 32;
};
struct ipv6_bpf_stub {
int (*inet6_bind)(struct sock *, struct sockaddr *, int, u32);
struct sock * (*udp6_lib_lookup)(struct net *, const struct in6_addr *, __be16, const struct in6_addr *, __be16, int, int, struct udp_table *, struct sk_buff *);
int (*ipv6_setsockopt)(struct sock *, int, int, sockptr_t, unsigned int);
int (*ipv6_getsockopt)(struct sock *, int, int, sockptr_t, sockptr_t);
};
struct mptcp_sock {};
struct strp_msg {
int full_len;
int offset;
};
struct _strp_msg {
struct strp_msg strp;
int accum_len;
};
struct tls_msg {
u8 control;
};
struct sk_skb_cb {
unsigned char data[20];
unsigned char pad[4];
struct _strp_msg strp;
struct tls_msg tls;
u64 temp_reg;
};
struct xdp_sock {
struct sock sk;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct xsk_queue *rx;
struct net_device *dev;
struct xdp_umem *umem;
struct list_head flush_node;
struct xsk_buff_pool *pool;
u16 queue_id;
bool zc;
enum {
XSK_READY = 0,
XSK_BOUND = 1,
XSK_UNBOUND = 2,
} state;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct xsk_queue *tx;
struct list_head tx_list;
spinlock_t rx_lock;
u64 rx_dropped;
u64 rx_queue_full;
struct list_head map_list;
spinlock_t map_list_lock;
struct mutex mutex;
struct xsk_queue *fq_tmp;
struct xsk_queue *cq_tmp;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct tls_crypto_info {
__u16 version;
__u16 cipher_type;
};
struct tls12_crypto_info_aes_gcm_128 {
struct tls_crypto_info info;
unsigned char iv[8];
unsigned char key[16];
unsigned char salt[4];
unsigned char rec_seq[8];
};
struct tls12_crypto_info_aes_gcm_256 {
struct tls_crypto_info info;
unsigned char iv[8];
unsigned char key[32];
unsigned char salt[4];
unsigned char rec_seq[8];
};
struct tls12_crypto_info_chacha20_poly1305 {
struct tls_crypto_info info;
unsigned char iv[12];
unsigned char key[32];
unsigned char salt[0];
unsigned char rec_seq[8];
};
struct tls12_crypto_info_sm4_gcm {
struct tls_crypto_info info;
unsigned char iv[8];
unsigned char key[16];
unsigned char salt[4];
unsigned char rec_seq[8];
};
struct tls12_crypto_info_sm4_ccm {
struct tls_crypto_info info;
unsigned char iv[8];
unsigned char key[16];
unsigned char salt[4];
unsigned char rec_seq[8];
};
struct tls_strparser {
struct sock *sk;
u32 mark: 8;
u32 stopped: 1;
u32 copy_mode: 1;
u32 msg_ready: 1;
struct strp_msg stm;
struct sk_buff *anchor;
struct work_struct work;
};
struct tls_sw_context_rx {
struct crypto_aead *aead_recv;
struct crypto_wait async_wait;
struct sk_buff_head rx_list;
void (*saved_data_ready)(struct sock *);
u8 reader_present;
u8 async_capable: 1;
u8 zc_capable: 1;
u8 reader_contended: 1;
struct tls_strparser strp;
atomic_t decrypt_pending;
spinlock_t decrypt_compl_lock;
struct sk_buff_head async_hold;
struct wait_queue_head wq;
};
struct tls_prot_info {
u16 version;
u16 cipher_type;
u16 prepend_size;
u16 tag_size;
u16 overhead_size;
u16 iv_size;
u16 salt_size;
u16 rec_seq_size;
u16 aad_size;
u16 tail_size;
};
struct cipher_context {
char *iv;
char *rec_seq;
};
union tls_crypto_context {
struct tls_crypto_info info;
union {
struct tls12_crypto_info_aes_gcm_128 aes_gcm_128;
struct tls12_crypto_info_aes_gcm_256 aes_gcm_256;
struct tls12_crypto_info_chacha20_poly1305 chacha20_poly1305;
struct tls12_crypto_info_sm4_gcm sm4_gcm;
struct tls12_crypto_info_sm4_ccm sm4_ccm;
};
};
struct tls_context {
struct tls_prot_info prot_info;
u8 tx_conf: 3;
u8 rx_conf: 3;
u8 zerocopy_sendfile: 1;
u8 rx_no_pad: 1;
int (*push_pending_record)(struct sock *, int);
void (*sk_write_space)(struct sock *);
void *priv_ctx_tx;
void *priv_ctx_rx;
struct net_device *netdev;
struct cipher_context tx;
struct cipher_context rx;
struct scatterlist *partially_sent_record;
u16 partially_sent_offset;
bool in_tcp_sendpages;
bool pending_open_record_frags;
struct mutex tx_lock;
long unsigned int flags;
struct proto *sk_proto;
struct sock *sk;
void (*sk_destruct)(struct sock *);
union tls_crypto_context crypto_send;
union tls_crypto_context crypto_recv;
struct list_head list;
refcount_t refcount;
struct callback_head rcu;
};
typedef u64 (*btf_bpf_skb_get_pay_offset)(struct sk_buff *);
typedef u64 (*btf_bpf_skb_get_nlattr)(struct sk_buff *, u32, u32);
typedef u64 (*btf_bpf_skb_get_nlattr_nest)(struct sk_buff *, u32, u32);
typedef u64 (*btf_bpf_skb_load_helper_8)(const struct sk_buff *, const void *, int, int);
typedef u64 (*btf_bpf_skb_load_helper_8_no_cache)(const struct sk_buff *, int);
typedef u64 (*btf_bpf_skb_load_helper_16)(const struct sk_buff *, const void *, int, int);
typedef u64 (*btf_bpf_skb_load_helper_16_no_cache)(const struct sk_buff *, int);
typedef u64 (*btf_bpf_skb_load_helper_32)(const struct sk_buff *, const void *, int, int);
typedef u64 (*btf_bpf_skb_load_helper_32_no_cache)(const struct sk_buff *, int);
struct bpf_scratchpad {
union {
__be32 diff[128];
u8 buff[512];
};
};
typedef u64 (*btf_bpf_skb_store_bytes)(struct sk_buff *, u32, const void *, u32, u64);
typedef u64 (*btf_bpf_skb_load_bytes)(const struct sk_buff *, u32, void *, u32);
typedef u64 (*btf_bpf_flow_dissector_load_bytes)(const struct bpf_flow_dissector *, u32, void *, u32);
typedef u64 (*btf_bpf_skb_load_bytes_relative)(const struct sk_buff *, u32, void *, u32, u32);
typedef u64 (*btf_bpf_skb_pull_data)(struct sk_buff *, u32);
typedef u64 (*btf_bpf_sk_fullsock)(struct sock *);
typedef u64 (*btf_sk_skb_pull_data)(struct sk_buff *, u32);
typedef u64 (*btf_bpf_l3_csum_replace)(struct sk_buff *, u32, u64, u64, u64);
typedef u64 (*btf_bpf_l4_csum_replace)(struct sk_buff *, u32, u64, u64, u64);
typedef u64 (*btf_bpf_csum_diff)(__be32 *, u32, __be32 *, u32, __wsum);
typedef u64 (*btf_bpf_csum_update)(struct sk_buff *, __wsum);
typedef u64 (*btf_bpf_csum_level)(struct sk_buff *, u64);
enum {
BPF_F_NEIGH = 2,
BPF_F_PEER = 4,
BPF_F_NEXTHOP = 8,
};
typedef u64 (*btf_bpf_clone_redirect)(struct sk_buff *, u32, u64);
typedef u64 (*btf_bpf_redirect)(u32, u64);
typedef u64 (*btf_bpf_redirect_peer)(u32, u64);
typedef u64 (*btf_bpf_redirect_neigh)(u32, struct bpf_redir_neigh *, int, u64);
typedef u64 (*btf_bpf_msg_apply_bytes)(struct sk_msg *, u32);
typedef u64 (*btf_bpf_msg_cork_bytes)(struct sk_msg *, u32);
typedef u64 (*btf_bpf_msg_pull_data)(struct sk_msg *, u32, u32, u64);
typedef u64 (*btf_bpf_msg_push_data)(struct sk_msg *, u32, u32, u64);
typedef u64 (*btf_bpf_msg_pop_data)(struct sk_msg *, u32, u32, u64);
typedef u64 (*btf_bpf_get_cgroup_classid)(const struct sk_buff *);
typedef u64 (*btf_bpf_get_route_realm)(const struct sk_buff *);
typedef u64 (*btf_bpf_get_hash_recalc)(struct sk_buff *);
typedef u64 (*btf_bpf_set_hash_invalid)(struct sk_buff *);
typedef u64 (*btf_bpf_set_hash)(struct sk_buff *, u32);
typedef u64 (*btf_bpf_skb_vlan_push)(struct sk_buff *, __be16, u16);
typedef u64 (*btf_bpf_skb_vlan_pop)(struct sk_buff *);
typedef u64 (*btf_bpf_skb_change_proto)(struct sk_buff *, __be16, u64);
typedef u64 (*btf_bpf_skb_change_type)(struct sk_buff *, u32);
typedef u64 (*btf_sk_skb_adjust_room)(struct sk_buff *, s32, u32, u64);
typedef u64 (*btf_bpf_skb_adjust_room)(struct sk_buff *, s32, u32, u64);
typedef u64 (*btf_bpf_skb_change_tail)(struct sk_buff *, u32, u64);
typedef u64 (*btf_sk_skb_change_tail)(struct sk_buff *, u32, u64);
typedef u64 (*btf_bpf_skb_change_head)(struct sk_buff *, u32, u64);
typedef u64 (*btf_sk_skb_change_head)(struct sk_buff *, u32, u64);
typedef u64 (*btf_bpf_xdp_get_buff_len)(struct xdp_buff *);
typedef u64 (*btf_bpf_xdp_adjust_head)(struct xdp_buff *, int);
typedef u64 (*btf_bpf_xdp_load_bytes)(struct xdp_buff *, u32, void *, u32);
typedef u64 (*btf_bpf_xdp_store_bytes)(struct xdp_buff *, u32, void *, u32);
typedef u64 (*btf_bpf_xdp_adjust_tail)(struct xdp_buff *, int);
typedef u64 (*btf_bpf_xdp_adjust_meta)(struct xdp_buff *, int);
typedef u64 (*btf_bpf_xdp_redirect)(u32, u64);
typedef u64 (*btf_bpf_xdp_redirect_map)(struct bpf_map *, u32, u64);
typedef u64 (*btf_bpf_skb_event_output)(struct sk_buff *, struct bpf_map *, u64, void *, u64);
typedef u64 (*btf_bpf_skb_get_tunnel_key)(struct sk_buff *, struct bpf_tunnel_key *, u32, u64);
typedef u64 (*btf_bpf_skb_get_tunnel_opt)(struct sk_buff *, u8 *, u32);
typedef u64 (*btf_bpf_skb_set_tunnel_key)(struct sk_buff *, const struct bpf_tunnel_key *, u32, u64);
typedef u64 (*btf_bpf_skb_set_tunnel_opt)(struct sk_buff *, const u8 *, u32);
typedef u64 (*btf_bpf_skb_under_cgroup)(struct sk_buff *, struct bpf_map *, u32);
typedef u64 (*btf_bpf_xdp_event_output)(struct xdp_buff *, struct bpf_map *, u64, void *, u64);
typedef u64 (*btf_bpf_get_socket_cookie)(struct sk_buff *);
typedef u64 (*btf_bpf_get_socket_cookie_sock_addr)(struct bpf_sock_addr_kern *);
typedef u64 (*btf_bpf_get_socket_cookie_sock)(struct sock *);
typedef u64 (*btf_bpf_get_socket_ptr_cookie)(struct sock *);
typedef u64 (*btf_bpf_get_socket_cookie_sock_ops)(struct bpf_sock_ops_kern *);
typedef u64 (*btf_bpf_get_netns_cookie_sock)(struct sock *);
typedef u64 (*btf_bpf_get_netns_cookie_sock_addr)(struct bpf_sock_addr_kern *);
typedef u64 (*btf_bpf_get_netns_cookie_sock_ops)(struct bpf_sock_ops_kern *);
typedef u64 (*btf_bpf_get_netns_cookie_sk_msg)(struct sk_msg *);
typedef u64 (*btf_bpf_get_socket_uid)(struct sk_buff *);
typedef u64 (*btf_bpf_sk_setsockopt)(struct sock *, int, int, char *, int);
typedef u64 (*btf_bpf_sk_getsockopt)(struct sock *, int, int, char *, int);
typedef u64 (*btf_bpf_unlocked_sk_setsockopt)(struct sock *, int, int, char *, int);
typedef u64 (*btf_bpf_unlocked_sk_getsockopt)(struct sock *, int, int, char *, int);
typedef u64 (*btf_bpf_sock_addr_setsockopt)(struct bpf_sock_addr_kern *, int, int, char *, int);
typedef u64 (*btf_bpf_sock_addr_getsockopt)(struct bpf_sock_addr_kern *, int, int, char *, int);
typedef u64 (*btf_bpf_sock_ops_setsockopt)(struct bpf_sock_ops_kern *, int, int, char *, int);
typedef u64 (*btf_bpf_sock_ops_getsockopt)(struct bpf_sock_ops_kern *, int, int, char *, int);
typedef u64 (*btf_bpf_sock_ops_cb_flags_set)(struct bpf_sock_ops_kern *, int);
typedef u64 (*btf_bpf_bind)(struct bpf_sock_addr_kern *, struct sockaddr *, int);
typedef u64 (*btf_bpf_skb_get_xfrm_state)(struct sk_buff *, u32, struct bpf_xfrm_state *, u32, u64);
typedef u64 (*btf_bpf_xdp_fib_lookup)(struct xdp_buff *, struct bpf_fib_lookup *, int, u32);
typedef u64 (*btf_bpf_skb_fib_lookup)(struct sk_buff *, struct bpf_fib_lookup *, int, u32);
typedef u64 (*btf_bpf_skb_check_mtu)(struct sk_buff *, u32, u32 *, s32, u64);
typedef u64 (*btf_bpf_xdp_check_mtu)(struct xdp_buff *, u32, u32 *, s32, u64);
typedef u64 (*btf_bpf_lwt_in_push_encap)(struct sk_buff *, u32, void *, u32);
typedef u64 (*btf_bpf_lwt_xmit_push_encap)(struct sk_buff *, u32, void *, u32);
typedef u64 (*btf_bpf_skc_lookup_tcp)(struct sk_buff *, struct bpf_sock_tuple *, u32, u64, u64);
typedef u64 (*btf_bpf_sk_lookup_tcp)(struct sk_buff *, struct bpf_sock_tuple *, u32, u64, u64);
typedef u64 (*btf_bpf_sk_lookup_udp)(struct sk_buff *, struct bpf_sock_tuple *, u32, u64, u64);
typedef u64 (*btf_bpf_sk_release)(struct sock *);
typedef u64 (*btf_bpf_xdp_sk_lookup_udp)(struct xdp_buff *, struct bpf_sock_tuple *, u32, u32, u64);
typedef u64 (*btf_bpf_xdp_skc_lookup_tcp)(struct xdp_buff *, struct bpf_sock_tuple *, u32, u32, u64);
typedef u64 (*btf_bpf_xdp_sk_lookup_tcp)(struct xdp_buff *, struct bpf_sock_tuple *, u32, u32, u64);
typedef u64 (*btf_bpf_sock_addr_skc_lookup_tcp)(struct bpf_sock_addr_kern *, struct bpf_sock_tuple *, u32, u64, u64);
typedef u64 (*btf_bpf_sock_addr_sk_lookup_tcp)(struct bpf_sock_addr_kern *, struct bpf_sock_tuple *, u32, u64, u64);
typedef u64 (*btf_bpf_sock_addr_sk_lookup_udp)(struct bpf_sock_addr_kern *, struct bpf_sock_tuple *, u32, u64, u64);
typedef u64 (*btf_bpf_tcp_sock)(struct sock *);
typedef u64 (*btf_bpf_get_listener_sock)(struct sock *);
typedef u64 (*btf_bpf_skb_ecn_set_ce)(struct sk_buff *);
typedef u64 (*btf_bpf_tcp_check_syncookie)(struct sock *, void *, u32, struct tcphdr *, u32);
typedef u64 (*btf_bpf_tcp_gen_syncookie)(struct sock *, void *, u32, struct tcphdr *, u32);
typedef u64 (*btf_bpf_sk_assign)(struct sk_buff *, struct sock *, u64);
typedef u64 (*btf_bpf_sock_ops_load_hdr_opt)(struct bpf_sock_ops_kern *, void *, u32, u64);
typedef u64 (*btf_bpf_sock_ops_store_hdr_opt)(struct bpf_sock_ops_kern *, const void *, u32, u64);
typedef u64 (*btf_bpf_sock_ops_reserve_hdr_opt)(struct bpf_sock_ops_kern *, u32, u64);
typedef u64 (*btf_bpf_skb_set_tstamp)(struct sk_buff *, u64, u32);
typedef u64 (*btf_bpf_tcp_raw_gen_syncookie_ipv4)(struct iphdr *, struct tcphdr *, u32);
typedef u64 (*btf_bpf_tcp_raw_gen_syncookie_ipv6)(struct ipv6hdr *, struct tcphdr *, u32);
typedef u64 (*btf_bpf_tcp_raw_check_syncookie_ipv4)(struct iphdr *, struct tcphdr *);
typedef u64 (*btf_bpf_tcp_raw_check_syncookie_ipv6)(struct ipv6hdr *, struct tcphdr *);
typedef u64 (*btf_sk_select_reuseport)(struct sk_reuseport_kern *, struct bpf_map *, void *, u32);
typedef u64 (*btf_sk_reuseport_load_bytes)(const struct sk_reuseport_kern *, u32, void *, u32);
typedef u64 (*btf_sk_reuseport_load_bytes_relative)(const struct sk_reuseport_kern *, u32, void *, u32, u32);
typedef u64 (*btf_bpf_sk_lookup_assign)(struct bpf_sk_lookup_kern *, struct sock *, u64);
typedef u64 (*btf_bpf_skc_to_tcp6_sock)(struct sock *);
typedef u64 (*btf_bpf_skc_to_tcp_sock)(struct sock *);
typedef u64 (*btf_bpf_skc_to_tcp_timewait_sock)(struct sock *);
typedef u64 (*btf_bpf_skc_to_tcp_request_sock)(struct sock *);
typedef u64 (*btf_bpf_skc_to_udp6_sock)(struct sock *);
typedef u64 (*btf_bpf_skc_to_unix_sock)(struct sock *);
typedef u64 (*btf_bpf_skc_to_mptcp_sock)(struct sock *);
typedef u64 (*btf_bpf_sock_from_file)(struct file *);
struct eee_reply_data {
struct ethnl_reply_data base;
struct ethtool_eee eee;
};
struct ip_rt_info {
__be32 daddr;
__be32 saddr;
u_int8_t tos;
u_int32_t mark;
};
struct nf_queue_entry;
struct nf_ipv6_ops {
void (*route_input)(struct sk_buff *);
int (*fragment)(struct net *, struct sock *, struct sk_buff *, int (*)(struct net *, struct sock *, struct sk_buff *));
int (*reroute)(struct sk_buff *, const struct nf_queue_entry *);
};
struct nf_queue_entry {
struct list_head list;
struct sk_buff *skb;
unsigned int id;
unsigned int hook_index;
struct nf_hook_state state;
u16 size;
};
enum tcp_metric_index {
TCP_METRIC_RTT = 0,
TCP_METRIC_RTTVAR = 1,
TCP_METRIC_SSTHRESH = 2,
TCP_METRIC_CWND = 3,
TCP_METRIC_REORDERING = 4,
TCP_METRIC_RTT_US = 5,
TCP_METRIC_RTTVAR_US = 6,
__TCP_METRIC_MAX = 7,
};
enum {
TCP_METRICS_ATTR_UNSPEC = 0,
TCP_METRICS_ATTR_ADDR_IPV4 = 1,
TCP_METRICS_ATTR_ADDR_IPV6 = 2,
TCP_METRICS_ATTR_AGE = 3,
TCP_METRICS_ATTR_TW_TSVAL = 4,
TCP_METRICS_ATTR_TW_TS_STAMP = 5,
TCP_METRICS_ATTR_VALS = 6,
TCP_METRICS_ATTR_FOPEN_MSS = 7,
TCP_METRICS_ATTR_FOPEN_SYN_DROPS = 8,
TCP_METRICS_ATTR_FOPEN_SYN_DROP_TS = 9,
TCP_METRICS_ATTR_FOPEN_COOKIE = 10,
TCP_METRICS_ATTR_SADDR_IPV4 = 11,
TCP_METRICS_ATTR_SADDR_IPV6 = 12,
TCP_METRICS_ATTR_PAD = 13,
__TCP_METRICS_ATTR_MAX = 14,
};
enum {
TCP_METRICS_CMD_UNSPEC = 0,
TCP_METRICS_CMD_GET = 1,
TCP_METRICS_CMD_DEL = 2,
__TCP_METRICS_CMD_MAX = 3,
};
struct genl_multicast_group {
char name[16];
u8 flags;
};
struct genl_ops;
struct genl_small_ops;
struct genl_family {
int id;
unsigned int hdrsize;
char name[16];
unsigned int version;
unsigned int maxattr;
unsigned int mcgrp_offset;
u8 netnsok: 1;
u8 parallel_ops: 1;
u8 n_ops;
u8 n_small_ops;
u8 n_mcgrps;
u8 resv_start_op;
const struct nla_policy *policy;
int (*pre_doit)(const struct genl_ops *, struct sk_buff *, struct genl_info *);
void (*post_doit)(const struct genl_ops *, struct sk_buff *, struct genl_info *);
const struct genl_ops *ops;
const struct genl_small_ops *small_ops;
const struct genl_multicast_group *mcgrps;
struct module *module;
};
struct genl_ops {
int (*doit)(struct sk_buff *, struct genl_info *);
int (*start)(struct netlink_callback *);
int (*dumpit)(struct sk_buff *, struct netlink_callback *);
int (*done)(struct netlink_callback *);
const struct nla_policy *policy;
unsigned int maxattr;
u8 cmd;
u8 internal_flags;
u8 flags;
u8 validate;
};
struct genl_small_ops {
int (*doit)(struct sk_buff *, struct genl_info *);
int (*dumpit)(struct sk_buff *, struct netlink_callback *);
u8 cmd;
u8 internal_flags;
u8 flags;
u8 validate;
};
enum genl_validate_flags {
GENL_DONT_VALIDATE_STRICT = 1,
GENL_DONT_VALIDATE_DUMP = 2,
GENL_DONT_VALIDATE_DUMP_STRICT = 4,
};
struct tcp_fastopen_metrics {
u16 mss;
u16 syn_loss: 10;
u16 try_exp: 2;
long unsigned int last_syn_loss;
struct tcp_fastopen_cookie cookie;
};
struct tcp_metrics_block {
struct tcp_metrics_block *tcpm_next;
possible_net_t tcpm_net;
struct inetpeer_addr tcpm_saddr;
struct inetpeer_addr tcpm_daddr;
long unsigned int tcpm_stamp;
u32 tcpm_lock;
u32 tcpm_vals[5];
long: 32;
struct tcp_fastopen_metrics tcpm_fastopen;
struct callback_head callback_head;
};
struct tcpm_hash_bucket {
struct tcp_metrics_block *chain;
};
struct arpreq {
struct sockaddr arp_pa;
struct sockaddr arp_ha;
int arp_flags;
struct sockaddr arp_netmask;
char arp_dev[16];
};
enum {
AX25_VALUES_IPDEFMODE = 0,
AX25_VALUES_AXDEFMODE = 1,
AX25_VALUES_BACKOFF = 2,
AX25_VALUES_CONMODE = 3,
AX25_VALUES_WINDOW = 4,
AX25_VALUES_EWINDOW = 5,
AX25_VALUES_T1 = 6,
AX25_VALUES_T2 = 7,
AX25_VALUES_T3 = 8,
AX25_VALUES_IDLE = 9,
AX25_VALUES_N2 = 10,
AX25_VALUES_PACLEN = 11,
AX25_VALUES_PROTOCOL = 12,
AX25_VALUES_DS_TIMEOUT = 13,
AX25_MAX_VALUES = 14,
};
struct igmphdr {
__u8 type;
__u8 code;
__sum16 csum;
__be32 group;
};
typedef short unsigned int vifi_t;
struct vifctl {
vifi_t vifc_vifi;
unsigned char vifc_flags;
unsigned char vifc_threshold;
unsigned int vifc_rate_limit;
union {
struct in_addr vifc_lcl_addr;
int vifc_lcl_ifindex;
};
struct in_addr vifc_rmt_addr;
};
struct mfcctl {
struct in_addr mfcc_origin;
struct in_addr mfcc_mcastgrp;
vifi_t mfcc_parent;
unsigned char mfcc_ttls[32];
unsigned int mfcc_pkt_cnt;
unsigned int mfcc_byte_cnt;
unsigned int mfcc_wrong_if;
int mfcc_expire;
};
struct sioc_sg_req {
struct in_addr src;
struct in_addr grp;
long unsigned int pktcnt;
long unsigned int bytecnt;
long unsigned int wrong_if;
};
struct sioc_vif_req {
vifi_t vifi;
long unsigned int icount;
long unsigned int ocount;
long unsigned int ibytes;
long unsigned int obytes;
};
struct igmpmsg {
__u32 unused1;
__u32 unused2;
unsigned char im_msgtype;
unsigned char im_mbz;
unsigned char im_vif;
unsigned char im_vif_hi;
struct in_addr im_src;
struct in_addr im_dst;
};
enum {
IPMRA_TABLE_UNSPEC = 0,
IPMRA_TABLE_ID = 1,
IPMRA_TABLE_CACHE_RES_QUEUE_LEN = 2,
IPMRA_TABLE_MROUTE_REG_VIF_NUM = 3,
IPMRA_TABLE_MROUTE_DO_ASSERT = 4,
IPMRA_TABLE_MROUTE_DO_PIM = 5,
IPMRA_TABLE_VIFS = 6,
IPMRA_TABLE_MROUTE_DO_WRVIFWHOLE = 7,
__IPMRA_TABLE_MAX = 8,
};
enum {
IPMRA_VIF_UNSPEC = 0,
IPMRA_VIF = 1,
__IPMRA_VIF_MAX = 2,
};
enum {
IPMRA_VIFA_UNSPEC = 0,
IPMRA_VIFA_IFINDEX = 1,
IPMRA_VIFA_VIF_ID = 2,
IPMRA_VIFA_FLAGS = 3,
IPMRA_VIFA_BYTES_IN = 4,
IPMRA_VIFA_BYTES_OUT = 5,
IPMRA_VIFA_PACKETS_IN = 6,
IPMRA_VIFA_PACKETS_OUT = 7,
IPMRA_VIFA_LOCAL_ADDR = 8,
IPMRA_VIFA_REMOTE_ADDR = 9,
IPMRA_VIFA_PAD = 10,
__IPMRA_VIFA_MAX = 11,
};
enum {
IPMRA_CREPORT_UNSPEC = 0,
IPMRA_CREPORT_MSGTYPE = 1,
IPMRA_CREPORT_VIF_ID = 2,
IPMRA_CREPORT_SRC_ADDR = 3,
IPMRA_CREPORT_DST_ADDR = 4,
IPMRA_CREPORT_PKT = 5,
IPMRA_CREPORT_TABLE = 6,
__IPMRA_CREPORT_MAX = 7,
};
struct mfc_cache_cmp_arg {
__be32 mfc_mcastgrp;
__be32 mfc_origin;
};
struct mfc_cache {
struct mr_mfc _c;
union {
struct {
__be32 mfc_mcastgrp;
__be32 mfc_origin;
};
struct mfc_cache_cmp_arg cmparg;
};
};
struct net_protocol {
int (*handler)(struct sk_buff *);
int (*err_handler)(struct sk_buff *, u32);
unsigned int no_policy: 1;
unsigned int icmp_strict_tag_validation: 1;
};
struct icmp_filter {
__u32 data;
};
struct raw_sock {
struct inet_sock inet;
struct icmp_filter filter;
u32 ipmr_table;
};
struct mmpin {
struct user_struct *user;
unsigned int num_pg;
};
struct ubuf_info_msgzc {
struct ubuf_info ubuf;
union {
struct {
long unsigned int desc;
void *ctx;
};
struct {
u32 id;
u16 len;
u16 zerocopy: 1;
u32 bytelen;
};
};
struct mmpin mmp;
};
struct hop_jumbo_hdr {
u8 nexthdr;
u8 hdrlen;
u8 tlv_type;
u8 tlv_len;
__be32 jumbo_payload_len;
};
struct ip6_fraglist_iter {
struct ipv6hdr *tmp_hdr;
struct sk_buff *frag;
int offset;
unsigned int hlen;
__be32 frag_id;
u8 nexthdr;
};
struct ip6_frag_state {
u8 *prevhdr;
unsigned int hlen;
unsigned int mtu;
unsigned int left;
int offset;
int ptr;
int hroom;
int troom;
__be32 frag_id;
u8 nexthdr;
};
struct ip6_ra_chain {
struct ip6_ra_chain *next;
struct sock *sk;
int sel;
void (*destructor)(struct sock *);
};
enum {
LWTUNNEL_XMIT_DONE = 0,
LWTUNNEL_XMIT_CONTINUE = 1,
};
struct cmsghdr {
__kernel_size_t cmsg_len;
int cmsg_level;
int cmsg_type;
};
struct in_pktinfo {
int ipi_ifindex;
struct in_addr ipi_spec_dst;
struct in_addr ipi_addr;
};
struct inflate_workspace {
struct inflate_state inflate_state;
unsigned char working_window[32768];
};
struct perf_callchain_entry_ctx {
struct perf_callchain_entry *entry;
u32 max_stack;
u32 nr;
short int contexts;
bool contexts_maxed;
};
struct jit_context {
struct bpf_prog *program;
u32 *descriptors;
u32 *target;
u32 bpf_index;
u32 jit_index;
u32 changes;
u32 accessed;
u32 clobbered;
u32 stack_size;
u32 saved_size;
u32 stack_used;
};
enum {
GP_IDLE = 0,
GP_ENTER = 1,
GP_PASSED = 2,
GP_EXIT = 3,
GP_REPLAY = 4,
};
enum pci_p2pdma_map_type {
PCI_P2PDMA_MAP_UNKNOWN = 0,
PCI_P2PDMA_MAP_NOT_SUPPORTED = 1,
PCI_P2PDMA_MAP_BUS_ADDR = 2,
PCI_P2PDMA_MAP_THRU_HOST_BRIDGE = 3,
};
struct pci_p2pdma_map_state {
struct dev_pagemap *pgmap;
int map;
u64 bus_off;
};
enum tick_dep_bits {
TICK_DEP_BIT_POSIX_TIMER = 0,
TICK_DEP_BIT_PERF_EVENTS = 1,
TICK_DEP_BIT_SCHED = 2,
TICK_DEP_BIT_CLOCK_UNSTABLE = 3,
TICK_DEP_BIT_RCU = 4,
TICK_DEP_BIT_RCU_EXP = 5,
};
struct cgroupstats {
__u64 nr_sleeping;
__u64 nr_running;
__u64 nr_stopped;
__u64 nr_uninterruptible;
__u64 nr_io_wait;
};
enum cgroup_filetype {
CGROUP_FILE_PROCS = 0,
CGROUP_FILE_TASKS = 1,
};
struct cgroup_pidlist {
struct {
enum cgroup_filetype type;
struct pid_namespace *ns;
} key;
pid_t *list;
int length;
struct list_head links;
struct cgroup *owner;
struct delayed_work destroy_dwork;
};
enum cgroup1_param {
Opt_all = 0,
Opt_clone_children = 1,
Opt_cpuset_v2_mode = 2,
Opt_name = 3,
Opt_none = 4,
Opt_noprefix = 5,
Opt_release_agent = 6,
Opt_xattr = 7,
Opt_favordynmods___2 = 8,
Opt_nofavordynmods = 9,
};
struct ftrace_func_entry {
struct hlist_node hlist;
long unsigned int ip;
long unsigned int direct;
};
struct ftrace_graph_ent {
long unsigned int func;
int depth;
};
struct ftrace_graph_ret {
long unsigned int func;
int depth;
unsigned int overrun;
long long unsigned int calltime;
long long unsigned int rettime;
};
typedef void (*trace_func_graph_ret_t)(struct ftrace_graph_ret *);
typedef int (*trace_func_graph_ent_t)(struct ftrace_graph_ent *);
struct fgraph_ops {
trace_func_graph_ent_t entryfunc;
trace_func_graph_ret_t retfunc;
};
struct ftrace_graph_ent_entry {
struct trace_entry ent;
struct ftrace_graph_ent graph_ent;
};
struct ftrace_graph_ret_entry {
struct trace_entry ent;
struct ftrace_graph_ret ret;
};
enum {
FTRACE_HASH_FL_MOD = 1,
};
struct fgraph_cpu_data {
pid_t last_pid;
int depth;
int depth_irq;
int ignore;
long unsigned int enter_funcs[50];
};
struct fgraph_data {
struct fgraph_cpu_data *cpu_data;
struct ftrace_graph_ent_entry ent;
struct ftrace_graph_ret_entry ret;
int failed;
int cpu;
};
enum {
FLAGS_FILL_FULL = 268435456,
FLAGS_FILL_START = 536870912,
FLAGS_FILL_END = 805306368,
};
struct bpf_iter__bpf_map_elem {
union {
struct bpf_iter_meta *meta;
};
union {
struct bpf_map *map;
};
union {
void *key;
};
union {
void *value;
};
};
struct pcpu_freelist_node;
struct pcpu_freelist_head {
struct pcpu_freelist_node *first;
raw_spinlock_t lock;
};
struct pcpu_freelist_node {
struct pcpu_freelist_node *next;
};
struct pcpu_freelist {
struct pcpu_freelist_head *freelist;
struct pcpu_freelist_head extralist;
};
struct bpf_lru_node {
struct list_head list;
u16 cpu;
u8 type;
u8 ref;
};
struct bpf_lru_list {
struct list_head lists[3];
unsigned int counts[2];
struct list_head *next_inactive_rotation;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
raw_spinlock_t lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_lru_locallist {
struct list_head lists[2];
u16 next_steal;
raw_spinlock_t lock;
};
struct bpf_common_lru {
struct bpf_lru_list lru_list;
struct bpf_lru_locallist *local_list;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef bool (*del_from_htab_func)(void *, struct bpf_lru_node *);
struct bpf_lru {
union {
struct bpf_common_lru common_lru;
struct bpf_lru_list *percpu_lru;
};
del_from_htab_func del_from_htab;
void *del_arg;
unsigned int hash_offset;
unsigned int nr_scans;
bool percpu;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_mem_caches;
struct bpf_mem_cache;
struct bpf_mem_alloc {
struct bpf_mem_caches *caches;
struct bpf_mem_cache *cache;
struct work_struct work;
};
struct bucket {
struct hlist_nulls_head head;
raw_spinlock_t raw_lock;
};
struct htab_elem;
struct bpf_htab {
struct bpf_map map;
struct bpf_mem_alloc ma;
struct bpf_mem_alloc pcpu_ma;
struct bucket *buckets;
void *elems;
long: 32;
long: 32;
union {
struct pcpu_freelist freelist;
struct bpf_lru lru;
};
struct htab_elem **extra_elems;
long: 32;
struct percpu_counter pcount;
atomic_t count;
bool use_percpu_counter;
u32 n_buckets;
u32 elem_size;
u32 hashrnd;
struct lock_class_key lockdep_key;
int *map_locked[8];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct htab_elem {
union {
struct hlist_nulls_node hash_node;
struct {
void *padding;
union {
struct pcpu_freelist_node fnode;
struct htab_elem *batch_flink;
};
};
};
union {
void *ptr_to_pptr;
struct bpf_lru_node lru_node;
};
u32 hash;
char key[0];
};
struct bpf_iter_seq_hash_map_info {
struct bpf_map *map;
struct bpf_htab *htab;
void *percpu_value_buf;
u32 bucket_id;
u32 skip_elems;
};
enum bpf_link_type {
BPF_LINK_TYPE_UNSPEC = 0,
BPF_LINK_TYPE_RAW_TRACEPOINT = 1,
BPF_LINK_TYPE_TRACING = 2,
BPF_LINK_TYPE_CGROUP = 3,
BPF_LINK_TYPE_ITER = 4,
BPF_LINK_TYPE_NETNS = 5,
BPF_LINK_TYPE_XDP = 6,
BPF_LINK_TYPE_PERF_EVENT = 7,
BPF_LINK_TYPE_KPROBE_MULTI = 8,
BPF_LINK_TYPE_STRUCT_OPS = 9,
MAX_BPF_LINK_TYPE = 10,
};
struct bpf_tramp_link;
struct bpf_tramp_links {
struct bpf_tramp_link *links[38];
int nr_links;
};
struct bpf_link_ops;
struct bpf_link {
atomic64_t refcnt;
u32 id;
enum bpf_link_type type;
const struct bpf_link_ops *ops;
struct bpf_prog *prog;
struct work_struct work;
};
struct bpf_tramp_link {
struct bpf_link link;
struct hlist_node tramp_hlist;
u64 cookie;
};
struct bpf_link_ops {
void (*release)(struct bpf_link *);
void (*dealloc)(struct bpf_link *);
int (*detach)(struct bpf_link *);
int (*update_prog)(struct bpf_link *, struct bpf_prog *, struct bpf_prog *);
void (*show_fdinfo)(const struct bpf_link *, struct seq_file *);
int (*fill_link_info)(const struct bpf_link *, struct bpf_link_info *);
};
struct bpf_dummy_ops_state {
int val;
};
struct bpf_dummy_ops {
int (*test_1)(struct bpf_dummy_ops_state *);
int (*test_2)(struct bpf_dummy_ops_state *, int, short unsigned int, char, long unsigned int);
};
enum bpf_struct_ops_state {
BPF_STRUCT_OPS_STATE_INIT = 0,
BPF_STRUCT_OPS_STATE_INUSE = 1,
BPF_STRUCT_OPS_STATE_TOBEFREE = 2,
};
struct bpf_struct_ops_value {
refcount_t refcnt;
enum bpf_struct_ops_state state;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
char data[0];
};
struct bpf_struct_ops_map {
struct bpf_map map;
struct callback_head rcu;
const struct bpf_struct_ops *st_ops;
struct mutex lock;
struct bpf_link **links;
void *image;
struct bpf_struct_ops_value *uvalue;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct bpf_struct_ops_value kvalue;
};
struct bpf_struct_ops_bpf_dummy_ops {
refcount_t refcnt;
enum bpf_struct_ops_state state;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct bpf_dummy_ops data;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_struct_ops_tcp_congestion_ops {
refcount_t refcnt;
enum bpf_struct_ops_state state;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct tcp_congestion_ops data;
};
enum {
BPF_STRUCT_OPS_TYPE_bpf_dummy_ops = 0,
BPF_STRUCT_OPS_TYPE_tcp_congestion_ops = 1,
__NR_BPF_STRUCT_OPS_TYPE = 2,
};
enum vm_fault_reason {
VM_FAULT_OOM = 1,
VM_FAULT_SIGBUS = 2,
VM_FAULT_MAJOR = 4,
VM_FAULT_WRITE = 8,
VM_FAULT_HWPOISON = 16,
VM_FAULT_HWPOISON_LARGE = 32,
VM_FAULT_SIGSEGV = 64,
VM_FAULT_NOPAGE = 256,
VM_FAULT_LOCKED = 512,
VM_FAULT_RETRY = 1024,
VM_FAULT_FALLBACK = 2048,
VM_FAULT_DONE_COW = 4096,
VM_FAULT_NEEDDSYNC = 8192,
VM_FAULT_COMPLETED = 16384,
VM_FAULT_HINDEX_MASK = 983040,
};
typedef struct {
long unsigned int pd;
} hugepd_t;
struct follow_page_context {
struct dev_pagemap *pgmap;
unsigned int page_mask;
};
struct open_how {
__u64 flags;
__u64 mode;
__u64 resolve;
};
struct open_flags {
int open_flag;
umode_t mode;
int acc_mode;
int intent;
int lookup_flags;
};
struct dnotify_struct {
struct dnotify_struct *dn_next;
__u32 dn_mask;
int dn_fd;
struct file *dn_filp;
fl_owner_t dn_owner;
};
struct dnotify_mark {
struct fsnotify_mark fsn_mark;
struct dnotify_struct *dn;
};
enum {
QIF_BLIMITS_B = 0,
QIF_SPACE_B = 1,
QIF_ILIMITS_B = 2,
QIF_INODES_B = 3,
QIF_BTIME_B = 4,
QIF_ITIME_B = 5,
};
enum {
DQF_INFO_DIRTY_B = 17,
};
struct dqstats {
long unsigned int stat[8];
struct percpu_counter counter[8];
};
struct quota_module_name {
int qm_fmt_id;
char *qm_mod_name;
};
struct dquot_warn {
struct super_block *w_sb;
struct kqid w_dq_id;
short int w_type;
};
struct pts_mount_opts {
int setuid;
int setgid;
kuid_t uid;
kgid_t gid;
umode_t mode;
umode_t ptmxmode;
int reserve;
int max;
};
enum {
Opt_uid = 0,
Opt_gid = 1,
Opt_mode = 2,
Opt_ptmxmode = 3,
Opt_newinstance = 4,
Opt_max = 5,
Opt_err___2 = 6,
};
struct pts_fs_info {
struct ida allocated_ptys;
struct pts_mount_opts mount_opts;
struct super_block *sb;
struct dentry *ptmx_dentry;
};
struct bvec_iter_all {
struct bio_vec bv;
int idx;
unsigned int done;
};
enum bio_post_read_step {
STEP_INITIAL = 0,
STEP_DECRYPT = 1,
STEP_VERITY = 2,
STEP_MAX = 3,
};
struct bio_post_read_ctx {
struct bio *bio;
struct work_struct work;
unsigned int cur_step;
unsigned int enabled_steps;
};
struct fsverity_info;
struct fileattr {
u32 flags;
u32 fsx_xflags;
u32 fsx_extsize;
u32 fsx_nextents;
u32 fsx_projid;
u32 fsx_cowextsize;
bool flags_valid: 1;
bool fsx_valid: 1;
};
enum nfs_ftype {
NFNON = 0,
NFREG = 1,
NFDIR = 2,
NFBLK = 3,
NFCHR = 4,
NFLNK = 5,
NFSOCK = 6,
NFBAD = 7,
NFFIFO = 8,
};
enum {
NFSD_NET_PAYLOAD_MISSES = 0,
NFSD_NET_DRC_MEM_USAGE = 1,
NFSD_NET_COUNTERS_NUM = 2,
};
struct nfsd_sattrargs {
struct svc_fh fh;
struct iattr attrs;
};
struct nfsd_diropargs {
struct svc_fh fh;
char *name;
unsigned int len;
};
struct nfsd_readargs {
struct svc_fh fh;
__u32 offset;
__u32 count;
};
struct nfsd_writeargs {
svc_fh fh;
__u32 offset;
__u32 len;
struct xdr_buf payload;
long: 32;
};
struct nfsd_createargs {
struct svc_fh fh;
char *name;
unsigned int len;
struct iattr attrs;
};
struct nfsd_renameargs {
struct svc_fh ffh;
char *fname;
unsigned int flen;
struct svc_fh tfh;
char *tname;
unsigned int tlen;
};
struct nfsd_linkargs {
struct svc_fh ffh;
struct svc_fh tfh;
char *tname;
unsigned int tlen;
};
struct nfsd_symlinkargs {
struct svc_fh ffh;
char *fname;
unsigned int flen;
char *tname;
unsigned int tlen;
struct iattr attrs;
struct kvec first;
};
struct nfsd_readdirargs {
struct svc_fh fh;
__u32 cookie;
__u32 count;
};
struct nfsd_stat {
__be32 status;
};
struct nfsd_attrstat {
__be32 status;
long: 32;
struct svc_fh fh;
struct kstat stat;
};
struct nfsd_diropres {
__be32 status;
long: 32;
struct svc_fh fh;
struct kstat stat;
};
struct nfsd_readlinkres {
__be32 status;
int len;
struct page *page;
};
struct nfsd_readres {
__be32 status;
long: 32;
struct svc_fh fh;
long unsigned int count;
long: 32;
struct kstat stat;
struct page **pages;
long: 32;
};
struct nfsd_readdirres {
__be32 status;
int count;
struct xdr_stream xdr;
struct xdr_buf dirlist;
struct readdir_cd common;
unsigned int cookie_offset;
};
struct nfsd_statfsres {
__be32 status;
long: 32;
struct kstatfs stats;
};
enum {
CRYPTO_MSG_ALG_REQUEST = 0,
CRYPTO_MSG_ALG_REGISTER = 1,
CRYPTO_MSG_ALG_LOADED = 2,
};
struct crypto_larval {
struct crypto_alg alg;
struct crypto_alg *adult;
struct completion completion;
u32 mask;
bool test_started;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct chksum_ctx {
u32 key;
};
struct chksum_desc_ctx {
u32 crc;
};
enum {
BIOSET_NEED_BVECS = 1,
BIOSET_NEED_RESCUER = 2,
BIOSET_PERCPU_CACHE = 4,
};
enum {
DIO_SHOULD_DIRTY = 1,
DIO_IS_SYNC = 2,
};
struct blkdev_dio {
union {
struct kiocb *iocb;
struct task_struct *waiter;
};
size_t size;
atomic_t ref;
unsigned int flags;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct bio bio;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct disk_events {
struct list_head node;
struct gendisk *disk;
spinlock_t lock;
struct mutex block_mutex;
int block;
unsigned int pending;
unsigned int clearing;
long int poll_msecs;
struct delayed_work dwork;
};
struct io_sync {
struct file *file;
long: 32;
loff_t len;
loff_t off;
int flags;
int mode;
};
struct io_uring_rsrc_register {
__u32 nr;
__u32 flags;
__u64 resv2;
__u64 data;
__u64 tags;
};
struct io_uring_rsrc_update2 {
__u32 offset;
__u32 resv;
__u64 data;
__u64 tags;
__u32 nr;
__u32 resv2;
};
struct scm_fp_list {
short int count;
short int max;
struct user_struct *user;
struct file *fp[253];
};
struct unix_skb_parms {
struct pid *pid;
kuid_t uid;
kgid_t gid;
struct scm_fp_list *fp;
u32 consumed;
};
enum {
IORING_RSRC_FILE = 0,
IORING_RSRC_BUFFER = 1,
};
struct io_rsrc_update {
struct file *file;
long: 32;
u64 arg;
u32 nr_args;
u32 offset;
};
typedef u32 pci_bus_addr_t;
struct pci_bus_region {
pci_bus_addr_t start;
pci_bus_addr_t end;
};
struct fb_cmap_user {
__u32 start;
__u32 len;
__u16 *red;
__u16 *green;
__u16 *blue;
__u16 *transp;
};
struct clk_fractional_divider {
struct clk_hw hw;
void *reg;
u8 mshift;
u8 mwidth;
u32 mmask;
u8 nshift;
u8 nwidth;
u32 nmask;
u8 flags;
void (*approximation)(struct clk_hw *, long unsigned int, long unsigned int *, long unsigned int *, long unsigned int *);
spinlock_t *lock;
};
struct earlycon_device {
struct console *con;
long: 32;
struct uart_port port;
char options[16];
unsigned int baud;
long: 32;
};
struct earlycon_id {
char name[15];
char name_term;
char compatible[128];
int (*setup)(struct earlycon_device *, const char *);
};
struct software_node {
const char *name;
const struct software_node *parent;
const struct property_entry *properties;
};
struct irq_affinity {
unsigned int pre_vectors;
unsigned int post_vectors;
unsigned int nr_sets;
unsigned int set_size[4];
void (*calc_sets)(struct irq_affinity *, unsigned int);
void *priv;
};
typedef void *acpi_handle;
struct irq_affinity_devres {
unsigned int count;
unsigned int irq[0];
};
struct platform_object {
struct platform_device pdev;
char name[0];
};
struct mtd_blktrans_ops;
struct mtd_blktrans_dev {
struct mtd_blktrans_ops *tr;
struct list_head list;
struct mtd_info *mtd;
struct mutex lock;
int devnum;
bool bg_stop;
long unsigned int size;
int readonly;
int open;
struct kref ref;
struct gendisk *disk;
struct attribute_group *disk_attributes;
struct request_queue *rq;
struct list_head rq_list;
struct blk_mq_tag_set *tag_set;
spinlock_t queue_lock;
void *priv;
fmode_t file_mode;
};
struct mtd_blktrans_ops {
char *name;
int major;
int part_bits;
int blksize;
int blkshift;
int (*readsect)(struct mtd_blktrans_dev *, long unsigned int, char *);
int (*writesect)(struct mtd_blktrans_dev *, long unsigned int, char *);
int (*discard)(struct mtd_blktrans_dev *, long unsigned int, unsigned int);
void (*background)(struct mtd_blktrans_dev *);
int (*getgeo)(struct mtd_blktrans_dev *, struct hd_geometry *);
int (*flush)(struct mtd_blktrans_dev *);
int (*open)(struct mtd_blktrans_dev *);
void (*release)(struct mtd_blktrans_dev *);
void (*add_mtd)(struct mtd_blktrans_ops *, struct mtd_info *);
void (*remove_dev)(struct mtd_blktrans_dev *);
struct list_head devs;
struct list_head list;
struct module *owner;
};
struct mtd_notifier {
void (*add)(struct mtd_info *);
void (*remove)(struct mtd_info *);
struct list_head list;
};
struct req_iterator {
struct bvec_iter iter;
struct bio *bio;
};
enum ethtool_test_flags {
ETH_TEST_FL_OFFLINE = 1,
ETH_TEST_FL_FAILED = 2,
ETH_TEST_FL_EXTERNAL_LB = 4,
ETH_TEST_FL_EXTERNAL_LB_DONE = 8,
};
struct netdev_hw_addr {
struct list_head list;
struct rb_node node;
unsigned char addr[32];
unsigned char type;
bool global_use;
int sync_cnt;
int refcount;
int synced;
struct callback_head callback_head;
};
enum skb_free_reason {
SKB_REASON_CONSUMED = 0,
SKB_REASON_DROPPED = 1,
};
struct pcnet32_rx_head {
__le32 base;
__le16 buf_length;
__le16 status;
__le32 msg_length;
__le32 reserved;
};
struct pcnet32_tx_head {
__le32 base;
__le16 length;
__le16 status;
__le32 misc;
__le32 reserved;
};
struct pcnet32_init_block {
__le16 mode;
__le16 tlen_rlen;
u8 phys_addr[6];
__le16 reserved;
__le32 filter[2];
__le32 rx_ring;
__le32 tx_ring;
};
struct pcnet32_access {
u16 (*read_csr)(long unsigned int, int);
void (*write_csr)(long unsigned int, int, u16);
u16 (*read_bcr)(long unsigned int, int);
void (*write_bcr)(long unsigned int, int, u16);
u16 (*read_rap)(long unsigned int);
void (*write_rap)(long unsigned int, u16);
void (*reset)(long unsigned int);
};
struct pcnet32_private {
struct pcnet32_init_block *init_block;
struct pcnet32_rx_head *rx_ring;
struct pcnet32_tx_head *tx_ring;
dma_addr_t init_dma_addr;
struct pci_dev *pci_dev;
const char *name;
struct sk_buff **tx_skbuff;
struct sk_buff **rx_skbuff;
dma_addr_t *tx_dma_addr;
dma_addr_t *rx_dma_addr;
const struct pcnet32_access *a;
spinlock_t lock;
unsigned int cur_rx;
unsigned int cur_tx;
unsigned int rx_ring_size;
unsigned int tx_ring_size;
unsigned int rx_mod_mask;
unsigned int tx_mod_mask;
short unsigned int rx_len_bits;
short unsigned int tx_len_bits;
dma_addr_t rx_ring_dma_addr;
dma_addr_t tx_ring_dma_addr;
unsigned int dirty_rx;
unsigned int dirty_tx;
struct net_device *dev;
struct napi_struct napi;
char tx_full;
char phycount;
int options;
unsigned int shared_irq: 1;
unsigned int dxsuflo: 1;
unsigned int mii: 1;
unsigned int autoneg: 1;
unsigned int port_tp: 1;
unsigned int fdx: 1;
struct net_device *next;
struct mii_if_info mii_if;
struct timer_list watchdog_timer;
u32 msg_enable;
u32 phymask;
short unsigned int chip_version;
u16 save_regs[4];
};
enum __sk_action {
__SK_DROP = 0,
__SK_PASS = 1,
__SK_REDIRECT = 2,
__SK_NONE = 3,
};
enum sk_psock_state_bits {
SK_PSOCK_TX_ENABLED = 0,
};
struct sk_psock_link {
struct list_head list;
struct bpf_map *map;
void *link_raw;
};
enum ethtool_podl_pse_admin_state {
ETHTOOL_PODL_PSE_ADMIN_STATE_UNKNOWN = 1,
ETHTOOL_PODL_PSE_ADMIN_STATE_DISABLED = 2,
ETHTOOL_PODL_PSE_ADMIN_STATE_ENABLED = 3,
};
enum ethtool_podl_pse_pw_d_status {
ETHTOOL_PODL_PSE_PW_D_STATUS_UNKNOWN = 1,
ETHTOOL_PODL_PSE_PW_D_STATUS_DISABLED = 2,
ETHTOOL_PODL_PSE_PW_D_STATUS_SEARCHING = 3,
ETHTOOL_PODL_PSE_PW_D_STATUS_DELIVERING = 4,
ETHTOOL_PODL_PSE_PW_D_STATUS_SLEEP = 5,
ETHTOOL_PODL_PSE_PW_D_STATUS_IDLE = 6,
ETHTOOL_PODL_PSE_PW_D_STATUS_ERROR = 7,
};
struct pse_control_config {
enum ethtool_podl_pse_admin_state admin_cotrol;
};
struct pse_control_status {
enum ethtool_podl_pse_admin_state podl_admin_state;
enum ethtool_podl_pse_pw_d_status podl_pw_status;
};
struct pse_reply_data {
struct ethnl_reply_data base;
struct pse_control_status status;
};
struct tcp_request_sock_ops;
struct tcp_request_sock {
struct inet_request_sock req;
const struct tcp_request_sock_ops *af_specific;
long: 32;
u64 snt_synack;
bool tfo_listener;
bool is_mptcp;
u32 txhash;
u32 rcv_isn;
u32 snt_isn;
u32 ts_off;
u32 last_oow_ack_time;
u32 rcv_nxt;
u8 syn_tos;
};
enum tcp_synack_type {
TCP_SYNACK_NORMAL = 0,
TCP_SYNACK_FASTOPEN = 1,
TCP_SYNACK_COOKIE = 2,
};
struct tcp_request_sock_ops {
u16 mss_clamp;
struct tcp_md5sig_key * (*req_md5_lookup)(const struct sock *, const struct sock *);
int (*calc_md5_hash)(char *, const struct tcp_md5sig_key *, const struct sock *, const struct sk_buff *);
__u32 (*cookie_init_seq)(const struct sk_buff *, __u16 *);
struct dst_entry * (*route_req)(const struct sock *, struct sk_buff *, struct flowi *, struct request_sock *);
u32 (*init_seq)(const struct sk_buff *);
u32 (*init_ts_off)(const struct net *, const struct sk_buff *);
int (*send_synack)(const struct sock *, struct dst_entry *, struct flowi *, struct request_sock *, struct tcp_fastopen_cookie *, enum tcp_synack_type, struct sk_buff *);
};
typedef struct sk_buff * (*gro_receive_t)(struct list_head *, struct sk_buff *);
typedef struct sk_buff * (*gro_receive_sk_t)(struct sock *, struct list_head *, struct sk_buff *);
struct nduseroptmsg {
unsigned char nduseropt_family;
unsigned char nduseropt_pad1;
short unsigned int nduseropt_opts_len;
int nduseropt_ifindex;
__u8 nduseropt_icmp_type;
__u8 nduseropt_icmp_code;
short unsigned int nduseropt_pad2;
unsigned int nduseropt_pad3;
};
enum {
NDUSEROPT_UNSPEC = 0,
NDUSEROPT_SRCADDR = 1,
__NDUSEROPT_MAX = 2,
};
struct nd_msg {
struct icmp6hdr icmph;
struct in6_addr target;
__u8 opt[0];
};
struct rs_msg {
struct icmp6hdr icmph;
__u8 opt[0];
};
struct ra_msg {
struct icmp6hdr icmph;
__be32 reachable_time;
__be32 retrans_timer;
};
struct ioam6_trace_hdr {
__be16 namespace_id;
char: 2;
__u8 overflow: 1;
__u8 nodelen: 5;
__u8 remlen: 7;
union {
__be32 type_be32;
struct {
__u32 bit7: 1;
__u32 bit6: 1;
__u32 bit5: 1;
__u32 bit4: 1;
__u32 bit3: 1;
__u32 bit2: 1;
__u32 bit1: 1;
__u32 bit0: 1;
__u32 bit15: 1;
__u32 bit14: 1;
__u32 bit13: 1;
__u32 bit12: 1;
__u32 bit11: 1;
__u32 bit10: 1;
__u32 bit9: 1;
__u32 bit8: 1;
__u32 bit23: 1;
__u32 bit22: 1;
__u32 bit21: 1;
__u32 bit20: 1;
__u32 bit19: 1;
__u32 bit18: 1;
__u32 bit17: 1;
__u32 bit16: 1;
} type;
};
__u8 data[0];
};
enum {
IOAM6_ATTR_UNSPEC = 0,
IOAM6_ATTR_NS_ID = 1,
IOAM6_ATTR_NS_DATA = 2,
IOAM6_ATTR_NS_DATA_WIDE = 3,
IOAM6_ATTR_SC_ID = 4,
IOAM6_ATTR_SC_DATA = 5,
IOAM6_ATTR_SC_NONE = 6,
IOAM6_ATTR_PAD = 7,
__IOAM6_ATTR_MAX = 8,
};
enum {
IOAM6_CMD_UNSPEC = 0,
IOAM6_CMD_ADD_NAMESPACE = 1,
IOAM6_CMD_DEL_NAMESPACE = 2,
IOAM6_CMD_DUMP_NAMESPACES = 3,
IOAM6_CMD_ADD_SCHEMA = 4,
IOAM6_CMD_DEL_SCHEMA = 5,
IOAM6_CMD_DUMP_SCHEMAS = 6,
IOAM6_CMD_NS_SET_SCHEMA = 7,
__IOAM6_CMD_MAX = 8,
};
struct ioam6_pernet_data {
struct mutex lock;
struct rhashtable namespaces;
struct rhashtable schemas;
};
struct ioam6_schema;
struct ioam6_namespace {
struct rhash_head head;
struct callback_head rcu;
struct ioam6_schema *schema;
__be16 id;
__be32 data;
__be64 data_wide;
};
struct ioam6_schema {
struct rhash_head head;
struct callback_head rcu;
struct ioam6_namespace *ns;
u32 id;
int len;
__be32 hdr;
u8 data[0];
};
struct mld_msg {
struct icmp6hdr mld_hdr;
struct in6_addr mld_mca;
};
typedef void (*rpc_action)(struct rpc_task *);
struct rpc_create_args {
struct net *net;
int protocol;
struct sockaddr *address;
size_t addrsize;
struct sockaddr *saddress;
const struct rpc_timeout *timeout;
const char *servername;
const char *nodename;
const struct rpc_program *program;
u32 prognumber;
u32 version;
rpc_authflavor_t authflavor;
u32 nconnect;
long unsigned int flags;
char *client_name;
struct svc_xprt *bc_xprt;
const struct cred *cred;
unsigned int max_connect;
};
struct sunrpc_net {
struct proc_dir_entry *proc_net_rpc;
struct cache_detail *ip_map_cache;
struct cache_detail *unix_gid_cache;
struct cache_detail *rsc_cache;
struct cache_detail *rsi_cache;
struct super_block *pipefs_sb;
struct rpc_pipe *gssd_dummy;
struct mutex pipefs_sb_lock;
struct list_head all_clients;
spinlock_t rpc_client_lock;
struct rpc_clnt *rpcb_local_clnt;
struct rpc_clnt *rpcb_local_clnt4;
spinlock_t rpcb_clnt_lock;
unsigned int rpcb_users;
unsigned int rpcb_is_af_local: 1;
struct mutex gssp_lock;
struct rpc_clnt *gssp_clnt;
int use_gss_proxy;
int pipe_version;
atomic_t pipe_users;
struct proc_dir_entry *use_gssp_proc;
};
enum {
RPCBPROC_NULL = 0,
RPCBPROC_SET = 1,
RPCBPROC_UNSET = 2,
RPCBPROC_GETPORT = 3,
RPCBPROC_GETADDR = 3,
RPCBPROC_DUMP = 4,
RPCBPROC_CALLIT = 5,
RPCBPROC_BCAST = 5,
RPCBPROC_GETTIME = 6,
RPCBPROC_UADDR2TADDR = 7,
RPCBPROC_TADDR2UADDR = 8,
RPCBPROC_GETVERSADDR = 9,
RPCBPROC_INDIRECT = 10,
RPCBPROC_GETADDRLIST = 11,
RPCBPROC_GETSTAT = 12,
};
struct rpcbind_args {
struct rpc_xprt *r_xprt;
u32 r_prog;
u32 r_vers;
u32 r_prot;
short unsigned int r_port;
const char *r_netid;
const char *r_addr;
const char *r_owner;
int r_status;
};
struct rpcb_info {
u32 rpc_vers;
const struct rpc_procinfo *rpc_proc;
};
enum lockdep_ok {
LOCKDEP_STILL_OK = 0,
LOCKDEP_NOW_UNRELIABLE = 1,
};
enum major_op {
spec_op = 0,
bcond_op = 1,
j_op = 2,
jal_op = 3,
beq_op = 4,
bne_op = 5,
blez_op = 6,
bgtz_op = 7,
addi_op = 8,
pop10_op = 8,
addiu_op = 9,
slti_op = 10,
sltiu_op = 11,
andi_op = 12,
ori_op = 13,
xori_op = 14,
lui_op = 15,
cop0_op = 16,
cop1_op = 17,
cop2_op = 18,
cop1x_op = 19,
beql_op = 20,
bnel_op = 21,
blezl_op = 22,
bgtzl_op = 23,
daddi_op = 24,
pop30_op = 24,
daddiu_op = 25,
ldl_op = 26,
ldr_op = 27,
spec2_op = 28,
jalx_op = 29,
mdmx_op = 30,
msa_op = 30,
spec3_op = 31,
lb_op = 32,
lh_op = 33,
lwl_op = 34,
lw_op = 35,
lbu_op = 36,
lhu_op = 37,
lwr_op = 38,
lwu_op = 39,
sb_op = 40,
sh_op = 41,
swl_op = 42,
sw_op = 43,
sdl_op = 44,
sdr_op = 45,
swr_op = 46,
cache_op = 47,
ll_op = 48,
lwc1_op = 49,
lwc2_op = 50,
bc6_op = 50,
pref_op = 51,
lld_op = 52,
ldc1_op = 53,
ldc2_op = 54,
pop66_op = 54,
ld_op = 55,
sc_op = 56,
swc1_op = 57,
swc2_op = 58,
balc6_op = 58,
major_3b_op = 59,
scd_op = 60,
sdc1_op = 61,
sdc2_op = 62,
pop76_op = 62,
sd_op = 63,
};
enum cpu_pm_event {
CPU_PM_ENTER = 0,
CPU_PM_ENTER_FAILED = 1,
CPU_PM_EXIT = 2,
CPU_CLUSTER_PM_ENTER = 3,
CPU_CLUSTER_PM_ENTER_FAILED = 4,
CPU_CLUSTER_PM_EXIT = 5,
};
enum cu2_ops {
CU2_EXCEPTION = 0,
CU2_LWC2_OP = 1,
CU2_LDC2_OP = 2,
CU2_SWC2_OP = 3,
CU2_SDC2_OP = 4,
};
enum fpu_mode {
FPU_32BIT = 0,
FPU_64BIT = 1,
FPU_AS_IS = 2,
FPU_HYBRID = 3,
};
struct mcs_spinlock {
struct mcs_spinlock *next;
int locked;
int count;
};
struct qnode {
struct mcs_spinlock mcs;
};
struct arch_msi_msg_addr_lo {
u32 address_lo;
};
typedef struct arch_msi_msg_addr_lo arch_msi_msg_addr_lo_t;
struct arch_msi_msg_addr_hi {
u32 address_hi;
};
typedef struct arch_msi_msg_addr_hi arch_msi_msg_addr_hi_t;
struct arch_msi_msg_data {
u32 data;
};
typedef struct arch_msi_msg_data arch_msi_msg_data_t;
struct msi_msg {
union {
u32 address_lo;
arch_msi_msg_addr_lo_t arch_addr_lo;
};
union {
u32 address_hi;
arch_msi_msg_addr_hi_t arch_addr_hi;
};
union {
u32 data;
arch_msi_msg_data_t arch_data;
};
};
struct pci_msi_desc {
union {
u32 msi_mask;
u32 msix_ctrl;
};
struct {
u8 is_msix: 1;
u8 multiple: 3;
u8 multi_cap: 3;
u8 can_mask: 1;
u8 is_64: 1;
u8 is_virtual: 1;
unsigned int default_irq;
} msi_attrib;
union {
u8 mask_pos;
void *mask_base;
};
};
struct msi_desc {
unsigned int irq;
unsigned int nvec_used;
struct device *dev;
struct msi_msg msg;
struct irq_affinity_desc *affinity;
struct device_attribute *sysfs_attrs;
void (*write_msi_msg)(struct msi_desc *, void *);
void *write_msi_msg_data;
u16 msi_index;
struct pci_msi_desc pci;
};
enum {
IRQ_STARTUP_NORMAL = 0,
IRQ_STARTUP_MANAGED = 1,
IRQ_STARTUP_ABORT = 2,
};
struct rcu_cblist {
struct callback_head *head;
struct callback_head **tail;
long int len;
};
struct trace_event_raw_timer_class {
struct trace_entry ent;
void *timer;
char __data[0];
};
struct trace_event_raw_timer_start {
struct trace_entry ent;
void *timer;
void *function;
long unsigned int expires;
long unsigned int now;
unsigned int flags;
char __data[0];
};
struct trace_event_raw_timer_expire_entry {
struct trace_entry ent;
void *timer;
long unsigned int now;
void *function;
long unsigned int baseclk;
char __data[0];
};
struct trace_event_raw_hrtimer_init {
struct trace_entry ent;
void *hrtimer;
clockid_t clockid;
enum hrtimer_mode mode;
char __data[0];
};
struct trace_event_raw_hrtimer_start {
struct trace_entry ent;
void *hrtimer;
void *function;
s64 expires;
s64 softexpires;
enum hrtimer_mode mode;
char __data[0];
long: 32;
};
struct trace_event_raw_hrtimer_expire_entry {
struct trace_entry ent;
void *hrtimer;
long: 32;
s64 now;
void *function;
char __data[0];
long: 32;
};
struct trace_event_raw_hrtimer_class {
struct trace_entry ent;
void *hrtimer;
char __data[0];
};
struct trace_event_raw_itimer_state {
struct trace_entry ent;
int which;
long: 32;
long long unsigned int expires;
long int value_sec;
long int value_nsec;
long int interval_sec;
long int interval_nsec;
char __data[0];
};
struct trace_event_raw_itimer_expire {
struct trace_entry ent;
int which;
pid_t pid;
long long unsigned int now;
char __data[0];
};
struct trace_event_raw_tick_stop {
struct trace_entry ent;
int success;
int dependency;
char __data[0];
};
struct trace_event_data_offsets_timer_class {};
struct trace_event_data_offsets_timer_start {};
struct trace_event_data_offsets_timer_expire_entry {};
struct trace_event_data_offsets_hrtimer_init {};
struct trace_event_data_offsets_hrtimer_start {};
struct trace_event_data_offsets_hrtimer_expire_entry {};
struct trace_event_data_offsets_hrtimer_class {};
struct trace_event_data_offsets_itimer_state {};
struct trace_event_data_offsets_itimer_expire {};
struct trace_event_data_offsets_tick_stop {};
typedef void (*btf_trace_timer_init)(void *, struct timer_list *);
typedef void (*btf_trace_timer_start)(void *, struct timer_list *, long unsigned int, unsigned int);
typedef void (*btf_trace_timer_expire_entry)(void *, struct timer_list *, long unsigned int);
typedef void (*btf_trace_timer_expire_exit)(void *, struct timer_list *);
typedef void (*btf_trace_timer_cancel)(void *, struct timer_list *);
typedef void (*btf_trace_hrtimer_init)(void *, struct hrtimer *, clockid_t, enum hrtimer_mode);
typedef void (*btf_trace_hrtimer_start)(void *, struct hrtimer *, enum hrtimer_mode);
typedef void (*btf_trace_hrtimer_expire_entry)(void *, struct hrtimer *, ktime_t *);
typedef void (*btf_trace_hrtimer_expire_exit)(void *, struct hrtimer *);
typedef void (*btf_trace_hrtimer_cancel)(void *, struct hrtimer *);
typedef void (*btf_trace_itimer_state)(void *, int, const struct itimerspec64 * const, long long unsigned int);
typedef void (*btf_trace_itimer_expire)(void *, int, struct pid *, long long unsigned int);
typedef void (*btf_trace_tick_stop)(void *, int, int);
struct timer_base {
raw_spinlock_t lock;
struct timer_list *running_timer;
long unsigned int clk;
long unsigned int next_expiry;
unsigned int cpu;
bool next_expiry_recalc;
bool is_idle;
bool timers_pending;
long unsigned int pending_map[16];
struct hlist_head vectors[512];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct process_timer {
struct timer_list timer;
struct task_struct *task;
};
enum bpf_task_fd_type {
BPF_FD_TYPE_RAW_TRACEPOINT = 0,
BPF_FD_TYPE_TRACEPOINT = 1,
BPF_FD_TYPE_KPROBE = 2,
BPF_FD_TYPE_KRETPROBE = 3,
BPF_FD_TYPE_UPROBE = 4,
BPF_FD_TYPE_URETPROBE = 5,
};
enum uprobe_filter_ctx {
UPROBE_FILTER_REGISTER = 0,
UPROBE_FILTER_UNREGISTER = 1,
UPROBE_FILTER_MMAP = 2,
};
struct uprobe_consumer {
int (*handler)(struct uprobe_consumer *, struct pt_regs *);
int (*ret_handler)(struct uprobe_consumer *, long unsigned int, struct pt_regs *);
bool (*filter)(struct uprobe_consumer *, enum uprobe_filter_ctx, struct mm_struct *);
struct uprobe_consumer *next;
};
struct bpf_trace_run_ctx {
struct bpf_run_ctx run_ctx;
u64 bpf_cookie;
};
typedef u32 (*bpf_prog_run_fn)(const struct bpf_prog *, const void *);
struct dyn_event;
struct dyn_event_operations {
struct list_head list;
int (*create)(const char *);
int (*show)(struct seq_file *, struct dyn_event *);
bool (*is_busy)(struct dyn_event *);
int (*free)(struct dyn_event *);
bool (*match)(const char *, const char *, int, const char **, struct dyn_event *);
};
struct dyn_event {
struct list_head list;
struct dyn_event_operations *ops;
};
typedef int (*print_type_func_t)(struct trace_seq *, void *, void *);
enum fetch_op {
FETCH_OP_NOP = 0,
FETCH_OP_REG = 1,
FETCH_OP_STACK = 2,
FETCH_OP_STACKP = 3,
FETCH_OP_RETVAL = 4,
FETCH_OP_IMM = 5,
FETCH_OP_COMM = 6,
FETCH_OP_ARG = 7,
FETCH_OP_FOFFS = 8,
FETCH_OP_DATA = 9,
FETCH_OP_DEREF = 10,
FETCH_OP_UDEREF = 11,
FETCH_OP_ST_RAW = 12,
FETCH_OP_ST_MEM = 13,
FETCH_OP_ST_UMEM = 14,
FETCH_OP_ST_STRING = 15,
FETCH_OP_ST_USTRING = 16,
FETCH_OP_MOD_BF = 17,
FETCH_OP_LP_ARRAY = 18,
FETCH_OP_TP_ARG = 19,
FETCH_OP_END = 20,
FETCH_NOP_SYMBOL = 21,
};
struct fetch_insn {
enum fetch_op op;
union {
unsigned int param;
struct {
unsigned int size;
int offset;
};
struct {
unsigned char basesize;
unsigned char lshift;
unsigned char rshift;
};
long unsigned int immediate;
void *data;
};
};
struct fetch_type {
const char *name;
size_t size;
int is_signed;
print_type_func_t print;
const char *fmt;
const char *fmttype;
};
struct probe_arg {
struct fetch_insn *code;
bool dynamic;
unsigned int offset;
unsigned int count;
const char *name;
const char *comm;
char *fmt;
const struct fetch_type *type;
};
struct trace_uprobe_filter {
rwlock_t rwlock;
int nr_systemwide;
struct list_head perf_events;
};
struct trace_probe_event {
unsigned int flags;
struct trace_event_class class;
struct trace_event_call call;
struct list_head files;
struct list_head probes;
struct trace_uprobe_filter filter[0];
};
struct trace_probe {
struct list_head list;
struct trace_probe_event *event;
ssize_t size;
unsigned int nr_args;
struct probe_arg args[0];
};
struct event_file_link {
struct trace_event_file *file;
struct list_head list;
};
enum probe_print_type {
PROBE_PRINT_NORMAL = 0,
PROBE_PRINT_RETURN = 1,
PROBE_PRINT_EVENT = 2,
};
enum {
TP_ERR_FILE_NOT_FOUND = 0,
TP_ERR_NO_REGULAR_FILE = 1,
TP_ERR_BAD_REFCNT = 2,
TP_ERR_REFCNT_OPEN_BRACE = 3,
TP_ERR_BAD_REFCNT_SUFFIX = 4,
TP_ERR_BAD_UPROBE_OFFS = 5,
TP_ERR_MAXACT_NO_KPROBE = 6,
TP_ERR_BAD_MAXACT = 7,
TP_ERR_MAXACT_TOO_BIG = 8,
TP_ERR_BAD_PROBE_ADDR = 9,
TP_ERR_BAD_RETPROBE = 10,
TP_ERR_BAD_ADDR_SUFFIX = 11,
TP_ERR_NO_GROUP_NAME = 12,
TP_ERR_GROUP_TOO_LONG = 13,
TP_ERR_BAD_GROUP_NAME = 14,
TP_ERR_NO_EVENT_NAME = 15,
TP_ERR_EVENT_TOO_LONG = 16,
TP_ERR_BAD_EVENT_NAME = 17,
TP_ERR_EVENT_EXIST = 18,
TP_ERR_RETVAL_ON_PROBE = 19,
TP_ERR_BAD_STACK_NUM = 20,
TP_ERR_BAD_ARG_NUM = 21,
TP_ERR_BAD_VAR = 22,
TP_ERR_BAD_REG_NAME = 23,
TP_ERR_BAD_MEM_ADDR = 24,
TP_ERR_BAD_IMM = 25,
TP_ERR_IMMSTR_NO_CLOSE = 26,
TP_ERR_FILE_ON_KPROBE = 27,
TP_ERR_BAD_FILE_OFFS = 28,
TP_ERR_SYM_ON_UPROBE = 29,
TP_ERR_TOO_MANY_OPS = 30,
TP_ERR_DEREF_NEED_BRACE = 31,
TP_ERR_BAD_DEREF_OFFS = 32,
TP_ERR_DEREF_OPEN_BRACE = 33,
TP_ERR_COMM_CANT_DEREF = 34,
TP_ERR_BAD_FETCH_ARG = 35,
TP_ERR_ARRAY_NO_CLOSE = 36,
TP_ERR_BAD_ARRAY_SUFFIX = 37,
TP_ERR_BAD_ARRAY_NUM = 38,
TP_ERR_ARRAY_TOO_BIG = 39,
TP_ERR_BAD_TYPE = 40,
TP_ERR_BAD_STRING = 41,
TP_ERR_BAD_BITFIELD = 42,
TP_ERR_ARG_NAME_TOO_LONG = 43,
TP_ERR_NO_ARG_NAME = 44,
TP_ERR_BAD_ARG_NAME = 45,
TP_ERR_USED_ARG_NAME = 46,
TP_ERR_ARG_TOO_LONG = 47,
TP_ERR_NO_ARG_BODY = 48,
TP_ERR_BAD_INSN_BNDRY = 49,
TP_ERR_FAIL_REG_PROBE = 50,
TP_ERR_DIFF_PROBE_TYPE = 51,
TP_ERR_DIFF_ARG_TYPE = 52,
TP_ERR_SAME_PROBE = 53,
TP_ERR_NO_EVENT_INFO = 54,
TP_ERR_BAD_ATTACH_EVENT = 55,
TP_ERR_BAD_ATTACH_ARG = 56,
TP_ERR_NO_EP_FILTER = 57,
};
struct uprobe_trace_entry_head {
struct trace_entry ent;
long unsigned int vaddr[0];
};
struct trace_uprobe {
struct dyn_event devent;
struct uprobe_consumer consumer;
struct path path;
struct inode *inode;
char *filename;
long unsigned int offset;
long unsigned int ref_ctr_offset;
long unsigned int nhit;
struct trace_probe tp;
};
struct uprobe_dispatch_data {
struct trace_uprobe *tu;
long unsigned int bp_addr;
};
struct uprobe_cpu_buffer {
struct mutex mutex;
void *buf;
};
typedef bool (*filter_func_t)(struct uprobe_consumer *, enum uprobe_filter_ctx, struct mm_struct *);
typedef unsigned int zap_flags_t;
struct zap_details {
struct folio *single_folio;
bool even_cows;
zap_flags_t zap_flags;
};
enum oom_constraint {
CONSTRAINT_NONE = 0,
CONSTRAINT_CPUSET = 1,
CONSTRAINT_MEMORY_POLICY = 2,
CONSTRAINT_MEMCG = 3,
};
struct oom_control {
struct zonelist *zonelist;
nodemask_t *nodemask;
struct mem_cgroup *memcg;
const gfp_t gfp_mask;
const int order;
long unsigned int totalpages;
struct task_struct *chosen;
long int chosen_points;
enum oom_constraint constraint;
};
enum memcg_memory_event {
MEMCG_LOW = 0,
MEMCG_HIGH = 1,
MEMCG_MAX = 2,
MEMCG_OOM = 3,
MEMCG_OOM_KILL = 4,
MEMCG_OOM_GROUP_KILL = 5,
MEMCG_SWAP_HIGH = 6,
MEMCG_SWAP_MAX = 7,
MEMCG_SWAP_FAIL = 8,
MEMCG_NR_MEMORY_EVENTS = 9,
};
struct trace_event_raw_oom_score_adj_update {
struct trace_entry ent;
pid_t pid;
char comm[16];
short int oom_score_adj;
char __data[0];
};
struct trace_event_raw_reclaim_retry_zone {
struct trace_entry ent;
int node;
int zone_idx;
int order;
long unsigned int reclaimable;
long unsigned int available;
long unsigned int min_wmark;
int no_progress_loops;
bool wmark_check;
char __data[0];
};
struct trace_event_raw_mark_victim {
struct trace_entry ent;
int pid;
char __data[0];
};
struct trace_event_raw_wake_reaper {
struct trace_entry ent;
int pid;
char __data[0];
};
struct trace_event_raw_start_task_reaping {
struct trace_entry ent;
int pid;
char __data[0];
};
struct trace_event_raw_finish_task_reaping {
struct trace_entry ent;
int pid;
char __data[0];
};
struct trace_event_raw_skip_task_reaping {
struct trace_entry ent;
int pid;
char __data[0];
};
struct trace_event_raw_compact_retry {
struct trace_entry ent;
int order;
int priority;
int result;
int retries;
int max_retries;
bool ret;
char __data[0];
};
struct trace_event_data_offsets_oom_score_adj_update {};
struct trace_event_data_offsets_reclaim_retry_zone {};
struct trace_event_data_offsets_mark_victim {};
struct trace_event_data_offsets_wake_reaper {};
struct trace_event_data_offsets_start_task_reaping {};
struct trace_event_data_offsets_finish_task_reaping {};
struct trace_event_data_offsets_skip_task_reaping {};
struct trace_event_data_offsets_compact_retry {};
typedef void (*btf_trace_oom_score_adj_update)(void *, struct task_struct *);
typedef void (*btf_trace_reclaim_retry_zone)(void *, struct zoneref *, int, long unsigned int, long unsigned int, long unsigned int, int, bool);
typedef void (*btf_trace_mark_victim)(void *, int);
typedef void (*btf_trace_wake_reaper)(void *, int);
typedef void (*btf_trace_start_task_reaping)(void *, int);
typedef void (*btf_trace_finish_task_reaping)(void *, int);
typedef void (*btf_trace_skip_task_reaping)(void *, int);
typedef void (*btf_trace_compact_retry)(void *, int, enum compact_priority, enum compact_result, int, int, bool);
struct madvise_walk_private {
struct mmu_gather *tlb;
bool pageout;
};
struct posix_acl_xattr_entry {
__le16 e_tag;
__le16 e_perm;
__le32 e_id;
};
struct posix_acl_xattr_header {
__le32 a_version;
};
struct proc_fs_context {
struct pid_namespace *pid_ns;
unsigned int mask;
enum proc_hidepid hidepid;
int gid;
enum proc_pidonly pidonly;
};
enum proc_param {
Opt_gid___2 = 0,
Opt_hidepid = 1,
Opt_subset = 2,
};
struct ext4_fc_tl {
__le16 fc_tag;
__le16 fc_len;
};
struct ext4_fc_head {
__le32 fc_features;
__le32 fc_tid;
};
struct ext4_fc_add_range {
__le32 fc_ino;
__u8 fc_ex[12];
};
struct ext4_fc_del_range {
__le32 fc_ino;
__le32 fc_lblk;
__le32 fc_len;
};
struct ext4_fc_dentry_info {
__le32 fc_parent_ino;
__le32 fc_ino;
__u8 fc_dname[0];
};
struct ext4_fc_inode {
__le32 fc_ino;
__u8 fc_raw_inode[0];
};
struct ext4_fc_tail {
__le32 fc_tid;
__le32 fc_crc;
};
enum {
EXT4_FC_STATUS_OK = 0,
EXT4_FC_STATUS_INELIGIBLE = 1,
EXT4_FC_STATUS_SKIPPED = 2,
EXT4_FC_STATUS_FAILED = 3,
};
struct ext4_fc_dentry_update {
int fcd_op;
int fcd_parent;
int fcd_ino;
long: 32;
struct qstr fcd_name;
unsigned char fcd_iname[36];
struct list_head fcd_list;
struct list_head fcd_dilist;
long: 32;
};
struct ext4_iloc {
struct buffer_head *bh;
long unsigned int offset;
ext4_group_t block_group;
};
struct __track_dentry_update_args {
struct dentry *dentry;
int op;
};
struct __track_range_args {
ext4_lblk_t start;
ext4_lblk_t end;
};
struct dentry_info_args {
int parent_ino;
int dname_len;
int ino;
int inode_len;
char *dname;
};
struct nfs2_fh {
char data[32];
};
struct nfs3_fh {
short unsigned int size;
unsigned char data[64];
};
struct nfs_mount_data {
int version;
int fd;
struct nfs2_fh old_root;
int flags;
int rsize;
int wsize;
int timeo;
int retrans;
int acregmin;
int acregmax;
int acdirmin;
int acdirmax;
struct sockaddr_in addr;
char hostname[256];
int namlen;
unsigned int bsize;
struct nfs3_fh root;
int pseudoflavor;
char context[257];
};
struct nfs_clone_mount {
struct super_block *sb;
struct dentry *dentry;
struct nfs_fattr *fattr;
unsigned int inherited_bsize;
};
struct nfs_fs_context {
bool internal;
bool skip_reconfig_option_check;
bool need_mount;
bool sloppy;
unsigned int flags;
unsigned int rsize;
unsigned int wsize;
unsigned int timeo;
unsigned int retrans;
unsigned int acregmin;
unsigned int acregmax;
unsigned int acdirmin;
unsigned int acdirmax;
unsigned int namlen;
unsigned int options;
unsigned int bsize;
struct nfs_auth_info auth_info;
rpc_authflavor_t selected_flavor;
char *client_address;
unsigned int version;
unsigned int minorversion;
char *fscache_uniq;
short unsigned int protofamily;
short unsigned int mountfamily;
bool has_sec_mnt_opts;
struct {
union {
struct sockaddr address;
struct __kernel_sockaddr_storage _address;
};
size_t addrlen;
char *hostname;
u32 version;
int port;
short unsigned int protocol;
} mount_server;
struct {
union {
struct sockaddr address;
struct __kernel_sockaddr_storage _address;
};
size_t addrlen;
char *hostname;
char *export_path;
int port;
short unsigned int protocol;
short unsigned int nconnect;
short unsigned int max_connect;
short unsigned int export_path_len;
} nfs_server;
struct nfs_fh *mntfh;
struct nfs_server *server;
struct nfs_subversion *nfs_mod;
struct nfs_clone_mount clone_data;
};
enum nfs_param {
Opt_ac = 0,
Opt_acdirmax = 1,
Opt_acdirmin = 2,
Opt_acl___2 = 3,
Opt_acregmax = 4,
Opt_acregmin = 5,
Opt_actimeo = 6,
Opt_addr = 7,
Opt_bg = 8,
Opt_bsize = 9,
Opt_clientaddr = 10,
Opt_cto = 11,
Opt_fg = 12,
Opt_fscache = 13,
Opt_fscache_flag = 14,
Opt_hard = 15,
Opt_intr = 16,
Opt_local_lock = 17,
Opt_lock = 18,
Opt_lookupcache = 19,
Opt_migration = 20,
Opt_minorversion = 21,
Opt_mountaddr = 22,
Opt_mounthost = 23,
Opt_mountport = 24,
Opt_mountproto = 25,
Opt_mountvers = 26,
Opt_namelen = 27,
Opt_nconnect = 28,
Opt_max_connect = 29,
Opt_port = 30,
Opt_posix = 31,
Opt_proto = 32,
Opt_rdirplus = 33,
Opt_rdma = 34,
Opt_resvport = 35,
Opt_retrans = 36,
Opt_retry = 37,
Opt_rsize = 38,
Opt_sec = 39,
Opt_sharecache = 40,
Opt_sloppy = 41,
Opt_soft = 42,
Opt_softerr = 43,
Opt_softreval = 44,
Opt_source = 45,
Opt_tcp = 46,
Opt_timeo = 47,
Opt_trunkdiscovery = 48,
Opt_udp = 49,
Opt_v = 50,
Opt_vers = 51,
Opt_wsize = 52,
Opt_write = 53,
};
enum {
Opt_local_lock_all = 0,
Opt_local_lock_flock = 1,
Opt_local_lock_none = 2,
Opt_local_lock_posix = 3,
};
enum {
Opt_lookupcache_all = 0,
Opt_lookupcache_none = 1,
Opt_lookupcache_positive = 2,
};
enum {
Opt_write_lazy = 0,
Opt_write_eager = 1,
Opt_write_wait = 2,
};
enum {
Opt_vers_2 = 0,
Opt_vers_3 = 1,
Opt_vers_4 = 2,
Opt_vers_4_0 = 3,
Opt_vers_4_1 = 4,
Opt_vers_4_2 = 5,
};
enum {
Opt_xprt_rdma = 0,
Opt_xprt_rdma6 = 1,
Opt_xprt_tcp = 2,
Opt_xprt_tcp6 = 3,
Opt_xprt_udp = 4,
Opt_xprt_udp6 = 5,
nr__Opt_xprt = 6,
};
enum {
Opt_sec_krb5 = 0,
Opt_sec_krb5i = 1,
Opt_sec_krb5p = 2,
Opt_sec_lkey = 3,
Opt_sec_lkeyi = 4,
Opt_sec_lkeyp = 5,
Opt_sec_none = 6,
Opt_sec_spkm = 7,
Opt_sec_spkmi = 8,
Opt_sec_spkmp = 9,
Opt_sec_sys = 10,
nr__Opt_sec = 11,
};
struct lock_manager {
struct list_head list;
bool block_opens;
};
struct cld_net;
struct nfsd4_client_tracking_ops;
struct nfsd_drc_bucket;
struct nfsd_fcache_disposal;
struct nfsd_net {
struct cld_net *cld_net;
struct cache_detail *svc_expkey_cache;
struct cache_detail *svc_export_cache;
struct cache_detail *idtoname_cache;
struct cache_detail *nametoid_cache;
struct lock_manager nfsd4_manager;
bool grace_ended;
long: 32;
time64_t boot_time;
struct dentry *nfsd_client_dir;
struct list_head *reclaim_str_hashtbl;
int reclaim_str_hashtbl_size;
struct list_head *conf_id_hashtbl;
struct rb_root conf_name_tree;
struct list_head *unconf_id_hashtbl;
struct rb_root unconf_name_tree;
struct list_head *sessionid_hashtbl;
struct list_head client_lru;
struct list_head close_lru;
struct list_head del_recall_lru;
struct list_head blocked_locks_lru;
struct delayed_work laundromat_work;
spinlock_t client_lock;
spinlock_t blocked_locks_lock;
struct file *rec_file;
bool in_grace;
const struct nfsd4_client_tracking_ops *client_tracking_ops;
time64_t nfsd4_lease;
time64_t nfsd4_grace;
bool somebody_reclaimed;
bool track_reclaim_completes;
atomic_t nr_reclaim_complete;
bool nfsd_net_up;
bool lockd_up;
seqlock_t writeverf_lock;
unsigned char writeverf[8];
unsigned int max_connections;
u32 clientid_base;
u32 clientid_counter;
u32 clverifier_counter;
struct svc_serv *nfsd_serv;
int keep_active;
u32 s2s_cp_cl_id;
struct idr s2s_cp_stateids;
spinlock_t s2s_cp_lock;
bool *nfsd_versions;
bool *nfsd4_minorversions;
struct nfsd_drc_bucket *drc_hashtbl;
unsigned int max_drc_entries;
unsigned int maskbits;
unsigned int drc_hashsize;
atomic_t num_drc_entries;
long: 32;
struct percpu_counter counter[2];
unsigned int longest_chain;
unsigned int longest_chain_cachesize;
struct shrinker nfsd_reply_cache_shrinker;
spinlock_t nfsd_ssc_lock;
struct list_head nfsd_ssc_mount_list;
wait_queue_head_t nfsd_ssc_waitq;
char nfsd_name[65];
struct nfsd_fcache_disposal *fcache_disposal;
siphash_key_t siphash_key;
atomic_t nfs4_client_count;
int nfs4_max_clients;
atomic_t nfsd_courtesy_clients;
struct shrinker nfsd_client_shrinker;
struct delayed_work nfsd_shrinker_work;
};
struct nfsd_fcache_disposal {
struct work_struct work;
spinlock_t lock;
struct list_head freeme;
};
struct nfsd_file_mark {
struct fsnotify_mark nfm_mark;
refcount_t nfm_ref;
};
struct nfsd_file {
struct rhash_head nf_rhash;
struct list_head nf_lru;
struct callback_head nf_rcu;
struct file *nf_file;
const struct cred *nf_cred;
struct net *nf_net;
long unsigned int nf_flags;
struct inode *nf_inode;
refcount_t nf_ref;
unsigned char nf_may;
struct nfsd_file_mark *nf_mark;
long: 32;
ktime_t nf_birthtime;
};
enum nfsd_file_lookup_type {
NFSD_FILE_KEY_INODE = 0,
NFSD_FILE_KEY_FULL = 1,
};
struct nfsd_file_lookup_key {
struct inode *inode;
struct net *net;
const struct cred *cred;
unsigned char need;
enum nfsd_file_lookup_type type;
};
struct msgbuf;
struct ipc_kludge {
struct msgbuf *msgp;
long int msgtyp;
};
struct unix_address {
refcount_t refcnt;
int len;
struct sockaddr_un name[0];
};
struct scm_stat {
atomic_t nr_fds;
};
struct unix_sock {
struct sock sk;
struct unix_address *addr;
struct path path;
struct mutex iolock;
struct mutex bindlock;
struct sock *peer;
struct list_head link;
atomic_long_t inflight;
spinlock_t lock;
long unsigned int gc_flags;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct socket_wq peer_wq;
wait_queue_entry_t peer_wake;
struct scm_stat scm_stat;
struct sk_buff *oob_skb;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct dccp_hdr {
__be16 dccph_sport;
__be16 dccph_dport;
__u8 dccph_doff;
__u8 dccph_cscov: 4;
__u8 dccph_ccval: 4;
__sum16 dccph_checksum;
__u8 dccph_x: 1;
__u8 dccph_type: 4;
__u8 dccph_reserved: 3;
__u8 dccph_seq2;
__be16 dccph_seq;
};
struct sctphdr {
__be16 source;
__be16 dest;
__be32 vtag;
__le32 checksum;
};
struct lsm_network_audit {
int netif;
const struct sock *sk;
u16 family;
__be16 dport;
__be16 sport;
union {
struct {
__be32 daddr;
__be32 saddr;
} v4;
struct {
struct in6_addr daddr;
struct in6_addr saddr;
} v6;
} fam;
};
struct lsm_ioctlop_audit {
struct path path;
u16 cmd;
};
struct lsm_ibpkey_audit {
u64 subnet_prefix;
u16 pkey;
long: 32;
};
struct lsm_ibendport_audit {
const char *dev_name;
u8 port;
};
struct common_audit_data {
char type;
union {
struct path path;
struct dentry *dentry;
struct inode *inode;
struct lsm_network_audit *net;
int cap;
int ipc_id;
struct task_struct *tsk;
struct {
key_serial_t key;
char *key_desc;
} key_struct;
char *kmod_name;
struct lsm_ioctlop_audit *op;
struct file *file;
struct lsm_ibpkey_audit *ibpkey;
struct lsm_ibendport_audit *ibendport;
int reason;
const char *anonclass;
} u;
union {};
};
struct audit_buffer;
struct audit_context;
struct pr_reservation {
__u64 key;
__u32 type;
__u32 flags;
};
struct pr_registration {
__u64 old_key;
__u64 new_key;
__u32 flags;
__u32 __pad;
};
struct pr_preempt {
__u64 old_key;
__u64 new_key;
__u32 type;
__u32 flags;
};
struct pr_clear {
__u64 key;
__u32 flags;
__u32 __pad;
};
struct xattr_name {
char name[256];
};
struct xattr_ctx {
union {
const void *cvalue;
void *value;
};
void *kvalue;
size_t size;
struct xattr_name *kname;
unsigned int flags;
};
struct io_xattr {
struct file *file;
struct xattr_ctx ctx;
struct filename *filename;
};
typedef uint64_t vli_type;
enum xz_check {
XZ_CHECK_NONE = 0,
XZ_CHECK_CRC32 = 1,
XZ_CHECK_CRC64 = 4,
XZ_CHECK_SHA256 = 10,
};
struct xz_dec_hash {
vli_type unpadded;
vli_type uncompressed;
uint32_t crc32;
long: 32;
};
struct xz_dec_lzma2;
struct xz_dec_bcj;
struct xz_dec {
enum {
SEQ_STREAM_HEADER = 0,
SEQ_BLOCK_START = 1,
SEQ_BLOCK_HEADER = 2,
SEQ_BLOCK_UNCOMPRESS = 3,
SEQ_BLOCK_PADDING = 4,
SEQ_BLOCK_CHECK = 5,
SEQ_INDEX = 6,
SEQ_INDEX_PADDING = 7,
SEQ_INDEX_CRC32 = 8,
SEQ_STREAM_FOOTER = 9,
} sequence;
uint32_t pos;
vli_type vli;
size_t in_start;
size_t out_start;
uint32_t crc32;
enum xz_check check_type;
enum xz_mode mode;
bool allow_buf_error;
struct {
vli_type compressed;
vli_type uncompressed;
uint32_t size;
long: 32;
} block_header;
struct {
vli_type compressed;
vli_type uncompressed;
vli_type count;
struct xz_dec_hash hash;
} block;
struct {
enum {
SEQ_INDEX_COUNT = 0,
SEQ_INDEX_UNPADDED = 1,
SEQ_INDEX_UNCOMPRESSED = 2,
} sequence;
long: 32;
vli_type size;
vli_type count;
struct xz_dec_hash hash;
} index;
struct {
size_t pos;
size_t size;
uint8_t buf[1024];
} temp;
struct xz_dec_lzma2 *lzma2;
struct xz_dec_bcj *bcj;
bool bcj_active;
long: 32;
};
struct nla_bitfield32 {
__u32 value;
__u32 selector;
};
enum spec_op {
sll_op = 0,
movc_op = 1,
srl_op = 2,
sra_op = 3,
sllv_op = 4,
pmon_op = 5,
srlv_op = 6,
srav_op = 7,
jr_op = 8,
jalr_op = 9,
movz_op = 10,
movn_op = 11,
syscall_op = 12,
break_op = 13,
spim_op = 14,
sync_op = 15,
mfhi_op = 16,
mthi_op = 17,
mflo_op = 18,
mtlo_op = 19,
dsllv_op = 20,
spec2_unused_op = 21,
dsrlv_op = 22,
dsrav_op = 23,
mult_op = 24,
multu_op = 25,
div_op = 26,
divu_op = 27,
dmult_op = 28,
dmultu_op = 29,
ddiv_op = 30,
ddivu_op = 31,
add_op = 32,
addu_op = 33,
sub_op = 34,
subu_op = 35,
and_op = 36,
or_op = 37,
xor_op = 38,
nor_op = 39,
spec3_unused_op = 40,
spec4_unused_op = 41,
slt_op = 42,
sltu_op = 43,
dadd_op = 44,
daddu_op = 45,
dsub_op = 46,
dsubu_op = 47,
tge_op = 48,
tgeu_op = 49,
tlt_op = 50,
tltu_op = 51,
teq_op = 52,
seleqz_op = 53,
tne_op = 54,
selnez_op = 55,
dsll_op = 56,
spec5_unused_op = 57,
dsrl_op = 58,
dsra_op = 59,
dsll32_op = 60,
spec6_unused_op = 61,
dsrl32_op = 62,
dsra32_op = 63,
};
enum rt_op {
bltz_op = 0,
bgez_op = 1,
bltzl_op = 2,
bgezl_op = 3,
spimi_op = 4,
unused_rt_op_0x05 = 5,
unused_rt_op_0x06 = 6,
unused_rt_op_0x07 = 7,
tgei_op = 8,
tgeiu_op = 9,
tlti_op = 10,
tltiu_op = 11,
teqi_op = 12,
unused_0x0d_rt_op = 13,
tnei_op = 14,
unused_0x0f_rt_op = 15,
bltzal_op = 16,
bgezal_op = 17,
bltzall_op = 18,
bgezall_op = 19,
rt_op_0x14 = 20,
rt_op_0x15 = 21,
rt_op_0x16 = 22,
rt_op_0x17 = 23,
rt_op_0x18 = 24,
rt_op_0x19 = 25,
rt_op_0x1a = 26,
rt_op_0x1b = 27,
bposge32_op = 28,
rt_op_0x1d = 29,
rt_op_0x1e = 30,
synci_op = 31,
};
enum cop_op {
mfc_op = 0,
dmfc_op = 1,
cfc_op = 2,
mfhc0_op = 2,
mfhc_op = 3,
mtc_op = 4,
dmtc_op = 5,
ctc_op = 6,
mthc0_op = 6,
mthc_op = 7,
bc_op = 8,
bc1eqz_op = 9,
mfmc0_op = 11,
bc1nez_op = 13,
wrpgpr_op = 14,
cop_op = 16,
copm_op = 24,
};
enum bcop_op {
bcf_op = 0,
bct_op = 1,
bcfl_op = 2,
bctl_op = 3,
};
enum cop1_fmt {
s_fmt = 0,
d_fmt = 1,
e_fmt = 2,
q_fmt = 3,
w_fmt = 4,
l_fmt = 5,
};
enum cop1_sdw_func {
fadd_op = 0,
fsub_op = 1,
fmul_op = 2,
fdiv_op = 3,
fsqrt_op = 4,
fabs_op = 5,
fmov_op = 6,
fneg_op = 7,
froundl_op = 8,
ftruncl_op = 9,
fceill_op = 10,
ffloorl_op = 11,
fround_op = 12,
ftrunc_op = 13,
fceil_op = 14,
ffloor_op = 15,
fsel_op = 16,
fmovc_op = 17,
fmovz_op = 18,
fmovn_op = 19,
fseleqz_op = 20,
frecip_op = 21,
frsqrt_op = 22,
fselnez_op = 23,
fmaddf_op = 24,
fmsubf_op = 25,
frint_op = 26,
fclass_op = 27,
fmin_op = 28,
fmina_op = 29,
fmax_op = 30,
fmaxa_op = 31,
fcvts_op = 32,
fcvtd_op = 33,
fcvte_op = 34,
fcvtw_op = 36,
fcvtl_op = 37,
fcmp_op = 48,
};
enum cop1x_func {
lwxc1_op = 0,
ldxc1_op = 1,
swxc1_op = 8,
sdxc1_op = 9,
pfetch_op = 15,
madd_s_op = 32,
madd_d_op = 33,
madd_e_op = 34,
msub_s_op = 40,
msub_d_op = 41,
msub_e_op = 42,
nmadd_s_op = 48,
nmadd_d_op = 49,
nmadd_e_op = 50,
nmsub_s_op = 56,
nmsub_d_op = 57,
nmsub_e_op = 58,
};
enum mm_32i_minor_op {
mm_bltz_op = 0,
mm_bltzal_op = 1,
mm_bgez_op = 2,
mm_bgezal_op = 3,
mm_blez_op = 4,
mm_bnezc_op = 5,
mm_bgtz_op = 6,
mm_beqzc_op = 7,
mm_tlti_op = 8,
mm_tgei_op = 9,
mm_tltiu_op = 10,
mm_tgeiu_op = 11,
mm_tnei_op = 12,
mm_lui_op = 13,
mm_teqi_op = 14,
mm_reserved13_op = 15,
mm_synci_op = 16,
mm_bltzals_op = 17,
mm_reserved14_op = 18,
mm_bgezals_op = 19,
mm_bc2f_op = 20,
mm_bc2t_op = 21,
mm_reserved15_op = 22,
mm_reserved16_op = 23,
mm_reserved17_op = 24,
mm_reserved18_op = 25,
mm_bposge64_op = 26,
mm_bposge32_op = 27,
mm_bc1f_op = 28,
mm_bc1t_op = 29,
mm_reserved19_op = 30,
mm_reserved20_op = 31,
mm_bc1any2f_op = 32,
mm_bc1any2t_op = 33,
mm_bc1any4f_op = 34,
mm_bc1any4t_op = 35,
};
enum mm_32f_minor_op {
mm_32f_00_op = 0,
mm_32f_01_op = 1,
mm_32f_02_op = 2,
mm_32f_10_op = 8,
mm_32f_11_op = 9,
mm_32f_12_op = 10,
mm_32f_20_op = 16,
mm_32f_30_op = 24,
mm_32f_40_op = 32,
mm_32f_41_op = 33,
mm_32f_42_op = 34,
mm_32f_50_op = 40,
mm_32f_51_op = 41,
mm_32f_52_op = 42,
mm_32f_60_op = 48,
mm_32f_70_op = 56,
mm_32f_73_op = 59,
mm_32f_74_op = 60,
};
enum mm_32f_10_minor_op {
mm_lwxc1_op = 1,
mm_swxc1_op = 2,
mm_ldxc1_op = 3,
mm_sdxc1_op = 4,
mm_luxc1_op = 5,
mm_suxc1_op = 6,
};
enum mm_32f_40_minor_op {
mm_fmovf_op = 0,
mm_fmovt_op = 1,
};
enum mm_32f_60_minor_op {
mm_fadd_op = 0,
mm_fsub_op = 1,
mm_fmul_op = 2,
mm_fdiv_op = 3,
};
enum mm_32f_70_minor_op {
mm_fmovn_op = 0,
mm_fmovz_op = 1,
};
enum mm_32f_73_minor_op {
mm_fmov0_op = 1,
mm_fcvtl_op = 4,
mm_movf0_op = 5,
mm_frsqrt_op = 8,
mm_ffloorl_op = 12,
mm_fabs0_op = 13,
mm_fcvtw_op = 36,
mm_movt0_op = 37,
mm_fsqrt_op = 40,
mm_ffloorw_op = 44,
mm_fneg0_op = 45,
mm_cfc1_op = 64,
mm_frecip_op = 72,
mm_fceill_op = 76,
mm_fcvtd0_op = 77,
mm_ctc1_op = 96,
mm_fceilw_op = 108,
mm_fcvts0_op = 109,
mm_mfc1_op = 128,
mm_fmov1_op = 129,
mm_movf1_op = 133,
mm_ftruncl_op = 140,
mm_fabs1_op = 141,
mm_mtc1_op = 160,
mm_movt1_op = 165,
mm_ftruncw_op = 172,
mm_fneg1_op = 173,
mm_mfhc1_op = 192,
mm_froundl_op = 204,
mm_fcvtd1_op = 205,
mm_mthc1_op = 224,
mm_froundw_op = 236,
mm_fcvts1_op = 237,
};
struct mm_decoded_insn {
mips_instruction insn;
mips_instruction next_insn;
int pc_inc;
int next_pc_inc;
int micro_mips_mode;
};
typedef void (*of_init_fn_1)(struct device_node *);
struct clk_fixed_rate {
struct clk_hw hw;
long unsigned int fixed_rate;
long unsigned int fixed_accuracy;
long unsigned int flags;
};
struct uni_pagedict {
u16 **uni_pgdir[32];
long unsigned int refcount;
long unsigned int sum;
unsigned char *inverse_translations[4];
u16 *inverse_trans_unicode;
};
struct class_dev_iter {
struct klist_iter ki;
const struct device_type *type;
};
struct class_attribute {
struct attribute attr;
ssize_t (*show)(struct class *, struct class_attribute *, char *);
ssize_t (*store)(struct class *, struct class_attribute *, const char *, size_t);
};
struct class_attribute_string {
struct class_attribute attr;
char *str;
};
struct class_compat {
struct kobject *kobj;
};
struct regcache_rbtree_node {
void *block;
long int *cache_present;
unsigned int base_reg;
unsigned int blklen;
struct rb_node node;
};
struct regcache_rbtree_ctx {
struct rb_root root;
struct regcache_rbtree_node *cached_rbnode;
};
struct ata_bmdma_prd {
__le32 addr;
__le32 flags_len;
};
enum ata_lpm_policy {
ATA_LPM_UNKNOWN = 0,
ATA_LPM_MAX_POWER = 1,
ATA_LPM_MED_POWER = 2,
ATA_LPM_MED_POWER_WITH_DIPM = 3,
ATA_LPM_MIN_POWER_WITH_PARTIAL = 4,
ATA_LPM_MIN_POWER = 5,
};
struct ata_queued_cmd;
typedef void (*ata_qc_cb_t)(struct ata_queued_cmd *);
struct ata_taskfile {
long unsigned int flags;
u8 protocol;
u8 ctl;
u8 hob_feature;
u8 hob_nsect;
u8 hob_lbal;
u8 hob_lbam;
u8 hob_lbah;
union {
u8 error;
u8 feature;
};
u8 nsect;
u8 lbal;
u8 lbam;
u8 lbah;
u8 device;
union {
u8 status;
u8 command;
};
u32 auxiliary;
};
struct ata_port;
struct ata_device;
struct ata_queued_cmd {
struct ata_port *ap;
struct ata_device *dev;
struct scsi_cmnd *scsicmd;
void (*scsidone)(struct scsi_cmnd *);
struct ata_taskfile tf;
u8 cdb[16];
long unsigned int flags;
unsigned int tag;
unsigned int hw_tag;
unsigned int n_elem;
unsigned int orig_n_elem;
int dma_dir;
unsigned int sect_size;
unsigned int nbytes;
unsigned int extrabytes;
unsigned int curbytes;
struct scatterlist sgent;
struct scatterlist *sg;
struct scatterlist *cursg;
unsigned int cursg_ofs;
unsigned int err_mask;
struct ata_taskfile result_tf;
ata_qc_cb_t complete_fn;
void *private_data;
void *lldd_task;
};
struct ata_link;
typedef int (*ata_prereset_fn_t)(struct ata_link *, long unsigned int);
struct ata_eh_info {
struct ata_device *dev;
u32 serror;
unsigned int err_mask;
unsigned int action;
unsigned int dev_action[2];
unsigned int flags;
unsigned int probe_mask;
char desc[80];
int desc_len;
};
struct ata_eh_context {
struct ata_eh_info i;
int tries[2];
int cmd_timeout_idx[14];
unsigned int classes[2];
unsigned int did_probe_mask;
unsigned int unloaded_mask;
unsigned int saved_ncq_enabled;
u8 saved_xfer_mode[2];
long unsigned int last_reset;
};
struct ata_ering_entry {
unsigned int eflags;
unsigned int err_mask;
u64 timestamp;
};
struct ata_ering {
int cursor;
long: 32;
struct ata_ering_entry ring[32];
};
struct ata_cpr_log;
struct ata_device {
struct ata_link *link;
unsigned int devno;
unsigned int horkage;
long unsigned int flags;
struct scsi_device *sdev;
void *private_data;
struct device tdev;
u64 n_sectors;
u64 n_native_sectors;
unsigned int class;
long unsigned int unpark_deadline;
u8 pio_mode;
u8 dma_mode;
u8 xfer_mode;
unsigned int xfer_shift;
unsigned int multi_count;
unsigned int max_sectors;
unsigned int cdb_len;
unsigned int pio_mask;
unsigned int mwdma_mask;
unsigned int udma_mask;
u16 cylinders;
u16 heads;
u16 sectors;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
union {
u16 id[256];
u32 gscr[128];
};
u8 devslp_timing[8];
u8 ncq_send_recv_cmds[20];
u8 ncq_non_data_cmds[64];
u32 zac_zoned_cap;
u32 zac_zones_optimal_open;
u32 zac_zones_optimal_nonseq;
u32 zac_zones_max_open;
struct ata_cpr_log *cpr_log;
int spdn_cnt;
long: 32;
struct ata_ering ering;
};
struct ata_link {
struct ata_port *ap;
int pmp;
struct device tdev;
unsigned int active_tag;
u32 sactive;
unsigned int flags;
u32 saved_scontrol;
unsigned int hw_sata_spd_limit;
unsigned int sata_spd_limit;
unsigned int sata_spd;
enum ata_lpm_policy lpm_policy;
struct ata_eh_info eh_info;
struct ata_eh_context eh_context;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct ata_device device[2];
long unsigned int last_lpm_change;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef int (*ata_reset_fn_t)(struct ata_link *, unsigned int *, long unsigned int);
typedef void (*ata_postreset_fn_t)(struct ata_link *, unsigned int *);
enum sw_activity {
OFF = 0,
BLINK_ON = 1,
BLINK_OFF = 2,
};
struct ata_ioports {
void *cmd_addr;
void *data_addr;
void *error_addr;
void *feature_addr;
void *nsect_addr;
void *lbal_addr;
void *lbam_addr;
void *lbah_addr;
void *device_addr;
void *status_addr;
void *command_addr;
void *altstatus_addr;
void *ctl_addr;
void *bmdma_addr;
void *scr_addr;
};
struct ata_port_operations;
struct ata_host {
spinlock_t lock;
struct device *dev;
void * const *iomap;
unsigned int n_ports;
unsigned int n_tags;
void *private_data;
struct ata_port_operations *ops;
long unsigned int flags;
struct kref kref;
struct mutex eh_mutex;
struct task_struct *eh_owner;
struct ata_port *simplex_claimed;
struct ata_port *ports[0];
};
struct ata_port_operations {
int (*qc_defer)(struct ata_queued_cmd *);
int (*check_atapi_dma)(struct ata_queued_cmd *);
enum ata_completion_errors (*qc_prep)(struct ata_queued_cmd *);
unsigned int (*qc_issue)(struct ata_queued_cmd *);
bool (*qc_fill_rtf)(struct ata_queued_cmd *);
int (*cable_detect)(struct ata_port *);
unsigned int (*mode_filter)(struct ata_device *, unsigned int);
void (*set_piomode)(struct ata_port *, struct ata_device *);
void (*set_dmamode)(struct ata_port *, struct ata_device *);
int (*set_mode)(struct ata_link *, struct ata_device **);
unsigned int (*read_id)(struct ata_device *, struct ata_taskfile *, __le16 *);
void (*dev_config)(struct ata_device *);
void (*freeze)(struct ata_port *);
void (*thaw)(struct ata_port *);
ata_prereset_fn_t prereset;
ata_reset_fn_t softreset;
ata_reset_fn_t hardreset;
ata_postreset_fn_t postreset;
ata_prereset_fn_t pmp_prereset;
ata_reset_fn_t pmp_softreset;
ata_reset_fn_t pmp_hardreset;
ata_postreset_fn_t pmp_postreset;
void (*error_handler)(struct ata_port *);
void (*lost_interrupt)(struct ata_port *);
void (*post_internal_cmd)(struct ata_queued_cmd *);
void (*sched_eh)(struct ata_port *);
void (*end_eh)(struct ata_port *);
int (*scr_read)(struct ata_link *, unsigned int, u32 *);
int (*scr_write)(struct ata_link *, unsigned int, u32);
void (*pmp_attach)(struct ata_port *);
void (*pmp_detach)(struct ata_port *);
int (*set_lpm)(struct ata_link *, enum ata_lpm_policy, unsigned int);
int (*port_suspend)(struct ata_port *, pm_message_t);
int (*port_resume)(struct ata_port *);
int (*port_start)(struct ata_port *);
void (*port_stop)(struct ata_port *);
void (*host_stop)(struct ata_host *);
void (*sff_dev_select)(struct ata_port *, unsigned int);
void (*sff_set_devctl)(struct ata_port *, u8);
u8 (*sff_check_status)(struct ata_port *);
u8 (*sff_check_altstatus)(struct ata_port *);
void (*sff_tf_load)(struct ata_port *, const struct ata_taskfile *);
void (*sff_tf_read)(struct ata_port *, struct ata_taskfile *);
void (*sff_exec_command)(struct ata_port *, const struct ata_taskfile *);
unsigned int (*sff_data_xfer)(struct ata_queued_cmd *, unsigned char *, unsigned int, int);
void (*sff_irq_on)(struct ata_port *);
bool (*sff_irq_check)(struct ata_port *);
void (*sff_irq_clear)(struct ata_port *);
void (*sff_drain_fifo)(struct ata_queued_cmd *);
void (*bmdma_setup)(struct ata_queued_cmd *);
void (*bmdma_start)(struct ata_queued_cmd *);
void (*bmdma_stop)(struct ata_queued_cmd *);
u8 (*bmdma_status)(struct ata_port *);
ssize_t (*em_show)(struct ata_port *, char *);
ssize_t (*em_store)(struct ata_port *, const char *, size_t);
ssize_t (*sw_activity_show)(struct ata_device *, char *);
ssize_t (*sw_activity_store)(struct ata_device *, enum sw_activity);
ssize_t (*transmit_led_message)(struct ata_port *, u32, ssize_t);
void (*phy_reset)(struct ata_port *);
void (*eng_timeout)(struct ata_port *);
const struct ata_port_operations *inherits;
};
struct ata_port_stats {
long unsigned int unhandled_irq;
long unsigned int idle_irq;
long unsigned int rw_reqbuf;
};
struct ata_port {
struct Scsi_Host *scsi_host;
struct ata_port_operations *ops;
spinlock_t *lock;
long unsigned int flags;
unsigned int pflags;
unsigned int print_id;
unsigned int local_port_no;
unsigned int port_no;
struct ata_ioports ioaddr;
u8 ctl;
u8 last_ctl;
struct ata_link *sff_pio_task_link;
struct delayed_work sff_pio_task;
struct ata_bmdma_prd *bmdma_prd;
dma_addr_t bmdma_prd_dma;
unsigned int pio_mask;
unsigned int mwdma_mask;
unsigned int udma_mask;
unsigned int cbl;
struct ata_queued_cmd qcmd[33];
long: 32;
u64 qc_active;
int nr_active_links;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct ata_link link;
struct ata_link *slave_link;
int nr_pmp_links;
struct ata_link *pmp_link;
struct ata_link *excl_link;
struct ata_port_stats stats;
struct ata_host *host;
struct device *dev;
long: 32;
struct device tdev;
struct mutex scsi_scan_mutex;
struct delayed_work hotplug_task;
struct work_struct scsi_rescan_task;
unsigned int hsm_task_state;
struct list_head eh_done_q;
wait_queue_head_t eh_wait_q;
int eh_tries;
struct completion park_req_pending;
pm_message_t pm_mesg;
enum ata_lpm_policy target_lpm_policy;
struct timer_list fastdrain_timer;
unsigned int fastdrain_cnt;
async_cookie_t cookie;
int em_message_type;
void *private_data;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
u8 sector_buf[512];
};
struct ata_cpr {
u8 num;
u8 num_storage_elements;
long: 32;
u64 start_lba;
u64 num_lbas;
};
struct ata_cpr_log {
u8 nr_cpr;
long: 32;
struct ata_cpr cpr[0];
};
struct ata_timing {
short unsigned int mode;
short unsigned int setup;
short unsigned int act8b;
short unsigned int rec8b;
short unsigned int cyc8b;
short unsigned int active;
short unsigned int recover;
short unsigned int dmack_hold;
short unsigned int cycle;
short unsigned int udma;
};
union ixgbe_adv_rx_desc {
struct {
__le64 pkt_addr;
__le64 hdr_addr;
} read;
struct {
struct {
union {
__le32 data;
struct {
__le16 pkt_info;
__le16 hdr_info;
} hs_rss;
} lo_dword;
union {
__le32 rss;
struct {
__le16 ip_id;
__le16 csum;
} csum_ip;
} hi_dword;
} lower;
struct {
__le32 status_error;
__le16 length;
__le16 vlan;
} upper;
} wb;
};
enum ixgbe_ring_state_t {
__IXGBE_RX_3K_BUFFER = 0,
__IXGBE_RX_BUILD_SKB_ENABLED = 1,
__IXGBE_RX_RSC_ENABLED = 2,
__IXGBE_RX_CSUM_UDP_ZERO_ERR = 3,
__IXGBE_RX_FCOE = 4,
__IXGBE_TX_FDIR_INIT_DONE = 5,
__IXGBE_TX_XPS_INIT_DONE = 6,
__IXGBE_TX_DETECT_HANG = 7,
__IXGBE_HANG_CHECK_ARMED = 8,
__IXGBE_TX_XDP_RING = 9,
__IXGBE_TX_DISABLED = 10,
};
struct ixgbe_fdir_filter {
struct hlist_node fdir_node;
union ixgbe_atr_input filter;
u16 sw_idx;
u64 action;
};
enum {
NETDEV_STATS = 0,
IXGBE_STATS = 1,
};
struct ixgbe_stats {
char stat_string[32];
int type;
int sizeof_stat;
int stat_offset;
};
struct ixgbe_reg_test {
u16 reg;
u8 array_len;
u8 test_type;
u32 mask;
u32 write;
};
struct mc146818_get_time_callback_param {
struct rtc_time *time;
unsigned char ctrl;
};
typedef int (*of_init_fn_1_ret)(struct device_node *);
struct __kernel_old_timespec {
__kernel_old_time_t tv_sec;
long int tv_nsec;
};
struct __kernel_sock_timeval {
__s64 tv_sec;
__s64 tv_usec;
};
struct mmsghdr {
struct user_msghdr msg_hdr;
unsigned int msg_len;
};
struct scm_timestamping_internal {
struct timespec64 ts[3];
};
struct net_proto_family {
int family;
int (*create)(struct net *, struct socket *, int, int);
struct module *owner;
};
enum {
SOCK_WAKE_IO = 0,
SOCK_WAKE_WAITD = 1,
SOCK_WAKE_SPACE = 2,
SOCK_WAKE_URG = 3,
};
struct ifconf {
int ifc_len;
union {
char *ifcu_buf;
struct ifreq *ifcu_req;
} ifc_ifcu;
};
struct libipw_device;
struct iw_spy_data;
struct iw_public_data {
struct iw_spy_data *spy_data;
struct libipw_device *libipw;
};
struct scm_ts_pktinfo {
__u32 if_index;
__u32 pkt_length;
__u32 reserved[2];
};
struct socket_alloc {
struct socket socket;
struct inode vfs_inode;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct sock_skb_cb {
u32 dropcount;
};
typedef u32 compat_ulong_t;
typedef u32 compat_caddr_t;
struct compat_ifmap {
compat_ulong_t mem_start;
compat_ulong_t mem_end;
short unsigned int base_addr;
unsigned char irq;
unsigned char dma;
unsigned char port;
};
struct compat_if_settings {
unsigned int type;
unsigned int size;
compat_uptr_t ifs_ifsu;
};
struct compat_ifreq {
union {
char ifrn_name[16];
} ifr_ifrn;
union {
struct sockaddr ifru_addr;
struct sockaddr ifru_dstaddr;
struct sockaddr ifru_broadaddr;
struct sockaddr ifru_netmask;
struct sockaddr ifru_hwaddr;
short int ifru_flags;
compat_int_t ifru_ivalue;
compat_int_t ifru_mtu;
struct compat_ifmap ifru_map;
char ifru_slave[16];
char ifru_newname[16];
compat_caddr_t ifru_data;
struct compat_if_settings ifru_settings;
} ifr_ifru;
};
struct iw_param {
__s32 value;
__u8 fixed;
__u8 disabled;
__u16 flags;
};
struct iw_point {
void *pointer;
__u16 length;
__u16 flags;
};
struct iw_freq {
__s32 m;
__s16 e;
__u8 i;
__u8 flags;
};
struct iw_quality {
__u8 qual;
__u8 level;
__u8 noise;
__u8 updated;
};
struct iw_discarded {
__u32 nwid;
__u32 code;
__u32 fragment;
__u32 retries;
__u32 misc;
};
struct iw_missed {
__u32 beacon;
};
struct iw_statistics {
__u16 status;
struct iw_quality qual;
struct iw_discarded discard;
struct iw_missed miss;
};
union iwreq_data {
char name[16];
struct iw_point essid;
struct iw_param nwid;
struct iw_freq freq;
struct iw_param sens;
struct iw_param bitrate;
struct iw_param txpower;
struct iw_param rts;
struct iw_param frag;
__u32 mode;
struct iw_param retry;
struct iw_point encoding;
struct iw_param power;
struct iw_quality qual;
struct sockaddr ap_addr;
struct sockaddr addr;
struct iw_param param;
struct iw_point data;
};
struct iw_priv_args {
__u32 cmd;
__u16 set_args;
__u16 get_args;
char name[16];
};
struct compat_mmsghdr {
struct compat_msghdr msg_hdr;
compat_uint_t msg_len;
};
struct iw_request_info {
__u16 cmd;
__u16 flags;
};
struct iw_spy_data {
int spy_number;
u_char spy_address[48];
struct iw_quality spy_stat[8];
struct iw_quality spy_thr_low;
struct iw_quality spy_thr_high;
u_char spy_thr_under[8];
};
struct sock_ee_data_rfc4884 {
__u16 len;
__u8 flags;
__u8 reserved;
};
struct sock_extended_err {
__u32 ee_errno;
__u8 ee_origin;
__u8 ee_type;
__u8 ee_code;
__u8 ee_pad;
__u32 ee_info;
union {
__u32 ee_data;
struct sock_ee_data_rfc4884 ee_rfc4884;
};
};
struct sock_exterr_skb {
union {
struct inet_skb_parm h4;
struct inet6_skb_parm h6;
} header;
struct sock_extended_err ee;
u16 addr_offset;
__be16 port;
u8 opt_stats: 1;
u8 unused: 7;
};
struct used_address {
struct __kernel_sockaddr_storage name;
unsigned int name_len;
};
struct tc_qopt_offload_stats {
struct gnet_stats_basic_sync *bstats;
struct gnet_stats_queue *qstats;
};
enum tc_mq_command {
TC_MQ_CREATE = 0,
TC_MQ_DESTROY = 1,
TC_MQ_STATS = 2,
TC_MQ_GRAFT = 3,
};
struct tc_mq_opt_offload_graft_params {
long unsigned int queue;
u32 child_handle;
};
struct tc_mq_qopt_offload {
enum tc_mq_command command;
u32 handle;
union {
struct tc_qopt_offload_stats stats;
struct tc_mq_opt_offload_graft_params graft_params;
};
};
struct mq_sched {
struct Qdisc **qdiscs;
};
enum tca_id {
TCA_ID_UNSPEC = 0,
TCA_ID_POLICE = 1,
TCA_ID_GACT = 5,
TCA_ID_IPT = 6,
TCA_ID_PEDIT = 7,
TCA_ID_MIRRED = 8,
TCA_ID_NAT = 9,
TCA_ID_XT = 10,
TCA_ID_SKBEDIT = 11,
TCA_ID_VLAN = 12,
TCA_ID_BPF = 13,
TCA_ID_CONNMARK = 14,
TCA_ID_SKBMOD = 15,
TCA_ID_CSUM = 16,
TCA_ID_TUNNEL_KEY = 17,
TCA_ID_SIMP = 22,
TCA_ID_IFE = 25,
TCA_ID_SAMPLE = 26,
TCA_ID_CTINFO = 27,
TCA_ID_MPLS = 28,
TCA_ID_CT = 29,
TCA_ID_GATE = 30,
__TCA_ID_MAX = 255,
};
struct tc_police {
__u32 index;
int action;
__u32 limit;
__u32 burst;
__u32 mtu;
struct tc_ratespec rate;
struct tc_ratespec peakrate;
int refcnt;
int bindcnt;
__u32 capab;
};
struct tcf_t {
__u64 install;
__u64 lastuse;
__u64 expires;
__u64 firstuse;
};
enum {
TCA_POLICE_UNSPEC = 0,
TCA_POLICE_TBF = 1,
TCA_POLICE_RATE = 2,
TCA_POLICE_PEAKRATE = 3,
TCA_POLICE_AVRATE = 4,
TCA_POLICE_RESULT = 5,
TCA_POLICE_TM = 6,
TCA_POLICE_PAD = 7,
TCA_POLICE_RATE64 = 8,
TCA_POLICE_PEAKRATE64 = 9,
TCA_POLICE_PKTRATE64 = 10,
TCA_POLICE_PKTBURST64 = 11,
__TCA_POLICE_MAX = 12,
};
enum flow_action_id {
FLOW_ACTION_ACCEPT = 0,
FLOW_ACTION_DROP = 1,
FLOW_ACTION_TRAP = 2,
FLOW_ACTION_GOTO = 3,
FLOW_ACTION_REDIRECT = 4,
FLOW_ACTION_MIRRED = 5,
FLOW_ACTION_REDIRECT_INGRESS = 6,
FLOW_ACTION_MIRRED_INGRESS = 7,
FLOW_ACTION_VLAN_PUSH = 8,
FLOW_ACTION_VLAN_POP = 9,
FLOW_ACTION_VLAN_MANGLE = 10,
FLOW_ACTION_TUNNEL_ENCAP = 11,
FLOW_ACTION_TUNNEL_DECAP = 12,
FLOW_ACTION_MANGLE = 13,
FLOW_ACTION_ADD = 14,
FLOW_ACTION_CSUM = 15,
FLOW_ACTION_MARK = 16,
FLOW_ACTION_PTYPE = 17,
FLOW_ACTION_PRIORITY = 18,
FLOW_ACTION_WAKE = 19,
FLOW_ACTION_QUEUE = 20,
FLOW_ACTION_SAMPLE = 21,
FLOW_ACTION_POLICE = 22,
FLOW_ACTION_CT = 23,
FLOW_ACTION_CT_METADATA = 24,
FLOW_ACTION_MPLS_PUSH = 25,
FLOW_ACTION_MPLS_POP = 26,
FLOW_ACTION_MPLS_MANGLE = 27,
FLOW_ACTION_GATE = 28,
FLOW_ACTION_PPPOE_PUSH = 29,
FLOW_ACTION_JUMP = 30,
FLOW_ACTION_PIPE = 31,
FLOW_ACTION_VLAN_PUSH_ETH = 32,
FLOW_ACTION_VLAN_POP_ETH = 33,
FLOW_ACTION_CONTINUE = 34,
NUM_FLOW_ACTIONS = 35,
};
enum flow_action_mangle_base {
FLOW_ACT_MANGLE_UNSPEC = 0,
FLOW_ACT_MANGLE_HDR_TYPE_ETH = 1,
FLOW_ACT_MANGLE_HDR_TYPE_IP4 = 2,
FLOW_ACT_MANGLE_HDR_TYPE_IP6 = 3,
FLOW_ACT_MANGLE_HDR_TYPE_TCP = 4,
FLOW_ACT_MANGLE_HDR_TYPE_UDP = 5,
};
enum flow_action_hw_stats {
FLOW_ACTION_HW_STATS_IMMEDIATE = 1,
FLOW_ACTION_HW_STATS_DELAYED = 2,
FLOW_ACTION_HW_STATS_ANY = 3,
FLOW_ACTION_HW_STATS_DISABLED = 4,
FLOW_ACTION_HW_STATS_DONT_CARE = 7,
};
typedef void (*action_destr)(void *);
struct flow_action_cookie {
u32 cookie_len;
u8 cookie[0];
};
struct nf_flowtable;
struct psample_group;
struct action_gate_entry;
struct flow_action_entry {
enum flow_action_id id;
u32 hw_index;
enum flow_action_hw_stats hw_stats;
action_destr destructor;
void *destructor_priv;
long: 32;
union {
u32 chain_index;
struct net_device *dev;
struct {
u16 vid;
__be16 proto;
u8 prio;
} vlan;
struct {
unsigned char dst[6];
unsigned char src[6];
} vlan_push_eth;
struct {
enum flow_action_mangle_base htype;
u32 offset;
u32 mask;
u32 val;
} mangle;
struct ip_tunnel_info *tunnel;
u32 csum_flags;
u32 mark;
u16 ptype;
u32 priority;
struct {
u32 ctx;
u32 index;
u8 vf;
} queue;
struct {
struct psample_group *psample_group;
u32 rate;
u32 trunc_size;
bool truncate;
} sample;
struct {
u32 burst;
long: 32;
u64 rate_bytes_ps;
u64 peakrate_bytes_ps;
u32 avrate;
u16 overhead;
u64 burst_pkt;
u64 rate_pkt_ps;
u32 mtu;
struct {
enum flow_action_id act_id;
u32 extval;
} exceed;
struct {
enum flow_action_id act_id;
u32 extval;
} notexceed;
long: 32;
} police;
struct {
int action;
u16 zone;
struct nf_flowtable *flow_table;
} ct;
struct {
long unsigned int cookie;
u32 mark;
u32 labels[4];
bool orig_dir;
} ct_metadata;
struct {
u32 label;
__be16 proto;
u8 tc;
u8 bos;
u8 ttl;
} mpls_push;
struct {
__be16 proto;
} mpls_pop;
struct {
u32 label;
u8 tc;
u8 bos;
u8 ttl;
} mpls_mangle;
struct {
s32 prio;
long: 32;
u64 basetime;
u64 cycletime;
u64 cycletimeext;
u32 num_entries;
struct action_gate_entry *entries;
} gate;
struct {
u16 sid;
} pppoe;
};
struct flow_action_cookie *cookie;
long: 32;
};
struct flow_action {
unsigned int num_entries;
long: 32;
struct flow_action_entry entries[0];
};
struct flow_stats {
u64 pkts;
u64 bytes;
u64 drops;
u64 lastused;
enum flow_action_hw_stats used_hw_stats;
bool used_hw_stats_valid;
};
enum offload_act_command {
FLOW_ACT_REPLACE = 0,
FLOW_ACT_DESTROY = 1,
FLOW_ACT_STATS = 2,
};
struct flow_offload_action {
struct netlink_ext_ack *extack;
enum offload_act_command command;
enum flow_action_id id;
u32 index;
struct flow_stats stats;
struct flow_action action;
};
struct gnet_stats_rate_est64 {
__u64 bps;
__u64 pps;
};
struct tcf_idrinfo {
struct mutex lock;
struct idr action_idr;
struct net *net;
};
struct tc_action_ops;
struct tc_cookie;
struct tc_action {
const struct tc_action_ops *ops;
__u32 type;
struct tcf_idrinfo *idrinfo;
u32 tcfa_index;
refcount_t tcfa_refcnt;
atomic_t tcfa_bindcnt;
int tcfa_action;
long: 32;
struct tcf_t tcfa_tm;
struct gnet_stats_basic_sync tcfa_bstats;
struct gnet_stats_basic_sync tcfa_bstats_hw;
struct gnet_stats_queue tcfa_qstats;
struct net_rate_estimator *tcfa_rate_est;
spinlock_t tcfa_lock;
struct gnet_stats_basic_sync *cpu_bstats;
struct gnet_stats_basic_sync *cpu_bstats_hw;
struct gnet_stats_queue *cpu_qstats;
struct tc_cookie *act_cookie;
struct tcf_chain *goto_chain;
u32 tcfa_flags;
u8 hw_stats;
u8 used_hw_stats;
bool used_hw_stats_valid;
u32 in_hw_count;
long: 32;
};
typedef void (*tc_action_priv_destructor)(void *);
struct tc_action_ops {
struct list_head head;
char kind[16];
enum tca_id id;
unsigned int net_id;
size_t size;
struct module *owner;
int (*act)(struct sk_buff *, const struct tc_action *, struct tcf_result *);
int (*dump)(struct sk_buff *, struct tc_action *, int, int);
void (*cleanup)(struct tc_action *);
int (*lookup)(struct net *, struct tc_action **, u32);
int (*init)(struct net *, struct nlattr *, struct nlattr *, struct tc_action **, struct tcf_proto *, u32, struct netlink_ext_ack *);
int (*walk)(struct net *, struct sk_buff *, struct netlink_callback *, int, const struct tc_action_ops *, struct netlink_ext_ack *);
void (*stats_update)(struct tc_action *, u64, u64, u64, u64, bool);
size_t (*get_fill_size)(const struct tc_action *);
struct net_device * (*get_dev)(const struct tc_action *, tc_action_priv_destructor *);
struct psample_group * (*get_psample_group)(const struct tc_action *, tc_action_priv_destructor *);
int (*offload_act_setup)(struct tc_action *, void *, u32 *, bool, struct netlink_ext_ack *);
};
struct tc_cookie {
u8 *data;
u32 len;
struct callback_head rcu;
};
struct tc_action_net {
struct tcf_idrinfo *idrinfo;
const struct tc_action_ops *ops;
};
struct tcf_police_params {
int tcfp_result;
u32 tcfp_ewma_rate;
s64 tcfp_burst;
u32 tcfp_mtu;
long: 32;
s64 tcfp_mtu_ptoks;
s64 tcfp_pkt_burst;
struct psched_ratecfg rate;
bool rate_present;
long: 32;
struct psched_ratecfg peak;
bool peak_present;
long: 32;
struct psched_pktrate ppsrate;
bool pps_present;
struct callback_head rcu;
long: 32;
};
struct tcf_police {
struct tc_action common;
struct tcf_police_params *params;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
spinlock_t tcfp_lock;
long: 32;
s64 tcfp_toks;
s64 tcfp_ptoks;
s64 tcfp_pkttoks;
s64 tcfp_t_c;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct tcp_md5sig {
struct __kernel_sockaddr_storage tcpm_addr;
__u8 tcpm_flags;
__u8 tcpm_prefixlen;
__u16 tcpm_keylen;
int tcpm_ifindex;
__u8 tcpm_key[80];
};
struct ip_reply_arg {
struct kvec iov[1];
int flags;
__wsum csum;
int csumoffset;
int bound_dev_if;
u8 tos;
kuid_t uid;
};
struct icmp_err {
int errno;
unsigned int fatal: 1;
};
enum tcp_tw_status {
TCP_TW_SUCCESS = 0,
TCP_TW_RST = 1,
TCP_TW_ACK = 2,
TCP_TW_SYN = 3,
};
struct tcp4_pseudohdr {
__be32 saddr;
__be32 daddr;
__u8 pad;
__u8 protocol;
__be16 len;
};
struct tcp_md5sig_pool {
struct ahash_request *md5_req;
void *scratch;
};
enum tcp_seq_states {
TCP_SEQ_STATE_LISTENING = 0,
TCP_SEQ_STATE_ESTABLISHED = 1,
};
struct tcp_seq_afinfo {
sa_family_t family;
};
struct tcp_iter_state {
struct seq_net_private p;
enum tcp_seq_states state;
struct sock *syn_wait_sk;
int bucket;
int offset;
int sbucket;
int num;
long: 32;
loff_t last_pos;
};
struct bpf_tcp_iter_state {
struct tcp_iter_state state;
unsigned int cur_sk;
unsigned int end_sk;
unsigned int max_sk;
struct sock **batch;
bool st_bucket_done;
long: 32;
};
struct bpf_iter__tcp {
union {
struct bpf_iter_meta *meta;
};
union {
struct sock_common *sk_common;
};
uid_t uid;
long: 32;
};
struct packet_offload {
__be16 type;
u16 priority;
struct offload_callbacks callbacks;
struct list_head list;
};
enum sk_pacing {
SK_PACING_NONE = 0,
SK_PACING_NEEDED = 1,
SK_PACING_FQ = 2,
};
struct bictcp {
u32 cnt;
u32 last_max_cwnd;
u32 last_cwnd;
u32 last_time;
u32 bic_origin_point;
u32 bic_K;
u32 delay_min;
u32 epoch_start;
u32 ack_cnt;
u32 tcp_cwnd;
u16 unused;
u8 sample_cnt;
u8 found;
u32 round_start;
u32 end_seq;
u32 last_ack;
u32 curr_rtt;
};
struct ucred {
__u32 pid;
__u32 uid;
__u32 gid;
};
struct scm_cookie {
struct pid *pid;
struct scm_fp_list *fp;
struct scm_creds creds;
};
struct unix_stream_read_state {
int (*recv_actor)(struct sk_buff *, int, int, struct unix_stream_read_state *);
struct socket *socket;
struct msghdr *msg;
struct pipe_inode_info *pipe;
size_t size;
int flags;
unsigned int splice_flags;
};
struct bpf_unix_iter_state {
struct seq_net_private p;
unsigned int cur_sk;
unsigned int end_sk;
unsigned int max_sk;
struct sock **batch;
bool st_bucket_done;
};
struct bpf_iter__unix {
union {
struct bpf_iter_meta *meta;
};
union {
struct unix_sock *unix_sk;
};
uid_t uid;
long: 32;
};
enum pkt_hash_types {
PKT_HASH_TYPE_NONE = 0,
PKT_HASH_TYPE_L2 = 1,
PKT_HASH_TYPE_L3 = 2,
PKT_HASH_TYPE_L4 = 3,
};
enum flowlabel_reflect {
FLOWLABEL_REFLECT_ESTABLISHED = 1,
FLOWLABEL_REFLECT_TCP_RESET = 2,
FLOWLABEL_REFLECT_ICMPV6_ECHO_REPLIES = 4,
};
struct tcp6_pseudohdr {
struct in6_addr saddr;
struct in6_addr daddr;
__be32 len;
__be32 protocol;
};
struct inet_protosw {
struct list_head list;
short unsigned int type;
short unsigned int protocol;
struct proto *prot;
const struct proto_ops *ops;
unsigned char flags;
};
struct iw_thrspy {
struct sockaddr addr;
struct iw_quality qual;
struct iw_quality low;
struct iw_quality high;
};
typedef int (*decompress_fn)(unsigned char *, long int, long int (*)(void *, long unsigned int), long int (*)(void *, long unsigned int), unsigned char *, long int *, void (*)(char *));
struct compress_format {
unsigned char magic[2];
const char *name;
decompress_fn decompressor;
};
struct group_data {
int limit[21];
int base[20];
int permute[258];
int minLen;
int maxLen;
};
struct bunzip_data {
int writeCopies;
int writePos;
int writeRunCountdown;
int writeCount;
int writeCurrent;
long int (*fill)(void *, long unsigned int);
long int inbufCount;
long int inbufPos;
unsigned char *inbuf;
unsigned int inbufBitCount;
unsigned int inbufBits;
unsigned int crc32Table[256];
unsigned int headerCRC;
unsigned int totalCRC;
unsigned int writeCRC;
unsigned int *dbuf;
unsigned int dbufSize;
unsigned char selectors[32768];
struct group_data groups[6];
int io_error;
int byteCount[256];
unsigned char symToByte[256];
unsigned char mtfSymbol[256];
};
struct maple_metadata {
unsigned char end;
unsigned char gap;
};
struct maple_pnode;
struct maple_range_64 {
struct maple_pnode *parent;
long unsigned int pivot[31];
union {
void *slot[32];
struct {
void *pad[31];
struct maple_metadata meta;
};
};
};
struct maple_arange_64 {
struct maple_pnode *parent;
long unsigned int pivot[20];
void *slot[21];
long unsigned int gap[21];
struct maple_metadata meta;
};
struct maple_topiary {
struct maple_pnode *parent;
struct maple_enode *next;
};
enum maple_type {
maple_dense = 0,
maple_leaf_64 = 1,
maple_range_64 = 2,
maple_arange_64 = 3,
};
struct maple_node {
union {
struct {
struct maple_pnode *parent;
void *slot[63];
};
struct {
void *pad;
struct callback_head rcu;
struct maple_enode *piv_parent;
unsigned char parent_slot;
enum maple_type type;
unsigned char slot_len;
unsigned int ma_flags;
};
struct maple_range_64 mr64;
struct maple_arange_64 ma64;
struct maple_alloc alloc;
};
};
struct ma_topiary {
struct maple_enode *head;
struct maple_enode *tail;
struct maple_tree *mtree;
};
struct ma_wr_state {
struct ma_state *mas;
struct maple_node *node;
long unsigned int r_min;
long unsigned int r_max;
enum maple_type type;
unsigned char offset_end;
unsigned char node_end;
long unsigned int *pivots;
long unsigned int end_piv;
void **slots;
void *entry;
void *content;
};
struct trace_event_raw_ma_op {
struct trace_entry ent;
const char *fn;
long unsigned int min;
long unsigned int max;
long unsigned int index;
long unsigned int last;
void *node;
char __data[0];
};
struct trace_event_raw_ma_read {
struct trace_entry ent;
const char *fn;
long unsigned int min;
long unsigned int max;
long unsigned int index;
long unsigned int last;
void *node;
char __data[0];
};
struct trace_event_raw_ma_write {
struct trace_entry ent;
const char *fn;
long unsigned int min;
long unsigned int max;
long unsigned int index;
long unsigned int last;
long unsigned int piv;
void *val;
void *node;
char __data[0];
};
struct trace_event_data_offsets_ma_op {};
struct trace_event_data_offsets_ma_read {};
struct trace_event_data_offsets_ma_write {};
typedef void (*btf_trace_ma_op)(void *, const char *, struct ma_state *);
typedef void (*btf_trace_ma_read)(void *, const char *, struct ma_state *);
typedef void (*btf_trace_ma_write)(void *, const char *, struct ma_state *, long unsigned int, void *);
struct maple_big_node {
struct maple_pnode *parent;
long unsigned int pivot[65];
union {
struct maple_enode *slot[66];
struct {
long unsigned int padding[43];
long unsigned int gap[43];
};
};
unsigned char b_end;
enum maple_type type;
};
struct maple_subtree_state {
struct ma_state *orig_l;
struct ma_state *orig_r;
struct ma_state *l;
struct ma_state *m;
struct ma_state *r;
struct ma_topiary *free;
struct ma_topiary *destroy;
struct maple_big_node *bn;
};
struct waitid_info {
pid_t pid;
uid_t uid;
int status;
int cause;
};
struct wait_opts {
enum pid_type wo_type;
int wo_flags;
struct pid *wo_pid;
struct waitid_info *wo_info;
int wo_stat;
struct rusage *wo_rusage;
wait_queue_entry_t child_wait;
int notask_error;
};
enum tick_device_mode {
TICKDEV_MODE_PERIODIC = 0,
TICKDEV_MODE_ONESHOT = 1,
};
struct tick_device {
struct clock_event_device *evtdev;
enum tick_device_mode mode;
};
enum tick_nohz_mode {
NOHZ_MODE_INACTIVE = 0,
NOHZ_MODE_LOWRES = 1,
NOHZ_MODE_HIGHRES = 2,
};
struct tick_sched {
struct hrtimer sched_timer;
long unsigned int check_clocks;
enum tick_nohz_mode nohz_mode;
unsigned int inidle: 1;
unsigned int tick_stopped: 1;
unsigned int idle_active: 1;
unsigned int do_timer_last: 1;
unsigned int got_idle_tick: 1;
long: 32;
ktime_t last_tick;
ktime_t next_tick;
long unsigned int idle_jiffies;
long unsigned int idle_calls;
long unsigned int idle_sleeps;
long: 32;
ktime_t idle_entrytime;
ktime_t idle_waketime;
ktime_t idle_exittime;
ktime_t idle_sleeptime;
ktime_t iowait_sleeptime;
long unsigned int last_jiffies;
long: 32;
u64 timer_expires;
u64 timer_expires_base;
u64 next_timer;
ktime_t idle_expires;
atomic_t tick_dep_mask;
long unsigned int last_tick_jiffies;
unsigned int stalled_jiffies;
long: 32;
};
struct timer_list_iter {
int cpu;
bool second_pass;
u64 now;
};
enum tick_broadcast_state {
TICK_BROADCAST_EXIT = 0,
TICK_BROADCAST_ENTER = 1,
};
struct kernel_cpustat {
u64 cpustat[10];
};
enum ring_buffer_flags {
RB_FL_OVERWRITE = 1,
};
typedef struct vfsmount * (*debugfs_automount_t)(struct dentry *, void *);
struct partial_page {
unsigned int offset;
unsigned int len;
long unsigned int private;
};
struct splice_pipe_desc {
struct page **pages;
struct partial_page *partial;
int nr_pages;
unsigned int nr_pages_max;
const struct pipe_buf_operations *ops;
void (*spd_release)(struct splice_pipe_desc *, unsigned int);
};
struct trace_export {
struct trace_export *next;
void (*write)(struct trace_export *, const void *, unsigned int);
int flags;
};
enum event_trigger_type {
ETT_NONE = 0,
ETT_TRACE_ONOFF = 1,
ETT_SNAPSHOT = 2,
ETT_STACKTRACE = 4,
ETT_EVENT_ENABLE = 8,
ETT_EVENT_HIST = 16,
ETT_HIST_ENABLE = 32,
ETT_EVENT_EPROBE = 64,
};
typedef bool (*cond_update_fn_t)(struct trace_array *, void *);
struct trace_min_max_param {
struct mutex *lock;
u64 *val;
u64 *min;
u64 *max;
};
struct saved_cmdlines_buffer {
unsigned int map_pid_to_cmdline[32769];
unsigned int *map_cmdline_to_pid;
unsigned int cmdline_num;
int cmdline_idx;
char *saved_cmdlines;
};
struct ftrace_stack {
long unsigned int calls[4096];
};
struct ftrace_stacks {
struct ftrace_stack stacks[4];
};
struct trace_buffer_struct {
int nesting;
char buffer[4096];
};
struct ftrace_buffer_info {
struct trace_iterator iter;
void *spare;
unsigned int spare_cpu;
unsigned int read;
long: 32;
};
struct err_info {
const char **errs;
u8 type;
u16 pos;
u64 ts;
};
struct tracing_log_err {
struct list_head list;
struct err_info info;
char loc[128];
char *cmd;
long: 32;
};
struct buffer_ref {
struct trace_buffer *buffer;
void *page;
int cpu;
refcount_t refcount;
};
struct prepend_buffer {
char *buf;
int len;
};
enum siginfo_layout {
SIL_KILL = 0,
SIL_TIMER = 1,
SIL_POLL = 2,
SIL_FAULT = 3,
SIL_FAULT_TRAPNO = 4,
SIL_FAULT_MCEERR = 5,
SIL_FAULT_BNDERR = 6,
SIL_FAULT_PKUERR = 7,
SIL_FAULT_PERF_EVENT = 8,
SIL_CHLD = 9,
SIL_RT = 10,
SIL_SYS = 11,
};
struct signalfd_siginfo {
__u32 ssi_signo;
__s32 ssi_errno;
__s32 ssi_code;
__u32 ssi_pid;
__u32 ssi_uid;
__s32 ssi_fd;
__u32 ssi_tid;
__u32 ssi_band;
__u32 ssi_overrun;
__u32 ssi_trapno;
__s32 ssi_status;
__s32 ssi_int;
__u64 ssi_ptr;
__u64 ssi_utime;
__u64 ssi_stime;
__u64 ssi_addr;
__u16 ssi_addr_lsb;
__u16 __pad2;
__s32 ssi_syscall;
__u64 ssi_call_addr;
__u32 ssi_arch;
__u8 __pad[28];
};
struct signalfd_ctx {
sigset_t sigmask;
};
enum SHIFT_DIRECTION {
SHIFT_LEFT = 0,
SHIFT_RIGHT = 1,
};
struct ext4_io_end_vec {
struct list_head list;
loff_t offset;
ssize_t size;
long: 32;
};
struct ext4_io_end {
struct list_head list;
handle_t *handle;
struct inode *inode;
struct bio *bio;
unsigned int flag;
refcount_t count;
struct list_head list_vec;
};
typedef struct ext4_io_end ext4_io_end_t;
struct ext4_extent_tail {
__le32 et_checksum;
};
struct rpc_iostats {
spinlock_t om_lock;
long unsigned int om_ops;
long unsigned int om_ntrans;
long unsigned int om_timeouts;
long long unsigned int om_bytes_sent;
long long unsigned int om_bytes_recv;
ktime_t om_queue;
ktime_t om_rtt;
ktime_t om_execute;
long unsigned int om_error_status;
long: 32;
};
struct nfs_find_desc {
struct nfs_fh *fh;
struct nfs_fattr *fattr;
};
struct renamedata {
struct user_namespace *old_mnt_userns;
struct inode *old_dir;
struct dentry *old_dentry;
struct user_namespace *new_mnt_userns;
struct inode *new_dir;
struct dentry *new_dentry;
struct inode **delegated_inode;
unsigned int flags;
};
struct splice_desc {
size_t total_len;
unsigned int len;
unsigned int flags;
union {
void *userptr;
struct file *file;
void *data;
} u;
loff_t pos;
loff_t *opos;
size_t num_spliced;
bool need_wakeup;
long: 32;
};
typedef int splice_actor(struct pipe_inode_info *, struct pipe_buffer *, struct splice_desc *);
typedef int splice_direct_actor(struct pipe_inode_info *, struct splice_desc *);
enum nfsstat4 {
NFS4_OK = 0,
NFS4ERR_PERM = 1,
NFS4ERR_NOENT = 2,
NFS4ERR_IO = 5,
NFS4ERR_NXIO = 6,
NFS4ERR_ACCESS = 13,
NFS4ERR_EXIST = 17,
NFS4ERR_XDEV = 18,
NFS4ERR_NOTDIR = 20,
NFS4ERR_ISDIR = 21,
NFS4ERR_INVAL = 22,
NFS4ERR_FBIG = 27,
NFS4ERR_NOSPC = 28,
NFS4ERR_ROFS = 30,
NFS4ERR_MLINK = 31,
NFS4ERR_NAMETOOLONG = 63,
NFS4ERR_NOTEMPTY = 66,
NFS4ERR_DQUOT = 69,
NFS4ERR_STALE = 70,
NFS4ERR_BADHANDLE = 10001,
NFS4ERR_BAD_COOKIE = 10003,
NFS4ERR_NOTSUPP = 10004,
NFS4ERR_TOOSMALL = 10005,
NFS4ERR_SERVERFAULT = 10006,
NFS4ERR_BADTYPE = 10007,
NFS4ERR_DELAY = 10008,
NFS4ERR_SAME = 10009,
NFS4ERR_DENIED = 10010,
NFS4ERR_EXPIRED = 10011,
NFS4ERR_LOCKED = 10012,
NFS4ERR_GRACE = 10013,
NFS4ERR_FHEXPIRED = 10014,
NFS4ERR_SHARE_DENIED = 10015,
NFS4ERR_WRONGSEC = 10016,
NFS4ERR_CLID_INUSE = 10017,
NFS4ERR_RESOURCE = 10018,
NFS4ERR_MOVED = 10019,
NFS4ERR_NOFILEHANDLE = 10020,
NFS4ERR_MINOR_VERS_MISMATCH = 10021,
NFS4ERR_STALE_CLIENTID = 10022,
NFS4ERR_STALE_STATEID = 10023,
NFS4ERR_OLD_STATEID = 10024,
NFS4ERR_BAD_STATEID = 10025,
NFS4ERR_BAD_SEQID = 10026,
NFS4ERR_NOT_SAME = 10027,
NFS4ERR_LOCK_RANGE = 10028,
NFS4ERR_SYMLINK = 10029,
NFS4ERR_RESTOREFH = 10030,
NFS4ERR_LEASE_MOVED = 10031,
NFS4ERR_ATTRNOTSUPP = 10032,
NFS4ERR_NO_GRACE = 10033,
NFS4ERR_RECLAIM_BAD = 10034,
NFS4ERR_RECLAIM_CONFLICT = 10035,
NFS4ERR_BADXDR = 10036,
NFS4ERR_LOCKS_HELD = 10037,
NFS4ERR_OPENMODE = 10038,
NFS4ERR_BADOWNER = 10039,
NFS4ERR_BADCHAR = 10040,
NFS4ERR_BADNAME = 10041,
NFS4ERR_BAD_RANGE = 10042,
NFS4ERR_LOCK_NOTSUPP = 10043,
NFS4ERR_OP_ILLEGAL = 10044,
NFS4ERR_DEADLOCK = 10045,
NFS4ERR_FILE_OPEN = 10046,
NFS4ERR_ADMIN_REVOKED = 10047,
NFS4ERR_CB_PATH_DOWN = 10048,
NFS4ERR_BADIOMODE = 10049,
NFS4ERR_BADLAYOUT = 10050,
NFS4ERR_BAD_SESSION_DIGEST = 10051,
NFS4ERR_BADSESSION = 10052,
NFS4ERR_BADSLOT = 10053,
NFS4ERR_COMPLETE_ALREADY = 10054,
NFS4ERR_CONN_NOT_BOUND_TO_SESSION = 10055,
NFS4ERR_DELEG_ALREADY_WANTED = 10056,
NFS4ERR_BACK_CHAN_BUSY = 10057,
NFS4ERR_LAYOUTTRYLATER = 10058,
NFS4ERR_LAYOUTUNAVAILABLE = 10059,
NFS4ERR_NOMATCHING_LAYOUT = 10060,
NFS4ERR_RECALLCONFLICT = 10061,
NFS4ERR_UNKNOWN_LAYOUTTYPE = 10062,
NFS4ERR_SEQ_MISORDERED = 10063,
NFS4ERR_SEQUENCE_POS = 10064,
NFS4ERR_REQ_TOO_BIG = 10065,
NFS4ERR_REP_TOO_BIG = 10066,
NFS4ERR_REP_TOO_BIG_TO_CACHE = 10067,
NFS4ERR_RETRY_UNCACHED_REP = 10068,
NFS4ERR_UNSAFE_COMPOUND = 10069,
NFS4ERR_TOO_MANY_OPS = 10070,
NFS4ERR_OP_NOT_IN_SESSION = 10071,
NFS4ERR_HASH_ALG_UNSUPP = 10072,
NFS4ERR_CLIENTID_BUSY = 10074,
NFS4ERR_PNFS_IO_HOLE = 10075,
NFS4ERR_SEQ_FALSE_RETRY = 10076,
NFS4ERR_BAD_HIGH_SLOT = 10077,
NFS4ERR_DEADSESSION = 10078,
NFS4ERR_ENCR_ALG_UNSUPP = 10079,
NFS4ERR_PNFS_NO_LAYOUT = 10080,
NFS4ERR_NOT_ONLY_OP = 10081,
NFS4ERR_WRONG_CRED = 10082,
NFS4ERR_WRONG_TYPE = 10083,
NFS4ERR_DIRDELEG_UNAVAIL = 10084,
NFS4ERR_REJECT_DELEG = 10085,
NFS4ERR_RETURNCONFLICT = 10086,
NFS4ERR_DELEG_REVOKED = 10087,
NFS4ERR_PARTNER_NOTSUPP = 10088,
NFS4ERR_PARTNER_NO_AUTH = 10089,
NFS4ERR_UNION_NOTSUPP = 10090,
NFS4ERR_OFFLOAD_DENIED = 10091,
NFS4ERR_WRONG_LFS = 10092,
NFS4ERR_BADLABEL = 10093,
NFS4ERR_OFFLOAD_NO_REQS = 10094,
NFS4ERR_NOXATTR = 10095,
NFS4ERR_XATTR2BIG = 10096,
};
struct accessmap {
u32 access;
int how;
};
struct buffered_dirent {
u64 ino;
loff_t offset;
int namlen;
unsigned int d_type;
char name[0];
};
struct readdir_data {
struct dir_context ctx;
char *dirent;
size_t used;
int full;
long: 32;
};
enum {
Opt_err___3 = 0,
Opt_fd = 1,
Opt_uid___2 = 2,
Opt_gid___3 = 3,
Opt_pgrp = 4,
Opt_minproto = 5,
Opt_maxproto = 6,
Opt_indirect = 7,
Opt_direct = 8,
Opt_offset = 9,
Opt_strictexpire = 10,
Opt_ignore = 11,
};
struct tree_descr {
const char *name;
const struct file_operations *ops;
int mode;
};
struct tracefs_dir_ops {
int (*mkdir)(const char *);
int (*rmdir)(const char *);
};
struct tracefs_mount_opts {
kuid_t uid;
kgid_t gid;
umode_t mode;
unsigned int opts;
};
enum {
Opt_uid___3 = 0,
Opt_gid___4 = 1,
Opt_mode___2 = 2,
Opt_err___4 = 3,
};
struct tracefs_fs_info {
struct tracefs_mount_opts mount_opts;
};
struct user_key_payload {
struct callback_head rcu;
short unsigned int datalen;
long: 32;
char data[0];
};
struct aead_instance {
void (*free)(struct aead_instance *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
union {
struct {
char head[128];
struct crypto_instance base;
} s;
struct aead_alg alg;
};
};
struct crypto_aead_spawn {
struct crypto_spawn base;
};
struct aead_geniv_ctx {
spinlock_t lock;
struct crypto_aead *child;
struct crypto_sync_skcipher *sknull;
u8 salt[0];
};
struct crypto_rng;
struct rng_alg {
int (*generate)(struct crypto_rng *, const u8 *, unsigned int, u8 *, unsigned int);
int (*seed)(struct crypto_rng *, const u8 *, unsigned int);
void (*set_ent)(struct crypto_rng *, const u8 *, unsigned int);
unsigned int seedsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct crypto_rng {
struct crypto_tfm base;
};
struct bio_alloc_cache {
struct bio *free_list;
unsigned int nr;
};
enum {
sysctl_hung_task_timeout_secs = 0,
};
enum xen_domain_type {
XEN_NATIVE = 0,
XEN_PV_DOMAIN = 1,
XEN_HVM_DOMAIN = 2,
};
struct biovec_slab {
int nr_vecs;
char *name;
struct kmem_cache *slab;
};
struct bio_slab {
struct kmem_cache *slab;
unsigned int slab_ref;
unsigned int slab_size;
char name[8];
};
struct bd_holder_disk {
struct list_head list;
struct block_device *bdev;
int refcnt;
};
struct ksignal {
struct k_sigaction ka;
kernel_siginfo_t info;
int sig;
};
enum {
IOSQE_FIXED_FILE_BIT = 0,
IOSQE_IO_DRAIN_BIT = 1,
IOSQE_IO_LINK_BIT = 2,
IOSQE_IO_HARDLINK_BIT = 3,
IOSQE_ASYNC_BIT = 4,
IOSQE_BUFFER_SELECT_BIT = 5,
IOSQE_CQE_SKIP_SUCCESS_BIT = 6,
};
enum {
IORING_REGISTER_BUFFERS = 0,
IORING_UNREGISTER_BUFFERS = 1,
IORING_REGISTER_FILES = 2,
IORING_UNREGISTER_FILES = 3,
IORING_REGISTER_EVENTFD = 4,
IORING_UNREGISTER_EVENTFD = 5,
IORING_REGISTER_FILES_UPDATE = 6,
IORING_REGISTER_EVENTFD_ASYNC = 7,
IORING_REGISTER_PROBE = 8,
IORING_REGISTER_PERSONALITY = 9,
IORING_UNREGISTER_PERSONALITY = 10,
IORING_REGISTER_RESTRICTIONS = 11,
IORING_REGISTER_ENABLE_RINGS = 12,
IORING_REGISTER_FILES2 = 13,
IORING_REGISTER_FILES_UPDATE2 = 14,
IORING_REGISTER_BUFFERS2 = 15,
IORING_REGISTER_BUFFERS_UPDATE = 16,
IORING_REGISTER_IOWQ_AFF = 17,
IORING_UNREGISTER_IOWQ_AFF = 18,
IORING_REGISTER_IOWQ_MAX_WORKERS = 19,
IORING_REGISTER_RING_FDS = 20,
IORING_UNREGISTER_RING_FDS = 21,
IORING_REGISTER_PBUF_RING = 22,
IORING_UNREGISTER_PBUF_RING = 23,
IORING_REGISTER_SYNC_CANCEL = 24,
IORING_REGISTER_FILE_ALLOC_RANGE = 25,
IORING_REGISTER_LAST = 26,
};
enum {
IO_WQ_BOUND = 0,
IO_WQ_UNBOUND = 1,
};
typedef struct io_wq_work *free_work_fn(struct io_wq_work *);
typedef void io_wq_work_fn(struct io_wq_work *);
struct io_wqe;
struct io_wq {
long unsigned int state;
free_work_fn *free_work;
io_wq_work_fn *do_work;
struct io_wq_hash *hash;
atomic_t worker_refs;
struct completion worker_done;
struct hlist_node cpuhp_node;
struct task_struct *task;
struct io_wqe *wqes[0];
};
enum {
REQ_F_FIXED_FILE_BIT = 0,
REQ_F_IO_DRAIN_BIT = 1,
REQ_F_LINK_BIT = 2,
REQ_F_HARDLINK_BIT = 3,
REQ_F_FORCE_ASYNC_BIT = 4,
REQ_F_BUFFER_SELECT_BIT = 5,
REQ_F_CQE_SKIP_BIT = 6,
REQ_F_FAIL_BIT = 8,
REQ_F_INFLIGHT_BIT = 9,
REQ_F_CUR_POS_BIT = 10,
REQ_F_NOWAIT_BIT = 11,
REQ_F_LINK_TIMEOUT_BIT = 12,
REQ_F_NEED_CLEANUP_BIT = 13,
REQ_F_POLLED_BIT = 14,
REQ_F_BUFFER_SELECTED_BIT = 15,
REQ_F_BUFFER_RING_BIT = 16,
REQ_F_REISSUE_BIT = 17,
REQ_F_CREDS_BIT = 18,
REQ_F_REFCOUNT_BIT = 19,
REQ_F_ARM_LTIMEOUT_BIT = 20,
REQ_F_ASYNC_DATA_BIT = 21,
REQ_F_SKIP_LINK_CQES_BIT = 22,
REQ_F_SINGLE_POLL_BIT = 23,
REQ_F_DOUBLE_POLL_BIT = 24,
REQ_F_PARTIAL_IO_BIT = 25,
REQ_F_CQE32_INIT_BIT = 26,
REQ_F_APOLL_MULTISHOT_BIT = 27,
REQ_F_CLEAR_POLLIN_BIT = 28,
REQ_F_HASH_LOCKED_BIT = 29,
REQ_F_SUPPORT_NOWAIT_BIT = 30,
REQ_F_ISREG_BIT = 31,
__REQ_F_LAST_BIT = 32,
};
enum {
IO_WQ_WORK_CANCEL = 1,
IO_WQ_WORK_HASHED = 2,
IO_WQ_WORK_UNBOUND = 4,
IO_WQ_WORK_CONCURRENT = 16,
IO_WQ_HASH_SHIFT = 24,
};
struct io_wq_data {
struct io_wq_hash *hash;
struct task_struct *task;
io_wq_work_fn *do_work;
free_work_fn *free_work;
};
enum {
IO_WORKER_F_UP = 1,
IO_WORKER_F_RUNNING = 2,
IO_WORKER_F_FREE = 4,
IO_WORKER_F_BOUND = 8,
};
enum {
IO_WQ_BIT_EXIT = 0,
};
enum {
IO_ACCT_STALLED_BIT = 0,
};
struct io_worker {
refcount_t ref;
unsigned int flags;
struct hlist_nulls_node nulls_node;
struct list_head all_list;
struct task_struct *task;
struct io_wqe *wqe;
struct io_wq_work *cur_work;
struct io_wq_work *next_work;
raw_spinlock_t lock;
struct completion ref_done;
long unsigned int create_state;
struct callback_head create_work;
int create_index;
union {
struct callback_head rcu;
struct work_struct work;
};
};
struct io_wqe_acct {
unsigned int nr_workers;
unsigned int max_workers;
int index;
atomic_t nr_running;
raw_spinlock_t lock;
struct io_wq_work_list work_list;
long unsigned int flags;
};
struct io_wqe {
raw_spinlock_t lock;
struct io_wqe_acct acct[2];
int node;
struct hlist_nulls_head free_list;
struct list_head all_list;
struct wait_queue_entry wait;
struct io_wq *wq;
struct io_wq_work *hash_tail[32];
cpumask_var_t cpu_mask;
};
enum {
IO_WQ_ACCT_BOUND = 0,
IO_WQ_ACCT_UNBOUND = 1,
IO_WQ_ACCT_NR = 2,
};
struct io_cb_cancel_data {
work_cancel_fn *fn;
void *data;
int nr_running;
int nr_pending;
bool cancel_all;
};
struct online_data {
unsigned int cpu;
bool online;
};
enum devm_ioremap_type {
DEVM_IOREMAP = 0,
DEVM_IOREMAP_UC = 1,
DEVM_IOREMAP_WC = 2,
DEVM_IOREMAP_NP = 3,
};
struct pcim_iomap_devres {
void *table[6];
};
struct arch_io_reserve_memtype_wc_devres {
resource_size_t start;
resource_size_t size;
};
struct xz_dec_bcj {
enum {
BCJ_X86 = 4,
BCJ_POWERPC = 5,
BCJ_IA64 = 6,
BCJ_ARM = 7,
BCJ_ARMTHUMB = 8,
BCJ_SPARC = 9,
} type;
enum xz_ret ret;
bool single_call;
uint32_t pos;
uint32_t x86_prev_mask;
uint8_t *out;
size_t out_pos;
size_t out_size;
struct {
size_t filtered;
size_t size;
uint8_t buf[16];
} temp;
};
enum pci_mmap_state {
pci_mmap_io = 0,
pci_mmap_mem = 1,
};
struct n_tty_data {
size_t read_head;
size_t commit_head;
size_t canon_head;
size_t echo_head;
size_t echo_commit;
size_t echo_mark;
long unsigned int char_map[8];
long unsigned int overrun_time;
int num_overrun;
bool no_room;
unsigned char lnext: 1;
unsigned char erasing: 1;
unsigned char raw: 1;
unsigned char real_raw: 1;
unsigned char icanon: 1;
unsigned char push: 1;
char read_buf[4096];
long unsigned int read_flags[128];
unsigned char echo_buf[4096];
size_t read_tail;
size_t line_start;
size_t lookahead_count;
unsigned int column;
unsigned int canon_column;
size_t echo_tail;
struct mutex atomic_read_lock;
struct mutex output_lock;
};
enum {
ERASE = 0,
WERASE = 1,
KILL = 2,
};
struct uart_8250_port;
struct uart_8250_ops {
int (*setup_irq)(struct uart_8250_port *);
void (*release_irq)(struct uart_8250_port *);
void (*setup_timer)(struct uart_8250_port *);
};
struct mctrl_gpios;
struct uart_8250_dma;
struct uart_8250_em485;
struct uart_8250_port {
struct uart_port port;
struct timer_list timer;
struct list_head list;
u32 capabilities;
short unsigned int bugs;
bool fifo_bug;
unsigned int tx_loadsz;
unsigned char acr;
unsigned char fcr;
unsigned char ier;
unsigned char lcr;
unsigned char mcr;
unsigned char cur_iotype;
unsigned int rpm_tx_active;
unsigned char canary;
unsigned char probe;
struct mctrl_gpios *gpios;
u16 lsr_saved_flags;
u16 lsr_save_mask;
unsigned char msr_saved_flags;
struct uart_8250_dma *dma;
const struct uart_8250_ops *ops;
int (*dl_read)(struct uart_8250_port *);
void (*dl_write)(struct uart_8250_port *, int);
struct uart_8250_em485 *em485;
void (*rs485_start_tx)(struct uart_8250_port *);
void (*rs485_stop_tx)(struct uart_8250_port *);
struct delayed_work overrun_backoff;
u32 overrun_backoff_time_ms;
};
struct uart_8250_em485 {
struct hrtimer start_tx_timer;
struct hrtimer stop_tx_timer;
struct hrtimer *active_timer;
struct uart_8250_port *port;
unsigned int tx_stopped: 1;
long: 32;
};
struct dma_chan;
typedef bool (*dma_filter_fn)(struct dma_chan *, void *);
enum dma_transfer_direction {
DMA_MEM_TO_MEM = 0,
DMA_MEM_TO_DEV = 1,
DMA_DEV_TO_MEM = 2,
DMA_DEV_TO_DEV = 3,
DMA_TRANS_NONE = 4,
};
enum dma_slave_buswidth {
DMA_SLAVE_BUSWIDTH_UNDEFINED = 0,
DMA_SLAVE_BUSWIDTH_1_BYTE = 1,
DMA_SLAVE_BUSWIDTH_2_BYTES = 2,
DMA_SLAVE_BUSWIDTH_3_BYTES = 3,
DMA_SLAVE_BUSWIDTH_4_BYTES = 4,
DMA_SLAVE_BUSWIDTH_8_BYTES = 8,
DMA_SLAVE_BUSWIDTH_16_BYTES = 16,
DMA_SLAVE_BUSWIDTH_32_BYTES = 32,
DMA_SLAVE_BUSWIDTH_64_BYTES = 64,
DMA_SLAVE_BUSWIDTH_128_BYTES = 128,
};
struct dma_slave_config {
enum dma_transfer_direction direction;
phys_addr_t src_addr;
phys_addr_t dst_addr;
enum dma_slave_buswidth src_addr_width;
enum dma_slave_buswidth dst_addr_width;
u32 src_maxburst;
u32 dst_maxburst;
u32 src_port_window_size;
u32 dst_port_window_size;
bool device_fc;
void *peripheral_config;
size_t peripheral_size;
};
typedef s32 dma_cookie_t;
struct uart_8250_dma {
int (*tx_dma)(struct uart_8250_port *);
int (*rx_dma)(struct uart_8250_port *);
void (*prepare_tx_dma)(struct uart_8250_port *);
void (*prepare_rx_dma)(struct uart_8250_port *);
dma_filter_fn fn;
void *rx_param;
void *tx_param;
struct dma_slave_config rxconf;
struct dma_slave_config txconf;
struct dma_chan *rxchan;
struct dma_chan *txchan;
phys_addr_t rx_dma_addr;
phys_addr_t tx_dma_addr;
dma_addr_t rx_addr;
dma_addr_t tx_addr;
dma_cookie_t rx_cookie;
dma_cookie_t tx_cookie;
void *rx_buf;
size_t rx_size;
size_t tx_size;
unsigned char tx_running;
unsigned char tx_err;
unsigned char rx_running;
};
enum dma_status {
DMA_COMPLETE = 0,
DMA_IN_PROGRESS = 1,
DMA_PAUSED = 2,
DMA_ERROR = 3,
DMA_OUT_OF_ORDER = 4,
};
enum dma_transaction_type {
DMA_MEMCPY = 0,
DMA_XOR = 1,
DMA_PQ = 2,
DMA_XOR_VAL = 3,
DMA_PQ_VAL = 4,
DMA_MEMSET = 5,
DMA_MEMSET_SG = 6,
DMA_INTERRUPT = 7,
DMA_PRIVATE = 8,
DMA_ASYNC_TX = 9,
DMA_SLAVE = 10,
DMA_CYCLIC = 11,
DMA_INTERLEAVE = 12,
DMA_COMPLETION_NO_ORDER = 13,
DMA_REPEAT = 14,
DMA_LOAD_EOT = 15,
DMA_TX_TYPE_END = 16,
};
struct data_chunk {
size_t size;
size_t icg;
size_t dst_icg;
size_t src_icg;
};
struct dma_interleaved_template {
dma_addr_t src_start;
dma_addr_t dst_start;
enum dma_transfer_direction dir;
bool src_inc;
bool dst_inc;
bool src_sgl;
bool dst_sgl;
size_t numf;
size_t frame_size;
struct data_chunk sgl[0];
};
enum dma_ctrl_flags {
DMA_PREP_INTERRUPT = 1,
DMA_CTRL_ACK = 2,
DMA_PREP_PQ_DISABLE_P = 4,
DMA_PREP_PQ_DISABLE_Q = 8,
DMA_PREP_CONTINUE = 16,
DMA_PREP_FENCE = 32,
DMA_CTRL_REUSE = 64,
DMA_PREP_CMD = 128,
DMA_PREP_REPEAT = 256,
DMA_PREP_LOAD_EOT = 512,
};
enum sum_check_bits {
SUM_CHECK_P = 0,
SUM_CHECK_Q = 1,
};
enum sum_check_flags {
SUM_CHECK_P_RESULT = 1,
SUM_CHECK_Q_RESULT = 2,
};
typedef struct {
long unsigned int bits[1];
} dma_cap_mask_t;
enum dma_desc_metadata_mode {
DESC_METADATA_NONE = 0,
DESC_METADATA_CLIENT = 1,
DESC_METADATA_ENGINE = 2,
};
struct dma_chan_percpu {
long unsigned int memcpy_count;
long unsigned int bytes_transferred;
};
struct dma_router {
struct device *dev;
void (*route_free)(struct device *, void *);
};
struct dma_device;
struct dma_chan_dev;
struct dma_chan {
struct dma_device *device;
struct device *slave;
dma_cookie_t cookie;
dma_cookie_t completed_cookie;
int chan_id;
struct dma_chan_dev *dev;
const char *name;
char *dbg_client_name;
struct list_head device_node;
struct dma_chan_percpu *local;
int client_count;
int table_count;
struct dma_router *router;
void *route_data;
void *private;
};
struct dma_slave_map;
struct dma_filter {
dma_filter_fn fn;
int mapcnt;
const struct dma_slave_map *map;
};
enum dmaengine_alignment {
DMAENGINE_ALIGN_1_BYTE = 0,
DMAENGINE_ALIGN_2_BYTES = 1,
DMAENGINE_ALIGN_4_BYTES = 2,
DMAENGINE_ALIGN_8_BYTES = 3,
DMAENGINE_ALIGN_16_BYTES = 4,
DMAENGINE_ALIGN_32_BYTES = 5,
DMAENGINE_ALIGN_64_BYTES = 6,
DMAENGINE_ALIGN_128_BYTES = 7,
DMAENGINE_ALIGN_256_BYTES = 8,
};
enum dma_residue_granularity {
DMA_RESIDUE_GRANULARITY_DESCRIPTOR = 0,
DMA_RESIDUE_GRANULARITY_SEGMENT = 1,
DMA_RESIDUE_GRANULARITY_BURST = 2,
};
struct dma_async_tx_descriptor;
struct dma_slave_caps;
struct dma_tx_state;
struct dma_device {
struct kref ref;
unsigned int chancnt;
unsigned int privatecnt;
struct list_head channels;
struct list_head global_node;
struct dma_filter filter;
dma_cap_mask_t cap_mask;
enum dma_desc_metadata_mode desc_metadata_modes;
short unsigned int max_xor;
short unsigned int max_pq;
enum dmaengine_alignment copy_align;
enum dmaengine_alignment xor_align;
enum dmaengine_alignment pq_align;
enum dmaengine_alignment fill_align;
int dev_id;
struct device *dev;
struct module *owner;
struct ida chan_ida;
u32 src_addr_widths;
u32 dst_addr_widths;
u32 directions;
u32 min_burst;
u32 max_burst;
u32 max_sg_burst;
bool descriptor_reuse;
enum dma_residue_granularity residue_granularity;
int (*device_alloc_chan_resources)(struct dma_chan *);
int (*device_router_config)(struct dma_chan *);
void (*device_free_chan_resources)(struct dma_chan *);
struct dma_async_tx_descriptor * (*device_prep_dma_memcpy)(struct dma_chan *, dma_addr_t, dma_addr_t, size_t, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_xor)(struct dma_chan *, dma_addr_t, dma_addr_t *, unsigned int, size_t, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_xor_val)(struct dma_chan *, dma_addr_t *, unsigned int, size_t, enum sum_check_flags *, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_pq)(struct dma_chan *, dma_addr_t *, dma_addr_t *, unsigned int, const unsigned char *, size_t, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_pq_val)(struct dma_chan *, dma_addr_t *, dma_addr_t *, unsigned int, const unsigned char *, size_t, enum sum_check_flags *, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_memset)(struct dma_chan *, dma_addr_t, int, size_t, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_memset_sg)(struct dma_chan *, struct scatterlist *, unsigned int, int, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_interrupt)(struct dma_chan *, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_slave_sg)(struct dma_chan *, struct scatterlist *, unsigned int, enum dma_transfer_direction, long unsigned int, void *);
struct dma_async_tx_descriptor * (*device_prep_dma_cyclic)(struct dma_chan *, dma_addr_t, size_t, size_t, enum dma_transfer_direction, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_interleaved_dma)(struct dma_chan *, struct dma_interleaved_template *, long unsigned int);
struct dma_async_tx_descriptor * (*device_prep_dma_imm_data)(struct dma_chan *, dma_addr_t, u64, long unsigned int);
void (*device_caps)(struct dma_chan *, struct dma_slave_caps *);
int (*device_config)(struct dma_chan *, struct dma_slave_config *);
int (*device_pause)(struct dma_chan *);
int (*device_resume)(struct dma_chan *);
int (*device_terminate_all)(struct dma_chan *);
void (*device_synchronize)(struct dma_chan *);
enum dma_status (*device_tx_status)(struct dma_chan *, dma_cookie_t, struct dma_tx_state *);
void (*device_issue_pending)(struct dma_chan *);
void (*device_release)(struct dma_device *);
void (*dbg_summary_show)(struct seq_file *, struct dma_device *);
struct dentry *dbg_dev_root;
};
struct dma_chan_dev {
struct dma_chan *chan;
long: 32;
struct device device;
int dev_id;
bool chan_dma_dev;
};
struct dma_slave_caps {
u32 src_addr_widths;
u32 dst_addr_widths;
u32 directions;
u32 min_burst;
u32 max_burst;
u32 max_sg_burst;
bool cmd_pause;
bool cmd_resume;
bool cmd_terminate;
enum dma_residue_granularity residue_granularity;
bool descriptor_reuse;
};
typedef void (*dma_async_tx_callback)(void *);
enum dmaengine_tx_result {
DMA_TRANS_NOERROR = 0,
DMA_TRANS_READ_FAILED = 1,
DMA_TRANS_WRITE_FAILED = 2,
DMA_TRANS_ABORTED = 3,
};
struct dmaengine_result {
enum dmaengine_tx_result result;
u32 residue;
};
typedef void (*dma_async_tx_callback_result)(void *, const struct dmaengine_result *);
struct dmaengine_unmap_data {
u8 map_cnt;
u8 to_cnt;
u8 from_cnt;
u8 bidi_cnt;
struct device *dev;
struct kref kref;
size_t len;
dma_addr_t addr[0];
};
struct dma_descriptor_metadata_ops {
int (*attach)(struct dma_async_tx_descriptor *, void *, size_t);
void * (*get_ptr)(struct dma_async_tx_descriptor *, size_t *, size_t *);
int (*set_len)(struct dma_async_tx_descriptor *, size_t);
};
struct dma_async_tx_descriptor {
dma_cookie_t cookie;
enum dma_ctrl_flags flags;
dma_addr_t phys;
struct dma_chan *chan;
dma_cookie_t (*tx_submit)(struct dma_async_tx_descriptor *);
int (*desc_free)(struct dma_async_tx_descriptor *);
dma_async_tx_callback callback;
dma_async_tx_callback_result callback_result;
void *callback_param;
struct dmaengine_unmap_data *unmap;
enum dma_desc_metadata_mode desc_metadata_mode;
struct dma_descriptor_metadata_ops *metadata_ops;
};
struct dma_tx_state {
dma_cookie_t last;
dma_cookie_t used;
u32 residue;
u32 in_flight_bytes;
};
struct dma_slave_map {
const char *devname;
const char *slave;
void *param;
};
struct pericom8250 {
void *virt;
unsigned int nr;
int line[0];
};
struct attribute_container {
struct list_head node;
struct klist containers;
struct class *class;
const struct attribute_group *grp;
struct device_attribute **attrs;
int (*match)(struct attribute_container *, struct device *);
long unsigned int flags;
};
struct internal_container {
struct klist_node node;
struct attribute_container *cont;
long: 32;
struct device classdev;
};
enum {
mechtype_caddy = 0,
mechtype_tray = 1,
mechtype_popup = 2,
mechtype_individual_changer = 4,
mechtype_cartridge_changer = 5,
};
struct event_header {
__be16 data_len;
__u8 notification_class: 3;
__u8 reserved1: 4;
__u8 nea: 1;
__u8 supp_event_class;
};
struct media_event_desc {
__u8 media_event_code: 4;
__u8 reserved1: 4;
__u8 door_open: 1;
__u8 media_present: 1;
__u8 reserved2: 6;
__u8 start_slot;
__u8 end_slot;
};
struct phy_fixup {
struct list_head list;
char bus_id[64];
u32 phy_uid;
u32 phy_uid_mask;
int (*run)(struct phy_device *);
};
struct sfp_eeprom_base {
u8 phys_id;
u8 phys_ext_id;
u8 connector;
u8 if_1x_copper_passive: 1;
u8 if_1x_copper_active: 1;
u8 if_1x_lx: 1;
u8 if_1x_sx: 1;
u8 e10g_base_sr: 1;
u8 e10g_base_lr: 1;
u8 e10g_base_lrm: 1;
u8 e10g_base_er: 1;
u8 sonet_oc3_short_reach: 1;
u8 sonet_oc3_smf_intermediate_reach: 1;
u8 sonet_oc3_smf_long_reach: 1;
u8 unallocated_5_3: 1;
u8 sonet_oc12_short_reach: 1;
u8 sonet_oc12_smf_intermediate_reach: 1;
u8 sonet_oc12_smf_long_reach: 1;
u8 unallocated_5_7: 1;
u8 sonet_oc48_short_reach: 1;
u8 sonet_oc48_intermediate_reach: 1;
u8 sonet_oc48_long_reach: 1;
u8 sonet_reach_bit2: 1;
u8 sonet_reach_bit1: 1;
u8 sonet_oc192_short_reach: 1;
u8 escon_smf_1310_laser: 1;
u8 escon_mmf_1310_led: 1;
u8 e1000_base_sx: 1;
u8 e1000_base_lx: 1;
u8 e1000_base_cx: 1;
u8 e1000_base_t: 1;
u8 e100_base_lx: 1;
u8 e100_base_fx: 1;
u8 e_base_bx10: 1;
u8 e_base_px: 1;
u8 fc_tech_electrical_inter_enclosure: 1;
u8 fc_tech_lc: 1;
u8 fc_tech_sa: 1;
u8 fc_ll_m: 1;
u8 fc_ll_l: 1;
u8 fc_ll_i: 1;
u8 fc_ll_s: 1;
u8 fc_ll_v: 1;
u8 unallocated_8_0: 1;
u8 unallocated_8_1: 1;
u8 sfp_ct_passive: 1;
u8 sfp_ct_active: 1;
u8 fc_tech_ll: 1;
u8 fc_tech_sl: 1;
u8 fc_tech_sn: 1;
u8 fc_tech_electrical_intra_enclosure: 1;
u8 fc_media_sm: 1;
u8 unallocated_9_1: 1;
u8 fc_media_m5: 1;
u8 fc_media_m6: 1;
u8 fc_media_tv: 1;
u8 fc_media_mi: 1;
u8 fc_media_tp: 1;
u8 fc_media_tw: 1;
u8 fc_speed_100: 1;
u8 unallocated_10_1: 1;
u8 fc_speed_200: 1;
u8 fc_speed_3200: 1;
u8 fc_speed_400: 1;
u8 fc_speed_1600: 1;
u8 fc_speed_800: 1;
u8 fc_speed_1200: 1;
u8 encoding;
u8 br_nominal;
u8 rate_id;
u8 link_len[6];
char vendor_name[16];
u8 extended_cc;
char vendor_oui[3];
char vendor_pn[16];
char vendor_rev[4];
union {
__be16 optical_wavelength;
__be16 cable_compliance;
struct {
u8 sff8431_app_e: 1;
u8 fc_pi_4_app_h: 1;
u8 reserved60_2: 6;
u8 reserved61: 8;
} passive;
struct {
u8 sff8431_app_e: 1;
u8 fc_pi_4_app_h: 1;
u8 sff8431_lim: 1;
u8 fc_pi_4_lim: 1;
u8 reserved60_4: 4;
u8 reserved61: 8;
} active;
};
u8 reserved62;
u8 cc_base;
};
struct sfp_eeprom_ext {
__be16 options;
u8 br_max;
u8 br_min;
char vendor_sn[16];
char datecode[8];
u8 diagmon;
u8 enhopts;
u8 sff8472_compliance;
u8 cc_ext;
};
struct sfp_eeprom_id {
struct sfp_eeprom_base base;
struct sfp_eeprom_ext ext;
};
struct sfp_upstream_ops {
void (*attach)(void *, struct sfp_bus *);
void (*detach)(void *, struct sfp_bus *);
int (*module_insert)(void *, const struct sfp_eeprom_id *);
void (*module_remove)(void *);
int (*module_start)(void *);
void (*module_stop)(void *);
void (*link_down)(void *);
void (*link_up)(void *);
int (*connect_phy)(void *, struct phy_device *);
void (*disconnect_phy)(void *);
};
struct amba_cs_uci_id {
unsigned int devarch;
unsigned int devarch_mask;
unsigned int devtype;
void *data;
};
struct amba_device {
struct device dev;
struct resource res;
struct clk *pclk;
struct device_dma_parameters dma_parms;
unsigned int periphid;
struct mutex periphid_lock;
unsigned int cid;
struct amba_cs_uci_id uci;
unsigned int irq[9];
const char *driver_override;
};
struct of_dev_auxdata {
char *compatible;
resource_size_t phys_addr;
char *name;
void *platform_data;
};
enum {
IF_LINK_MODE_DEFAULT = 0,
IF_LINK_MODE_DORMANT = 1,
IF_LINK_MODE_TESTING = 2,
};
struct netdev_name_node {
struct hlist_node hlist;
struct list_head list;
struct net_device *dev;
const char *name;
};
enum lw_bits {
LW_URGENT = 0,
};
typedef int (*dummy_ops_test_ret_fn)(struct bpf_dummy_ops_state *, ...);
struct bpf_dummy_ops_test_args {
u64 args[12];
struct bpf_dummy_ops_state state;
long: 32;
};
struct channels_reply_data {
struct ethnl_reply_data base;
struct ethtool_channels channels;
};
struct nf_loginfo {
u_int8_t type;
union {
struct {
u_int32_t copy_len;
u_int16_t group;
u_int16_t qthreshold;
u_int16_t flags;
} ulog;
struct {
u_int8_t level;
u_int8_t logflags;
} log;
} u;
};
struct nf_log_buf {
unsigned int count;
char buf[1020];
};
enum {
TCP_FLAG_CWR = 32768,
TCP_FLAG_ECE = 16384,
TCP_FLAG_URG = 8192,
TCP_FLAG_ACK = 4096,
TCP_FLAG_PSH = 2048,
TCP_FLAG_RST = 1024,
TCP_FLAG_SYN = 512,
TCP_FLAG_FIN = 256,
TCP_RESERVED_BITS = 15,
TCP_DATA_OFFSET = 240,
};
struct ipfrag_skb_cb {
union {
struct inet_skb_parm h4;
struct inet6_skb_parm h6;
};
struct sk_buff *next_frag;
int frag_run_len;
};
struct xfrm_tunnel {
int (*handler)(struct sk_buff *);
int (*cb_handler)(struct sk_buff *, int);
int (*err_handler)(struct sk_buff *, u32);
struct xfrm_tunnel *next;
int priority;
};
struct sadb_alg {
__u8 sadb_alg_id;
__u8 sadb_alg_ivlen;
__u16 sadb_alg_minbits;
__u16 sadb_alg_maxbits;
__u16 sadb_alg_reserved;
};
struct xfrm_algo_aead_info {
char *geniv;
u16 icv_truncbits;
};
struct xfrm_algo_auth_info {
u16 icv_truncbits;
u16 icv_fullbits;
};
struct xfrm_algo_encr_info {
char *geniv;
u16 blockbits;
u16 defkeybits;
};
struct xfrm_algo_comp_info {
u16 threshold;
};
struct xfrm_algo_desc {
char *name;
char *compat;
u8 available: 1;
u8 pfkey_supported: 1;
union {
struct xfrm_algo_aead_info aead;
struct xfrm_algo_auth_info auth;
struct xfrm_algo_encr_info encr;
struct xfrm_algo_comp_info comp;
} uinfo;
struct sadb_alg desc;
};
struct xfrm_algo_list {
struct xfrm_algo_desc *algs;
int entries;
u32 type;
u32 mask;
};
struct xfrm_aead_name {
const char *name;
int icvbits;
};
struct ipv6_sr_hdr {
__u8 nexthdr;
__u8 hdrlen;
__u8 type;
__u8 segments_left;
__u8 first_segment;
__u8 flags;
__u16 tag;
struct in6_addr segments[0];
};
struct udp_skb_cb {
union {
struct inet_skb_parm h4;
struct inet6_skb_parm h6;
} header;
__u16 cscov;
__u8 partial_cov;
};
struct udp_seq_afinfo {
sa_family_t family;
struct udp_table *udp_table;
};
struct udp_iter_state {
struct seq_net_private p;
int bucket;
struct udp_seq_afinfo *bpf_seq_afinfo;
};
struct radix_tree_iter {
long unsigned int index;
long unsigned int next_index;
long unsigned int tags;
struct xa_node *node;
};
enum {
RADIX_TREE_ITER_TAG_MASK = 15,
RADIX_TREE_ITER_TAGGED = 16,
RADIX_TREE_ITER_CONTIG = 32,
};
struct ida_bitmap {
long unsigned int bitmap[32];
};
struct minix_super_block {
__u16 s_ninodes;
__u16 s_nzones;
__u16 s_imap_blocks;
__u16 s_zmap_blocks;
__u16 s_firstdatazone;
__u16 s_log_zone_size;
__u32 s_max_size;
__u16 s_magic;
__u16 s_state;
__u32 s_zones;
};
struct romfs_super_block {
__be32 word0;
__be32 word1;
__be32 size;
__be32 checksum;
char name[0];
};
struct cramfs_inode {
__u32 mode: 16;
__u32 uid: 16;
__u32 size: 24;
__u32 gid: 8;
__u32 namelen: 6;
__u32 offset: 26;
};
struct cramfs_info {
__u32 crc;
__u32 edition;
__u32 blocks;
__u32 files;
};
struct cramfs_super {
__u32 magic;
__u32 size;
__u32 flags;
__u32 future;
__u8 signature[16];
struct cramfs_info fsid;
__u8 name[16];
struct cramfs_inode root;
};
struct squashfs_super_block {
__le32 s_magic;
__le32 inodes;
__le32 mkfs_time;
__le32 block_size;
__le32 fragments;
__le16 compression;
__le16 block_log;
__le16 flags;
__le16 no_ids;
__le16 s_major;
__le16 s_minor;
__le64 root_inode;
__le64 bytes_used;
__le64 id_table_start;
__le64 xattr_id_table_start;
__le64 inode_table_start;
__le64 directory_table_start;
__le64 fragment_table_start;
__le64 lookup_table_start;
};
typedef void (*call_rcu_func_t)(struct callback_head *, rcu_callback_t);
typedef int (*task_call_f)(struct task_struct *, void *);
struct rcu_synchronize {
struct callback_head head;
struct completion completion;
};
struct trace_event_raw_rcu_utilization {
struct trace_entry ent;
const char *s;
char __data[0];
};
struct trace_event_raw_rcu_grace_period {
struct trace_entry ent;
const char *rcuname;
long int gp_seq;
const char *gpevent;
char __data[0];
};
struct trace_event_raw_rcu_future_grace_period {
struct trace_entry ent;
const char *rcuname;
long int gp_seq;
long int gp_seq_req;
u8 level;
int grplo;
int grphi;
const char *gpevent;
char __data[0];
};
struct trace_event_raw_rcu_grace_period_init {
struct trace_entry ent;
const char *rcuname;
long int gp_seq;
u8 level;
int grplo;
int grphi;
long unsigned int qsmask;
char __data[0];
};
struct trace_event_raw_rcu_exp_grace_period {
struct trace_entry ent;
const char *rcuname;
long int gpseq;
const char *gpevent;
char __data[0];
};
struct trace_event_raw_rcu_exp_funnel_lock {
struct trace_entry ent;
const char *rcuname;
u8 level;
int grplo;
int grphi;
const char *gpevent;
char __data[0];
};
struct trace_event_raw_rcu_preempt_task {
struct trace_entry ent;
const char *rcuname;
long int gp_seq;
int pid;
char __data[0];
};
struct trace_event_raw_rcu_unlock_preempted_task {
struct trace_entry ent;
const char *rcuname;
long int gp_seq;
int pid;
char __data[0];
};
struct trace_event_raw_rcu_quiescent_state_report {
struct trace_entry ent;
const char *rcuname;
long int gp_seq;
long unsigned int mask;
long unsigned int qsmask;
u8 level;
int grplo;
int grphi;
u8 gp_tasks;
char __data[0];
};
struct trace_event_raw_rcu_fqs {
struct trace_entry ent;
const char *rcuname;
long int gp_seq;
int cpu;
const char *qsevent;
char __data[0];
};
struct trace_event_raw_rcu_stall_warning {
struct trace_entry ent;
const char *rcuname;
const char *msg;
char __data[0];
};
struct trace_event_raw_rcu_dyntick {
struct trace_entry ent;
const char *polarity;
long int oldnesting;
long int newnesting;
int dynticks;
char __data[0];
};
struct trace_event_raw_rcu_callback {
struct trace_entry ent;
const char *rcuname;
void *rhp;
void *func;
long int qlen;
char __data[0];
};
struct trace_event_raw_rcu_segcb_stats {
struct trace_entry ent;
const char *ctx;
long unsigned int gp_seq[4];
long int seglen[4];
char __data[0];
};
struct trace_event_raw_rcu_kvfree_callback {
struct trace_entry ent;
const char *rcuname;
void *rhp;
long unsigned int offset;
long int qlen;
char __data[0];
};
struct trace_event_raw_rcu_batch_start {
struct trace_entry ent;
const char *rcuname;
long int qlen;
long int blimit;
char __data[0];
};
struct trace_event_raw_rcu_invoke_callback {
struct trace_entry ent;
const char *rcuname;
void *rhp;
void *func;
char __data[0];
};
struct trace_event_raw_rcu_invoke_kvfree_callback {
struct trace_entry ent;
const char *rcuname;
void *rhp;
long unsigned int offset;
char __data[0];
};
struct trace_event_raw_rcu_invoke_kfree_bulk_callback {
struct trace_entry ent;
const char *rcuname;
long unsigned int nr_records;
void **p;
char __data[0];
};
struct trace_event_raw_rcu_batch_end {
struct trace_entry ent;
const char *rcuname;
int callbacks_invoked;
char cb;
char nr;
char iit;
char risk;
char __data[0];
};
struct trace_event_raw_rcu_torture_read {
struct trace_entry ent;
char rcutorturename[8];
struct callback_head *rhp;
long unsigned int secs;
long unsigned int c_old;
long unsigned int c;
char __data[0];
};
struct trace_event_raw_rcu_barrier {
struct trace_entry ent;
const char *rcuname;
const char *s;
int cpu;
int cnt;
long unsigned int done;
char __data[0];
};
struct trace_event_data_offsets_rcu_utilization {};
struct trace_event_data_offsets_rcu_grace_period {};
struct trace_event_data_offsets_rcu_future_grace_period {};
struct trace_event_data_offsets_rcu_grace_period_init {};
struct trace_event_data_offsets_rcu_exp_grace_period {};
struct trace_event_data_offsets_rcu_exp_funnel_lock {};
struct trace_event_data_offsets_rcu_preempt_task {};
struct trace_event_data_offsets_rcu_unlock_preempted_task {};
struct trace_event_data_offsets_rcu_quiescent_state_report {};
struct trace_event_data_offsets_rcu_fqs {};
struct trace_event_data_offsets_rcu_stall_warning {};
struct trace_event_data_offsets_rcu_dyntick {};
struct trace_event_data_offsets_rcu_callback {};
struct trace_event_data_offsets_rcu_segcb_stats {};
struct trace_event_data_offsets_rcu_kvfree_callback {};
struct trace_event_data_offsets_rcu_batch_start {};
struct trace_event_data_offsets_rcu_invoke_callback {};
struct trace_event_data_offsets_rcu_invoke_kvfree_callback {};
struct trace_event_data_offsets_rcu_invoke_kfree_bulk_callback {};
struct trace_event_data_offsets_rcu_batch_end {};
struct trace_event_data_offsets_rcu_torture_read {};
struct trace_event_data_offsets_rcu_barrier {};
typedef void (*btf_trace_rcu_utilization)(void *, const char *);
typedef void (*btf_trace_rcu_grace_period)(void *, const char *, long unsigned int, const char *);
typedef void (*btf_trace_rcu_future_grace_period)(void *, const char *, long unsigned int, long unsigned int, u8, int, int, const char *);
typedef void (*btf_trace_rcu_grace_period_init)(void *, const char *, long unsigned int, u8, int, int, long unsigned int);
typedef void (*btf_trace_rcu_exp_grace_period)(void *, const char *, long unsigned int, const char *);
typedef void (*btf_trace_rcu_exp_funnel_lock)(void *, const char *, u8, int, int, const char *);
typedef void (*btf_trace_rcu_preempt_task)(void *, const char *, int, long unsigned int);
typedef void (*btf_trace_rcu_unlock_preempted_task)(void *, const char *, long unsigned int, int);
typedef void (*btf_trace_rcu_quiescent_state_report)(void *, const char *, long unsigned int, long unsigned int, long unsigned int, u8, int, int, int);
typedef void (*btf_trace_rcu_fqs)(void *, const char *, long unsigned int, int, const char *);
typedef void (*btf_trace_rcu_stall_warning)(void *, const char *, const char *);
typedef void (*btf_trace_rcu_dyntick)(void *, const char *, long int, long int, int);
typedef void (*btf_trace_rcu_callback)(void *, const char *, struct callback_head *, long int);
typedef void (*btf_trace_rcu_segcb_stats)(void *, struct rcu_segcblist *, const char *);
typedef void (*btf_trace_rcu_kvfree_callback)(void *, const char *, struct callback_head *, long unsigned int, long int);
typedef void (*btf_trace_rcu_batch_start)(void *, const char *, long int, long int);
typedef void (*btf_trace_rcu_invoke_callback)(void *, const char *, struct callback_head *);
typedef void (*btf_trace_rcu_invoke_kvfree_callback)(void *, const char *, struct callback_head *, long unsigned int);
typedef void (*btf_trace_rcu_invoke_kfree_bulk_callback)(void *, const char *, long unsigned int, void **);
typedef void (*btf_trace_rcu_batch_end)(void *, const char *, int, char, char, char, char);
typedef void (*btf_trace_rcu_torture_read)(void *, const char *, struct callback_head *, long unsigned int, long unsigned int, long unsigned int);
typedef void (*btf_trace_rcu_barrier)(void *, const char *, const char *, int, int, long unsigned int);
struct rcu_tasks;
typedef void (*rcu_tasks_gp_func_t)(struct rcu_tasks *);
typedef void (*pregp_func_t)(struct list_head *);
typedef void (*pertask_func_t)(struct task_struct *, struct list_head *);
typedef void (*postscan_func_t)(struct list_head *);
typedef void (*holdouts_func_t)(struct list_head *, bool, bool *);
typedef void (*postgp_func_t)(struct rcu_tasks *);
struct rcu_tasks_percpu;
struct rcu_tasks {
struct rcuwait cbs_wait;
raw_spinlock_t cbs_gbl_lock;
struct mutex tasks_gp_mutex;
int gp_state;
int gp_sleep;
int init_fract;
long unsigned int gp_jiffies;
long unsigned int gp_start;
long unsigned int tasks_gp_seq;
long unsigned int n_ipis;
long unsigned int n_ipis_fails;
struct task_struct *kthread_ptr;
rcu_tasks_gp_func_t gp_func;
pregp_func_t pregp_func;
pertask_func_t pertask_func;
postscan_func_t postscan_func;
holdouts_func_t holdouts_func;
postgp_func_t postgp_func;
call_rcu_func_t call_func;
struct rcu_tasks_percpu *rtpcpu;
int percpu_enqueue_shift;
int percpu_enqueue_lim;
int percpu_dequeue_lim;
long unsigned int percpu_dequeue_gpseq;
struct mutex barrier_q_mutex;
atomic_t barrier_q_count;
struct completion barrier_q_completion;
long unsigned int barrier_q_seq;
char *name;
char *kname;
};
struct rcu_tasks_percpu {
struct rcu_segcblist cblist;
raw_spinlock_t lock;
long unsigned int rtp_jiffies;
long unsigned int rtp_n_lock_retries;
struct work_struct rtp_work;
struct irq_work rtp_irq_work;
struct callback_head barrier_q_head;
struct list_head rtp_blkd_tasks;
int cpu;
struct rcu_tasks *rtpp;
};
struct trc_stall_chk_rdr {
int nesting;
int ipi_to_cpu;
u8 needqs;
};
struct perf_event_mmap_page {
__u32 version;
__u32 compat_version;
__u32 lock;
__u32 index;
__s64 offset;
__u64 time_enabled;
__u64 time_running;
union {
__u64 capabilities;
struct {
__u64 cap_bit0: 1;
__u64 cap_bit0_is_deprecated: 1;
__u64 cap_user_rdpmc: 1;
__u64 cap_user_time: 1;
__u64 cap_user_time_zero: 1;
__u64 cap_user_time_short: 1;
__u64 cap_____res: 58;
};
};
__u16 pmc_width;
__u16 time_shift;
__u32 time_mult;
__u64 time_offset;
__u64 time_zero;
__u32 size;
__u32 __reserved_1;
__u64 time_cycles;
__u64 time_mask;
__u8 __reserved[928];
__u64 data_head;
__u64 data_tail;
__u64 data_offset;
__u64 data_size;
__u64 aux_head;
__u64 aux_tail;
__u64 aux_offset;
__u64 aux_size;
};
enum perf_callchain_context {
PERF_CONTEXT_HV = 18446744073709551584ULL,
PERF_CONTEXT_KERNEL = 18446744073709551488ULL,
PERF_CONTEXT_USER = 18446744073709551104ULL,
PERF_CONTEXT_GUEST = 18446744073709549568ULL,
PERF_CONTEXT_GUEST_KERNEL = 18446744073709549440ULL,
PERF_CONTEXT_GUEST_USER = 18446744073709549056ULL,
PERF_CONTEXT_MAX = 18446744073709547521ULL,
};
struct perf_buffer {
refcount_t refcount;
struct callback_head callback_head;
struct work_struct work;
int page_order;
int nr_pages;
int overwrite;
int paused;
atomic_t poll;
local_t head;
unsigned int nest;
local_t events;
local_t wakeup;
local_t lost;
long int watermark;
long int aux_watermark;
spinlock_t event_lock;
struct list_head event_list;
atomic_t mmap_count;
long unsigned int mmap_locked;
struct user_struct *mmap_user;
long int aux_head;
unsigned int aux_nest;
long int aux_wakeup;
long unsigned int aux_pgoff;
int aux_nr_pages;
int aux_overwrite;
atomic_t aux_mmap_count;
long unsigned int aux_mmap_locked;
void (*free_aux)(void *);
refcount_t aux_refcount;
int aux_in_sampling;
void **aux_pages;
void *aux_priv;
struct perf_event_mmap_page *user_page;
void *data_pages[0];
};
struct callchain_cpus_entries {
struct callback_head callback_head;
struct perf_callchain_entry *cpu_entries[0];
};
enum pageblock_bits {
PB_migrate = 0,
PB_migrate_end = 2,
PB_migrate_skip = 3,
NR_PAGEBLOCK_BITS = 4,
};
struct page_frag_cache {
void *va;
__u16 offset;
__u16 size;
unsigned int pagecnt_bias;
bool pfmemalloc;
};
enum zone_flags {
ZONE_BOOSTED_WATERMARK = 0,
ZONE_RECLAIM_ACTIVE = 1,
};
enum meminit_context {
MEMINIT_EARLY = 0,
MEMINIT_HOTPLUG = 1,
};
typedef void compound_page_dtor(struct page *);
struct alloc_context {
struct zonelist *zonelist;
nodemask_t *nodemask;
struct zoneref *preferred_zoneref;
int migratetype;
enum zone_type highest_zoneidx;
bool spread_dirty_pages;
};
enum mminit_level {
MMINIT_WARNING = 0,
MMINIT_VERIFY = 1,
MMINIT_TRACE = 2,
};
typedef int fpi_t;
struct mpage_readpage_args {
struct bio *bio;
struct folio *folio;
unsigned int nr_pages;
bool is_readahead;
sector_t last_block_in_bio;
struct buffer_head map_bh;
long unsigned int first_logical_block;
get_block_t *get_block;
};
struct mpage_data {
struct bio *bio;
long: 32;
sector_t last_block_in_bio;
get_block_t *get_block;
long: 32;
};
struct folio_iter {
struct folio *folio;
size_t offset;
size_t length;
struct folio *_next;
size_t _seg_count;
int _i;
};
struct iomap_ioend {
struct list_head io_list;
u16 io_type;
u16 io_flags;
u32 io_folios;
struct inode *io_inode;
size_t io_size;
loff_t io_offset;
sector_t io_sector;
struct bio *io_bio;
struct bio io_inline_bio;
long: 32;
};
struct iomap_writepage_ctx;
struct iomap_writeback_ops {
int (*map_blocks)(struct iomap_writepage_ctx *, struct inode *, loff_t);
int (*prepare_ioend)(struct iomap_ioend *, int);
void (*discard_folio)(struct folio *, loff_t);
};
struct iomap_writepage_ctx {
struct iomap iomap;
struct iomap_ioend *ioend;
const struct iomap_writeback_ops *ops;
};
struct iomap_page {
atomic_t read_bytes_pending;
atomic_t write_bytes_pending;
spinlock_t uptodate_lock;
long unsigned int uptodate[0];
};
struct iomap_readpage_ctx {
struct folio *cur_folio;
bool cur_folio_in_bio;
struct bio *bio;
struct readahead_control *rac;
};
enum utf8_normalization {
UTF8_NFDI = 0,
UTF8_NFDICF = 1,
UTF8_NMAX = 2,
};
struct fscrypt_str {
unsigned char *name;
u32 len;
};
struct ext4_dir_entry_hash {
__le32 hash;
__le32 minor_hash;
};
struct ext4_dir_entry_2 {
__le32 inode;
__le16 rec_len;
__u8 name_len;
__u8 file_type;
char name[255];
};
struct fname;
struct dir_private_info {
struct rb_root root;
struct rb_node *curr_node;
struct fname *extra_fname;
long: 32;
loff_t last_pos;
__u32 curr_hash;
__u32 curr_minor_hash;
__u32 next_hash;
long: 32;
};
struct fname {
__u32 hash;
__u32 minor_hash;
struct rb_node rb_hash;
struct fname *next;
__u32 inode;
__u8 name_len;
__u8 file_type;
char name[0];
};
struct svc_expkey {
struct cache_head h;
struct auth_domain *ek_client;
int ek_fsidtype;
u32 ek_fsid[6];
struct path ek_path;
struct callback_head ek_rcu;
};
struct flags {
int flag;
char *name[2];
};
struct sem;
struct sem_queue;
struct sem_undo;
struct semid_ds {
struct ipc_perm sem_perm;
__kernel_old_time_t sem_otime;
__kernel_old_time_t sem_ctime;
struct sem *sem_base;
struct sem_queue *sem_pending;
struct sem_queue **sem_pending_last;
struct sem_undo *undo;
short unsigned int sem_nsems;
};
struct sem {
int semval;
struct pid *sempid;
spinlock_t lock;
struct list_head pending_alter;
struct list_head pending_const;
long: 32;
time64_t sem_otime;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct sem_queue {
struct list_head list;
struct task_struct *sleeper;
struct sem_undo *undo;
struct pid *pid;
int status;
struct sembuf *sops;
struct sembuf *blocking;
int nsops;
bool alter;
bool dupsop;
};
struct sem_undo {
struct list_head list_proc;
struct callback_head rcu;
struct sem_undo_list *ulp;
struct list_head list_id;
int semid;
short int *semadj;
};
struct semid64_ds {
struct ipc64_perm sem_perm;
long unsigned int sem_otime;
long unsigned int sem_ctime;
long unsigned int sem_nsems;
long unsigned int sem_otime_high;
long unsigned int sem_ctime_high;
};
struct seminfo {
int semmap;
int semmni;
int semmns;
int semmnu;
int semmsl;
int semopm;
int semume;
int semusz;
int semvmx;
int semaem;
};
struct sem_undo_list {
refcount_t refcnt;
spinlock_t lock;
struct list_head list_proc;
};
struct sem_array {
struct kern_ipc_perm sem_perm;
time64_t sem_ctime;
struct list_head pending_alter;
struct list_head pending_const;
struct list_head list_id;
int sem_nsems;
int complex_count;
unsigned int use_global_lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct sem sems[0];
};
enum asn1_class {
ASN1_UNIV = 0,
ASN1_APPL = 1,
ASN1_CONT = 2,
ASN1_PRIV = 3,
};
enum asn1_method {
ASN1_PRIM = 0,
ASN1_CONS = 1,
};
typedef int (*asn1_action_t)(void *, size_t, unsigned char, const void *, size_t);
struct asn1_decoder {
const unsigned char *machine;
size_t machlen;
const asn1_action_t *actions;
};
enum asn1_opcode {
ASN1_OP_MATCH = 0,
ASN1_OP_MATCH_OR_SKIP = 1,
ASN1_OP_MATCH_ACT = 2,
ASN1_OP_MATCH_ACT_OR_SKIP = 3,
ASN1_OP_MATCH_JUMP = 4,
ASN1_OP_MATCH_JUMP_OR_SKIP = 5,
ASN1_OP_MATCH_ANY = 8,
ASN1_OP_MATCH_ANY_OR_SKIP = 9,
ASN1_OP_MATCH_ANY_ACT = 10,
ASN1_OP_MATCH_ANY_ACT_OR_SKIP = 11,
ASN1_OP_COND_MATCH_OR_SKIP = 17,
ASN1_OP_COND_MATCH_ACT_OR_SKIP = 19,
ASN1_OP_COND_MATCH_JUMP_OR_SKIP = 21,
ASN1_OP_COND_MATCH_ANY = 24,
ASN1_OP_COND_MATCH_ANY_OR_SKIP = 25,
ASN1_OP_COND_MATCH_ANY_ACT = 26,
ASN1_OP_COND_MATCH_ANY_ACT_OR_SKIP = 27,
ASN1_OP_COND_FAIL = 28,
ASN1_OP_COMPLETE = 29,
ASN1_OP_ACT = 30,
ASN1_OP_MAYBE_ACT = 31,
ASN1_OP_END_SEQ = 32,
ASN1_OP_END_SET = 33,
ASN1_OP_END_SEQ_OF = 34,
ASN1_OP_END_SET_OF = 35,
ASN1_OP_END_SEQ_ACT = 36,
ASN1_OP_END_SET_ACT = 37,
ASN1_OP_END_SEQ_OF_ACT = 38,
ASN1_OP_END_SET_OF_ACT = 39,
ASN1_OP_RETURN = 40,
ASN1_OP__NR = 41,
};
enum rsapubkey_actions {
ACT_rsa_get_e = 0,
ACT_rsa_get_n = 1,
NR__rsapubkey_actions = 2,
};
struct rsa_key {
const u8 *n;
const u8 *e;
const u8 *d;
const u8 *p;
const u8 *q;
const u8 *dp;
const u8 *dq;
const u8 *qinv;
size_t n_sz;
size_t e_sz;
size_t d_sz;
size_t p_sz;
size_t q_sz;
size_t dp_sz;
size_t dq_sz;
size_t qinv_sz;
};
struct rsa_mpi_key {
MPI n;
MPI e;
MPI d;
MPI p;
MPI q;
MPI dp;
MPI dq;
MPI qinv;
};
struct x509_certificate {
struct x509_certificate *next;
struct x509_certificate *signer;
struct public_key *pub;
struct public_key_signature *sig;
char *issuer;
char *subject;
struct asymmetric_key_id *id;
struct asymmetric_key_id *skid;
time64_t valid_from;
time64_t valid_to;
const void *tbs;
unsigned int tbs_size;
unsigned int raw_sig_size;
const void *raw_sig;
const void *raw_serial;
unsigned int raw_serial_size;
unsigned int raw_issuer_size;
const void *raw_issuer;
const void *raw_subject;
unsigned int raw_subject_size;
unsigned int raw_skid_size;
const void *raw_skid;
unsigned int index;
bool seen;
bool verified;
bool self_signed;
bool unsupported_sig;
bool blacklisted;
long: 32;
};
struct pkcs7_signed_info {
struct pkcs7_signed_info *next;
struct x509_certificate *signer;
unsigned int index;
bool unsupported_crypto;
bool blacklisted;
const void *msgdigest;
unsigned int msgdigest_len;
unsigned int authattrs_len;
const void *authattrs;
long unsigned int aa_set;
long: 32;
time64_t signing_time;
struct public_key_signature *sig;
long: 32;
};
struct pkcs7_message {
struct x509_certificate *certs;
struct x509_certificate *crl;
struct pkcs7_signed_info *signed_infos;
u8 version;
bool have_authattrs;
enum OID data_type;
size_t data_len;
size_t data_hdrlen;
const void *data;
};
enum bio_merge_status {
BIO_MERGE_OK = 0,
BIO_MERGE_NONE = 1,
BIO_MERGE_FAILED = 2,
};
struct io_op_def {
unsigned int needs_file: 1;
unsigned int plug: 1;
unsigned int hash_reg_file: 1;
unsigned int unbound_nonreg_file: 1;
unsigned int pollin: 1;
unsigned int pollout: 1;
unsigned int poll_exclusive: 1;
unsigned int buffer_select: 1;
unsigned int not_supported: 1;
unsigned int audit_skip: 1;
unsigned int ioprio: 1;
unsigned int iopoll: 1;
unsigned int manual_alloc: 1;
short unsigned int async_size;
const char *name;
int (*prep)(struct io_kiocb *, const struct io_uring_sqe *);
int (*issue)(struct io_kiocb *, unsigned int);
int (*prep_async)(struct io_kiocb *);
void (*cleanup)(struct io_kiocb *);
void (*fail)(struct io_kiocb *);
};
struct font_data {
unsigned int extra[4];
const unsigned char data[0];
};
enum pci_mmap_api {
PCI_MMAP_SYSFS = 0,
PCI_MMAP_PROCFS = 1,
};
struct pci_filp_private {
enum pci_mmap_state mmap_state;
int write_combine;
};
struct tty_file_private {
struct tty_struct *tty;
struct file *file;
struct list_head list;
};
typedef void * (*devcon_match_fn_t)(struct fwnode_handle *, const char *, void *);
enum scsi_devinfo_key {
SCSI_DEVINFO_GLOBAL = 0,
SCSI_DEVINFO_SPI = 1,
};
struct scsi_dev_info_list {
struct list_head dev_info_list;
char vendor[8];
char model[16];
blist_flags_t flags;
unsigned int compatible;
long: 32;
};
struct scsi_dev_info_list_table {
struct list_head node;
struct list_head scsi_dev_info_list;
const char *name;
int key;
};
struct double_list {
struct list_head *top;
struct list_head *bottom;
};
enum ata_prot_flags {
ATA_PROT_FLAG_PIO = 1,
ATA_PROT_FLAG_DMA = 2,
ATA_PROT_FLAG_NCQ = 4,
ATA_PROT_FLAG_ATAPI = 8,
ATA_PROT_UNKNOWN = 255,
ATA_PROT_NODATA = 0,
ATA_PROT_PIO = 1,
ATA_PROT_DMA = 2,
ATA_PROT_NCQ_NODATA = 4,
ATA_PROT_NCQ = 6,
ATAPI_PROT_NODATA = 8,
ATAPI_PROT_PIO = 9,
ATAPI_PROT_DMA = 10,
};
enum hsm_task_states {
HSM_ST_IDLE = 0,
HSM_ST_FIRST = 1,
HSM_ST = 2,
HSM_ST_LAST = 3,
HSM_ST_ERR = 4,
};
struct ata_port_info {
long unsigned int flags;
long unsigned int link_flags;
unsigned int pio_mask;
unsigned int mwdma_mask;
unsigned int udma_mask;
struct ata_port_operations *port_ops;
void *private_data;
};
union input_seq_state {
struct {
short unsigned int pos;
bool mutex_acquired;
};
void *p;
};
struct input_devres {
struct input_dev *input;
};
struct pps_kinfo {
__u32 assert_sequence;
__u32 clear_sequence;
struct pps_ktime assert_tu;
struct pps_ktime clear_tu;
int current_mode;
long: 32;
};
struct pps_fdata {
struct pps_kinfo info;
struct pps_ktime timeout;
};
struct pps_bind_args {
int tsformat;
int edge;
int consumer;
};
struct of_intc_desc {
struct list_head list;
of_irq_init_cb_t irq_init_cb;
struct device_node *dev;
struct device_node *interrupt_parent;
};
enum {
SK_DIAG_BPF_STORAGE_REQ_NONE = 0,
SK_DIAG_BPF_STORAGE_REQ_MAP_FD = 1,
__SK_DIAG_BPF_STORAGE_REQ_MAX = 2,
};
enum {
SK_DIAG_BPF_STORAGE_REP_NONE = 0,
SK_DIAG_BPF_STORAGE = 1,
__SK_DIAG_BPF_STORAGE_REP_MAX = 2,
};
enum {
SK_DIAG_BPF_STORAGE_NONE = 0,
SK_DIAG_BPF_STORAGE_PAD = 1,
SK_DIAG_BPF_STORAGE_MAP_ID = 2,
SK_DIAG_BPF_STORAGE_MAP_VALUE = 3,
__SK_DIAG_BPF_STORAGE_MAX = 4,
};
typedef u64 (*btf_bpf_sk_storage_get)(struct bpf_map *, struct sock *, void *, u64, gfp_t);
typedef u64 (*btf_bpf_sk_storage_delete)(struct bpf_map *, struct sock *);
typedef u64 (*btf_bpf_sk_storage_get_tracing)(struct bpf_map *, struct sock *, void *, u64, gfp_t);
typedef u64 (*btf_bpf_sk_storage_delete_tracing)(struct bpf_map *, struct sock *);
struct bpf_sk_storage_diag {
u32 nr_maps;
struct bpf_map *maps[0];
};
struct bpf_iter_seq_sk_storage_map_info {
struct bpf_map *map;
unsigned int bucket_id;
unsigned int skip_elems;
};
struct bpf_iter__bpf_sk_storage_map {
union {
struct bpf_iter_meta *meta;
};
union {
struct bpf_map *map;
};
union {
struct sock *sk;
};
union {
void *value;
};
};
enum {
ETHTOOL_A_BITSET_BIT_UNSPEC = 0,
ETHTOOL_A_BITSET_BIT_INDEX = 1,
ETHTOOL_A_BITSET_BIT_NAME = 2,
ETHTOOL_A_BITSET_BIT_VALUE = 3,
__ETHTOOL_A_BITSET_BIT_CNT = 4,
ETHTOOL_A_BITSET_BIT_MAX = 3,
};
enum {
ETHTOOL_A_BITSET_BITS_UNSPEC = 0,
ETHTOOL_A_BITSET_BITS_BIT = 1,
__ETHTOOL_A_BITSET_BITS_CNT = 2,
ETHTOOL_A_BITSET_BITS_MAX = 1,
};
enum {
ETHTOOL_A_BITSET_UNSPEC = 0,
ETHTOOL_A_BITSET_NOMASK = 1,
ETHTOOL_A_BITSET_SIZE = 2,
ETHTOOL_A_BITSET_BITS = 3,
ETHTOOL_A_BITSET_VALUE = 4,
ETHTOOL_A_BITSET_MASK = 5,
__ETHTOOL_A_BITSET_CNT = 6,
ETHTOOL_A_BITSET_MAX = 5,
};
enum nf_dev_hooks {
NF_NETDEV_INGRESS = 0,
NF_NETDEV_EGRESS = 1,
NF_NETDEV_NUMHOOKS = 2,
};
enum nf_hook_ops_type {
NF_HOOK_OP_UNDEFINED = 0,
NF_HOOK_OP_NF_TABLES = 1,
};
struct nf_hook_ops {
nf_hookfn *hook;
struct net_device *dev;
void *priv;
u8 pf;
enum nf_hook_ops_type hook_ops_type: 8;
unsigned int hooknum;
int priority;
};
struct nf_hook_entries_rcu_head {
struct callback_head head;
void *allocation;
};
enum nf_nat_manip_type;
struct nf_nat_hook {
int (*parse_nat_setup)(struct nf_conn *, enum nf_nat_manip_type, const struct nlattr *);
void (*decode_session)(struct sk_buff *, struct flowi *);
unsigned int (*manip_pkt)(struct sk_buff *, struct nf_conn *, enum nf_nat_manip_type, enum ip_conntrack_dir);
void (*remove_nat_bysrc)(struct nf_conn *);
};
struct nf_conntrack_zone {
u16 id;
u8 flags;
u8 dir;
};
struct nf_ct_hook {
int (*update)(struct net *, struct sk_buff *);
void (*destroy)(struct nf_conntrack *);
bool (*get_tuple_skb)(struct nf_conntrack_tuple *, const struct sk_buff *);
void (*attach)(struct sk_buff *, const struct sk_buff *);
};
struct nfnl_ct_hook {
size_t (*build_size)(const struct nf_conn *);
int (*build)(struct sk_buff *, struct nf_conn *, enum ip_conntrack_info, u_int16_t, u_int16_t);
int (*parse)(const struct nlattr *, struct nf_conn *);
int (*attach_expect)(const struct nlattr *, struct nf_conn *, u32, u32);
void (*seq_adjust)(struct sk_buff *, struct nf_conn *, enum ip_conntrack_info, s32);
};
struct rps_sock_flow_table {
u32 mask;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
u32 ents[0];
};
struct pingv6_ops {
int (*ipv6_recv_error)(struct sock *, struct msghdr *, int, int *);
void (*ip6_datagram_recv_common_ctl)(struct sock *, struct msghdr *, struct sk_buff *);
void (*ip6_datagram_recv_specific_ctl)(struct sock *, struct msghdr *, struct sk_buff *);
int (*icmpv6_err_convert)(u8, u8, int *);
void (*ipv6_icmp_error)(struct sock *, struct sk_buff *, int, __be16, u32, u8 *);
int (*ipv6_chk_addr)(struct net *, const struct in6_addr *, const struct net_device *, int);
};
enum {
SKB_FCLONE_UNAVAILABLE = 0,
SKB_FCLONE_ORIG = 1,
SKB_FCLONE_CLONE = 2,
};
struct sk_buff_fclones {
struct sk_buff skb1;
struct sk_buff skb2;
refcount_t fclone_ref;
long: 32;
};
enum {
XFRM_LOOKUP_ICMP = 1,
XFRM_LOOKUP_QUEUE = 2,
XFRM_LOOKUP_KEEP_DST_REF = 4,
};
struct xfrm_if_decode_session_result {
struct net *net;
u32 if_id;
};
struct xfrm_if_cb {
bool (*decode_session)(struct sk_buff *, short unsigned int, struct xfrm_if_decode_session_result *);
};
struct xfrm_policy_afinfo {
struct dst_ops *dst_ops;
struct dst_entry * (*dst_lookup)(struct net *, int, int, const xfrm_address_t *, const xfrm_address_t *, u32);
int (*get_saddr)(struct net *, int, xfrm_address_t *, xfrm_address_t *, u32);
int (*fill_dst)(struct xfrm_dst *, struct net_device *, const struct flowi *);
struct dst_entry * (*blackhole_route)(struct net *, struct dst_entry *);
};
struct xfrm_policy_walk {
struct xfrm_policy_walk_entry walk;
u8 type;
u32 seq;
};
struct xfrm_kmaddress {
xfrm_address_t local;
xfrm_address_t remote;
u32 reserved;
u16 family;
};
struct xfrm_migrate {
xfrm_address_t old_daddr;
xfrm_address_t old_saddr;
xfrm_address_t new_daddr;
xfrm_address_t new_saddr;
u8 proto;
u8 mode;
u16 reserved;
u32 reqid;
u16 old_family;
u16 new_family;
};
struct xfrmk_spdinfo {
u32 incnt;
u32 outcnt;
u32 fwdcnt;
u32 inscnt;
u32 outscnt;
u32 fwdscnt;
u32 spdhcnt;
u32 spdhmcnt;
};
struct xfrm_flo {
struct dst_entry *dst_orig;
u8 flags;
};
struct xfrm_pol_inexact_node {
struct rb_node node;
union {
xfrm_address_t addr;
struct callback_head rcu;
};
u8 prefixlen;
struct rb_root root;
struct hlist_head hhead;
};
struct xfrm_pol_inexact_key {
possible_net_t net;
u32 if_id;
u16 family;
u8 dir;
u8 type;
};
struct xfrm_pol_inexact_bin {
struct xfrm_pol_inexact_key k;
struct rhash_head head;
struct hlist_head hhead;
seqcount_spinlock_t count;
struct rb_root root_d;
struct rb_root root_s;
struct list_head inexact_bins;
struct callback_head rcu;
};
enum xfrm_pol_inexact_candidate_type {
XFRM_POL_CAND_BOTH = 0,
XFRM_POL_CAND_SADDR = 1,
XFRM_POL_CAND_DADDR = 2,
XFRM_POL_CAND_ANY = 3,
XFRM_POL_CAND_MAX = 4,
};
struct xfrm_pol_inexact_candidates {
struct hlist_head *res[4];
};
enum rpc_reply_stat {
RPC_MSG_ACCEPTED = 0,
RPC_MSG_DENIED = 1,
};
enum rpc_reject_stat {
RPC_MISMATCH = 0,
RPC_AUTH_ERROR = 1,
};
enum {
SUNRPC_PIPEFS_NFS_PRIO = 0,
SUNRPC_PIPEFS_RPC_PRIO = 1,
};
enum {
RPC_PIPEFS_MOUNT = 0,
RPC_PIPEFS_UMOUNT = 1,
};
struct rpc_add_xprt_test {
void (*add_xprt_test)(struct rpc_clnt *, struct rpc_xprt *, void *);
void *data;
};
struct rpc_cb_add_xprt_calldata {
struct rpc_xprt_switch *xps;
struct rpc_xprt *xprt;
};
struct connect_timeout_data {
long unsigned int connect_timeout;
long unsigned int reconnect_timeout;
};
enum nl80211_iftype {
NL80211_IFTYPE_UNSPECIFIED = 0,
NL80211_IFTYPE_ADHOC = 1,
NL80211_IFTYPE_STATION = 2,
NL80211_IFTYPE_AP = 3,
NL80211_IFTYPE_AP_VLAN = 4,
NL80211_IFTYPE_WDS = 5,
NL80211_IFTYPE_MONITOR = 6,
NL80211_IFTYPE_MESH_POINT = 7,
NL80211_IFTYPE_P2P_CLIENT = 8,
NL80211_IFTYPE_P2P_GO = 9,
NL80211_IFTYPE_P2P_DEVICE = 10,
NL80211_IFTYPE_OCB = 11,
NL80211_IFTYPE_NAN = 12,
NUM_NL80211_IFTYPES = 13,
NL80211_IFTYPE_MAX = 12,
};
struct cfg80211_conn;
struct cfg80211_cached_keys;
enum ieee80211_bss_type {
IEEE80211_BSS_TYPE_ESS = 0,
IEEE80211_BSS_TYPE_PBSS = 1,
IEEE80211_BSS_TYPE_IBSS = 2,
IEEE80211_BSS_TYPE_MBSS = 3,
IEEE80211_BSS_TYPE_ANY = 4,
};
struct cfg80211_cqm_config;
enum nl80211_chan_width {
NL80211_CHAN_WIDTH_20_NOHT = 0,
NL80211_CHAN_WIDTH_20 = 1,
NL80211_CHAN_WIDTH_40 = 2,
NL80211_CHAN_WIDTH_80 = 3,
NL80211_CHAN_WIDTH_80P80 = 4,
NL80211_CHAN_WIDTH_160 = 5,
NL80211_CHAN_WIDTH_5 = 6,
NL80211_CHAN_WIDTH_10 = 7,
NL80211_CHAN_WIDTH_1 = 8,
NL80211_CHAN_WIDTH_2 = 9,
NL80211_CHAN_WIDTH_4 = 10,
NL80211_CHAN_WIDTH_8 = 11,
NL80211_CHAN_WIDTH_16 = 12,
NL80211_CHAN_WIDTH_320 = 13,
};
enum ieee80211_edmg_bw_config {
IEEE80211_EDMG_BW_CONFIG_4 = 4,
IEEE80211_EDMG_BW_CONFIG_5 = 5,
IEEE80211_EDMG_BW_CONFIG_6 = 6,
IEEE80211_EDMG_BW_CONFIG_7 = 7,
IEEE80211_EDMG_BW_CONFIG_8 = 8,
IEEE80211_EDMG_BW_CONFIG_9 = 9,
IEEE80211_EDMG_BW_CONFIG_10 = 10,
IEEE80211_EDMG_BW_CONFIG_11 = 11,
IEEE80211_EDMG_BW_CONFIG_12 = 12,
IEEE80211_EDMG_BW_CONFIG_13 = 13,
IEEE80211_EDMG_BW_CONFIG_14 = 14,
IEEE80211_EDMG_BW_CONFIG_15 = 15,
};
struct ieee80211_edmg {
u8 channels;
enum ieee80211_edmg_bw_config bw_config;
};
struct ieee80211_channel;
struct cfg80211_chan_def {
struct ieee80211_channel *chan;
enum nl80211_chan_width width;
u32 center_freq1;
u32 center_freq2;
struct ieee80211_edmg edmg;
u16 freq1_offset;
};
struct cfg80211_internal_bss;
struct wiphy;
struct wireless_dev {
struct wiphy *wiphy;
enum nl80211_iftype iftype;
struct list_head list;
struct net_device *netdev;
u32 identifier;
struct list_head mgmt_registrations;
u8 mgmt_registrations_need_update: 1;
struct mutex mtx;
bool use_4addr;
bool is_running;
bool registered;
bool registering;
u8 address[6];
struct cfg80211_conn *conn;
struct cfg80211_cached_keys *connect_keys;
enum ieee80211_bss_type conn_bss_type;
u32 conn_owner_nlportid;
struct work_struct disconnect_wk;
u8 disconnect_bssid[6];
struct list_head event_list;
spinlock_t event_lock;
u8 connected: 1;
bool ps;
int ps_timeout;
u32 ap_unexpected_nlportid;
u32 owner_nlportid;
bool nl_owner_dead;
bool cac_started;
long unsigned int cac_start_time;
unsigned int cac_time_ms;
struct cfg80211_cqm_config *cqm_config;
struct list_head pmsr_list;
spinlock_t pmsr_lock;
struct work_struct pmsr_free_wk;
long unsigned int unprot_beacon_reported;
union {
struct {
u8 connected_addr[6];
u8 ssid[32];
u8 ssid_len;
long: 0;
} client;
struct {
int beacon_interval;
struct cfg80211_chan_def preset_chandef;
struct cfg80211_chan_def chandef;
u8 id[32];
u8 id_len;
u8 id_up_len;
} mesh;
struct {
struct cfg80211_chan_def preset_chandef;
u8 ssid[32];
u8 ssid_len;
} ap;
struct {
struct cfg80211_internal_bss *current_bss;
struct cfg80211_chan_def chandef;
int beacon_interval;
u8 ssid[32];
u8 ssid_len;
} ibss;
struct {
struct cfg80211_chan_def chandef;
} ocb;
} u;
struct {
u8 addr[6];
union {
struct {
unsigned int beacon_interval;
struct cfg80211_chan_def chandef;
} ap;
struct {
struct cfg80211_internal_bss *current_bss;
} client;
};
} links[15];
u16 valid_links;
};
struct iw_encode_ext {
__u32 ext_flags;
__u8 tx_seq[8];
__u8 rx_seq[8];
struct sockaddr addr;
__u16 alg;
__u16 key_len;
__u8 key[0];
};
struct iwreq {
union {
char ifrn_name[16];
} ifr_ifrn;
union iwreq_data u;
};
struct iw_event {
__u16 len;
__u16 cmd;
union iwreq_data u;
};
enum nl80211_reg_initiator {
NL80211_REGDOM_SET_BY_CORE = 0,
NL80211_REGDOM_SET_BY_USER = 1,
NL80211_REGDOM_SET_BY_DRIVER = 2,
NL80211_REGDOM_SET_BY_COUNTRY_IE = 3,
};
enum nl80211_dfs_regions {
NL80211_DFS_UNSET = 0,
NL80211_DFS_FCC = 1,
NL80211_DFS_ETSI = 2,
NL80211_DFS_JP = 3,
};
enum nl80211_user_reg_hint_type {
NL80211_USER_REG_HINT_USER = 0,
NL80211_USER_REG_HINT_CELL_BASE = 1,
NL80211_USER_REG_HINT_INDOOR = 2,
};
enum nl80211_mntr_flags {
__NL80211_MNTR_FLAG_INVALID = 0,
NL80211_MNTR_FLAG_FCSFAIL = 1,
NL80211_MNTR_FLAG_PLCPFAIL = 2,
NL80211_MNTR_FLAG_CONTROL = 3,
NL80211_MNTR_FLAG_OTHER_BSS = 4,
NL80211_MNTR_FLAG_COOK_FRAMES = 5,
NL80211_MNTR_FLAG_ACTIVE = 6,
__NL80211_MNTR_FLAG_AFTER_LAST = 7,
NL80211_MNTR_FLAG_MAX = 6,
};
enum nl80211_band {
NL80211_BAND_2GHZ = 0,
NL80211_BAND_5GHZ = 1,
NL80211_BAND_60GHZ = 2,
NL80211_BAND_6GHZ = 3,
NL80211_BAND_S1GHZ = 4,
NL80211_BAND_LC = 5,
NUM_NL80211_BANDS = 6,
};
enum nl80211_ext_feature_index {
NL80211_EXT_FEATURE_VHT_IBSS = 0,
NL80211_EXT_FEATURE_RRM = 1,
NL80211_EXT_FEATURE_MU_MIMO_AIR_SNIFFER = 2,
NL80211_EXT_FEATURE_SCAN_START_TIME = 3,
NL80211_EXT_FEATURE_BSS_PARENT_TSF = 4,
NL80211_EXT_FEATURE_SET_SCAN_DWELL = 5,
NL80211_EXT_FEATURE_BEACON_RATE_LEGACY = 6,
NL80211_EXT_FEATURE_BEACON_RATE_HT = 7,
NL80211_EXT_FEATURE_BEACON_RATE_VHT = 8,
NL80211_EXT_FEATURE_FILS_STA = 9,
NL80211_EXT_FEATURE_MGMT_TX_RANDOM_TA = 10,
NL80211_EXT_FEATURE_MGMT_TX_RANDOM_TA_CONNECTED = 11,
NL80211_EXT_FEATURE_SCHED_SCAN_RELATIVE_RSSI = 12,
NL80211_EXT_FEATURE_CQM_RSSI_LIST = 13,
NL80211_EXT_FEATURE_FILS_SK_OFFLOAD = 14,
NL80211_EXT_FEATURE_4WAY_HANDSHAKE_STA_PSK = 15,
NL80211_EXT_FEATURE_4WAY_HANDSHAKE_STA_1X = 16,
NL80211_EXT_FEATURE_FILS_MAX_CHANNEL_TIME = 17,
NL80211_EXT_FEATURE_ACCEPT_BCAST_PROBE_RESP = 18,
NL80211_EXT_FEATURE_OCE_PROBE_REQ_HIGH_TX_RATE = 19,
NL80211_EXT_FEATURE_OCE_PROBE_REQ_DEFERRAL_SUPPRESSION = 20,
NL80211_EXT_FEATURE_MFP_OPTIONAL = 21,
NL80211_EXT_FEATURE_LOW_SPAN_SCAN = 22,
NL80211_EXT_FEATURE_LOW_POWER_SCAN = 23,
NL80211_EXT_FEATURE_HIGH_ACCURACY_SCAN = 24,
NL80211_EXT_FEATURE_DFS_OFFLOAD = 25,
NL80211_EXT_FEATURE_CONTROL_PORT_OVER_NL80211 = 26,
NL80211_EXT_FEATURE_ACK_SIGNAL_SUPPORT = 27,
NL80211_EXT_FEATURE_DATA_ACK_SIGNAL_SUPPORT = 27,
NL80211_EXT_FEATURE_TXQS = 28,
NL80211_EXT_FEATURE_SCAN_RANDOM_SN = 29,
NL80211_EXT_FEATURE_SCAN_MIN_PREQ_CONTENT = 30,
NL80211_EXT_FEATURE_CAN_REPLACE_PTK0 = 31,
NL80211_EXT_FEATURE_ENABLE_FTM_RESPONDER = 32,
NL80211_EXT_FEATURE_AIRTIME_FAIRNESS = 33,
NL80211_EXT_FEATURE_AP_PMKSA_CACHING = 34,
NL80211_EXT_FEATURE_SCHED_SCAN_BAND_SPECIFIC_RSSI_THOLD = 35,
NL80211_EXT_FEATURE_EXT_KEY_ID = 36,
NL80211_EXT_FEATURE_STA_TX_PWR = 37,
NL80211_EXT_FEATURE_SAE_OFFLOAD = 38,
NL80211_EXT_FEATURE_VLAN_OFFLOAD = 39,
NL80211_EXT_FEATURE_AQL = 40,
NL80211_EXT_FEATURE_BEACON_PROTECTION = 41,
NL80211_EXT_FEATURE_CONTROL_PORT_NO_PREAUTH = 42,
NL80211_EXT_FEATURE_PROTECTED_TWT = 43,
NL80211_EXT_FEATURE_DEL_IBSS_STA = 44,
NL80211_EXT_FEATURE_MULTICAST_REGISTRATIONS = 45,
NL80211_EXT_FEATURE_BEACON_PROTECTION_CLIENT = 46,
NL80211_EXT_FEATURE_SCAN_FREQ_KHZ = 47,
NL80211_EXT_FEATURE_CONTROL_PORT_OVER_NL80211_TX_STATUS = 48,
NL80211_EXT_FEATURE_OPERATING_CHANNEL_VALIDATION = 49,
NL80211_EXT_FEATURE_4WAY_HANDSHAKE_AP_PSK = 50,
NL80211_EXT_FEATURE_SAE_OFFLOAD_AP = 51,
NL80211_EXT_FEATURE_FILS_DISCOVERY = 52,
NL80211_EXT_FEATURE_UNSOL_BCAST_PROBE_RESP = 53,
NL80211_EXT_FEATURE_BEACON_RATE_HE = 54,
NL80211_EXT_FEATURE_SECURE_LTF = 55,
NL80211_EXT_FEATURE_SECURE_RTT = 56,
NL80211_EXT_FEATURE_PROT_RANGE_NEGO_AND_MEASURE = 57,
NL80211_EXT_FEATURE_BSS_COLOR = 58,
NL80211_EXT_FEATURE_FILS_CRYPTO_OFFLOAD = 59,
NL80211_EXT_FEATURE_RADAR_BACKGROUND = 60,
NL80211_EXT_FEATURE_POWERED_ADDR_CHANGE = 61,
NUM_NL80211_EXT_FEATURES = 62,
MAX_NL80211_EXT_FEATURES = 61,
};
enum nl80211_dfs_state {
NL80211_DFS_USABLE = 0,
NL80211_DFS_UNAVAILABLE = 1,
NL80211_DFS_AVAILABLE = 2,
};
struct nl80211_vendor_cmd_info {
__u32 vendor_id;
__u32 subcmd;
};
enum nl80211_sar_type {
NL80211_SAR_TYPE_POWER = 0,
NUM_NL80211_SAR_TYPE = 1,
};
struct ieee80211_mcs_info {
u8 rx_mask[10];
__le16 rx_highest;
u8 tx_params;
u8 reserved[3];
};
struct ieee80211_ht_cap {
__le16 cap_info;
u8 ampdu_params_info;
struct ieee80211_mcs_info mcs;
__le16 extended_ht_cap_info;
__le32 tx_BF_cap_info;
u8 antenna_selection_info;
} __attribute__((packed));
struct ieee80211_vht_mcs_info {
__le16 rx_mcs_map;
__le16 rx_highest;
__le16 tx_mcs_map;
__le16 tx_highest;
};
struct ieee80211_vht_cap {
__le32 vht_cap_info;
struct ieee80211_vht_mcs_info supp_mcs;
};
struct ieee80211_he_cap_elem {
u8 mac_cap_info[6];
u8 phy_cap_info[11];
};
struct ieee80211_he_mcs_nss_supp {
__le16 rx_mcs_80;
__le16 tx_mcs_80;
__le16 rx_mcs_160;
__le16 tx_mcs_160;
__le16 rx_mcs_80p80;
__le16 tx_mcs_80p80;
};
struct ieee80211_eht_mcs_nss_supp_20mhz_only {
u8 rx_tx_mcs7_max_nss;
u8 rx_tx_mcs9_max_nss;
u8 rx_tx_mcs11_max_nss;
u8 rx_tx_mcs13_max_nss;
};
struct ieee80211_eht_mcs_nss_supp_bw {
u8 rx_tx_mcs9_max_nss;
u8 rx_tx_mcs11_max_nss;
u8 rx_tx_mcs13_max_nss;
};
struct ieee80211_eht_cap_elem_fixed {
u8 mac_cap_info[2];
u8 phy_cap_info[9];
};
struct ieee80211_he_6ghz_capa {
__le16 capa;
};
struct rfkill;
enum environment_cap {
ENVIRON_ANY = 0,
ENVIRON_INDOOR = 1,
ENVIRON_OUTDOOR = 2,
};
struct regulatory_request {
struct callback_head callback_head;
int wiphy_idx;
enum nl80211_reg_initiator initiator;
enum nl80211_user_reg_hint_type user_reg_hint_type;
char alpha2[3];
enum nl80211_dfs_regions dfs_region;
bool intersect;
bool processed;
enum environment_cap country_ie_env;
struct list_head list;
};
struct ieee80211_freq_range {
u32 start_freq_khz;
u32 end_freq_khz;
u32 max_bandwidth_khz;
};
struct ieee80211_power_rule {
u32 max_antenna_gain;
u32 max_eirp;
};
struct ieee80211_wmm_ac {
u16 cw_min;
u16 cw_max;
u16 cot;
u8 aifsn;
};
struct ieee80211_wmm_rule {
struct ieee80211_wmm_ac client[4];
struct ieee80211_wmm_ac ap[4];
};
struct ieee80211_reg_rule {
struct ieee80211_freq_range freq_range;
struct ieee80211_power_rule power_rule;
struct ieee80211_wmm_rule wmm_rule;
u32 flags;
u32 dfs_cac_ms;
bool has_wmm;
};
struct ieee80211_regdomain {
struct callback_head callback_head;
u32 n_reg_rules;
char alpha2[3];
enum nl80211_dfs_regions dfs_region;
struct ieee80211_reg_rule reg_rules[0];
};
struct ieee80211_channel {
enum nl80211_band band;
u32 center_freq;
u16 freq_offset;
u16 hw_value;
u32 flags;
int max_antenna_gain;
int max_power;
int max_reg_power;
bool beacon_found;
u32 orig_flags;
int orig_mag;
int orig_mpwr;
enum nl80211_dfs_state dfs_state;
long unsigned int dfs_state_entered;
unsigned int dfs_cac_ms;
};
struct ieee80211_rate {
u32 flags;
u16 bitrate;
u16 hw_value;
u16 hw_value_short;
};
struct ieee80211_sta_ht_cap {
u16 cap;
bool ht_supported;
u8 ampdu_factor;
u8 ampdu_density;
struct ieee80211_mcs_info mcs;
short: 0;
} __attribute__((packed));
struct ieee80211_sta_vht_cap {
bool vht_supported;
u32 cap;
struct ieee80211_vht_mcs_info vht_mcs;
};
struct ieee80211_sta_he_cap {
bool has_he;
struct ieee80211_he_cap_elem he_cap_elem;
struct ieee80211_he_mcs_nss_supp he_mcs_nss_supp;
u8 ppe_thres[25];
} __attribute__((packed));
struct ieee80211_eht_mcs_nss_supp {
union {
struct ieee80211_eht_mcs_nss_supp_20mhz_only only_20mhz;
struct {
struct ieee80211_eht_mcs_nss_supp_bw _80;
struct ieee80211_eht_mcs_nss_supp_bw _160;
struct ieee80211_eht_mcs_nss_supp_bw _320;
} bw;
};
};
struct ieee80211_sta_eht_cap {
bool has_eht;
struct ieee80211_eht_cap_elem_fixed eht_cap_elem;
struct ieee80211_eht_mcs_nss_supp eht_mcs_nss_supp;
u8 eht_ppe_thres[32];
};
struct ieee80211_sband_iftype_data {
u16 types_mask;
struct ieee80211_sta_he_cap he_cap;
struct ieee80211_he_6ghz_capa he_6ghz_capa;
struct ieee80211_sta_eht_cap eht_cap;
struct {
const u8 *data;
unsigned int len;
} vendor_elems;
} __attribute__((packed));
struct ieee80211_sta_s1g_cap {
bool s1g;
u8 cap[10];
u8 nss_mcs[5];
};
struct ieee80211_supported_band {
struct ieee80211_channel *channels;
struct ieee80211_rate *bitrates;
enum nl80211_band band;
int n_channels;
int n_bitrates;
struct ieee80211_sta_ht_cap ht_cap;
struct ieee80211_sta_vht_cap vht_cap;
struct ieee80211_sta_s1g_cap s1g_cap;
struct ieee80211_edmg edmg_cap;
u16 n_iftype_data;
const struct ieee80211_sband_iftype_data *iftype_data;
};
struct mac_address {
u8 addr[6];
};
struct cfg80211_sar_freq_ranges {
u32 start_freq;
u32 end_freq;
};
struct cfg80211_sar_capa {
enum nl80211_sar_type type;
u32 num_freq_ranges;
const struct cfg80211_sar_freq_ranges *freq_ranges;
};
enum cfg80211_signal_type {
CFG80211_SIGNAL_TYPE_NONE = 0,
CFG80211_SIGNAL_TYPE_MBM = 1,
CFG80211_SIGNAL_TYPE_UNSPEC = 2,
};
struct ieee80211_txrx_stypes;
struct ieee80211_iface_combination;
struct wiphy_iftype_akm_suites;
struct wiphy_iftype_ext_capab;
struct wiphy_coalesce_support;
struct wiphy_vendor_command;
struct cfg80211_pmsr_capabilities;
struct wiphy {
struct mutex mtx;
u8 perm_addr[6];
u8 addr_mask[6];
struct mac_address *addresses;
const struct ieee80211_txrx_stypes *mgmt_stypes;
const struct ieee80211_iface_combination *iface_combinations;
int n_iface_combinations;
u16 software_iftypes;
u16 n_addresses;
u16 interface_modes;
u16 max_acl_mac_addrs;
u32 flags;
u32 regulatory_flags;
u32 features;
u8 ext_features[8];
u32 ap_sme_capa;
enum cfg80211_signal_type signal_type;
int bss_priv_size;
u8 max_scan_ssids;
u8 max_sched_scan_reqs;
u8 max_sched_scan_ssids;
u8 max_match_sets;
u16 max_scan_ie_len;
u16 max_sched_scan_ie_len;
u32 max_sched_scan_plans;
u32 max_sched_scan_plan_interval;
u32 max_sched_scan_plan_iterations;
int n_cipher_suites;
const u32 *cipher_suites;
int n_akm_suites;
const u32 *akm_suites;
const struct wiphy_iftype_akm_suites *iftype_akm_suites;
unsigned int num_iftype_akm_suites;
u8 retry_short;
u8 retry_long;
u32 frag_threshold;
u32 rts_threshold;
u8 coverage_class;
char fw_version[32];
u32 hw_version;
u16 max_remain_on_channel_duration;
u8 max_num_pmkids;
u32 available_antennas_tx;
u32 available_antennas_rx;
u32 probe_resp_offload;
const u8 *extended_capabilities;
const u8 *extended_capabilities_mask;
u8 extended_capabilities_len;
const struct wiphy_iftype_ext_capab *iftype_ext_capab;
unsigned int num_iftype_ext_capab;
const void *privid;
struct ieee80211_supported_band *bands[6];
void (*reg_notifier)(struct wiphy *, struct regulatory_request *);
const struct ieee80211_regdomain *regd;
long: 32;
struct device dev;
bool registered;
struct dentry *debugfsdir;
const struct ieee80211_ht_cap *ht_capa_mod_mask;
const struct ieee80211_vht_cap *vht_capa_mod_mask;
struct list_head wdev_list;
possible_net_t _net;
const struct wiphy_coalesce_support *coalesce;
const struct wiphy_vendor_command *vendor_commands;
const struct nl80211_vendor_cmd_info *vendor_events;
int n_vendor_commands;
int n_vendor_events;
u16 max_ap_assoc_sta;
u8 max_num_csa_counters;
u32 bss_select_support;
u8 nan_supported_bands;
u32 txq_limit;
u32 txq_memory_limit;
u32 txq_quantum;
long unsigned int tx_queue_len;
u8 support_mbssid: 1;
u8 support_only_he_mbssid: 1;
const struct cfg80211_pmsr_capabilities *pmsr_capa;
long: 32;
struct {
u64 peer;
u64 vif;
u8 max_retry;
long: 32;
} tid_config_support;
u8 max_data_retry_count;
const struct cfg80211_sar_capa *sar_capa;
struct rfkill *rfkill;
u8 mbssid_max_interfaces;
u8 ema_max_profile_periodicity;
u16 max_num_akm_suites;
long: 32;
long: 32;
char priv[0];
};
struct ieee80211_iface_limit {
u16 max;
u16 types;
};
struct ieee80211_iface_combination {
const struct ieee80211_iface_limit *limits;
u32 num_different_channels;
u16 max_interfaces;
u8 n_limits;
bool beacon_int_infra_match;
u8 radar_detect_widths;
u8 radar_detect_regions;
u32 beacon_int_min_gcd;
};
struct ieee80211_txrx_stypes {
u16 tx;
u16 rx;
};
struct wiphy_coalesce_support {
int n_rules;
int max_delay;
int n_patterns;
int pattern_max_len;
int pattern_min_len;
int max_pkt_offset;
};
struct wiphy_vendor_command {
struct nl80211_vendor_cmd_info info;
u32 flags;
int (*doit)(struct wiphy *, struct wireless_dev *, const void *, int);
int (*dumpit)(struct wiphy *, struct wireless_dev *, struct sk_buff *, const void *, int, long unsigned int *);
const struct nla_policy *policy;
unsigned int maxattr;
};
struct wiphy_iftype_ext_capab {
enum nl80211_iftype iftype;
const u8 *extended_capabilities;
const u8 *extended_capabilities_mask;
u8 extended_capabilities_len;
u16 eml_capabilities;
u16 mld_capa_and_ops;
};
struct cfg80211_pmsr_capabilities {
unsigned int max_peers;
u8 report_ap_tsf: 1;
u8 randomize_mac_addr: 1;
struct {
u32 preambles;
u32 bandwidths;
s8 max_bursts_exponent;
u8 max_ftms_per_burst;
u8 supported: 1;
u8 asap: 1;
u8 non_asap: 1;
u8 request_lci: 1;
u8 request_civicloc: 1;
u8 trigger_based: 1;
u8 non_trigger_based: 1;
} ftm;
};
struct wiphy_iftype_akm_suites {
u16 iftypes_mask;
const u32 *akm_suites;
int n_akm_suites;
};
struct iw_ioctl_description {
__u8 header_type;
__u8 token_type;
__u16 token_size;
__u16 min_tokens;
__u16 max_tokens;
__u32 flags;
};
typedef int (*wext_ioctl_func)(struct net_device *, struct iwreq *, unsigned int, struct iw_request_info *, iw_handler);
struct flush_tlb_data {
struct vm_area_struct *vma;
long unsigned int addr1;
long unsigned int addr2;
};
struct vm_special_mapping {
const char *name;
struct page **pages;
vm_fault_t (*fault)(const struct vm_special_mapping *, struct vm_area_struct *, struct vm_fault *);
int (*mremap)(const struct vm_special_mapping *, struct vm_area_struct *);
};
struct mips_vdso_image {
void *data;
long unsigned int size;
long unsigned int off_sigreturn;
long unsigned int off_rt_sigreturn;
struct vm_special_mapping mapping;
};
struct wq_flusher;
struct worker;
struct workqueue_attrs;
struct pool_workqueue;
struct wq_device;
struct workqueue_struct {
struct list_head pwqs;
struct list_head list;
struct mutex mutex;
int work_color;
int flush_color;
atomic_t nr_pwqs_to_flush;
struct wq_flusher *first_flusher;
struct list_head flusher_queue;
struct list_head flusher_overflow;
struct list_head maydays;
struct worker *rescuer;
int nr_drainers;
int saved_max_active;
struct workqueue_attrs *unbound_attrs;
struct pool_workqueue *dfl_pwq;
struct wq_device *wq_dev;
char name[24];
struct callback_head rcu;
unsigned int flags;
struct pool_workqueue *cpu_pwqs;
struct pool_workqueue *numa_pwq_tbl[0];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct workqueue_attrs {
int nice;
cpumask_var_t cpumask;
bool no_numa;
};
struct worker_pool;
struct worker {
union {
struct list_head entry;
struct hlist_node hentry;
};
struct work_struct *current_work;
work_func_t current_func;
struct pool_workqueue *current_pwq;
unsigned int current_color;
struct list_head scheduled;
struct task_struct *task;
struct worker_pool *pool;
struct list_head node;
long unsigned int last_active;
unsigned int flags;
int id;
int sleeping;
char desc[24];
struct workqueue_struct *rescue_wq;
work_func_t last_func;
};
struct pool_workqueue {
struct worker_pool *pool;
struct workqueue_struct *wq;
int work_color;
int flush_color;
int refcnt;
int nr_in_flight[16];
int nr_active;
int max_active;
struct list_head inactive_works;
struct list_head pwqs_node;
struct list_head mayday_node;
struct work_struct unbound_release_work;
struct callback_head rcu;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct worker_pool {
raw_spinlock_t lock;
int cpu;
int node;
int id;
unsigned int flags;
long unsigned int watchdog_ts;
int nr_running;
struct list_head worklist;
int nr_workers;
int nr_idle;
struct list_head idle_list;
struct timer_list idle_timer;
struct timer_list mayday_timer;
struct hlist_head busy_hash[64];
struct worker *manager;
struct list_head workers;
struct completion *detach_completion;
struct ida worker_ida;
struct workqueue_attrs *attrs;
struct hlist_node hash_node;
int refcnt;
struct callback_head rcu;
};
enum {
POOL_MANAGER_ACTIVE = 1,
POOL_DISASSOCIATED = 4,
WORKER_DIE = 2,
WORKER_IDLE = 4,
WORKER_PREP = 8,
WORKER_CPU_INTENSIVE = 64,
WORKER_UNBOUND = 128,
WORKER_REBOUND = 256,
WORKER_NOT_RUNNING = 456,
NR_STD_WORKER_POOLS = 2,
UNBOUND_POOL_HASH_ORDER = 6,
BUSY_WORKER_HASH_ORDER = 6,
MAX_IDLE_WORKERS_RATIO = 4,
IDLE_WORKER_TIMEOUT = 30000,
MAYDAY_INITIAL_TIMEOUT = 2,
MAYDAY_INTERVAL = 10,
CREATE_COOLDOWN = 100,
RESCUER_NICE_LEVEL = -20,
HIGHPRI_NICE_LEVEL = -20,
WQ_NAME_LEN = 24,
};
struct wq_flusher {
struct list_head list;
int flush_color;
struct completion done;
};
struct wq_device {
struct workqueue_struct *wq;
long: 32;
struct device dev;
};
struct trace_event_raw_workqueue_queue_work {
struct trace_entry ent;
void *work;
void *function;
u32 __data_loc_workqueue;
int req_cpu;
int cpu;
char __data[0];
};
struct trace_event_raw_workqueue_activate_work {
struct trace_entry ent;
void *work;
char __data[0];
};
struct trace_event_raw_workqueue_execute_start {
struct trace_entry ent;
void *work;
void *function;
char __data[0];
};
struct trace_event_raw_workqueue_execute_end {
struct trace_entry ent;
void *work;
void *function;
char __data[0];
};
struct trace_event_data_offsets_workqueue_queue_work {
u32 workqueue;
};
struct trace_event_data_offsets_workqueue_activate_work {};
struct trace_event_data_offsets_workqueue_execute_start {};
struct trace_event_data_offsets_workqueue_execute_end {};
typedef void (*btf_trace_workqueue_queue_work)(void *, int, struct pool_workqueue *, struct work_struct *);
typedef void (*btf_trace_workqueue_activate_work)(void *, struct work_struct *);
typedef void (*btf_trace_workqueue_execute_start)(void *, struct work_struct *);
typedef void (*btf_trace_workqueue_execute_end)(void *, struct work_struct *, work_func_t);
struct wq_barrier {
struct work_struct work;
struct completion done;
struct task_struct *task;
};
struct cwt_wait {
wait_queue_entry_t wait;
struct work_struct *work;
};
struct apply_wqattrs_ctx {
struct workqueue_struct *wq;
struct workqueue_attrs *attrs;
struct list_head list;
struct pool_workqueue *dfl_pwq;
struct pool_workqueue *pwq_tbl[0];
};
struct work_for_cpu {
struct work_struct work;
long int (*fn)(void *);
void *arg;
long int ret;
};
struct rchan_percpu_buf_dispatcher {
struct rchan_buf *buf;
struct dentry *dentry;
};
struct trace_bprintk_fmt {
struct list_head list;
const char *fmt;
};
enum {
BPF_F_GET_BRANCH_RECORDS_SIZE = 1,
};
struct bpf_perf_event_value {
__u64 counter;
__u64 enabled;
__u64 running;
};
struct btf_ptr {
void *ptr;
__u32 type_id;
__u32 flags;
};
enum key_lookup_flag {
KEY_LOOKUP_CREATE = 1,
KEY_LOOKUP_PARTIAL = 2,
KEY_LOOKUP_ALL = 3,
};
struct bpf_event_entry {
struct perf_event *event;
struct file *perf_file;
struct file *map_file;
struct callback_head rcu;
};
struct bpf_dynptr_kern {
void *data;
u32 size;
u32 offset;
long: 32;
};
struct bpf_key {
struct key *key;
bool has_ref;
};
typedef int kprobe_opcode_t;
struct arch_specific_insn {
int dummy;
};
struct kprobe;
typedef int (*kprobe_pre_handler_t)(struct kprobe *, struct pt_regs *);
typedef void (*kprobe_post_handler_t)(struct kprobe *, struct pt_regs *, long unsigned int);
struct kprobe {
struct hlist_node hlist;
struct list_head list;
long unsigned int nmissed;
kprobe_opcode_t *addr;
const char *symbol_name;
unsigned int offset;
kprobe_pre_handler_t pre_handler;
kprobe_post_handler_t post_handler;
kprobe_opcode_t opcode;
struct arch_specific_insn ainsn;
u32 flags;
};
enum perf_type_id {
PERF_TYPE_HARDWARE = 0,
PERF_TYPE_SOFTWARE = 1,
PERF_TYPE_TRACEPOINT = 2,
PERF_TYPE_HW_CACHE = 3,
PERF_TYPE_RAW = 4,
PERF_TYPE_BREAKPOINT = 5,
PERF_TYPE_MAX = 6,
};
enum perf_event_sample_format {
PERF_SAMPLE_IP = 1,
PERF_SAMPLE_TID = 2,
PERF_SAMPLE_TIME = 4,
PERF_SAMPLE_ADDR = 8,
PERF_SAMPLE_READ = 16,
PERF_SAMPLE_CALLCHAIN = 32,
PERF_SAMPLE_ID = 64,
PERF_SAMPLE_CPU = 128,
PERF_SAMPLE_PERIOD = 256,
PERF_SAMPLE_STREAM_ID = 512,
PERF_SAMPLE_RAW = 1024,
PERF_SAMPLE_BRANCH_STACK = 2048,
PERF_SAMPLE_REGS_USER = 4096,
PERF_SAMPLE_STACK_USER = 8192,
PERF_SAMPLE_WEIGHT = 16384,
PERF_SAMPLE_DATA_SRC = 32768,
PERF_SAMPLE_IDENTIFIER = 65536,
PERF_SAMPLE_TRANSACTION = 131072,
PERF_SAMPLE_REGS_INTR = 262144,
PERF_SAMPLE_PHYS_ADDR = 524288,
PERF_SAMPLE_AUX = 1048576,
PERF_SAMPLE_CGROUP = 2097152,
PERF_SAMPLE_DATA_PAGE_SIZE = 4194304,
PERF_SAMPLE_CODE_PAGE_SIZE = 8388608,
PERF_SAMPLE_WEIGHT_STRUCT = 16777216,
PERF_SAMPLE_MAX = 33554432,
};
struct perf_event_query_bpf {
__u32 ids_len;
__u32 prog_cnt;
__u32 ids[0];
};
struct trace_event_raw_bpf_trace_printk {
struct trace_entry ent;
u32 __data_loc_bpf_string;
char __data[0];
};
struct trace_event_data_offsets_bpf_trace_printk {
u32 bpf_string;
};
typedef void (*btf_trace_bpf_trace_printk)(void *, const char *);
struct bpf_trace_module {
struct module *module;
struct list_head list;
};
typedef u64 (*btf_bpf_probe_read_user)(void *, u32, const void *);
typedef u64 (*btf_bpf_probe_read_user_str)(void *, u32, const void *);
typedef u64 (*btf_bpf_probe_read_kernel)(void *, u32, const void *);
typedef u64 (*btf_bpf_probe_read_kernel_str)(void *, u32, const void *);
typedef u64 (*btf_bpf_probe_read_compat)(void *, u32, const void *);
typedef u64 (*btf_bpf_probe_read_compat_str)(void *, u32, const void *);
typedef u64 (*btf_bpf_probe_write_user)(void *, const void *, u32);
typedef u64 (*btf_bpf_trace_printk)(char *, u32, u64, u64, u64);
typedef u64 (*btf_bpf_trace_vprintk)(char *, u32, const void *, u32);
typedef u64 (*btf_bpf_seq_printf)(struct seq_file *, char *, u32, const void *, u32);
typedef u64 (*btf_bpf_seq_write)(struct seq_file *, const void *, u32);
typedef u64 (*btf_bpf_seq_printf_btf)(struct seq_file *, struct btf_ptr *, u32, u64);
typedef u64 (*btf_bpf_perf_event_read)(struct bpf_map *, u64);
typedef u64 (*btf_bpf_perf_event_read_value)(struct bpf_map *, u64, struct bpf_perf_event_value *, u32);
struct bpf_trace_sample_data {
struct perf_sample_data sds[3];
};
typedef u64 (*btf_bpf_perf_event_output)(struct pt_regs *, struct bpf_map *, u64, void *, u64);
struct bpf_nested_pt_regs {
struct pt_regs regs[3];
};
typedef u64 (*btf_bpf_get_current_task)();
typedef u64 (*btf_bpf_get_current_task_btf)();
typedef u64 (*btf_bpf_task_pt_regs)(struct task_struct *);
typedef u64 (*btf_bpf_current_task_under_cgroup)(struct bpf_map *, u32);
struct send_signal_irq_work {
struct irq_work irq_work;
struct task_struct *task;
u32 sig;
enum pid_type type;
};
typedef u64 (*btf_bpf_send_signal)(u32);
typedef u64 (*btf_bpf_send_signal_thread)(u32);
typedef u64 (*btf_bpf_d_path)(struct path *, char *, u32);
typedef u64 (*btf_bpf_snprintf_btf)(char *, u32, struct btf_ptr *, u32, u64);
typedef u64 (*btf_bpf_get_func_ip_tracing)(void *);
typedef u64 (*btf_bpf_get_func_ip_kprobe)(struct pt_regs *);
typedef u64 (*btf_bpf_get_func_ip_kprobe_multi)(struct pt_regs *);
typedef u64 (*btf_bpf_get_attach_cookie_kprobe_multi)(struct pt_regs *);
typedef u64 (*btf_bpf_get_attach_cookie_trace)(void *);
typedef u64 (*btf_bpf_get_attach_cookie_pe)(struct bpf_perf_event_data_kern *);
typedef u64 (*btf_bpf_get_attach_cookie_tracing)(void *);
typedef u64 (*btf_bpf_get_branch_snapshot)(void *, u32, u64);
typedef u64 (*btf_get_func_arg)(void *, u32, u64 *);
typedef u64 (*btf_get_func_ret)(void *, u64 *);
typedef u64 (*btf_get_func_arg_cnt)(void *);
typedef u64 (*btf_bpf_perf_event_output_tp)(void *, struct bpf_map *, u64, void *, u64);
typedef u64 (*btf_bpf_get_stackid_tp)(void *, struct bpf_map *, u64);
typedef u64 (*btf_bpf_get_stack_tp)(void *, void *, u32, u64);
typedef u64 (*btf_bpf_perf_prog_read_value)(struct bpf_perf_event_data_kern *, struct bpf_perf_event_value *, u32);
typedef u64 (*btf_bpf_read_branch_records)(struct bpf_perf_event_data_kern *, void *, u32, u64);
struct bpf_raw_tp_regs {
struct pt_regs regs[3];
};
typedef u64 (*btf_bpf_perf_event_output_raw_tp)(struct bpf_raw_tracepoint_args *, struct bpf_map *, u64, void *, u64);
typedef u64 (*btf_bpf_get_stackid_raw_tp)(struct bpf_raw_tracepoint_args *, struct bpf_map *, u64);
typedef u64 (*btf_bpf_get_stack_raw_tp)(struct bpf_raw_tracepoint_args *, void *, u32, u64);
enum {
PERCPU_REF_INIT_ATOMIC = 1,
PERCPU_REF_INIT_DEAD = 2,
PERCPU_REF_ALLOW_REINIT = 4,
};
union swap_header {
struct {
char reserved[16374];
char magic[10];
} magic;
struct {
char bootbits[1024];
__u32 version;
__u32 last_page;
__u32 nr_badpages;
unsigned char sws_uuid[16];
unsigned char sws_volume[16];
__u32 padding[117];
__u32 badpages[1];
} info;
};
struct swap_extent {
struct rb_node rb_node;
long unsigned int start_page;
long unsigned int nr_pages;
long: 32;
sector_t start_block;
};
enum {
SWP_USED = 1,
SWP_WRITEOK = 2,
SWP_DISCARDABLE = 4,
SWP_DISCARDING = 8,
SWP_SOLIDSTATE = 16,
SWP_CONTINUED = 32,
SWP_BLKDEV = 64,
SWP_ACTIVATED = 128,
SWP_FS_OPS = 256,
SWP_AREA_DISCARD = 512,
SWP_PAGE_DISCARD = 1024,
SWP_STABLE_WRITES = 2048,
SWP_SYNCHRONOUS_IO = 4096,
SWP_SCANNING = 16384,
};
struct inotify_event_info {
struct fsnotify_event fse;
u32 mask;
int wd;
u32 sync_cookie;
int name_len;
char name[0];
};
struct inotify_inode_mark {
struct fsnotify_mark fsn_mark;
int wd;
};
struct arch_elf_state {
int nan_2008;
int fp_abi;
int interp_fp_abi;
int overall_fp_mode;
};
struct core_vma_metadata;
struct coredump_params {
const kernel_siginfo_t *siginfo;
struct pt_regs *regs;
struct file *file;
long unsigned int limit;
long unsigned int mm_flags;
long: 32;
loff_t written;
loff_t pos;
loff_t to_skip;
int vma_count;
size_t vma_data_size;
struct core_vma_metadata *vma_meta;
long: 32;
};
struct core_vma_metadata {
long unsigned int start;
long unsigned int end;
long unsigned int flags;
long unsigned int dump_size;
long unsigned int pgoff;
struct file *file;
};
struct memelfnote {
const char *name;
int type;
unsigned int datasz;
void *data;
};
struct elf_thread_core_info {
struct elf_thread_core_info *next;
struct task_struct *task;
struct elf_prstatus prstatus;
struct memelfnote notes[0];
};
struct elf_note_info {
struct elf_thread_core_info *thread;
struct memelfnote psinfo;
struct memelfnote signote;
struct memelfnote auxv;
struct memelfnote files;
siginfo_t csigdata;
size_t size;
int thread_notes;
};
struct fstrim_range {
__u64 start;
__u64 len;
__u64 minlen;
};
struct fiemap {
__u64 fm_start;
__u64 fm_length;
__u32 fm_flags;
__u32 fm_mapped_extents;
__u32 fm_extent_count;
__u32 fm_reserved;
struct fiemap_extent fm_extents[0];
};
struct ext4_new_group_input {
__u32 group;
long: 32;
__u64 block_bitmap;
__u64 inode_bitmap;
__u64 inode_table;
__u32 blocks_count;
__u16 reserved_blocks;
__u16 unused;
};
struct ext4_new_group_data {
__u32 group;
long: 32;
__u64 block_bitmap;
__u64 inode_bitmap;
__u64 inode_table;
__u32 blocks_count;
__u16 reserved_blocks;
__u16 mdata_blocks;
__u32 free_clusters_count;
long: 32;
};
struct fsuuid {
__u32 fsu_len;
__u32 fsu_flags;
__u8 fsu_uuid[0];
};
struct move_extent {
__u32 reserved;
__u32 donor_fd;
__u64 orig_start;
__u64 donor_start;
__u64 len;
__u64 moved_len;
};
struct fsmap_head {
__u32 fmh_iflags;
__u32 fmh_oflags;
__u32 fmh_count;
__u32 fmh_entries;
__u64 fmh_reserved[6];
struct fsmap fmh_keys[2];
struct fsmap fmh_recs[0];
};
typedef void ext4_update_sb_callback(struct ext4_super_block *, const void *);
struct getfsmap_info {
struct super_block *gi_sb;
struct fsmap_head *gi_data;
unsigned int gi_idx;
__u32 gi_last_flags;
};
struct nlm_reboot {
char *mon;
unsigned int len;
u32 state;
struct nsm_private priv;
};
struct keyring_search_context {
struct keyring_index_key index_key;
const struct cred *cred;
struct key_match_data match_data;
unsigned int flags;
int (*iterator)(const void *, void *);
int skipped_ret;
bool possessed;
key_ref_t result;
long: 32;
time64_t now;
};
struct keyring_read_iterator_context {
size_t buflen;
size_t count;
key_serial_t *buffer;
};
struct io_fadvise {
struct file *file;
long: 32;
u64 offset;
u32 len;
u32 advice;
};
struct io_madvise {
struct file *file;
long: 32;
u64 addr;
u32 len;
u32 advice;
};
struct sg_append_table {
struct sg_table sgt;
struct scatterlist *prv;
unsigned int total_nents;
};
struct sg_page_iter {
struct scatterlist *sg;
unsigned int sg_pgoffset;
unsigned int __nents;
int __pg_advance;
};
struct sg_dma_page_iter {
struct sg_page_iter base;
};
struct sg_mapping_iter {
struct page *page;
void *addr;
size_t length;
size_t consumed;
struct sg_page_iter piter;
unsigned int __offset;
unsigned int __remaining;
unsigned int __flags;
};
enum gcry_mpi_format {
GCRYMPI_FMT_NONE = 0,
GCRYMPI_FMT_STD = 1,
GCRYMPI_FMT_PGP = 2,
GCRYMPI_FMT_SSH = 3,
GCRYMPI_FMT_HEX = 4,
GCRYMPI_FMT_USG = 5,
GCRYMPI_FMT_OPAQUE = 8,
};
enum maddf_flags {
MADDF_NEGATE_PRODUCT = 1,
MADDF_NEGATE_ADDITION = 2,
};
struct resource_entry {
struct list_head node;
struct resource *res;
resource_size_t offset;
struct resource __res;
};
struct hotplug_slot_ops;
struct hotplug_slot {
const struct hotplug_slot_ops *ops;
struct list_head slot_list;
struct pci_slot *pci_slot;
struct module *owner;
const char *mod_name;
};
enum pci_bus_flags {
PCI_BUS_FLAGS_NO_MSI = 1,
PCI_BUS_FLAGS_NO_MMRBC = 2,
PCI_BUS_FLAGS_NO_AERSID = 4,
PCI_BUS_FLAGS_NO_EXTCFG = 8,
};
enum pci_bus_speed {
PCI_SPEED_33MHz = 0,
PCI_SPEED_66MHz = 1,
PCI_SPEED_66MHz_PCIX = 2,
PCI_SPEED_100MHz_PCIX = 3,
PCI_SPEED_133MHz_PCIX = 4,
PCI_SPEED_66MHz_PCIX_ECC = 5,
PCI_SPEED_100MHz_PCIX_ECC = 6,
PCI_SPEED_133MHz_PCIX_ECC = 7,
PCI_SPEED_66MHz_PCIX_266 = 9,
PCI_SPEED_100MHz_PCIX_266 = 10,
PCI_SPEED_133MHz_PCIX_266 = 11,
AGP_UNKNOWN = 12,
AGP_1X = 13,
AGP_2X = 14,
AGP_4X = 15,
AGP_8X = 16,
PCI_SPEED_66MHz_PCIX_533 = 17,
PCI_SPEED_100MHz_PCIX_533 = 18,
PCI_SPEED_133MHz_PCIX_533 = 19,
PCIE_SPEED_2_5GT = 20,
PCIE_SPEED_5_0GT = 21,
PCIE_SPEED_8_0GT = 22,
PCIE_SPEED_16_0GT = 23,
PCIE_SPEED_32_0GT = 24,
PCIE_SPEED_64_0GT = 25,
PCI_SPEED_UNKNOWN = 255,
};
enum pcie_bus_config_types {
PCIE_BUS_TUNE_OFF = 0,
PCIE_BUS_DEFAULT = 1,
PCIE_BUS_SAFE = 2,
PCIE_BUS_PERFORMANCE = 3,
PCIE_BUS_PEER2PEER = 4,
};
enum pci_fixup_pass {
pci_fixup_early = 0,
pci_fixup_header = 1,
pci_fixup_final = 2,
pci_fixup_enable = 3,
pci_fixup_resume = 4,
pci_fixup_suspend = 5,
pci_fixup_resume_early = 6,
pci_fixup_suspend_late = 7,
};
struct hotplug_slot_ops {
int (*enable_slot)(struct hotplug_slot *);
int (*disable_slot)(struct hotplug_slot *);
int (*set_attention_status)(struct hotplug_slot *, u8);
int (*hardware_test)(struct hotplug_slot *, u32);
int (*get_power_status)(struct hotplug_slot *, u8 *);
int (*get_attention_status)(struct hotplug_slot *, u8 *);
int (*get_latch_status)(struct hotplug_slot *, u8 *);
int (*get_adapter_status)(struct hotplug_slot *, u8 *);
int (*reset_slot)(struct hotplug_slot *, bool);
};
enum pci_bar_type {
pci_bar_unknown = 0,
pci_bar_io = 1,
pci_bar_mem32 = 2,
pci_bar_mem64 = 3,
};
struct pci_domain_busn_res {
struct list_head list;
struct resource res;
int domain_nr;
};
struct clk_gate {
struct clk_hw hw;
void *reg;
u8 bit_idx;
u8 flags;
spinlock_t *lock;
};
struct vc_selection {
struct mutex lock;
struct vc_data *cons;
char *buffer;
unsigned int buf_len;
volatile int start;
int end;
};
enum scsi_vpd_parameters {
SCSI_VPD_HEADER_SIZE = 4,
};
struct trace_event_raw_scsi_dispatch_cmd_start {
struct trace_entry ent;
unsigned int host_no;
unsigned int channel;
unsigned int id;
unsigned int lun;
unsigned int opcode;
unsigned int cmd_len;
int driver_tag;
int scheduler_tag;
unsigned int data_sglen;
unsigned int prot_sglen;
unsigned char prot_op;
u32 __data_loc_cmnd;
char __data[0];
};
struct trace_event_raw_scsi_dispatch_cmd_error {
struct trace_entry ent;
unsigned int host_no;
unsigned int channel;
unsigned int id;
unsigned int lun;
int rtn;
unsigned int opcode;
unsigned int cmd_len;
int driver_tag;
int scheduler_tag;
unsigned int data_sglen;
unsigned int prot_sglen;
unsigned char prot_op;
u32 __data_loc_cmnd;
char __data[0];
};
struct trace_event_raw_scsi_cmd_done_timeout_template {
struct trace_entry ent;
unsigned int host_no;
unsigned int channel;
unsigned int id;
unsigned int lun;
int result;
unsigned int opcode;
unsigned int cmd_len;
int driver_tag;
int scheduler_tag;
unsigned int data_sglen;
unsigned int prot_sglen;
unsigned char prot_op;
u32 __data_loc_cmnd;
char __data[0];
};
struct trace_event_raw_scsi_eh_wakeup {
struct trace_entry ent;
unsigned int host_no;
char __data[0];
};
struct trace_event_data_offsets_scsi_dispatch_cmd_start {
u32 cmnd;
};
struct trace_event_data_offsets_scsi_dispatch_cmd_error {
u32 cmnd;
};
struct trace_event_data_offsets_scsi_cmd_done_timeout_template {
u32 cmnd;
};
struct trace_event_data_offsets_scsi_eh_wakeup {};
typedef void (*btf_trace_scsi_dispatch_cmd_start)(void *, struct scsi_cmnd *);
typedef void (*btf_trace_scsi_dispatch_cmd_error)(void *, struct scsi_cmnd *, int);
typedef void (*btf_trace_scsi_dispatch_cmd_done)(void *, struct scsi_cmnd *);
typedef void (*btf_trace_scsi_dispatch_cmd_timeout)(void *, struct scsi_cmnd *);
typedef void (*btf_trace_scsi_eh_wakeup)(void *, struct Scsi_Host *);
enum ata_dev_iter_mode {
ATA_DITER_ENABLED = 0,
ATA_DITER_ENABLED_REVERSE = 1,
ATA_DITER_ALL = 2,
ATA_DITER_ALL_REVERSE = 3,
};
enum controller {
BIOS = 0,
SNOOP = 1,
PDC20230 = 2,
HT6560A = 3,
HT6560B = 4,
OPTI611A = 5,
OPTI46X = 6,
QDI6500 = 7,
QDI6580 = 8,
QDI6580DP = 9,
W83759A = 10,
UNKNOWN = -1,
};
struct legacy_data {
long unsigned int timing;
u8 clock[2];
u8 last;
int fast;
enum controller type;
struct platform_device *platform_dev;
};
struct legacy_probe {
unsigned char *name;
long unsigned int port;
unsigned int irq;
unsigned int slot;
enum controller type;
long unsigned int private;
};
struct legacy_controller {
const char *name;
struct ata_port_operations *ops;
unsigned int pio_mask;
unsigned int flags;
unsigned int pflags;
int (*setup)(struct platform_device *, struct legacy_probe *, struct legacy_data *);
};
struct dev_ext_attribute {
struct device_attribute attr;
void *var;
};
struct mdio_driver {
struct mdio_driver_common mdiodrv;
int (*probe)(struct mdio_device *);
void (*remove)(struct mdio_device *);
void (*shutdown)(struct mdio_device *);
};
struct mdio_board_info {
const char *bus_id;
char modalias[32];
int mdio_addr;
const void *platform_data;
};
struct trace_event_raw_mdio_access {
struct trace_entry ent;
char busid[61];
char read;
u8 addr;
u16 val;
unsigned int regnum;
char __data[0];
};
struct trace_event_data_offsets_mdio_access {};
typedef void (*btf_trace_mdio_access)(void *, struct mii_bus *, char, u8, unsigned int, u16, int);
struct mdio_bus_stat_attr {
int addr;
unsigned int field_offset;
};
struct input_event {
__kernel_ulong_t __sec;
__kernel_ulong_t __usec;
__u16 type;
__u16 code;
__s32 value;
};
struct ps2dev {
struct serio *serio;
struct mutex cmd_mutex;
wait_queue_head_t wait;
long unsigned int flags;
u8 cmdbuf[8];
u8 cmdcnt;
u8 nak;
};
enum psmouse_state {
PSMOUSE_IGNORE = 0,
PSMOUSE_INITIALIZING = 1,
PSMOUSE_RESYNCING = 2,
PSMOUSE_CMD_MODE = 3,
PSMOUSE_ACTIVATED = 4,
};
typedef enum {
PSMOUSE_BAD_DATA = 0,
PSMOUSE_GOOD_DATA = 1,
PSMOUSE_FULL_PACKET = 2,
} psmouse_ret_t;
enum psmouse_scale {
PSMOUSE_SCALE11 = 0,
PSMOUSE_SCALE21 = 1,
};
enum psmouse_type {
PSMOUSE_NONE = 0,
PSMOUSE_PS2 = 1,
PSMOUSE_PS2PP = 2,
PSMOUSE_THINKPS = 3,
PSMOUSE_GENPS = 4,
PSMOUSE_IMPS = 5,
PSMOUSE_IMEX = 6,
PSMOUSE_SYNAPTICS = 7,
PSMOUSE_ALPS = 8,
PSMOUSE_LIFEBOOK = 9,
PSMOUSE_TRACKPOINT = 10,
PSMOUSE_TOUCHKIT_PS2 = 11,
PSMOUSE_CORTRON = 12,
PSMOUSE_HGPK = 13,
PSMOUSE_ELANTECH = 14,
PSMOUSE_FSP = 15,
PSMOUSE_SYNAPTICS_RELATIVE = 16,
PSMOUSE_CYPRESS = 17,
PSMOUSE_FOCALTECH = 18,
PSMOUSE_VMMOUSE = 19,
PSMOUSE_BYD = 20,
PSMOUSE_SYNAPTICS_SMBUS = 21,
PSMOUSE_ELANTECH_SMBUS = 22,
PSMOUSE_AUTO = 23,
};
struct psmouse;
struct psmouse_protocol {
enum psmouse_type type;
bool maxproto;
bool ignore_parity;
bool try_passthru;
bool smbus_companion;
const char *name;
const char *alias;
int (*detect)(struct psmouse *, bool);
int (*init)(struct psmouse *);
};
struct psmouse {
void *private;
struct input_dev *dev;
struct ps2dev ps2dev;
struct delayed_work resync_work;
const char *vendor;
const char *name;
const struct psmouse_protocol *protocol;
unsigned char packet[8];
unsigned char badbyte;
unsigned char pktcnt;
unsigned char pktsize;
unsigned char oob_data_type;
unsigned char extra_buttons;
bool acks_disable_command;
unsigned int model;
long unsigned int last;
long unsigned int out_of_sync_cnt;
long unsigned int num_resyncs;
enum psmouse_state state;
char devname[64];
char phys[32];
unsigned int rate;
unsigned int resolution;
unsigned int resetafter;
unsigned int resync_time;
bool smartscroll;
psmouse_ret_t (*protocol_handler)(struct psmouse *);
void (*set_rate)(struct psmouse *, unsigned int);
void (*set_resolution)(struct psmouse *, unsigned int);
void (*set_scale)(struct psmouse *, enum psmouse_scale);
int (*reconnect)(struct psmouse *);
int (*fast_reconnect)(struct psmouse *);
void (*disconnect)(struct psmouse *);
void (*cleanup)(struct psmouse *);
int (*poll)(struct psmouse *);
void (*pt_activate)(struct psmouse *);
void (*pt_deactivate)(struct psmouse *);
};
struct psmouse_attribute {
struct device_attribute dattr;
void *data;
ssize_t (*show)(struct psmouse *, void *, char *);
ssize_t (*set)(struct psmouse *, void *, const char *, size_t);
bool protect;
};
struct kthread_work;
typedef void (*kthread_work_func_t)(struct kthread_work *);
struct kthread_worker;
struct kthread_work {
struct list_head node;
kthread_work_func_t func;
struct kthread_worker *worker;
int canceling;
};
struct kthread_worker {
unsigned int flags;
raw_spinlock_t lock;
struct list_head work_list;
struct list_head delayed_work_list;
struct task_struct *task;
struct kthread_work *current_work;
};
struct kthread_delayed_work {
struct kthread_work work;
struct timer_list timer;
};
struct posix_clock;
struct posix_clock_operations {
struct module *owner;
int (*clock_adjtime)(struct posix_clock *, struct __kernel_timex *);
int (*clock_gettime)(struct posix_clock *, struct timespec64 *);
int (*clock_getres)(struct posix_clock *, struct timespec64 *);
int (*clock_settime)(struct posix_clock *, const struct timespec64 *);
long int (*ioctl)(struct posix_clock *, unsigned int, long unsigned int);
int (*open)(struct posix_clock *, fmode_t);
__poll_t (*poll)(struct posix_clock *, struct file *, poll_table *);
int (*release)(struct posix_clock *);
ssize_t (*read)(struct posix_clock *, uint, char *, size_t);
};
struct posix_clock {
struct posix_clock_operations ops;
struct cdev cdev;
struct device *dev;
struct rw_semaphore rwsem;
bool zombie;
};
struct ptp_extts_event {
struct ptp_clock_time t;
unsigned int index;
unsigned int flags;
unsigned int rsv[2];
};
struct timestamp_event_queue {
struct ptp_extts_event buf[128];
int head;
int tail;
spinlock_t lock;
long: 32;
};
struct ptp_clock {
struct posix_clock clock;
struct device dev;
struct ptp_clock_info *info;
dev_t devid;
int index;
struct pps_device *pps_source;
long int dialed_frequency;
long: 32;
struct timestamp_event_queue tsevq;
struct mutex tsevq_mux;
struct mutex pincfg_mux;
wait_queue_head_t tsev_wq;
int defunct;
struct device_attribute *pin_dev_attr;
struct attribute **pin_attr;
struct attribute_group pin_attr_group;
const struct attribute_group *pin_attr_groups[2];
struct kthread_worker *kworker;
struct kthread_delayed_work aux_work;
unsigned int max_vclocks;
unsigned int n_vclocks;
int *vclock_index;
struct mutex n_vclocks_mux;
bool is_virtual_clock;
bool has_cycles;
};
struct ptp_vclock {
struct ptp_clock *pclock;
struct ptp_clock_info info;
struct ptp_clock *clock;
struct hlist_node vclock_hash_node;
struct cyclecounter cc;
struct timecounter tc;
spinlock_t lock;
long: 32;
};
enum ethtool_multicast_groups {
ETHNL_MCGRP_MONITOR = 0,
};
struct genl_dumpit_info {
const struct genl_family *family;
struct genl_ops op;
struct nlattr **attrs;
};
struct ethnl_dump_ctx {
const struct ethnl_request_ops *ops;
struct ethnl_req_info *req_info;
struct ethnl_reply_data *reply_data;
int pos_hash;
int pos_idx;
};
typedef void (*ethnl_notify_handler_t)(struct net_device *, unsigned int, const void *);
enum ethtool_supported_ring_param {
ETHTOOL_RING_USE_RX_BUF_LEN = 1,
ETHTOOL_RING_USE_CQE_SIZE = 2,
ETHTOOL_RING_USE_TX_PUSH = 4,
};
enum {
ETHTOOL_TCP_DATA_SPLIT_UNKNOWN = 0,
ETHTOOL_TCP_DATA_SPLIT_DISABLED = 1,
ETHTOOL_TCP_DATA_SPLIT_ENABLED = 2,
};
struct rings_reply_data {
struct ethnl_reply_data base;
struct ethtool_ringparam ringparam;
struct kernel_ethtool_ringparam kernel_ringparam;
};
struct nf_sockopt_ops {
struct list_head list;
u_int8_t pf;
int set_optmin;
int set_optmax;
int (*set)(struct sock *, int, sockptr_t, unsigned int);
int get_optmin;
int get_optmax;
int (*get)(struct sock *, int, void *, int *);
struct module *owner;
};
struct tcpvegas_info {
__u32 tcpv_enabled;
__u32 tcpv_rttcnt;
__u32 tcpv_rtt;
__u32 tcpv_minrtt;
};
struct tcp_dctcp_info {
__u16 dctcp_enabled;
__u16 dctcp_ce_state;
__u32 dctcp_alpha;
__u32 dctcp_ab_ecn;
__u32 dctcp_ab_tot;
};
struct tcp_bbr_info {
__u32 bbr_bw_lo;
__u32 bbr_bw_hi;
__u32 bbr_min_rtt;
__u32 bbr_pacing_gain;
__u32 bbr_cwnd_gain;
};
union tcp_cc_info {
struct tcpvegas_info vegas;
struct tcp_dctcp_info dctcp;
struct tcp_bbr_info bbr;
};
struct tcp_repair_opt {
__u32 opt_code;
__u32 opt_val;
};
struct tcp_repair_window {
__u32 snd_wl1;
__u32 snd_wnd;
__u32 max_window;
__u32 rcv_wnd;
__u32 rcv_wup;
};
enum {
TCP_NO_QUEUE = 0,
TCP_RECV_QUEUE = 1,
TCP_SEND_QUEUE = 2,
TCP_QUEUES_NR = 3,
};
struct tcp_info {
__u8 tcpi_state;
__u8 tcpi_ca_state;
__u8 tcpi_retransmits;
__u8 tcpi_probes;
__u8 tcpi_backoff;
__u8 tcpi_options;
__u8 tcpi_snd_wscale: 4;
__u8 tcpi_rcv_wscale: 4;
__u8 tcpi_delivery_rate_app_limited: 1;
__u8 tcpi_fastopen_client_fail: 2;
__u32 tcpi_rto;
__u32 tcpi_ato;
__u32 tcpi_snd_mss;
__u32 tcpi_rcv_mss;
__u32 tcpi_unacked;
__u32 tcpi_sacked;
__u32 tcpi_lost;
__u32 tcpi_retrans;
__u32 tcpi_fackets;
__u32 tcpi_last_data_sent;
__u32 tcpi_last_ack_sent;
__u32 tcpi_last_data_recv;
__u32 tcpi_last_ack_recv;
__u32 tcpi_pmtu;
__u32 tcpi_rcv_ssthresh;
__u32 tcpi_rtt;
__u32 tcpi_rttvar;
__u32 tcpi_snd_ssthresh;
__u32 tcpi_snd_cwnd;
__u32 tcpi_advmss;
__u32 tcpi_reordering;
__u32 tcpi_rcv_rtt;
__u32 tcpi_rcv_space;
__u32 tcpi_total_retrans;
__u64 tcpi_pacing_rate;
__u64 tcpi_max_pacing_rate;
__u64 tcpi_bytes_acked;
__u64 tcpi_bytes_received;
__u32 tcpi_segs_out;
__u32 tcpi_segs_in;
__u32 tcpi_notsent_bytes;
__u32 tcpi_min_rtt;
__u32 tcpi_data_segs_in;
__u32 tcpi_data_segs_out;
__u64 tcpi_delivery_rate;
__u64 tcpi_busy_time;
__u64 tcpi_rwnd_limited;
__u64 tcpi_sndbuf_limited;
__u32 tcpi_delivered;
__u32 tcpi_delivered_ce;
__u64 tcpi_bytes_sent;
__u64 tcpi_bytes_retrans;
__u32 tcpi_dsack_dups;
__u32 tcpi_reord_seen;
__u32 tcpi_rcv_ooopack;
__u32 tcpi_snd_wnd;
};
enum {
TCP_NLA_PAD = 0,
TCP_NLA_BUSY = 1,
TCP_NLA_RWND_LIMITED = 2,
TCP_NLA_SNDBUF_LIMITED = 3,
TCP_NLA_DATA_SEGS_OUT = 4,
TCP_NLA_TOTAL_RETRANS = 5,
TCP_NLA_PACING_RATE = 6,
TCP_NLA_DELIVERY_RATE = 7,
TCP_NLA_SND_CWND = 8,
TCP_NLA_REORDERING = 9,
TCP_NLA_MIN_RTT = 10,
TCP_NLA_RECUR_RETRANS = 11,
TCP_NLA_DELIVERY_RATE_APP_LMT = 12,
TCP_NLA_SNDQ_SIZE = 13,
TCP_NLA_CA_STATE = 14,
TCP_NLA_SND_SSTHRESH = 15,
TCP_NLA_DELIVERED = 16,
TCP_NLA_DELIVERED_CE = 17,
TCP_NLA_BYTES_SENT = 18,
TCP_NLA_BYTES_RETRANS = 19,
TCP_NLA_DSACK_DUPS = 20,
TCP_NLA_REORD_SEEN = 21,
TCP_NLA_SRTT = 22,
TCP_NLA_TIMEOUT_REHASH = 23,
TCP_NLA_BYTES_NOTSENT = 24,
TCP_NLA_EDT = 25,
TCP_NLA_TTL = 26,
};
struct tcp_zerocopy_receive {
__u64 address;
__u32 length;
__u32 recv_skip_hint;
__u32 inq;
__s32 err;
__u64 copybuf_address;
__s32 copybuf_len;
__u32 flags;
__u64 msg_control;
__u64 msg_controllen;
__u32 msg_flags;
__u32 reserved;
};
enum {
BPF_TCP_ESTABLISHED = 1,
BPF_TCP_SYN_SENT = 2,
BPF_TCP_SYN_RECV = 3,
BPF_TCP_FIN_WAIT1 = 4,
BPF_TCP_FIN_WAIT2 = 5,
BPF_TCP_TIME_WAIT = 6,
BPF_TCP_CLOSE = 7,
BPF_TCP_CLOSE_WAIT = 8,
BPF_TCP_LAST_ACK = 9,
BPF_TCP_LISTEN = 10,
BPF_TCP_CLOSING = 11,
BPF_TCP_NEW_SYN_RECV = 12,
BPF_TCP_MAX_STATES = 13,
};
enum tcp_chrono {
TCP_CHRONO_UNSPEC = 0,
TCP_CHRONO_BUSY = 1,
TCP_CHRONO_RWND_LIMITED = 2,
TCP_CHRONO_SNDBUF_LIMITED = 3,
__TCP_CHRONO_MAX = 4,
};
enum {
TCP_CMSG_INQ = 1,
TCP_CMSG_TS = 2,
};
struct tcp_splice_state {
struct pipe_inode_info *pipe;
size_t len;
unsigned int flags;
};
struct ip6_rt_info {
struct in6_addr daddr;
struct in6_addr saddr;
u_int32_t mark;
};
struct br_input_skb_cb {
struct net_device *brdev;
u16 frag_max_size;
u8 igmp;
u8 mrouters_only: 1;
u8 proxyarp_replied: 1;
u8 src_port_isolated: 1;
u8 br_netfilter_broute: 1;
};
struct nf_bridge_frag_data;
typedef __u64 Elf64_Addr;
typedef __u16 Elf64_Half;
typedef __u64 Elf64_Off;
typedef __u32 Elf64_Word;
typedef __u64 Elf64_Xword;
struct elf64_hdr {
unsigned char e_ident[16];
Elf64_Half e_type;
Elf64_Half e_machine;
Elf64_Word e_version;
Elf64_Addr e_entry;
Elf64_Off e_phoff;
Elf64_Off e_shoff;
Elf64_Word e_flags;
Elf64_Half e_ehsize;
Elf64_Half e_phentsize;
Elf64_Half e_phnum;
Elf64_Half e_shentsize;
Elf64_Half e_shnum;
Elf64_Half e_shstrndx;
};
typedef struct elf64_hdr Elf64_Ehdr;
typedef struct elf32_phdr Elf32_Phdr;
struct elf64_phdr {
Elf64_Word p_type;
Elf64_Word p_flags;
Elf64_Off p_offset;
Elf64_Addr p_vaddr;
Elf64_Addr p_paddr;
Elf64_Xword p_filesz;
Elf64_Xword p_memsz;
Elf64_Xword p_align;
};
typedef struct elf64_phdr Elf64_Phdr;
typedef struct elf32_note Elf32_Nhdr;
struct msc_irqmap {
int im_irq;
int im_type;
int im_lvl;
};
typedef struct msc_irqmap msc_irqmap_t;
typedef __s32 Elf32_Sword;
struct elf32_rel {
Elf32_Addr r_offset;
Elf32_Word r_info;
};
typedef struct elf32_rel Elf32_Rel;
struct elf32_rela {
Elf32_Addr r_offset;
Elf32_Word r_info;
Elf32_Sword r_addend;
};
typedef struct elf32_rela Elf32_Rela;
struct mips_hi16 {
struct mips_hi16 *next;
Elf32_Addr *addr;
Elf32_Addr value;
};
enum umh_disable_depth {
UMH_ENABLED = 0,
UMH_FREEZING = 1,
UMH_DISABLED = 2,
};
struct async_domain {
struct list_head pending;
unsigned int registered: 1;
};
struct async_entry {
struct list_head domain_list;
struct list_head global_list;
struct work_struct work;
async_cookie_t cookie;
async_func_t func;
void *data;
struct async_domain *domain;
long: 32;
};
struct ww_mutex {
struct mutex base;
struct ww_acquire_ctx *ctx;
};
struct ww_acquire_ctx {
struct task_struct *task;
long unsigned int stamp;
unsigned int acquired;
short unsigned int wounded;
short unsigned int is_wait_die;
};
struct trace_event_raw_contention_begin {
struct trace_entry ent;
void *lock_addr;
unsigned int flags;
char __data[0];
};
struct trace_event_raw_contention_end {
struct trace_entry ent;
void *lock_addr;
int ret;
char __data[0];
};
struct trace_event_data_offsets_contention_begin {};
struct trace_event_data_offsets_contention_end {};
typedef void (*btf_trace_contention_begin)(void *, void *, unsigned int);
typedef void (*btf_trace_contention_end)(void *, void *, int);
struct mutex_waiter {
struct list_head list;
struct task_struct *task;
struct ww_acquire_ctx *ww_ctx;
};
struct dma_coherent_mem {
void *virt_base;
dma_addr_t device_base;
long unsigned int pfn_base;
int size;
long unsigned int *bitmap;
spinlock_t spinlock;
bool use_dev_dma_pfn_offset;
};
struct reserved_mem_ops;
struct reserved_mem {
const char *name;
long unsigned int fdt_node;
long unsigned int phandle;
const struct reserved_mem_ops *ops;
phys_addr_t base;
phys_addr_t size;
void *priv;
};
struct reserved_mem_ops {
int (*device_init)(struct reserved_mem *, struct device *);
void (*device_release)(struct reserved_mem *, struct device *);
};
typedef int (*reservedmem_of_init_fn)(struct reserved_mem *);
struct posix_clock_desc {
struct file *fp;
struct posix_clock *clk;
};
struct dma_chan___2 {
int lock;
const char *device_id;
};
enum {
TRACE_NOP_OPT_ACCEPT = 1,
TRACE_NOP_OPT_REFUSE = 2,
};
typedef long unsigned int perf_trace_t[2048];
struct bpf_attach_target_info {
struct btf_func_model fmodel;
long int tgt_addr;
const char *tgt_name;
const struct btf_type *tgt_type;
};
struct bpf_kfunc_desc {
struct btf_func_model func_model;
u32 func_id;
s32 imm;
u16 offset;
};
struct bpf_kfunc_desc_tab {
struct bpf_kfunc_desc descs[256];
u32 nr_descs;
};
struct bpf_kfunc_btf {
struct btf *btf;
struct module *module;
u16 offset;
};
struct bpf_kfunc_btf_tab {
struct bpf_kfunc_btf descs[256];
u32 nr_descs;
};
typedef u32 (*bpf_convert_ctx_access_t)(enum bpf_access_type, const struct bpf_insn *, struct bpf_insn *, struct bpf_prog *, u32 *);
enum bpf_stack_slot_type {
STACK_INVALID = 0,
STACK_SPILL = 1,
STACK_MISC = 2,
STACK_ZERO = 3,
STACK_DYNPTR = 4,
};
struct bpf_verifier_stack_elem {
struct bpf_verifier_state st;
int insn_idx;
int prev_insn_idx;
struct bpf_verifier_stack_elem *next;
u32 log_pos;
};
typedef void (*bpf_insn_print_t)(void *, const char *, ...);
typedef const char * (*bpf_insn_revmap_call_t)(void *, const struct bpf_insn *);
typedef const char * (*bpf_insn_print_imm_t)(void *, const struct bpf_insn *, __u64);
struct bpf_insn_cbs {
bpf_insn_print_t cb_print;
bpf_insn_revmap_call_t cb_call;
bpf_insn_print_imm_t cb_imm;
void *private_data;
};
struct bpf_call_arg_meta {
struct bpf_map *map_ptr;
bool raw_mode;
bool pkt_access;
u8 release_regno;
int regno;
int access_size;
int mem_size;
long: 32;
u64 msize_max_value;
int ref_obj_id;
int map_uid;
int func_id;
struct btf *btf;
u32 btf_id;
struct btf *ret_btf;
u32 ret_btf_id;
u32 subprogno;
struct bpf_map_value_off_desc *kptr_off_desc;
u8 uninit_dynptr_regno;
};
enum reg_arg_type {
SRC_OP = 0,
DST_OP = 1,
DST_OP_NO_MARK = 2,
};
enum bpf_access_src {
ACCESS_DIRECT = 1,
ACCESS_HELPER = 2,
};
struct bpf_reg_types {
const enum bpf_reg_type types[10];
u32 *btf_id;
};
enum {
AT_PKT_END = -1,
BEYOND_PKT_END = -2,
};
typedef int (*set_callee_state_fn)(struct bpf_verifier_env *, struct bpf_func_state *, struct bpf_func_state *, int);
enum {
REASON_BOUNDS = -1,
REASON_TYPE = -2,
REASON_PATHS = -3,
REASON_LIMIT = -4,
REASON_STACK = -5,
};
struct bpf_sanitize_info {
struct bpf_insn_aux_data aux;
bool mask_to_left;
long: 32;
};
enum {
DISCOVERED = 16,
EXPLORED = 32,
FALLTHROUGH = 1,
BRANCH = 2,
};
enum {
DONE_EXPLORING = 0,
KEEP_EXPLORING = 1,
};
struct core_name {
char *corename;
int used;
int size;
};
struct mb_cache_entry {
struct list_head e_list;
struct hlist_bl_node e_hash_list;
atomic_t e_refcnt;
u32 e_key;
u32 e_referenced: 1;
u32 e_reusable: 1;
long: 32;
u64 e_value;
};
struct ext4_xattr_header {
__le32 h_magic;
__le32 h_refcount;
__le32 h_blocks;
__le32 h_hash;
__le32 h_checksum;
__u32 h_reserved[3];
};
struct ext4_xattr_ibody_header {
__le32 h_magic;
};
struct ext4_xattr_entry {
__u8 e_name_len;
__u8 e_name_index;
__le16 e_value_offs;
__le32 e_value_inum;
__le32 e_value_size;
__le32 e_hash;
char e_name[0];
};
struct ext4_xattr_info {
const char *name;
const void *value;
size_t value_len;
int name_index;
int in_inode;
};
struct ext4_xattr_search {
struct ext4_xattr_entry *first;
void *base;
void *end;
struct ext4_xattr_entry *here;
int not_found;
};
struct ext4_xattr_ibody_find {
struct ext4_xattr_search s;
struct ext4_iloc iloc;
};
struct ext4_xattr_inode_array {
unsigned int count;
struct inode *inodes[0];
};
struct ext4_xattr_block_find {
struct ext4_xattr_search s;
struct buffer_head *bh;
};
struct nlmsvc_binding {
__be32 (*fopen)(struct svc_rqst *, struct nfs_fh *, struct file **, int);
void (*fclose)(struct file *);
};
struct keyctl_dh_params {
union {
__s32 private;
__s32 priv;
};
__s32 prime;
__s32 base;
};
struct keyctl_kdf_params {
char *hashname;
char *otherinfo;
__u32 otherinfolen;
__u32 __spare[8];
};
struct keyctl_pkey_query {
__u32 supported_ops;
__u32 key_size;
__u16 max_data_size;
__u16 max_sig_size;
__u16 max_enc_size;
__u16 max_dec_size;
__u32 __spare[10];
};
struct keyctl_pkey_params {
__s32 key_id;
__u32 in_len;
union {
__u32 out_len;
__u32 in2_len;
};
__u32 __spare[7];
};
struct request_key_auth {
struct callback_head rcu;
struct key *target_key;
struct key *dest_keyring;
const struct cred *cred;
void *callout_info;
size_t callout_len;
pid_t pid;
char op[8];
};
enum pkcs7_actions {
ACT_pkcs7_check_content_type = 0,
ACT_pkcs7_extract_cert = 1,
ACT_pkcs7_note_OID = 2,
ACT_pkcs7_note_certificate_list = 3,
ACT_pkcs7_note_content = 4,
ACT_pkcs7_note_data = 5,
ACT_pkcs7_note_signed_info = 6,
ACT_pkcs7_note_signeddata_version = 7,
ACT_pkcs7_note_signerinfo_version = 8,
ACT_pkcs7_sig_note_authenticated_attr = 9,
ACT_pkcs7_sig_note_digest_algo = 10,
ACT_pkcs7_sig_note_issuer = 11,
ACT_pkcs7_sig_note_pkey_algo = 12,
ACT_pkcs7_sig_note_serial = 13,
ACT_pkcs7_sig_note_set_of_authattrs = 14,
ACT_pkcs7_sig_note_signature = 15,
ACT_pkcs7_sig_note_skid = 16,
NR__pkcs7_actions = 17,
};
struct blk_ia_range_sysfs_entry {
struct attribute attr;
ssize_t (*show)(struct blk_independent_access_range *, char *);
};
struct statx_timestamp {
__s64 tv_sec;
__u32 tv_nsec;
__s32 __reserved;
};
struct statx {
__u32 stx_mask;
__u32 stx_blksize;
__u64 stx_attributes;
__u32 stx_nlink;
__u32 stx_uid;
__u32 stx_gid;
__u16 stx_mode;
__u16 __spare0[1];
__u64 stx_ino;
__u64 stx_size;
__u64 stx_blocks;
__u64 stx_attributes_mask;
struct statx_timestamp stx_atime;
struct statx_timestamp stx_btime;
struct statx_timestamp stx_ctime;
struct statx_timestamp stx_mtime;
__u32 stx_rdev_major;
__u32 stx_rdev_minor;
__u32 stx_dev_major;
__u32 stx_dev_minor;
__u64 stx_mnt_id;
__u32 stx_dio_mem_align;
__u32 stx_dio_offset_align;
__u64 __spare3[12];
};
struct io_statx {
struct file *file;
int dfd;
unsigned int mask;
unsigned int flags;
struct filename *filename;
struct statx *buffer;
};
struct xxh32_state {
uint32_t total_len_32;
uint32_t large_len;
uint32_t v1;
uint32_t v2;
uint32_t v3;
uint32_t v4;
uint32_t mem32[4];
uint32_t memsize;
};
struct xxh64_state {
uint64_t total_len;
uint64_t v1;
uint64_t v2;
uint64_t v3;
uint64_t v4;
uint64_t mem64[4];
uint32_t memsize;
long: 32;
};
typedef long long unsigned int UDItype;
struct karatsuba_ctx {
struct karatsuba_ctx *next;
mpi_ptr_t tspace;
mpi_size_t tspace_size;
mpi_ptr_t tp;
mpi_size_t tp_size;
};
enum device_link_state {
DL_STATE_NONE = -1,
DL_STATE_DORMANT = 0,
DL_STATE_AVAILABLE = 1,
DL_STATE_CONSUMER_PROBE = 2,
DL_STATE_ACTIVE = 3,
DL_STATE_SUPPLIER_UNBIND = 4,
};
struct device_link {
struct device *supplier;
struct list_head s_node;
struct device *consumer;
struct list_head c_node;
struct device link_dev;
enum device_link_state status;
u32 flags;
refcount_t rpm_active;
struct kref kref;
struct work_struct rm_work;
bool supplier_preactivated;
long: 32;
};
enum {
NVME_REG_CAP = 0,
NVME_REG_VS = 8,
NVME_REG_INTMS = 12,
NVME_REG_INTMC = 16,
NVME_REG_CC = 20,
NVME_REG_CSTS = 28,
NVME_REG_NSSR = 32,
NVME_REG_AQA = 36,
NVME_REG_ASQ = 40,
NVME_REG_ACQ = 48,
NVME_REG_CMBLOC = 56,
NVME_REG_CMBSZ = 60,
NVME_REG_BPINFO = 64,
NVME_REG_BPRSEL = 68,
NVME_REG_BPMBL = 72,
NVME_REG_CMBMSC = 80,
NVME_REG_CRTO = 104,
NVME_REG_PMRCAP = 3584,
NVME_REG_PMRCTL = 3588,
NVME_REG_PMRSTS = 3592,
NVME_REG_PMREBS = 3596,
NVME_REG_PMRSWTP = 3600,
NVME_REG_DBS = 4096,
};
enum {
NVME_CC_ENABLE = 1,
NVME_CC_EN_SHIFT = 0,
NVME_CC_CSS_SHIFT = 4,
NVME_CC_MPS_SHIFT = 7,
NVME_CC_AMS_SHIFT = 11,
NVME_CC_SHN_SHIFT = 14,
NVME_CC_IOSQES_SHIFT = 16,
NVME_CC_IOCQES_SHIFT = 20,
NVME_CC_CSS_NVM = 0,
NVME_CC_CSS_CSI = 96,
NVME_CC_CSS_MASK = 112,
NVME_CC_AMS_RR = 0,
NVME_CC_AMS_WRRU = 2048,
NVME_CC_AMS_VS = 14336,
NVME_CC_SHN_NONE = 0,
NVME_CC_SHN_NORMAL = 16384,
NVME_CC_SHN_ABRUPT = 32768,
NVME_CC_SHN_MASK = 49152,
NVME_CC_IOSQES = 393216,
NVME_CC_IOCQES = 4194304,
NVME_CC_CRIME = 16777216,
};
enum {
NVME_CSTS_RDY = 1,
NVME_CSTS_CFS = 2,
NVME_CSTS_NSSRO = 16,
NVME_CSTS_PP = 32,
NVME_CSTS_SHST_NORMAL = 0,
NVME_CSTS_SHST_OCCUR = 4,
NVME_CSTS_SHST_CMPLT = 8,
NVME_CSTS_SHST_MASK = 12,
};
enum {
NVME_AEN_BIT_NS_ATTR = 8,
NVME_AEN_BIT_FW_ACT = 9,
NVME_AEN_BIT_ANA_CHANGE = 11,
NVME_AEN_BIT_DISC_CHANGE = 31,
};
enum {
SWITCHTEC_GAS_MRPC_OFFSET = 0,
SWITCHTEC_GAS_TOP_CFG_OFFSET = 4096,
SWITCHTEC_GAS_SW_EVENT_OFFSET = 6144,
SWITCHTEC_GAS_SYS_INFO_OFFSET = 8192,
SWITCHTEC_GAS_FLASH_INFO_OFFSET = 8704,
SWITCHTEC_GAS_PART_CFG_OFFSET = 16384,
SWITCHTEC_GAS_NTB_OFFSET = 65536,
SWITCHTEC_GAS_PFF_CSR_OFFSET = 1261568,
};
enum {
SWITCHTEC_NTB_REG_INFO_OFFSET = 0,
SWITCHTEC_NTB_REG_CTRL_OFFSET = 16384,
SWITCHTEC_NTB_REG_DBMSG_OFFSET = 409600,
};
struct nt_partition_info {
u32 xlink_enabled;
u32 target_part_low;
u32 target_part_high;
u32 reserved;
};
struct ntb_info_regs {
u8 partition_count;
u8 partition_id;
u16 reserved1;
u64 ep_map;
u16 requester_id;
u16 reserved2;
u32 reserved3[4];
struct nt_partition_info ntp_info[48];
};
struct ntb_ctrl_regs {
u32 partition_status;
u32 partition_op;
u32 partition_ctrl;
u32 bar_setup;
u32 bar_error;
u16 lut_table_entries;
u16 lut_table_offset;
u32 lut_error;
u16 req_id_table_size;
u16 req_id_table_offset;
u32 req_id_error;
u32 reserved1[7];
struct {
u32 ctl;
u32 win_size;
u64 xlate_addr;
} bar_entry[6];
struct {
u32 win_size;
u32 reserved[3];
} bar_ext_entry[6];
u32 reserved2[192];
u32 req_id_table[512];
u32 reserved3[256];
u64 lut_entry[512];
};
struct pci_dev_reset_methods {
u16 vendor;
u16 device;
int (*reset)(struct pci_dev *, bool);
};
struct pci_dev_acs_enabled {
u16 vendor;
u16 device;
int (*acs_enabled)(struct pci_dev *, u16);
};
struct pci_dev_acs_ops {
u16 vendor;
u16 device;
int (*enable_acs)(struct pci_dev *);
int (*disable_acs_redir)(struct pci_dev *);
};
struct clk {
struct clk_core *core;
struct device *dev;
const char *dev_id;
const char *con_id;
long unsigned int min_rate;
long unsigned int max_rate;
unsigned int exclusive_count;
struct hlist_node clks_node;
};
struct kbdiacruc {
unsigned int diacr;
unsigned int base;
unsigned int result;
};
struct exar8250_platform {
int (*rs485_config)(struct uart_port *, struct ktermios *, struct serial_rs485 *);
const struct serial_rs485 *rs485_supported;
int (*register_gpio)(struct pci_dev *, struct uart_8250_port *);
void (*unregister_gpio)(struct uart_8250_port *);
};
struct exar8250;
struct exar8250_board {
unsigned int num_ports;
unsigned int reg_shift;
int (*setup)(struct exar8250 *, struct pci_dev *, struct uart_8250_port *, int);
void (*exit)(struct pci_dev *);
};
struct exar8250 {
unsigned int nr;
struct exar8250_board *board;
void *virt;
int line[0];
};
struct devres_node {
struct list_head entry;
dr_release_t release;
const char *name;
size_t size;
};
struct devres {
struct devres_node node;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
u8 data[0];
};
struct devres_group {
struct devres_node node[2];
void *id;
int color;
};
struct action_devres {
void *data;
void (*action)(void *);
};
struct pages_devres {
long unsigned int addr;
unsigned int order;
};
struct reg_field {
unsigned int reg;
unsigned int lsb;
unsigned int msb;
unsigned int id_size;
unsigned int id_offset;
};
struct regmap_range_node {
struct rb_node node;
const char *name;
struct regmap *map;
unsigned int range_min;
unsigned int range_max;
unsigned int selector_reg;
unsigned int selector_mask;
int selector_shift;
unsigned int window_start;
unsigned int window_len;
};
struct regmap_field {
struct regmap *regmap;
unsigned int mask;
unsigned int shift;
unsigned int reg;
unsigned int id_size;
unsigned int id_offset;
};
struct trace_event_raw_regmap_reg {
struct trace_entry ent;
u32 __data_loc_name;
unsigned int reg;
unsigned int val;
char __data[0];
};
struct trace_event_raw_regmap_bulk {
struct trace_entry ent;
u32 __data_loc_name;
unsigned int reg;
u32 __data_loc_buf;
int val_len;
char __data[0];
};
struct trace_event_raw_regmap_block {
struct trace_entry ent;
u32 __data_loc_name;
unsigned int reg;
int count;
char __data[0];
};
struct trace_event_raw_regcache_sync {
struct trace_entry ent;
u32 __data_loc_name;
u32 __data_loc_status;
u32 __data_loc_type;
char __data[0];
};
struct trace_event_raw_regmap_bool {
struct trace_entry ent;
u32 __data_loc_name;
int flag;
char __data[0];
};
struct trace_event_raw_regmap_async {
struct trace_entry ent;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_regcache_drop_region {
struct trace_entry ent;
u32 __data_loc_name;
unsigned int from;
unsigned int to;
char __data[0];
};
struct trace_event_data_offsets_regmap_reg {
u32 name;
};
struct trace_event_data_offsets_regmap_bulk {
u32 name;
u32 buf;
};
struct trace_event_data_offsets_regmap_block {
u32 name;
};
struct trace_event_data_offsets_regcache_sync {
u32 name;
u32 status;
u32 type;
};
struct trace_event_data_offsets_regmap_bool {
u32 name;
};
struct trace_event_data_offsets_regmap_async {
u32 name;
};
struct trace_event_data_offsets_regcache_drop_region {
u32 name;
};
typedef void (*btf_trace_regmap_reg_write)(void *, struct regmap *, unsigned int, unsigned int);
typedef void (*btf_trace_regmap_reg_read)(void *, struct regmap *, unsigned int, unsigned int);
typedef void (*btf_trace_regmap_reg_read_cache)(void *, struct regmap *, unsigned int, unsigned int);
typedef void (*btf_trace_regmap_bulk_write)(void *, struct regmap *, unsigned int, const void *, int);
typedef void (*btf_trace_regmap_bulk_read)(void *, struct regmap *, unsigned int, const void *, int);
typedef void (*btf_trace_regmap_hw_read_start)(void *, struct regmap *, unsigned int, int);
typedef void (*btf_trace_regmap_hw_read_done)(void *, struct regmap *, unsigned int, int);
typedef void (*btf_trace_regmap_hw_write_start)(void *, struct regmap *, unsigned int, int);
typedef void (*btf_trace_regmap_hw_write_done)(void *, struct regmap *, unsigned int, int);
typedef void (*btf_trace_regcache_sync)(void *, struct regmap *, const char *, const char *);
typedef void (*btf_trace_regmap_cache_only)(void *, struct regmap *, bool);
typedef void (*btf_trace_regmap_cache_bypass)(void *, struct regmap *, bool);
typedef void (*btf_trace_regmap_async_write_start)(void *, struct regmap *, unsigned int, int);
typedef void (*btf_trace_regmap_async_io_complete)(void *, struct regmap *);
typedef void (*btf_trace_regmap_async_complete_start)(void *, struct regmap *);
typedef void (*btf_trace_regmap_async_complete_done)(void *, struct regmap *);
typedef void (*btf_trace_regcache_drop_region)(void *, struct regmap *, unsigned int, unsigned int);
struct mtd_partition {
const char *name;
const char * const *types;
uint64_t size;
uint64_t offset;
uint32_t mask_flags;
uint32_t add_flags;
struct device_node *of_node;
long: 32;
};
struct mtd_part_parser_data {
long unsigned int origin;
};
struct phy_setting {
u32 speed;
u8 duplex;
u8 bit;
};
struct atkbd {
struct ps2dev ps2dev;
struct input_dev *dev;
char name[64];
char phys[32];
short unsigned int id;
short unsigned int keycode[512];
long unsigned int force_release_mask[16];
unsigned char set;
bool translated;
bool extra;
bool write;
bool softrepeat;
bool softraw;
bool scroll;
bool enabled;
unsigned char emul;
bool resend;
bool release;
long unsigned int xl_bit;
unsigned int last;
long unsigned int time;
long unsigned int err_count;
struct delayed_work event_work;
long unsigned int event_jiffies;
long unsigned int event_mask;
struct mutex mutex;
struct vivaldi_data vdata;
};
struct ptp_clock_caps {
int max_adj;
int n_alarm;
int n_ext_ts;
int n_per_out;
int pps;
int n_pins;
int cross_timestamping;
int adjust_phase;
int rsv[12];
};
struct ptp_sys_offset {
unsigned int n_samples;
unsigned int rsv[3];
struct ptp_clock_time ts[51];
};
struct ptp_sys_offset_extended {
unsigned int n_samples;
unsigned int rsv[3];
struct ptp_clock_time ts[75];
};
struct ptp_sys_offset_precise {
struct ptp_clock_time device;
struct ptp_clock_time sys_realtime;
struct ptp_clock_time sys_monoraw;
unsigned int rsv[4];
};
struct netlink_dump_control {
int (*start)(struct netlink_callback *);
int (*dump)(struct sk_buff *, struct netlink_callback *);
int (*done)(struct netlink_callback *);
void *data;
struct module *module;
u32 min_dump_alloc;
};
struct rtnl_link_stats {
__u32 rx_packets;
__u32 tx_packets;
__u32 rx_bytes;
__u32 tx_bytes;
__u32 rx_errors;
__u32 tx_errors;
__u32 rx_dropped;
__u32 tx_dropped;
__u32 multicast;
__u32 collisions;
__u32 rx_length_errors;
__u32 rx_over_errors;
__u32 rx_crc_errors;
__u32 rx_frame_errors;
__u32 rx_fifo_errors;
__u32 rx_missed_errors;
__u32 tx_aborted_errors;
__u32 tx_carrier_errors;
__u32 tx_fifo_errors;
__u32 tx_heartbeat_errors;
__u32 tx_window_errors;
__u32 rx_compressed;
__u32 tx_compressed;
__u32 rx_nohandler;
};
struct rtnl_link_ifmap {
__u64 mem_start;
__u64 mem_end;
__u64 base_addr;
__u16 irq;
__u8 dma;
__u8 port;
long: 32;
};
enum {
IFLA_PROTO_DOWN_REASON_UNSPEC = 0,
IFLA_PROTO_DOWN_REASON_MASK = 1,
IFLA_PROTO_DOWN_REASON_VALUE = 2,
__IFLA_PROTO_DOWN_REASON_CNT = 3,
IFLA_PROTO_DOWN_REASON_MAX = 2,
};
enum {
IFLA_BRPORT_UNSPEC = 0,
IFLA_BRPORT_STATE = 1,
IFLA_BRPORT_PRIORITY = 2,
IFLA_BRPORT_COST = 3,
IFLA_BRPORT_MODE = 4,
IFLA_BRPORT_GUARD = 5,
IFLA_BRPORT_PROTECT = 6,
IFLA_BRPORT_FAST_LEAVE = 7,
IFLA_BRPORT_LEARNING = 8,
IFLA_BRPORT_UNICAST_FLOOD = 9,
IFLA_BRPORT_PROXYARP = 10,
IFLA_BRPORT_LEARNING_SYNC = 11,
IFLA_BRPORT_PROXYARP_WIFI = 12,
IFLA_BRPORT_ROOT_ID = 13,
IFLA_BRPORT_BRIDGE_ID = 14,
IFLA_BRPORT_DESIGNATED_PORT = 15,
IFLA_BRPORT_DESIGNATED_COST = 16,
IFLA_BRPORT_ID = 17,
IFLA_BRPORT_NO = 18,
IFLA_BRPORT_TOPOLOGY_CHANGE_ACK = 19,
IFLA_BRPORT_CONFIG_PENDING = 20,
IFLA_BRPORT_MESSAGE_AGE_TIMER = 21,
IFLA_BRPORT_FORWARD_DELAY_TIMER = 22,
IFLA_BRPORT_HOLD_TIMER = 23,
IFLA_BRPORT_FLUSH = 24,
IFLA_BRPORT_MULTICAST_ROUTER = 25,
IFLA_BRPORT_PAD = 26,
IFLA_BRPORT_MCAST_FLOOD = 27,
IFLA_BRPORT_MCAST_TO_UCAST = 28,
IFLA_BRPORT_VLAN_TUNNEL = 29,
IFLA_BRPORT_BCAST_FLOOD = 30,
IFLA_BRPORT_GROUP_FWD_MASK = 31,
IFLA_BRPORT_NEIGH_SUPPRESS = 32,
IFLA_BRPORT_ISOLATED = 33,
IFLA_BRPORT_BACKUP_PORT = 34,
IFLA_BRPORT_MRP_RING_OPEN = 35,
IFLA_BRPORT_MRP_IN_OPEN = 36,
IFLA_BRPORT_MCAST_EHT_HOSTS_LIMIT = 37,
IFLA_BRPORT_MCAST_EHT_HOSTS_CNT = 38,
IFLA_BRPORT_LOCKED = 39,
__IFLA_BRPORT_MAX = 40,
};
enum {
IFLA_INFO_UNSPEC = 0,
IFLA_INFO_KIND = 1,
IFLA_INFO_DATA = 2,
IFLA_INFO_XSTATS = 3,
IFLA_INFO_SLAVE_KIND = 4,
IFLA_INFO_SLAVE_DATA = 5,
__IFLA_INFO_MAX = 6,
};
enum {
IFLA_VF_INFO_UNSPEC = 0,
IFLA_VF_INFO = 1,
__IFLA_VF_INFO_MAX = 2,
};
enum {
IFLA_VF_UNSPEC = 0,
IFLA_VF_MAC = 1,
IFLA_VF_VLAN = 2,
IFLA_VF_TX_RATE = 3,
IFLA_VF_SPOOFCHK = 4,
IFLA_VF_LINK_STATE = 5,
IFLA_VF_RATE = 6,
IFLA_VF_RSS_QUERY_EN = 7,
IFLA_VF_STATS = 8,
IFLA_VF_TRUST = 9,
IFLA_VF_IB_NODE_GUID = 10,
IFLA_VF_IB_PORT_GUID = 11,
IFLA_VF_VLAN_LIST = 12,
IFLA_VF_BROADCAST = 13,
__IFLA_VF_MAX = 14,
};
struct ifla_vf_mac {
__u32 vf;
__u8 mac[32];
};
struct ifla_vf_broadcast {
__u8 broadcast[32];
};
struct ifla_vf_vlan {
__u32 vf;
__u32 vlan;
__u32 qos;
};
enum {
IFLA_VF_VLAN_INFO_UNSPEC = 0,
IFLA_VF_VLAN_INFO = 1,
__IFLA_VF_VLAN_INFO_MAX = 2,
};
struct ifla_vf_vlan_info {
__u32 vf;
__u32 vlan;
__u32 qos;
__be16 vlan_proto;
};
struct ifla_vf_tx_rate {
__u32 vf;
__u32 rate;
};
struct ifla_vf_rate {
__u32 vf;
__u32 min_tx_rate;
__u32 max_tx_rate;
};
struct ifla_vf_spoofchk {
__u32 vf;
__u32 setting;
};
struct ifla_vf_link_state {
__u32 vf;
__u32 link_state;
};
struct ifla_vf_rss_query_en {
__u32 vf;
__u32 setting;
};
enum {
IFLA_VF_STATS_RX_PACKETS = 0,
IFLA_VF_STATS_TX_PACKETS = 1,
IFLA_VF_STATS_RX_BYTES = 2,
IFLA_VF_STATS_TX_BYTES = 3,
IFLA_VF_STATS_BROADCAST = 4,
IFLA_VF_STATS_MULTICAST = 5,
IFLA_VF_STATS_PAD = 6,
IFLA_VF_STATS_RX_DROPPED = 7,
IFLA_VF_STATS_TX_DROPPED = 8,
__IFLA_VF_STATS_MAX = 9,
};
struct ifla_vf_trust {
__u32 vf;
__u32 setting;
};
enum {
IFLA_VF_PORT_UNSPEC = 0,
IFLA_VF_PORT = 1,
__IFLA_VF_PORT_MAX = 2,
};
enum {
IFLA_PORT_UNSPEC = 0,
IFLA_PORT_VF = 1,
IFLA_PORT_PROFILE = 2,
IFLA_PORT_VSI_TYPE = 3,
IFLA_PORT_INSTANCE_UUID = 4,
IFLA_PORT_HOST_UUID = 5,
IFLA_PORT_REQUEST = 6,
IFLA_PORT_RESPONSE = 7,
__IFLA_PORT_MAX = 8,
};
struct if_stats_msg {
__u8 family;
__u8 pad1;
__u16 pad2;
__u32 ifindex;
__u32 filter_mask;
};
enum {
IFLA_STATS_UNSPEC = 0,
IFLA_STATS_LINK_64 = 1,
IFLA_STATS_LINK_XSTATS = 2,
IFLA_STATS_LINK_XSTATS_SLAVE = 3,
IFLA_STATS_LINK_OFFLOAD_XSTATS = 4,
IFLA_STATS_AF_SPEC = 5,
__IFLA_STATS_MAX = 6,
};
enum {
IFLA_STATS_GETSET_UNSPEC = 0,
IFLA_STATS_GET_FILTERS = 1,
IFLA_STATS_SET_OFFLOAD_XSTATS_L3_STATS = 2,
__IFLA_STATS_GETSET_MAX = 3,
};
enum {
IFLA_OFFLOAD_XSTATS_UNSPEC = 0,
IFLA_OFFLOAD_XSTATS_CPU_HIT = 1,
IFLA_OFFLOAD_XSTATS_HW_S_INFO = 2,
IFLA_OFFLOAD_XSTATS_L3_STATS = 3,
__IFLA_OFFLOAD_XSTATS_MAX = 4,
};
enum {
IFLA_OFFLOAD_XSTATS_HW_S_INFO_UNSPEC = 0,
IFLA_OFFLOAD_XSTATS_HW_S_INFO_REQUEST = 1,
IFLA_OFFLOAD_XSTATS_HW_S_INFO_USED = 2,
__IFLA_OFFLOAD_XSTATS_HW_S_INFO_MAX = 3,
};
enum {
XDP_ATTACHED_NONE = 0,
XDP_ATTACHED_DRV = 1,
XDP_ATTACHED_SKB = 2,
XDP_ATTACHED_HW = 3,
XDP_ATTACHED_MULTI = 4,
};
enum {
IFLA_XDP_UNSPEC = 0,
IFLA_XDP_FD = 1,
IFLA_XDP_ATTACHED = 2,
IFLA_XDP_FLAGS = 3,
IFLA_XDP_PROG_ID = 4,
IFLA_XDP_DRV_PROG_ID = 5,
IFLA_XDP_SKB_PROG_ID = 6,
IFLA_XDP_HW_PROG_ID = 7,
IFLA_XDP_EXPECTED_FD = 8,
__IFLA_XDP_MAX = 9,
};
enum {
IFLA_EVENT_NONE = 0,
IFLA_EVENT_REBOOT = 1,
IFLA_EVENT_FEATURES = 2,
IFLA_EVENT_BONDING_FAILOVER = 3,
IFLA_EVENT_NOTIFY_PEERS = 4,
IFLA_EVENT_IGMP_RESEND = 5,
IFLA_EVENT_BONDING_OPTIONS = 6,
};
enum netdev_offload_xstats_type {
NETDEV_OFFLOAD_XSTATS_TYPE_L3 = 1,
};
enum {
IFLA_BRIDGE_FLAGS = 0,
IFLA_BRIDGE_MODE = 1,
IFLA_BRIDGE_VLAN_INFO = 2,
IFLA_BRIDGE_VLAN_TUNNEL_INFO = 3,
IFLA_BRIDGE_MRP = 4,
IFLA_BRIDGE_CFM = 5,
IFLA_BRIDGE_MST = 6,
__IFLA_BRIDGE_MAX = 7,
};
struct rta_cacheinfo {
__u32 rta_clntref;
__u32 rta_lastuse;
__s32 rta_expires;
__u32 rta_error;
__u32 rta_used;
__u32 rta_id;
__u32 rta_ts;
__u32 rta_tsage;
};
enum rtnl_kinds {
RTNL_KIND_NEW = 0,
RTNL_KIND_DEL = 1,
RTNL_KIND_GET = 2,
RTNL_KIND_SET = 3,
};
struct rtnl_link {
rtnl_doit_func doit;
rtnl_dumpit_func dumpit;
struct module *owner;
unsigned int flags;
struct callback_head rcu;
};
struct rtnl_newlink_tbs {
struct nlattr *tb[62];
struct nlattr *attr[51];
struct nlattr *slave_attr[41];
};
struct rtnl_offload_xstats_request_used {
bool request;
bool used;
};
struct rtnl_stats_dump_filters {
u32 mask[6];
};
enum {
ETHTOOL_A_TUNNEL_UDP_ENTRY_UNSPEC = 0,
ETHTOOL_A_TUNNEL_UDP_ENTRY_PORT = 1,
ETHTOOL_A_TUNNEL_UDP_ENTRY_TYPE = 2,
__ETHTOOL_A_TUNNEL_UDP_ENTRY_CNT = 3,
ETHTOOL_A_TUNNEL_UDP_ENTRY_MAX = 2,
};
enum {
ETHTOOL_A_TUNNEL_UDP_TABLE_UNSPEC = 0,
ETHTOOL_A_TUNNEL_UDP_TABLE_SIZE = 1,
ETHTOOL_A_TUNNEL_UDP_TABLE_TYPES = 2,
ETHTOOL_A_TUNNEL_UDP_TABLE_ENTRY = 3,
__ETHTOOL_A_TUNNEL_UDP_TABLE_CNT = 4,
ETHTOOL_A_TUNNEL_UDP_TABLE_MAX = 3,
};
enum {
ETHTOOL_A_TUNNEL_UDP_UNSPEC = 0,
ETHTOOL_A_TUNNEL_UDP_TABLE = 1,
__ETHTOOL_A_TUNNEL_UDP_CNT = 2,
ETHTOOL_A_TUNNEL_UDP_MAX = 1,
};
enum udp_parsable_tunnel_type {
UDP_TUNNEL_TYPE_VXLAN = 1,
UDP_TUNNEL_TYPE_GENEVE = 2,
UDP_TUNNEL_TYPE_VXLAN_GPE = 4,
};
enum udp_tunnel_nic_info_flags {
UDP_TUNNEL_NIC_INFO_MAY_SLEEP = 1,
UDP_TUNNEL_NIC_INFO_OPEN_ONLY = 2,
UDP_TUNNEL_NIC_INFO_IPV4_ONLY = 4,
UDP_TUNNEL_NIC_INFO_STATIC_IANA_VXLAN = 8,
};
struct udp_tunnel_nic_ops {
void (*get_port)(struct net_device *, unsigned int, unsigned int, struct udp_tunnel_info *);
void (*set_port_priv)(struct net_device *, unsigned int, unsigned int, u8);
void (*add_port)(struct net_device *, struct udp_tunnel_info *);
void (*del_port)(struct net_device *, struct udp_tunnel_info *);
void (*reset_ntf)(struct net_device *);
size_t (*dump_size)(struct net_device *, unsigned int);
int (*dump_write)(struct net_device *, unsigned int, struct sk_buff *);
};
struct ethnl_tunnel_info_dump_ctx {
struct ethnl_req_info req_info;
int pos_hash;
int pos_idx;
};
struct ip_options_data {
struct ip_options_rcu opt;
char data[40];
};
struct ipcm_cookie {
struct sockcm_cookie sockc;
__be32 addr;
int oif;
struct ip_options_rcu *opt;
__u8 ttl;
__s16 tos;
char priority;
__u16 gso_size;
long: 32;
};
struct raw_iter_state {
struct seq_net_private p;
int bucket;
};
struct raw_frag_vec {
struct msghdr *msg;
union {
struct icmphdr icmph;
char c[1];
} hdr;
int hlen;
};
struct ping_iter_state {
struct seq_net_private p;
int bucket;
sa_family_t family;
};
struct pingfakehdr {
struct icmphdr icmph;
struct msghdr *msg;
sa_family_t family;
__wsum wcheck;
};
struct ping_table {
struct hlist_nulls_head hash[64];
spinlock_t lock;
};
struct ip6_mtuinfo {
struct sockaddr_in6 ip6m_addr;
__u32 ip6m_mtu;
};
struct svc_xpt_user {
struct list_head list;
void (*callback)(struct svc_xpt_user *);
};
struct mips_abi {
int (* const setup_frame)(void *, struct ksignal *, struct pt_regs *, sigset_t *);
int (* const setup_rt_frame)(void *, struct ksignal *, struct pt_regs *, sigset_t *);
const long unsigned int restart;
unsigned int off_sc_fpregs;
unsigned int off_sc_fpc_csr;
unsigned int off_sc_used_math;
struct mips_vdso_image *vdso;
};
struct timens_offset {
s64 sec;
u64 nsec;
};
struct arch_vdso_data {};
struct vdso_timestamp {
u64 sec;
u64 nsec;
};
struct vdso_data {
u32 seq;
s32 clock_mode;
u64 cycle_last;
u64 mask;
u32 mult;
u32 shift;
union {
struct vdso_timestamp basetime[12];
struct timens_offset offset[12];
};
s32 tz_minuteswest;
s32 tz_dsttime;
u32 hrtimer_res;
u32 __unused;
struct arch_vdso_data arch_data;
};
union mips_vdso_data {
struct vdso_data data[2];
u8 page[16384];
};
enum sysctl_writes_mode {
SYSCTL_WRITES_LEGACY = -1,
SYSCTL_WRITES_WARN = 0,
SYSCTL_WRITES_STRICT = 1,
};
struct do_proc_dointvec_minmax_conv_param {
int *min;
int *max;
};
struct do_proc_douintvec_minmax_conv_param {
unsigned int *min;
unsigned int *max;
};
struct bpf_iter_seq_link_info {
u32 link_id;
};
struct bpf_iter__bpf_link {
union {
struct bpf_iter_meta *meta;
};
union {
struct bpf_link *link;
};
};
struct bpf_prog_info {
__u32 type;
__u32 id;
__u8 tag[8];
__u32 jited_prog_len;
__u32 xlated_prog_len;
__u64 jited_prog_insns;
__u64 xlated_prog_insns;
__u64 load_time;
__u32 created_by_uid;
__u32 nr_map_ids;
__u64 map_ids;
char name[16];
__u32 ifindex;
__u32 gpl_compatible: 1;
__u64 netns_dev;
__u64 netns_ino;
__u32 nr_jited_ksyms;
__u32 nr_jited_func_lens;
__u64 jited_ksyms;
__u64 jited_func_lens;
__u32 btf_id;
__u32 func_info_rec_size;
__u64 func_info;
__u32 nr_func_info;
__u32 nr_line_info;
__u64 line_info;
__u64 jited_line_info;
__u32 nr_jited_line_info;
__u32 line_info_rec_size;
__u32 jited_line_info_rec_size;
__u32 nr_prog_tags;
__u64 prog_tags;
__u64 run_time_ns;
__u64 run_cnt;
__u64 recursion_misses;
__u32 verified_insns;
__u32 attach_btf_obj_id;
__u32 attach_btf_id;
long: 32;
};
struct bpf_map_info {
__u32 type;
__u32 id;
__u32 key_size;
__u32 value_size;
__u32 max_entries;
__u32 map_flags;
char name[16];
__u32 ifindex;
__u32 btf_vmlinux_value_type_id;
__u64 netns_dev;
__u64 netns_ino;
__u32 btf_id;
__u32 btf_key_type_id;
__u32 btf_value_type_id;
long: 32;
__u64 map_extra;
};
struct bpf_prog_offload_ops {
int (*insn_hook)(struct bpf_verifier_env *, int, int);
int (*finalize)(struct bpf_verifier_env *);
int (*replace_insn)(struct bpf_verifier_env *, u32, struct bpf_insn *);
int (*remove_insns)(struct bpf_verifier_env *, u32, u32);
int (*prepare)(struct bpf_prog *);
int (*translate)(struct bpf_prog *);
void (*destroy)(struct bpf_prog *);
};
struct bpf_offload_dev {
const struct bpf_prog_offload_ops *ops;
struct list_head netdevs;
void *priv;
};
typedef struct ns_common *ns_get_path_helper_t(void *);
struct bpf_offload_netdev {
struct rhash_head l;
struct net_device *netdev;
struct bpf_offload_dev *offdev;
struct list_head progs;
struct list_head maps;
struct list_head offdev_netdevs;
};
struct ns_get_path_bpf_prog_args {
struct bpf_prog *prog;
struct bpf_prog_info *info;
};
struct ns_get_path_bpf_map_args {
struct bpf_offloaded_map *offmap;
struct bpf_map_info *info;
};
struct wait_page_key {
struct folio *folio;
int bit_nr;
int page_match;
};
struct folio_batch {
unsigned char nr;
bool percpu_pvec_drained;
struct folio *folios[15];
};
struct trace_event_raw_mm_filemap_op_page_cache {
struct trace_entry ent;
long unsigned int pfn;
long unsigned int i_ino;
long unsigned int index;
dev_t s_dev;
unsigned char order;
char __data[0];
};
struct trace_event_raw_filemap_set_wb_err {
struct trace_entry ent;
long unsigned int i_ino;
dev_t s_dev;
errseq_t errseq;
char __data[0];
};
struct trace_event_raw_file_check_and_advance_wb_err {
struct trace_entry ent;
struct file *file;
long unsigned int i_ino;
dev_t s_dev;
errseq_t old;
errseq_t new;
char __data[0];
};
struct trace_event_data_offsets_mm_filemap_op_page_cache {};
struct trace_event_data_offsets_filemap_set_wb_err {};
struct trace_event_data_offsets_file_check_and_advance_wb_err {};
typedef void (*btf_trace_mm_filemap_delete_from_page_cache)(void *, struct folio *);
typedef void (*btf_trace_mm_filemap_add_to_page_cache)(void *, struct folio *);
typedef void (*btf_trace_filemap_set_wb_err)(void *, struct address_space *, errseq_t);
typedef void (*btf_trace_file_check_and_advance_wb_err)(void *, struct file *, errseq_t);
enum behavior {
EXCLUSIVE = 0,
SHARED = 1,
DROP = 2,
};
struct mlock_pvec {
local_lock_t lock;
struct pagevec vec;
};
typedef struct kobject *kobj_probe_t(dev_t, int *, void *);
struct char_device_struct {
struct char_device_struct *next;
unsigned int major;
unsigned int baseminor;
int minorct;
char name[64];
struct cdev *cdev;
};
struct old_utimbuf32 {
old_time32_t actime;
old_time32_t modtime;
};
struct utimbuf {
__kernel_old_time_t actime;
__kernel_old_time_t modtime;
};
struct mb_cache {
struct hlist_bl_head *c_hash;
int c_bucket_bits;
long unsigned int c_max_entries;
spinlock_t c_list_lock;
struct list_head c_list;
long unsigned int c_entry_count;
struct shrinker c_shrink;
struct work_struct c_shrink_work;
};
struct pde_opener {
struct list_head lh;
struct file *file;
bool closing;
struct completion *c;
};
enum {
BIAS = 2147483648,
};
struct kernfs_global_locks {
struct mutex open_file_mutex[64];
};
struct ramfs_mount_opts {
umode_t mode;
};
struct ramfs_fs_info {
struct ramfs_mount_opts mount_opts;
};
enum ramfs_param {
Opt_mode___3 = 0,
};
struct nfs_io_completion {
void (*complete)(void *);
void *data;
struct kref refcount;
};
enum pnfs_try_status {
PNFS_ATTEMPTED = 0,
PNFS_NOT_ATTEMPTED = 1,
PNFS_TRY_AGAIN = 2,
};
struct crypto_report_kpp {
char type[64];
};
struct kpp_request {
struct crypto_async_request base;
struct scatterlist *src;
struct scatterlist *dst;
unsigned int src_len;
unsigned int dst_len;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__ctx[0];
};
struct crypto_kpp {
struct crypto_tfm base;
};
struct kpp_alg {
int (*set_secret)(struct crypto_kpp *, const void *, unsigned int);
int (*generate_public_key)(struct kpp_request *);
int (*compute_shared_secret)(struct kpp_request *);
unsigned int (*max_size)(struct crypto_kpp *);
int (*init)(struct crypto_kpp *);
void (*exit)(struct crypto_kpp *);
unsigned int reqsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct kpp_instance {
void (*free)(struct kpp_instance *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
union {
struct {
char head[128];
struct crypto_instance base;
} s;
struct kpp_alg alg;
};
};
struct crypto_kpp_spawn {
struct crypto_spawn base;
};
enum blacklist_hash_type {
BLACKLIST_HASH_X509_TBS = 1,
BLACKLIST_HASH_BINARY = 2,
};
struct blk_queue_stats {
struct list_head callbacks;
spinlock_t lock;
int accounting;
};
enum dd_data_dir {
DD_READ = 0,
DD_WRITE = 1,
};
enum {
DD_DIR_COUNT = 2,
};
enum dd_prio {
DD_RT_PRIO = 0,
DD_BE_PRIO = 1,
DD_IDLE_PRIO = 2,
DD_PRIO_MAX = 2,
};
enum {
DD_PRIO_COUNT = 3,
};
struct io_stats_per_prio {
uint32_t inserted;
uint32_t merged;
uint32_t dispatched;
atomic_t completed;
};
struct dd_per_prio {
struct list_head dispatch;
struct rb_root sort_list[2];
struct list_head fifo_list[2];
struct request *next_rq[2];
struct io_stats_per_prio stats;
};
struct deadline_data {
struct dd_per_prio per_prio[3];
enum dd_data_dir last_dir;
unsigned int batching;
unsigned int starved;
int fifo_expire[2];
int fifo_batch;
int writes_starved;
int front_merges;
u32 async_depth;
int prio_aging_expire;
spinlock_t lock;
spinlock_t zone_lock;
};
enum {
IO_APOLL_OK = 0,
IO_APOLL_ABORTED = 1,
IO_APOLL_READY = 2,
};
struct io_poll_update {
struct file *file;
long: 32;
u64 old_user_data;
u64 new_user_data;
__poll_t events;
bool update_events;
bool update_user_data;
};
struct io_poll_table {
struct poll_table_struct pt;
struct io_kiocb *req;
int nr_entries;
int error;
bool owning;
__poll_t result_mask;
};
enum {
IOU_POLL_DONE = 0,
IOU_POLL_NO_ACTION = 1,
IOU_POLL_REMOVE_POLL_USE_RES = 2,
};
typedef s16 int16_t;
typedef int16_t S16;
typedef uint64_t U64;
typedef struct {
size_t bitContainer;
unsigned int bitsConsumed;
const char *ptr;
const char *start;
const char *limitPtr;
} BIT_DStream_t;
typedef enum {
BIT_DStream_unfinished = 0,
BIT_DStream_endOfBuffer = 1,
BIT_DStream_completed = 2,
BIT_DStream_overflow = 3,
} BIT_DStream_status;
typedef unsigned int FSE_DTable;
typedef struct {
size_t state;
const void *table;
} FSE_DState_t;
typedef struct {
U16 tableLog;
U16 fastMode;
} FSE_DTableHeader;
typedef struct {
short unsigned int newState;
unsigned char symbol;
unsigned char nbBits;
} FSE_decode_t;
typedef struct {
short int ncount[256];
FSE_DTable dtable[1];
} FSE_DecompressWksp;
enum gcry_mpi_constants {
MPI_C_ZERO = 0,
MPI_C_ONE = 1,
MPI_C_TWO = 2,
MPI_C_THREE = 3,
MPI_C_FOUR = 4,
MPI_C_EIGHT = 5,
};
struct clk_notifier {
struct clk *clk;
struct srcu_notifier_head notifier_head;
struct list_head node;
};
struct clk_notifier_data {
struct clk *clk;
long unsigned int old_rate;
long unsigned int new_rate;
};
struct clk_parent_map;
struct clk_core {
const char *name;
const struct clk_ops *ops;
struct clk_hw *hw;
struct module *owner;
struct device *dev;
struct device_node *of_node;
struct clk_core *parent;
struct clk_parent_map *parents;
u8 num_parents;
u8 new_parent_index;
long unsigned int rate;
long unsigned int req_rate;
long unsigned int new_rate;
struct clk_core *new_parent;
struct clk_core *new_child;
long unsigned int flags;
bool orphan;
bool rpm_enabled;
unsigned int enable_count;
unsigned int prepare_count;
unsigned int protect_count;
long unsigned int min_rate;
long unsigned int max_rate;
long unsigned int accuracy;
int phase;
struct clk_duty duty;
struct hlist_head children;
struct hlist_node child_node;
struct hlist_head clks;
unsigned int notifier_count;
struct dentry *dentry;
struct hlist_node debug_node;
struct kref ref;
};
struct clk_onecell_data {
struct clk **clks;
unsigned int clk_num;
};
struct clk_hw_onecell_data {
unsigned int num;
struct clk_hw *hws[0];
};
struct clk_parent_map {
const struct clk_hw *hw;
struct clk_core *core;
const char *fw_name;
const char *name;
int index;
};
struct trace_event_raw_clk {
struct trace_entry ent;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_clk_rate {
struct trace_entry ent;
u32 __data_loc_name;
long unsigned int rate;
char __data[0];
};
struct trace_event_raw_clk_rate_range {
struct trace_entry ent;
u32 __data_loc_name;
long unsigned int min;
long unsigned int max;
char __data[0];
};
struct trace_event_raw_clk_parent {
struct trace_entry ent;
u32 __data_loc_name;
u32 __data_loc_pname;
char __data[0];
};
struct trace_event_raw_clk_phase {
struct trace_entry ent;
u32 __data_loc_name;
int phase;
char __data[0];
};
struct trace_event_raw_clk_duty_cycle {
struct trace_entry ent;
u32 __data_loc_name;
unsigned int num;
unsigned int den;
char __data[0];
};
struct trace_event_data_offsets_clk {
u32 name;
};
struct trace_event_data_offsets_clk_rate {
u32 name;
};
struct trace_event_data_offsets_clk_rate_range {
u32 name;
};
struct trace_event_data_offsets_clk_parent {
u32 name;
u32 pname;
};
struct trace_event_data_offsets_clk_phase {
u32 name;
};
struct trace_event_data_offsets_clk_duty_cycle {
u32 name;
};
typedef void (*btf_trace_clk_enable)(void *, struct clk_core *);
typedef void (*btf_trace_clk_enable_complete)(void *, struct clk_core *);
typedef void (*btf_trace_clk_disable)(void *, struct clk_core *);
typedef void (*btf_trace_clk_disable_complete)(void *, struct clk_core *);
typedef void (*btf_trace_clk_prepare)(void *, struct clk_core *);
typedef void (*btf_trace_clk_prepare_complete)(void *, struct clk_core *);
typedef void (*btf_trace_clk_unprepare)(void *, struct clk_core *);
typedef void (*btf_trace_clk_unprepare_complete)(void *, struct clk_core *);
typedef void (*btf_trace_clk_set_rate)(void *, struct clk_core *, long unsigned int);
typedef void (*btf_trace_clk_set_rate_complete)(void *, struct clk_core *, long unsigned int);
typedef void (*btf_trace_clk_set_min_rate)(void *, struct clk_core *, long unsigned int);
typedef void (*btf_trace_clk_set_max_rate)(void *, struct clk_core *, long unsigned int);
typedef void (*btf_trace_clk_set_rate_range)(void *, struct clk_core *, long unsigned int, long unsigned int);
typedef void (*btf_trace_clk_set_parent)(void *, struct clk_core *, struct clk_core *);
typedef void (*btf_trace_clk_set_parent_complete)(void *, struct clk_core *, struct clk_core *);
typedef void (*btf_trace_clk_set_phase)(void *, struct clk_core *, int);
typedef void (*btf_trace_clk_set_phase_complete)(void *, struct clk_core *, int);
typedef void (*btf_trace_clk_set_duty_cycle)(void *, struct clk_core *, struct clk_duty *);
typedef void (*btf_trace_clk_set_duty_cycle_complete)(void *, struct clk_core *, struct clk_duty *);
struct clk_notifier_devres {
struct clk *clk;
struct notifier_block *nb;
};
struct of_clk_provider {
struct list_head link;
struct device_node *node;
struct clk * (*get)(struct of_phandle_args *, void *);
struct clk_hw * (*get_hw)(struct of_phandle_args *, void *);
void *data;
};
struct clock_provider {
void (*clk_init_cb)(struct device_node *);
struct device_node *np;
struct list_head node;
};
struct brd_device {
int brd_number;
struct gendisk *brd_disk;
struct list_head brd_list;
spinlock_t brd_lock;
struct xarray brd_pages;
u64 brd_nr_pages;
};
struct transport_container {
struct attribute_container ac;
const struct attribute_group *statistics;
};
struct scsi_transport_template {
struct transport_container host_attrs;
struct transport_container target_attrs;
struct transport_container device_attrs;
int (*user_scan)(struct Scsi_Host *, uint, uint, u64);
int device_size;
int device_private_offset;
int target_size;
int target_private_offset;
int host_size;
unsigned int create_work_queue: 1;
void (*eh_strategy_handler)(struct Scsi_Host *);
};
enum ata_link_iter_mode {
ATA_LITER_EDGE = 0,
ATA_LITER_HOST_FIRST = 1,
ATA_LITER_PMP_FIRST = 2,
};
typedef unsigned int (*ata_xlat_func_t)(struct ata_queued_cmd *);
struct ata_scsi_args {
struct ata_device *dev;
u16 *id;
struct scsi_cmnd *cmd;
};
enum ptp_clock_events {
PTP_CLOCK_ALARM = 0,
PTP_CLOCK_EXTTS = 1,
PTP_CLOCK_PPS = 2,
PTP_CLOCK_PPSUSR = 3,
};
struct ptp_clock_event {
int type;
int index;
union {
u64 timestamp;
struct pps_event_time pps_times;
};
};
struct ts_state {
unsigned int offset;
char cb[48];
};
struct ts_config;
struct ts_ops {
const char *name;
struct ts_config * (*init)(const void *, unsigned int, gfp_t, int);
unsigned int (*find)(struct ts_config *, struct ts_state *);
void (*destroy)(struct ts_config *);
void * (*get_pattern)(struct ts_config *);
unsigned int (*get_pattern_len)(struct ts_config *);
struct module *owner;
struct list_head list;
};
struct ts_config {
struct ts_ops *ops;
int flags;
unsigned int (*get_next_block)(unsigned int, const u8 **, struct ts_config *, struct ts_state *);
void (*finish)(struct ts_config *, struct ts_state *);
};
struct skb_seq_state {
__u32 lower_offset;
__u32 upper_offset;
__u32 frag_idx;
__u32 stepped_offset;
struct sk_buff *root_skb;
struct sk_buff *cur_skb;
__u8 *frag_data;
__u32 frag_off;
};
struct skb_checksum_ops {
__wsum (*update)(const void *, int, __wsum);
__wsum (*combine)(__wsum, __wsum, int, int);
};
struct sd_flow_limit {
u64 count;
unsigned int num_buckets;
unsigned int history_head;
u16 history[128];
u8 buckets[0];
};
struct vlan_ethhdr {
union {
struct {
unsigned char h_dest[6];
unsigned char h_source[6];
};
struct {
unsigned char h_dest[6];
unsigned char h_source[6];
} addrs;
};
__be16 h_vlan_proto;
__be16 h_vlan_TCI;
__be16 h_vlan_encapsulated_proto;
};
struct ip_auth_hdr {
__u8 nexthdr;
__u8 hdrlen;
__be16 reserved;
__be32 spi;
__be32 seq_no;
__u8 auth_data[0];
};
enum {
SCM_TSTAMP_SND = 0,
SCM_TSTAMP_SCHED = 1,
SCM_TSTAMP_ACK = 2,
};
struct mpls_shim_hdr {
__be32 label_stack_entry;
};
struct page_frag_1k {};
struct napi_alloc_cache {
struct page_frag_cache page;
struct page_frag_1k page_small;
unsigned int skb_count;
void *skb_cache[64];
};
typedef int (*sendmsg_func)(struct sock *, struct msghdr *, struct kvec *, size_t, size_t);
typedef int (*sendpage_func)(struct sock *, struct page *, int, size_t, int);
enum {
IFLA_INET_UNSPEC = 0,
IFLA_INET_CONF = 1,
__IFLA_INET_MAX = 2,
};
struct in_validator_info {
__be32 ivi_addr;
struct in_device *ivi_dev;
struct netlink_ext_ack *extack;
};
struct inet_fill_args {
u32 portid;
u32 seq;
int event;
unsigned int flags;
int netnsid;
int ifindex;
};
struct devinet_sysctl_table {
struct ctl_table_header *sysctl_header;
struct ctl_table devinet_vars[34];
};
typedef struct {
long unsigned int key[2];
} hsiphash_key_t;
struct plat_serial8250_port {
long unsigned int iobase;
void *membase;
resource_size_t mapbase;
unsigned int irq;
long unsigned int irqflags;
unsigned int uartclk;
void *private_data;
unsigned char regshift;
unsigned char iotype;
unsigned char hub6;
unsigned char has_sysrq;
upf_t flags;
unsigned int type;
unsigned int (*serial_in)(struct uart_port *, int);
void (*serial_out)(struct uart_port *, int, int);
void (*set_termios)(struct uart_port *, struct ktermios *, const struct ktermios *);
void (*set_ldisc)(struct uart_port *, struct ktermios *);
unsigned int (*get_mctrl)(struct uart_port *);
int (*handle_irq)(struct uart_port *);
void (*pm)(struct uart_port *, unsigned int, unsigned int);
void (*handle_break)(struct uart_port *);
long: 32;
};
enum {
PLAT8250_DEV_LEGACY = -1,
PLAT8250_DEV_PLATFORM = 0,
PLAT8250_DEV_PLATFORM1 = 1,
PLAT8250_DEV_PLATFORM2 = 2,
PLAT8250_DEV_FOURPORT = 3,
PLAT8250_DEV_ACCENT = 4,
PLAT8250_DEV_BOCA = 5,
PLAT8250_DEV_EXAR_ST16C554 = 6,
PLAT8250_DEV_HUB6 = 7,
PLAT8250_DEV_AU1X00 = 8,
PLAT8250_DEV_SM501 = 9,
};
struct vm_unmapped_area_info {
long unsigned int flags;
long unsigned int length;
long unsigned int low_limit;
long unsigned int high_limit;
long unsigned int align_mask;
long unsigned int align_offset;
};
enum mmap_allocation_direction {
UP = 0,
DOWN = 1,
};
struct sched_param {
int sched_priority;
};
enum {
KTW_FREEZABLE = 1,
};
struct kthread_create_info {
int (*threadfn)(void *);
void *data;
int node;
struct task_struct *result;
struct completion *done;
struct list_head list;
};
struct kthread {
long unsigned int flags;
unsigned int cpu;
int result;
int (*threadfn)(void *);
void *data;
struct completion parked;
struct completion exited;
char *full_name;
};
enum KTHREAD_BITS {
KTHREAD_IS_PER_CPU = 0,
KTHREAD_SHOULD_STOP = 1,
KTHREAD_SHOULD_PARK = 2,
};
struct kthread_flush_work {
struct kthread_work work;
struct completion done;
};
enum cpu_idle_type {
CPU_IDLE = 0,
CPU_NOT_IDLE = 1,
CPU_NEWLY_IDLE = 2,
CPU_MAX_IDLE_TYPES = 3,
};
struct cpuidle_state_usage {
long long unsigned int disable;
long long unsigned int usage;
u64 time_ns;
long long unsigned int above;
long long unsigned int below;
long long unsigned int rejected;
};
struct cpuidle_device;
struct cpuidle_driver;
struct cpuidle_state {
char name[16];
char desc[32];
s64 exit_latency_ns;
s64 target_residency_ns;
unsigned int flags;
unsigned int exit_latency;
int power_usage;
unsigned int target_residency;
int (*enter)(struct cpuidle_device *, struct cpuidle_driver *, int);
int (*enter_dead)(struct cpuidle_device *, int);
int (*enter_s2idle)(struct cpuidle_device *, struct cpuidle_driver *, int);
long: 32;
};
struct cpuidle_state_kobj;
struct cpuidle_driver_kobj;
struct cpuidle_device_kobj;
struct cpuidle_device {
unsigned int registered: 1;
unsigned int enabled: 1;
unsigned int poll_time_limit: 1;
unsigned int cpu;
ktime_t next_hrtimer;
int last_state_idx;
long: 32;
u64 last_residency_ns;
u64 poll_limit_ns;
u64 forced_idle_latency_limit_ns;
struct cpuidle_state_usage states_usage[10];
struct cpuidle_state_kobj *kobjs[10];
struct cpuidle_driver_kobj *kobj_driver;
struct cpuidle_device_kobj *kobj_dev;
struct list_head device_list;
};
struct cpuidle_driver {
const char *name;
struct module *owner;
unsigned int bctimer: 1;
long: 32;
struct cpuidle_state states[10];
int state_count;
int safe_state_index;
struct cpumask *cpumask;
const char *governor;
};
struct cfs_bandwidth {};
enum cpu_util_type {
FREQUENCY_UTIL = 0,
ENERGY_UTIL = 1,
};
struct energy_env {
long unsigned int task_busy_time;
long unsigned int pd_busy_time;
long unsigned int cpu_cap;
long unsigned int pd_cap;
};
enum fbq_type {
regular = 0,
remote = 1,
all = 2,
};
enum group_type {
group_has_spare = 0,
group_fully_busy = 1,
group_misfit_task = 2,
group_asym_packing = 3,
group_imbalanced = 4,
group_overloaded = 5,
};
enum migration_type {
migrate_load = 0,
migrate_util = 1,
migrate_task = 2,
migrate_misfit = 3,
};
struct lb_env {
struct sched_domain *sd;
struct rq *src_rq;
int src_cpu;
int dst_cpu;
struct rq *dst_rq;
struct cpumask *dst_grpmask;
int new_dst_cpu;
enum cpu_idle_type idle;
long int imbalance;
struct cpumask *cpus;
unsigned int flags;
unsigned int loop;
unsigned int loop_break;
unsigned int loop_max;
enum fbq_type fbq_type;
enum migration_type migration_type;
struct list_head tasks;
};
struct sg_lb_stats {
long unsigned int avg_load;
long unsigned int group_load;
long unsigned int group_capacity;
long unsigned int group_util;
long unsigned int group_runnable;
unsigned int sum_nr_running;
unsigned int sum_h_nr_running;
unsigned int idle_cpus;
unsigned int group_weight;
enum group_type group_type;
unsigned int group_asym_packing;
long unsigned int group_misfit_task_load;
};
struct sd_lb_stats {
struct sched_group *busiest;
struct sched_group *local;
long unsigned int total_load;
long unsigned int total_capacity;
long unsigned int avg_load;
unsigned int prefer_sibling;
struct sg_lb_stats busiest_stat;
struct sg_lb_stats local_stat;
};
struct task_group;
typedef void (*swap_r_func_t)(void *, void *, int, const void *);
typedef int (*cmp_r_func_t)(const void *, const void *, const void *);
enum bpf_cmd {
BPF_MAP_CREATE = 0,
BPF_MAP_LOOKUP_ELEM = 1,
BPF_MAP_UPDATE_ELEM = 2,
BPF_MAP_DELETE_ELEM = 3,
BPF_MAP_GET_NEXT_KEY = 4,
BPF_PROG_LOAD = 5,
BPF_OBJ_PIN = 6,
BPF_OBJ_GET = 7,
BPF_PROG_ATTACH = 8,
BPF_PROG_DETACH = 9,
BPF_PROG_TEST_RUN = 10,
BPF_PROG_RUN = 10,
BPF_PROG_GET_NEXT_ID = 11,
BPF_MAP_GET_NEXT_ID = 12,
BPF_PROG_GET_FD_BY_ID = 13,
BPF_MAP_GET_FD_BY_ID = 14,
BPF_OBJ_GET_INFO_BY_FD = 15,
BPF_PROG_QUERY = 16,
BPF_RAW_TRACEPOINT_OPEN = 17,
BPF_BTF_LOAD = 18,
BPF_BTF_GET_FD_BY_ID = 19,
BPF_TASK_FD_QUERY = 20,
BPF_MAP_LOOKUP_AND_DELETE_ELEM = 21,
BPF_MAP_FREEZE = 22,
BPF_BTF_GET_NEXT_ID = 23,
BPF_MAP_LOOKUP_BATCH = 24,
BPF_MAP_LOOKUP_AND_DELETE_BATCH = 25,
BPF_MAP_UPDATE_BATCH = 26,
BPF_MAP_DELETE_BATCH = 27,
BPF_LINK_CREATE = 28,
BPF_LINK_UPDATE = 29,
BPF_LINK_GET_FD_BY_ID = 30,
BPF_LINK_GET_NEXT_ID = 31,
BPF_ENABLE_STATS = 32,
BPF_ITER_CREATE = 33,
BPF_LINK_DETACH = 34,
BPF_PROG_BIND_MAP = 35,
};
enum bpf_stats_type {
BPF_STATS_RUN_TIME = 0,
};
struct bpf_tracing_link {
struct bpf_tramp_link link;
enum bpf_attach_type attach_type;
struct bpf_trampoline *trampoline;
struct bpf_prog *tgt_prog;
long: 32;
};
struct bpf_link_primer {
struct bpf_link *link;
struct file *file;
int fd;
u32 id;
};
struct bpf_tramp_run_ctx {
struct bpf_run_ctx run_ctx;
u64 bpf_cookie;
struct bpf_run_ctx *saved_run_ctx;
long: 32;
};
enum perf_bpf_event_type {
PERF_BPF_EVENT_UNKNOWN = 0,
PERF_BPF_EVENT_PROG_LOAD = 1,
PERF_BPF_EVENT_PROG_UNLOAD = 2,
PERF_BPF_EVENT_MAX = 3,
};
enum bpf_audit {
BPF_AUDIT_LOAD = 0,
BPF_AUDIT_UNLOAD = 1,
BPF_AUDIT_MAX = 2,
};
struct bpf_prog_kstats {
u64 nsecs;
u64 cnt;
u64 misses;
};
struct bpf_raw_tp_link {
struct bpf_link link;
struct bpf_raw_event_map *btp;
long: 32;
};
struct bpf_perf_link {
struct bpf_link link;
struct file *perf_file;
long: 32;
};
typedef u64 (*btf_bpf_sys_bpf)(int, union bpf_attr *, u32);
typedef u64 (*btf_bpf_sys_close)(u32);
typedef u64 (*btf_bpf_kallsyms_lookup_name)(const char *, int, int, u64 *);
struct trace_event_raw_mmap_lock {
struct trace_entry ent;
struct mm_struct *mm;
u32 __data_loc_memcg_path;
bool write;
char __data[0];
};
struct trace_event_raw_mmap_lock_acquire_returned {
struct trace_entry ent;
struct mm_struct *mm;
u32 __data_loc_memcg_path;
bool write;
bool success;
char __data[0];
};
struct trace_event_data_offsets_mmap_lock {
u32 memcg_path;
};
struct trace_event_data_offsets_mmap_lock_acquire_returned {
u32 memcg_path;
};
typedef void (*btf_trace_mmap_lock_start_locking)(void *, struct mm_struct *, const char *, bool);
typedef void (*btf_trace_mmap_lock_released)(void *, struct mm_struct *, const char *, bool);
typedef void (*btf_trace_mmap_lock_acquire_returned)(void *, struct mm_struct *, const char *, bool, bool);
struct ext4_system_zone {
struct rb_node node;
long: 32;
ext4_fsblk_t start_blk;
unsigned int count;
u32 ino;
};
enum rsaprivkey_actions {
ACT_rsa_get_d = 0,
ACT_rsa_get_dp = 1,
ACT_rsa_get_dq = 2,
ACT_rsa_get_e___2 = 3,
ACT_rsa_get_n___2 = 4,
ACT_rsa_get_p = 5,
ACT_rsa_get_q = 6,
ACT_rsa_get_qinv = 7,
NR__rsaprivkey_actions = 8,
};
struct crypto_report_acomp {
char type[64];
};
struct acomp_req {
struct crypto_async_request base;
struct scatterlist *src;
struct scatterlist *dst;
unsigned int slen;
unsigned int dlen;
u32 flags;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
void *__ctx[0];
};
struct crypto_acomp {
int (*compress)(struct acomp_req *);
int (*decompress)(struct acomp_req *);
void (*dst_free)(struct scatterlist *);
unsigned int reqsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_tfm base;
};
struct acomp_alg {
int (*compress)(struct acomp_req *);
int (*decompress)(struct acomp_req *);
void (*dst_free)(struct scatterlist *);
int (*init)(struct crypto_acomp *);
void (*exit)(struct crypto_acomp *);
unsigned int reqsize;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct blk_integrity_profile;
struct blk_integrity {
const struct blk_integrity_profile *profile;
unsigned char flags;
unsigned char tuple_size;
unsigned char interval_exp;
unsigned char tag_size;
};
struct blk_integrity_iter;
typedef blk_status_t integrity_processing_fn(struct blk_integrity_iter *);
typedef void integrity_prepare_fn(struct request *);
typedef void integrity_complete_fn(struct request *, unsigned int);
struct blk_integrity_profile {
integrity_processing_fn *generate_fn;
integrity_processing_fn *verify_fn;
integrity_prepare_fn *prepare_fn;
integrity_complete_fn *complete_fn;
const char *name;
};
struct blk_integrity_iter {
void *prot_buf;
void *data_buf;
sector_t seed;
unsigned int data_size;
short unsigned int interval;
unsigned char tuple_size;
const char *disk_name;
long: 32;
};
struct bdev_inode {
struct block_device bdev;
struct inode vfs_inode;
};
struct trace_event_raw_kyber_latency {
struct trace_entry ent;
dev_t dev;
char domain[16];
char type[8];
u8 percentile;
u8 numerator;
u8 denominator;
unsigned int samples;
char __data[0];
};
struct trace_event_raw_kyber_adjust {
struct trace_entry ent;
dev_t dev;
char domain[16];
unsigned int depth;
char __data[0];
};
struct trace_event_raw_kyber_throttled {
struct trace_entry ent;
dev_t dev;
char domain[16];
char __data[0];
};
struct trace_event_data_offsets_kyber_latency {};
struct trace_event_data_offsets_kyber_adjust {};
struct trace_event_data_offsets_kyber_throttled {};
typedef void (*btf_trace_kyber_latency)(void *, dev_t, const char *, const char *, unsigned int, unsigned int, unsigned int, unsigned int);
typedef void (*btf_trace_kyber_adjust)(void *, dev_t, const char *, unsigned int);
typedef void (*btf_trace_kyber_throttled)(void *, dev_t, const char *);
enum {
KYBER_READ = 0,
KYBER_WRITE = 1,
KYBER_DISCARD = 2,
KYBER_OTHER = 3,
KYBER_NUM_DOMAINS = 4,
};
enum {
KYBER_ASYNC_PERCENT = 75,
};
enum {
KYBER_LATENCY_SHIFT = 2,
KYBER_GOOD_BUCKETS = 4,
KYBER_LATENCY_BUCKETS = 8,
};
enum {
KYBER_TOTAL_LATENCY = 0,
KYBER_IO_LATENCY = 1,
};
struct kyber_cpu_latency {
atomic_t buckets[48];
};
struct kyber_ctx_queue {
spinlock_t lock;
struct list_head rq_list[4];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct kyber_queue_data {
struct request_queue *q;
dev_t dev;
struct sbitmap_queue domain_tokens[4];
unsigned int async_depth;
struct kyber_cpu_latency *cpu_latency;
struct timer_list timer;
unsigned int latency_buckets[48];
long unsigned int latency_timeout[3];
int domain_p99[3];
long: 32;
u64 latency_targets[3];
};
struct kyber_hctx_data {
spinlock_t lock;
struct list_head rqs[4];
unsigned int cur_domain;
unsigned int batching;
struct kyber_ctx_queue *kcqs;
struct sbitmap kcq_map[4];
struct sbq_wait domain_wait[4];
struct sbq_wait_state *domain_ws[4];
atomic_t wait_index[4];
};
struct flush_kcq_data {
struct kyber_hctx_data *khd;
unsigned int sched_domain;
struct list_head *list;
};
struct wrapper {
cmp_func_t cmp;
swap_func_t swap;
};
typedef struct {
__u8 b[16];
} guid_t;
struct iov_iter_state {
size_t iov_offset;
size_t count;
long unsigned int nr_segs;
};
typedef s32 compat_ssize_t;
struct compat_iovec {
compat_uptr_t iov_base;
compat_size_t iov_len;
};
struct scsi_event {
enum scsi_device_event evt_type;
struct list_head node;
};
typedef void (*activate_complete)(void *, int);
struct scsi_device_handler {
struct list_head list;
struct module *module;
const char *name;
enum scsi_disposition (*check_sense)(struct scsi_device *, struct scsi_sense_hdr *);
int (*attach)(struct scsi_device *);
void (*detach)(struct scsi_device *);
int (*activate)(struct scsi_device *, activate_complete, void *);
blk_status_t (*prep_fn)(struct scsi_device *, struct request *);
int (*set_params)(struct scsi_device *, const char *);
void (*rescan)(struct scsi_device *);
};
enum scsi_ml_status {
SCSIML_STAT_OK = 0,
SCSIML_STAT_RESV_CONFLICT = 1,
SCSIML_STAT_NOSPC = 2,
SCSIML_STAT_MED_ERROR = 3,
SCSIML_STAT_TGT_FAILURE = 4,
};
enum {
ACTION_FAIL = 0,
ACTION_REPREP = 1,
ACTION_DELAYED_REPREP = 2,
ACTION_RETRY = 3,
ACTION_DELAYED_RETRY = 4,
};
struct chip_probe {
char *name;
int (*probe_chip)(struct map_info *, __u32, long unsigned int *, struct cfi_private *);
};
struct cfi_early_fixup {
uint16_t mfr;
uint16_t id;
void (*fixup)(struct cfi_private *);
};
struct ifbond {
__s32 bond_mode;
__s32 num_slaves;
__s32 miimon;
};
typedef struct ifbond ifbond;
struct ifslave {
__s32 slave_id;
char slave_name[16];
__s8 link;
__s8 state;
__u32 link_failure_count;
};
typedef struct ifslave ifslave;
enum {
NAPIF_STATE_SCHED = 1,
NAPIF_STATE_MISSED = 2,
NAPIF_STATE_DISABLE = 4,
NAPIF_STATE_NPSVC = 8,
NAPIF_STATE_LISTED = 16,
NAPIF_STATE_NO_BUSY_POLL = 32,
NAPIF_STATE_IN_BUSY_POLL = 64,
NAPIF_STATE_PREFER_BUSY_POLL = 128,
NAPIF_STATE_THREADED = 256,
NAPIF_STATE_SCHED_THREADED = 512,
};
struct net_device_path_stack {
int num_paths;
struct net_device_path path[5];
};
struct bpf_xdp_link {
struct bpf_link link;
struct net_device *dev;
int flags;
};
struct netdev_net_notifier {
struct list_head list;
struct notifier_block *nb;
};
struct netdev_notifier_changelowerstate_info {
struct netdev_notifier_info info;
void *lower_state_info;
};
struct netdev_notifier_pre_changeaddr_info {
struct netdev_notifier_info info;
const unsigned char *dev_addr;
};
struct netdev_notifier_offload_xstats_rd {
struct rtnl_hw_stats64 stats;
bool used;
long: 32;
};
struct netdev_notifier_offload_xstats_ru {
bool used;
};
struct netdev_notifier_offload_xstats_info {
struct netdev_notifier_info info;
enum netdev_offload_xstats_type type;
union {
struct netdev_notifier_offload_xstats_rd *report_delta;
struct netdev_notifier_offload_xstats_ru *report_used;
};
};
enum {
NESTED_SYNC_IMM_BIT = 0,
NESTED_SYNC_TODO_BIT = 1,
};
struct netdev_nested_priv {
unsigned char flags;
void *data;
};
struct netdev_bonding_info {
ifslave slave;
ifbond master;
};
struct netdev_notifier_bonding_info {
struct netdev_notifier_info info;
struct netdev_bonding_info bonding_info;
};
struct tc_skb_cb {
struct qdisc_skb_cb qdisc_cb;
u16 mru;
u8 post_ct: 1;
u8 post_ct_snat: 1;
u8 post_ct_dnat: 1;
u16 zone;
};
typedef int (*bpf_op_t)(struct net_device *, struct netdev_bpf *);
struct dev_kfree_skb_cb {
enum skb_free_reason reason;
};
struct netdev_adjacent {
struct net_device *dev;
netdevice_tracker dev_tracker;
bool master;
bool ignore;
u16 ref_nr;
void *private;
struct list_head list;
struct callback_head rcu;
};
struct ac6_iter_state {
struct seq_net_private p;
struct net_device *dev;
struct inet6_dev *idev;
};
struct rt0_hdr {
struct ipv6_rt_hdr rt_hdr;
__u32 reserved;
struct in6_addr addr[0];
};
struct ipv6_rpl_sr_hdr {
__u8 nexthdr;
__u8 hdrlen;
__u8 type;
__u8 segments_left;
__u32 cmpre: 4;
__u32 cmpri: 4;
__u32 reserved: 4;
__u32 pad: 4;
__u32 reserved1: 16;
union {
struct in6_addr addr[0];
__u8 data[0];
} segments;
};
struct ioam6_hdr {
__u8 opt_type;
__u8 opt_len;
char: 8;
__u8 type;
};
struct snmp_mib {
const char *name;
int entry;
};
struct trace_event_raw_rpc_xdr_buf_class {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
const void *head_base;
size_t head_len;
const void *tail_base;
size_t tail_len;
unsigned int page_base;
unsigned int page_len;
unsigned int msg_len;
char __data[0];
};
struct trace_event_raw_rpc_clnt_class {
struct trace_entry ent;
unsigned int client_id;
char __data[0];
};
struct trace_event_raw_rpc_clnt_new {
struct trace_entry ent;
unsigned int client_id;
u32 __data_loc_addr;
u32 __data_loc_port;
u32 __data_loc_program;
u32 __data_loc_server;
char __data[0];
};
struct trace_event_raw_rpc_clnt_new_err {
struct trace_entry ent;
int error;
u32 __data_loc_program;
u32 __data_loc_server;
char __data[0];
};
struct trace_event_raw_rpc_clnt_clone_err {
struct trace_entry ent;
unsigned int client_id;
int error;
char __data[0];
};
struct trace_event_raw_rpc_task_status {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
int status;
char __data[0];
};
struct trace_event_raw_rpc_request {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
int version;
bool async;
u32 __data_loc_progname;
u32 __data_loc_procname;
char __data[0];
};
struct trace_event_raw_rpc_task_running {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
const void *action;
long unsigned int runstate;
int status;
short unsigned int flags;
char __data[0];
};
struct trace_event_raw_rpc_task_queued {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
long unsigned int timeout;
long unsigned int runstate;
int status;
short unsigned int flags;
u32 __data_loc_q_name;
char __data[0];
};
struct trace_event_raw_rpc_failure {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
char __data[0];
};
struct trace_event_raw_rpc_reply_event {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
u32 xid;
u32 __data_loc_progname;
u32 version;
u32 __data_loc_procname;
u32 __data_loc_servername;
char __data[0];
};
struct trace_event_raw_rpc_buf_alloc {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
size_t callsize;
size_t recvsize;
int status;
char __data[0];
};
struct trace_event_raw_rpc_call_rpcerror {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
int tk_status;
int rpc_status;
char __data[0];
};
struct trace_event_raw_rpc_stats_latency {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
u32 xid;
int version;
u32 __data_loc_progname;
u32 __data_loc_procname;
long unsigned int backlog;
long unsigned int rtt;
long unsigned int execute;
char __data[0];
};
struct trace_event_raw_rpc_xdr_overflow {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
int version;
size_t requested;
const void *end;
const void *p;
const void *head_base;
size_t head_len;
const void *tail_base;
size_t tail_len;
unsigned int page_len;
unsigned int len;
u32 __data_loc_progname;
u32 __data_loc_procedure;
char __data[0];
};
struct trace_event_raw_rpc_xdr_alignment {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
int version;
size_t offset;
unsigned int copied;
const void *head_base;
size_t head_len;
const void *tail_base;
size_t tail_len;
unsigned int page_len;
unsigned int len;
u32 __data_loc_progname;
u32 __data_loc_procedure;
char __data[0];
};
struct trace_event_raw_xs_socket_event {
struct trace_entry ent;
unsigned int socket_state;
unsigned int sock_state;
long long unsigned int ino;
__u8 saddr[28];
__u8 daddr[28];
char __data[0];
};
struct trace_event_raw_xs_socket_event_done {
struct trace_entry ent;
int error;
unsigned int socket_state;
unsigned int sock_state;
long: 32;
long long unsigned int ino;
__u8 saddr[28];
__u8 daddr[28];
char __data[0];
};
struct trace_event_raw_rpc_socket_nospace {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
unsigned int total;
unsigned int remaining;
char __data[0];
};
struct trace_event_raw_rpc_xprt_lifetime_class {
struct trace_entry ent;
long unsigned int state;
u32 __data_loc_addr;
u32 __data_loc_port;
char __data[0];
};
struct trace_event_raw_rpc_xprt_event {
struct trace_entry ent;
u32 xid;
int status;
u32 __data_loc_addr;
u32 __data_loc_port;
char __data[0];
};
struct trace_event_raw_xprt_transmit {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
u32 xid;
u32 seqno;
int status;
char __data[0];
};
struct trace_event_raw_xprt_retransmit {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
u32 xid;
int ntrans;
int version;
long unsigned int timeout;
u32 __data_loc_progname;
u32 __data_loc_procname;
char __data[0];
};
struct trace_event_raw_xprt_ping {
struct trace_entry ent;
int status;
u32 __data_loc_addr;
u32 __data_loc_port;
char __data[0];
};
struct trace_event_raw_xprt_writelock_event {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
unsigned int snd_task_id;
char __data[0];
};
struct trace_event_raw_xprt_cong_event {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
unsigned int snd_task_id;
long unsigned int cong;
long unsigned int cwnd;
bool wait;
char __data[0];
};
struct trace_event_raw_xprt_reserve {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
u32 xid;
char __data[0];
};
struct trace_event_raw_xs_data_ready {
struct trace_entry ent;
u32 __data_loc_addr;
u32 __data_loc_port;
char __data[0];
};
struct trace_event_raw_xs_stream_read_data {
struct trace_entry ent;
ssize_t err;
size_t total;
u32 __data_loc_addr;
u32 __data_loc_port;
char __data[0];
};
struct trace_event_raw_xs_stream_read_request {
struct trace_entry ent;
u32 __data_loc_addr;
u32 __data_loc_port;
u32 xid;
long unsigned int copied;
unsigned int reclen;
unsigned int offset;
char __data[0];
};
struct trace_event_raw_rpcb_getport {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
unsigned int program;
unsigned int version;
int protocol;
unsigned int bind_version;
u32 __data_loc_servername;
char __data[0];
};
struct trace_event_raw_rpcb_setport {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
int status;
short unsigned int port;
char __data[0];
};
struct trace_event_raw_pmap_register {
struct trace_entry ent;
unsigned int program;
unsigned int version;
int protocol;
unsigned int port;
char __data[0];
};
struct trace_event_raw_rpcb_register {
struct trace_entry ent;
unsigned int program;
unsigned int version;
u32 __data_loc_addr;
u32 __data_loc_netid;
char __data[0];
};
struct trace_event_raw_rpcb_unregister {
struct trace_entry ent;
unsigned int program;
unsigned int version;
u32 __data_loc_netid;
char __data[0];
};
struct trace_event_raw_svc_xdr_msg_class {
struct trace_entry ent;
u32 xid;
const void *head_base;
size_t head_len;
const void *tail_base;
size_t tail_len;
unsigned int page_len;
unsigned int msg_len;
char __data[0];
};
struct trace_event_raw_svc_xdr_buf_class {
struct trace_entry ent;
u32 xid;
const void *head_base;
size_t head_len;
const void *tail_base;
size_t tail_len;
unsigned int page_base;
unsigned int page_len;
unsigned int msg_len;
char __data[0];
};
struct trace_event_raw_svc_authenticate {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
unsigned int netns_ino;
u32 xid;
long unsigned int svc_status;
long unsigned int auth_stat;
char __data[0];
};
struct trace_event_raw_svc_process {
struct trace_entry ent;
u32 xid;
u32 vers;
u32 proc;
u32 __data_loc_service;
u32 __data_loc_procedure;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_svc_rqst_event {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
unsigned int netns_ino;
u32 xid;
long unsigned int flags;
char __data[0];
};
struct trace_event_raw_svc_rqst_status {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
unsigned int netns_ino;
u32 xid;
int status;
long unsigned int flags;
char __data[0];
};
struct trace_event_raw_svc_stats_latency {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
unsigned int netns_ino;
u32 xid;
long unsigned int execute;
u32 __data_loc_procedure;
char __data[0];
};
struct trace_event_raw_svc_xprt_create_err {
struct trace_entry ent;
long int error;
u32 __data_loc_program;
u32 __data_loc_protocol;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_svc_xprt_enqueue {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
long unsigned int flags;
unsigned int netns_ino;
int pid;
char __data[0];
};
struct trace_event_raw_svc_xprt_dequeue {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
long unsigned int flags;
unsigned int netns_ino;
long unsigned int wakeup;
char __data[0];
};
struct trace_event_raw_svc_xprt_event {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
long unsigned int flags;
unsigned int netns_ino;
char __data[0];
};
struct trace_event_raw_svc_xprt_accept {
struct trace_entry ent;
u32 __data_loc_server;
u32 __data_loc_client;
long unsigned int flags;
unsigned int netns_ino;
u32 __data_loc_protocol;
u32 __data_loc_service;
char __data[0];
};
struct trace_event_raw_svc_wake_up {
struct trace_entry ent;
int pid;
char __data[0];
};
struct trace_event_raw_svc_alloc_arg_err {
struct trace_entry ent;
unsigned int requested;
unsigned int allocated;
char __data[0];
};
struct trace_event_raw_svc_deferred_event {
struct trace_entry ent;
const void *dr;
u32 xid;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_svcsock_new_socket {
struct trace_entry ent;
long unsigned int type;
long unsigned int family;
bool listener;
char __data[0];
};
struct trace_event_raw_svcsock_marker {
struct trace_entry ent;
unsigned int length;
bool last;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_svcsock_class {
struct trace_entry ent;
ssize_t result;
long unsigned int flags;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_svcsock_tcp_recv_short {
struct trace_entry ent;
u32 expected;
u32 received;
long unsigned int flags;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_svcsock_tcp_state {
struct trace_entry ent;
long unsigned int socket_state;
long unsigned int sock_state;
long unsigned int flags;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_svcsock_accept_class {
struct trace_entry ent;
long int status;
u32 __data_loc_service;
unsigned int netns_ino;
char __data[0];
};
struct trace_event_raw_cache_event {
struct trace_entry ent;
const struct cache_head *h;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_register_class {
struct trace_entry ent;
u32 version;
long unsigned int family;
short unsigned int protocol;
short unsigned int port;
int error;
u32 __data_loc_program;
char __data[0];
};
struct trace_event_raw_svc_unregister {
struct trace_entry ent;
u32 version;
int error;
u32 __data_loc_program;
char __data[0];
};
struct trace_event_data_offsets_rpc_xdr_buf_class {};
struct trace_event_data_offsets_rpc_clnt_class {};
struct trace_event_data_offsets_rpc_clnt_new {
u32 addr;
u32 port;
u32 program;
u32 server;
};
struct trace_event_data_offsets_rpc_clnt_new_err {
u32 program;
u32 server;
};
struct trace_event_data_offsets_rpc_clnt_clone_err {};
struct trace_event_data_offsets_rpc_task_status {};
struct trace_event_data_offsets_rpc_request {
u32 progname;
u32 procname;
};
struct trace_event_data_offsets_rpc_task_running {};
struct trace_event_data_offsets_rpc_task_queued {
u32 q_name;
};
struct trace_event_data_offsets_rpc_failure {};
struct trace_event_data_offsets_rpc_reply_event {
u32 progname;
u32 procname;
u32 servername;
};
struct trace_event_data_offsets_rpc_buf_alloc {};
struct trace_event_data_offsets_rpc_call_rpcerror {};
struct trace_event_data_offsets_rpc_stats_latency {
u32 progname;
u32 procname;
};
struct trace_event_data_offsets_rpc_xdr_overflow {
u32 progname;
u32 procedure;
};
struct trace_event_data_offsets_rpc_xdr_alignment {
u32 progname;
u32 procedure;
};
struct trace_event_data_offsets_xs_socket_event {};
struct trace_event_data_offsets_xs_socket_event_done {};
struct trace_event_data_offsets_rpc_socket_nospace {};
struct trace_event_data_offsets_rpc_xprt_lifetime_class {
u32 addr;
u32 port;
};
struct trace_event_data_offsets_rpc_xprt_event {
u32 addr;
u32 port;
};
struct trace_event_data_offsets_xprt_transmit {};
struct trace_event_data_offsets_xprt_retransmit {
u32 progname;
u32 procname;
};
struct trace_event_data_offsets_xprt_ping {
u32 addr;
u32 port;
};
struct trace_event_data_offsets_xprt_writelock_event {};
struct trace_event_data_offsets_xprt_cong_event {};
struct trace_event_data_offsets_xprt_reserve {};
struct trace_event_data_offsets_xs_data_ready {
u32 addr;
u32 port;
};
struct trace_event_data_offsets_xs_stream_read_data {
u32 addr;
u32 port;
};
struct trace_event_data_offsets_xs_stream_read_request {
u32 addr;
u32 port;
};
struct trace_event_data_offsets_rpcb_getport {
u32 servername;
};
struct trace_event_data_offsets_rpcb_setport {};
struct trace_event_data_offsets_pmap_register {};
struct trace_event_data_offsets_rpcb_register {
u32 addr;
u32 netid;
};
struct trace_event_data_offsets_rpcb_unregister {
u32 netid;
};
struct trace_event_data_offsets_svc_xdr_msg_class {};
struct trace_event_data_offsets_svc_xdr_buf_class {};
struct trace_event_data_offsets_svc_authenticate {
u32 server;
u32 client;
};
struct trace_event_data_offsets_svc_process {
u32 service;
u32 procedure;
u32 addr;
};
struct trace_event_data_offsets_svc_rqst_event {
u32 server;
u32 client;
};
struct trace_event_data_offsets_svc_rqst_status {
u32 server;
u32 client;
};
struct trace_event_data_offsets_svc_stats_latency {
u32 server;
u32 client;
u32 procedure;
};
struct trace_event_data_offsets_svc_xprt_create_err {
u32 program;
u32 protocol;
u32 addr;
};
struct trace_event_data_offsets_svc_xprt_enqueue {
u32 server;
u32 client;
};
struct trace_event_data_offsets_svc_xprt_dequeue {
u32 server;
u32 client;
};
struct trace_event_data_offsets_svc_xprt_event {
u32 server;
u32 client;
};
struct trace_event_data_offsets_svc_xprt_accept {
u32 server;
u32 client;
u32 protocol;
u32 service;
};
struct trace_event_data_offsets_svc_wake_up {};
struct trace_event_data_offsets_svc_alloc_arg_err {};
struct trace_event_data_offsets_svc_deferred_event {
u32 addr;
};
struct trace_event_data_offsets_svcsock_new_socket {};
struct trace_event_data_offsets_svcsock_marker {
u32 addr;
};
struct trace_event_data_offsets_svcsock_class {
u32 addr;
};
struct trace_event_data_offsets_svcsock_tcp_recv_short {
u32 addr;
};
struct trace_event_data_offsets_svcsock_tcp_state {
u32 addr;
};
struct trace_event_data_offsets_svcsock_accept_class {
u32 service;
};
struct trace_event_data_offsets_cache_event {
u32 name;
};
struct trace_event_data_offsets_register_class {
u32 program;
};
struct trace_event_data_offsets_svc_unregister {
u32 program;
};
typedef void (*btf_trace_rpc_xdr_sendto)(void *, const struct rpc_task *, const struct xdr_buf *);
typedef void (*btf_trace_rpc_xdr_recvfrom)(void *, const struct rpc_task *, const struct xdr_buf *);
typedef void (*btf_trace_rpc_xdr_reply_pages)(void *, const struct rpc_task *, const struct xdr_buf *);
typedef void (*btf_trace_rpc_clnt_free)(void *, const struct rpc_clnt *);
typedef void (*btf_trace_rpc_clnt_killall)(void *, const struct rpc_clnt *);
typedef void (*btf_trace_rpc_clnt_shutdown)(void *, const struct rpc_clnt *);
typedef void (*btf_trace_rpc_clnt_release)(void *, const struct rpc_clnt *);
typedef void (*btf_trace_rpc_clnt_replace_xprt)(void *, const struct rpc_clnt *);
typedef void (*btf_trace_rpc_clnt_replace_xprt_err)(void *, const struct rpc_clnt *);
typedef void (*btf_trace_rpc_clnt_new)(void *, const struct rpc_clnt *, const struct rpc_xprt *, const char *, const char *);
typedef void (*btf_trace_rpc_clnt_new_err)(void *, const char *, const char *, int);
typedef void (*btf_trace_rpc_clnt_clone_err)(void *, const struct rpc_clnt *, int);
typedef void (*btf_trace_rpc_call_status)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_connect_status)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_timeout_status)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_retry_refresh_status)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_refresh_status)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_request)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_task_begin)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_run_action)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_sync_sleep)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_sync_wake)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_complete)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_timeout)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_signalled)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_end)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_call_done)(void *, const struct rpc_task *, const void *);
typedef void (*btf_trace_rpc_task_sleep)(void *, const struct rpc_task *, const struct rpc_wait_queue *);
typedef void (*btf_trace_rpc_task_wakeup)(void *, const struct rpc_task *, const struct rpc_wait_queue *);
typedef void (*btf_trace_rpc_bad_callhdr)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_bad_verifier)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__prog_unavail)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__prog_mismatch)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__proc_unavail)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__garbage_args)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__unparsable)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__mismatch)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__stale_creds)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__bad_creds)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc__auth_tooweak)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpcb_prog_unavail_err)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpcb_timeout_err)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpcb_bind_version_err)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpcb_unreachable_err)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpcb_unrecognized_err)(void *, const struct rpc_task *);
typedef void (*btf_trace_rpc_buf_alloc)(void *, const struct rpc_task *, int);
typedef void (*btf_trace_rpc_call_rpcerror)(void *, const struct rpc_task *, int, int);
typedef void (*btf_trace_rpc_stats_latency)(void *, const struct rpc_task *, ktime_t, ktime_t, ktime_t);
typedef void (*btf_trace_rpc_xdr_overflow)(void *, const struct xdr_stream *, size_t);
typedef void (*btf_trace_rpc_xdr_alignment)(void *, const struct xdr_stream *, size_t, unsigned int);
typedef void (*btf_trace_rpc_socket_state_change)(void *, struct rpc_xprt *, struct socket *);
typedef void (*btf_trace_rpc_socket_connect)(void *, struct rpc_xprt *, struct socket *, int);
typedef void (*btf_trace_rpc_socket_error)(void *, struct rpc_xprt *, struct socket *, int);
typedef void (*btf_trace_rpc_socket_reset_connection)(void *, struct rpc_xprt *, struct socket *, int);
typedef void (*btf_trace_rpc_socket_close)(void *, struct rpc_xprt *, struct socket *);
typedef void (*btf_trace_rpc_socket_shutdown)(void *, struct rpc_xprt *, struct socket *);
typedef void (*btf_trace_rpc_socket_nospace)(void *, const struct rpc_rqst *, const struct sock_xprt *);
typedef void (*btf_trace_xprt_create)(void *, const struct rpc_xprt *);
typedef void (*btf_trace_xprt_connect)(void *, const struct rpc_xprt *);
typedef void (*btf_trace_xprt_disconnect_auto)(void *, const struct rpc_xprt *);
typedef void (*btf_trace_xprt_disconnect_done)(void *, const struct rpc_xprt *);
typedef void (*btf_trace_xprt_disconnect_force)(void *, const struct rpc_xprt *);
typedef void (*btf_trace_xprt_destroy)(void *, const struct rpc_xprt *);
typedef void (*btf_trace_xprt_timer)(void *, const struct rpc_xprt *, __be32, int);
typedef void (*btf_trace_xprt_lookup_rqst)(void *, const struct rpc_xprt *, __be32, int);
typedef void (*btf_trace_xprt_transmit)(void *, const struct rpc_rqst *, int);
typedef void (*btf_trace_xprt_retransmit)(void *, const struct rpc_rqst *);
typedef void (*btf_trace_xprt_ping)(void *, const struct rpc_xprt *, int);
typedef void (*btf_trace_xprt_reserve_xprt)(void *, const struct rpc_xprt *, const struct rpc_task *);
typedef void (*btf_trace_xprt_release_xprt)(void *, const struct rpc_xprt *, const struct rpc_task *);
typedef void (*btf_trace_xprt_reserve_cong)(void *, const struct rpc_xprt *, const struct rpc_task *);
typedef void (*btf_trace_xprt_release_cong)(void *, const struct rpc_xprt *, const struct rpc_task *);
typedef void (*btf_trace_xprt_get_cong)(void *, const struct rpc_xprt *, const struct rpc_task *);
typedef void (*btf_trace_xprt_put_cong)(void *, const struct rpc_xprt *, const struct rpc_task *);
typedef void (*btf_trace_xprt_reserve)(void *, const struct rpc_rqst *);
typedef void (*btf_trace_xs_data_ready)(void *, const struct rpc_xprt *);
typedef void (*btf_trace_xs_stream_read_data)(void *, struct rpc_xprt *, ssize_t, size_t);
typedef void (*btf_trace_xs_stream_read_request)(void *, struct sock_xprt *);
typedef void (*btf_trace_rpcb_getport)(void *, const struct rpc_clnt *, const struct rpc_task *, unsigned int);
typedef void (*btf_trace_rpcb_setport)(void *, const struct rpc_task *, int, short unsigned int);
typedef void (*btf_trace_pmap_register)(void *, u32, u32, int, short unsigned int);
typedef void (*btf_trace_rpcb_register)(void *, u32, u32, const char *, const char *);
typedef void (*btf_trace_rpcb_unregister)(void *, u32, u32, const char *);
typedef void (*btf_trace_svc_xdr_recvfrom)(void *, const struct xdr_buf *);
typedef void (*btf_trace_svc_xdr_sendto)(void *, __be32, const struct xdr_buf *);
typedef void (*btf_trace_svc_authenticate)(void *, const struct svc_rqst *, int);
typedef void (*btf_trace_svc_process)(void *, const struct svc_rqst *, const char *);
typedef void (*btf_trace_svc_defer)(void *, const struct svc_rqst *);
typedef void (*btf_trace_svc_drop)(void *, const struct svc_rqst *);
typedef void (*btf_trace_svc_send)(void *, const struct svc_rqst *, int);
typedef void (*btf_trace_svc_stats_latency)(void *, const struct svc_rqst *);
typedef void (*btf_trace_svc_xprt_create_err)(void *, const char *, const char *, struct sockaddr *, size_t, const struct svc_xprt *);
typedef void (*btf_trace_svc_xprt_enqueue)(void *, const struct svc_xprt *, const struct svc_rqst *);
typedef void (*btf_trace_svc_xprt_dequeue)(void *, const struct svc_rqst *);
typedef void (*btf_trace_svc_xprt_no_write_space)(void *, const struct svc_xprt *);
typedef void (*btf_trace_svc_xprt_close)(void *, const struct svc_xprt *);
typedef void (*btf_trace_svc_xprt_detach)(void *, const struct svc_xprt *);
typedef void (*btf_trace_svc_xprt_free)(void *, const struct svc_xprt *);
typedef void (*btf_trace_svc_xprt_accept)(void *, const struct svc_xprt *, const char *);
typedef void (*btf_trace_svc_wake_up)(void *, int);
typedef void (*btf_trace_svc_alloc_arg_err)(void *, unsigned int, unsigned int);
typedef void (*btf_trace_svc_defer_drop)(void *, const struct svc_deferred_req *);
typedef void (*btf_trace_svc_defer_queue)(void *, const struct svc_deferred_req *);
typedef void (*btf_trace_svc_defer_recv)(void *, const struct svc_deferred_req *);
typedef void (*btf_trace_svcsock_new_socket)(void *, const struct socket *);
typedef void (*btf_trace_svcsock_marker)(void *, const struct svc_xprt *, __be32);
typedef void (*btf_trace_svcsock_udp_send)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_udp_recv)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_udp_recv_err)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_tcp_send)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_tcp_recv)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_tcp_recv_eagain)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_tcp_recv_err)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_data_ready)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_write_space)(void *, const struct svc_xprt *, ssize_t);
typedef void (*btf_trace_svcsock_tcp_recv_short)(void *, const struct svc_xprt *, u32, u32);
typedef void (*btf_trace_svcsock_tcp_state)(void *, const struct svc_xprt *, const struct socket *);
typedef void (*btf_trace_svcsock_accept_err)(void *, const struct svc_xprt *, const char *, long int);
typedef void (*btf_trace_svcsock_getpeername_err)(void *, const struct svc_xprt *, const char *, long int);
typedef void (*btf_trace_cache_entry_expired)(void *, const struct cache_detail *, const struct cache_head *);
typedef void (*btf_trace_cache_entry_upcall)(void *, const struct cache_detail *, const struct cache_head *);
typedef void (*btf_trace_cache_entry_update)(void *, const struct cache_detail *, const struct cache_head *);
typedef void (*btf_trace_cache_entry_make_negative)(void *, const struct cache_detail *, const struct cache_head *);
typedef void (*btf_trace_cache_entry_no_listener)(void *, const struct cache_detail *, const struct cache_head *);
typedef void (*btf_trace_svc_register)(void *, const char *, const u32, const int, const short unsigned int, const short unsigned int, int);
typedef void (*btf_trace_svc_noregister)(void *, const char *, const u32, const int, const short unsigned int, const short unsigned int, int);
typedef void (*btf_trace_svc_unregister)(void *, const char *, const u32, int);
struct hash {
int ino;
int minor;
int major;
umode_t mode;
struct hash *next;
char name[4098];
};
struct dir_entry {
struct list_head list;
time64_t mtime;
char name[0];
};
enum state {
Start = 0,
Collect = 1,
GotHeader = 2,
SkipIt = 3,
GotName = 4,
CopyFile = 5,
GotSymlink = 6,
Reset = 7,
};
typedef u32 uprobe_opcode_t;
struct arch_uprobe {
long unsigned int resume_epc;
u32 insn[2];
u32 ixol[2];
};
struct taint_flag {
char c_true;
char c_false;
bool module;
};
enum kmsg_dump_reason {
KMSG_DUMP_UNDEF = 0,
KMSG_DUMP_PANIC = 1,
KMSG_DUMP_OOPS = 2,
KMSG_DUMP_EMERG = 3,
KMSG_DUMP_SHUTDOWN = 4,
KMSG_DUMP_MAX = 5,
};
enum reboot_mode {
REBOOT_UNDEFINED = -1,
REBOOT_COLD = 0,
REBOOT_WARM = 1,
REBOOT_HARD = 2,
REBOOT_SOFT = 3,
REBOOT_GPIO = 4,
};
enum con_flush_mode {
CONSOLE_FLUSH_PENDING = 0,
CONSOLE_REPLAY_ALL = 1,
};
enum error_detector {
ERROR_DETECTOR_KFENCE = 0,
ERROR_DETECTOR_KASAN = 1,
ERROR_DETECTOR_WARN = 2,
};
struct warn_args {
const char *fmt;
va_list args;
};
enum {
FTRACE_UPDATE_CALLS = 1,
FTRACE_DISABLE_CALLS = 2,
FTRACE_UPDATE_TRACE_FUNC = 4,
FTRACE_START_FUNC_RET = 8,
FTRACE_STOP_FUNC_RET = 16,
FTRACE_MAY_SLEEP = 32,
};
enum pm_qos_req_action {
PM_QOS_ADD_REQ = 0,
PM_QOS_UPDATE_REQ = 1,
PM_QOS_REMOVE_REQ = 2,
};
enum cpufreq_table_sorting {
CPUFREQ_TABLE_UNSORTED = 0,
CPUFREQ_TABLE_SORTED_ASCENDING = 1,
CPUFREQ_TABLE_SORTED_DESCENDING = 2,
};
struct cpufreq_cpuinfo {
unsigned int max_freq;
unsigned int min_freq;
unsigned int transition_latency;
};
struct cpufreq_stats;
struct thermal_cooling_device;
struct cpufreq_governor;
struct cpufreq_frequency_table;
struct cpufreq_policy {
cpumask_var_t cpus;
cpumask_var_t related_cpus;
cpumask_var_t real_cpus;
unsigned int shared_type;
unsigned int cpu;
struct clk *clk;
struct cpufreq_cpuinfo cpuinfo;
unsigned int min;
unsigned int max;
unsigned int cur;
unsigned int suspend_freq;
unsigned int policy;
unsigned int last_policy;
struct cpufreq_governor *governor;
void *governor_data;
char last_governor[16];
struct work_struct update;
struct freq_constraints constraints;
struct freq_qos_request *min_freq_req;
struct freq_qos_request *max_freq_req;
struct cpufreq_frequency_table *freq_table;
enum cpufreq_table_sorting freq_table_sorted;
struct list_head policy_list;
struct kobject kobj;
struct completion kobj_unregister;
struct rw_semaphore rwsem;
bool fast_switch_possible;
bool fast_switch_enabled;
bool strict_target;
bool efficiencies_available;
unsigned int transition_delay_us;
bool dvfs_possible_from_any_cpu;
unsigned int cached_target_freq;
unsigned int cached_resolved_idx;
bool transition_ongoing;
spinlock_t transition_lock;
wait_queue_head_t transition_wait;
struct task_struct *transition_task;
struct cpufreq_stats *stats;
void *driver_data;
struct thermal_cooling_device *cdev;
struct notifier_block nb_min;
struct notifier_block nb_max;
};
struct cpufreq_governor {
char name[16];
int (*init)(struct cpufreq_policy *);
void (*exit)(struct cpufreq_policy *);
int (*start)(struct cpufreq_policy *);
void (*stop)(struct cpufreq_policy *);
void (*limits)(struct cpufreq_policy *);
ssize_t (*show_setspeed)(struct cpufreq_policy *, char *);
int (*store_setspeed)(struct cpufreq_policy *, unsigned int);
struct list_head governor_list;
struct module *owner;
u8 flags;
};
struct cpufreq_frequency_table {
unsigned int flags;
unsigned int driver_data;
unsigned int frequency;
};
struct trace_event_raw_cpu {
struct trace_entry ent;
u32 state;
u32 cpu_id;
char __data[0];
};
struct trace_event_raw_cpu_idle_miss {
struct trace_entry ent;
u32 cpu_id;
u32 state;
bool below;
char __data[0];
};
struct trace_event_raw_powernv_throttle {
struct trace_entry ent;
int chip_id;
u32 __data_loc_reason;
int pmax;
char __data[0];
};
struct trace_event_raw_pstate_sample {
struct trace_entry ent;
u32 core_busy;
u32 scaled_busy;
u32 from;
u32 to;
u64 mperf;
u64 aperf;
u64 tsc;
u32 freq;
u32 io_boost;
char __data[0];
};
struct trace_event_raw_cpu_frequency_limits {
struct trace_entry ent;
u32 min_freq;
u32 max_freq;
u32 cpu_id;
char __data[0];
};
struct trace_event_raw_device_pm_callback_start {
struct trace_entry ent;
u32 __data_loc_device;
u32 __data_loc_driver;
u32 __data_loc_parent;
u32 __data_loc_pm_ops;
int event;
char __data[0];
};
struct trace_event_raw_device_pm_callback_end {
struct trace_entry ent;
u32 __data_loc_device;
u32 __data_loc_driver;
int error;
char __data[0];
};
struct trace_event_raw_suspend_resume {
struct trace_entry ent;
const char *action;
int val;
bool start;
char __data[0];
};
struct trace_event_raw_wakeup_source {
struct trace_entry ent;
u32 __data_loc_name;
long: 32;
u64 state;
char __data[0];
};
struct trace_event_raw_clock {
struct trace_entry ent;
u32 __data_loc_name;
long: 32;
u64 state;
u64 cpu_id;
char __data[0];
};
struct trace_event_raw_power_domain {
struct trace_entry ent;
u32 __data_loc_name;
long: 32;
u64 state;
u64 cpu_id;
char __data[0];
};
struct trace_event_raw_cpu_latency_qos_request {
struct trace_entry ent;
s32 value;
char __data[0];
};
struct trace_event_raw_pm_qos_update {
struct trace_entry ent;
enum pm_qos_req_action action;
int prev_value;
int curr_value;
char __data[0];
};
struct trace_event_raw_dev_pm_qos_request {
struct trace_entry ent;
u32 __data_loc_name;
enum dev_pm_qos_req_type type;
s32 new_value;
char __data[0];
};
struct trace_event_raw_guest_halt_poll_ns {
struct trace_entry ent;
bool grow;
unsigned int new;
unsigned int old;
char __data[0];
};
struct trace_event_data_offsets_cpu {};
struct trace_event_data_offsets_cpu_idle_miss {};
struct trace_event_data_offsets_powernv_throttle {
u32 reason;
};
struct trace_event_data_offsets_pstate_sample {};
struct trace_event_data_offsets_cpu_frequency_limits {};
struct trace_event_data_offsets_device_pm_callback_start {
u32 device;
u32 driver;
u32 parent;
u32 pm_ops;
};
struct trace_event_data_offsets_device_pm_callback_end {
u32 device;
u32 driver;
};
struct trace_event_data_offsets_suspend_resume {};
struct trace_event_data_offsets_wakeup_source {
u32 name;
};
struct trace_event_data_offsets_clock {
u32 name;
};
struct trace_event_data_offsets_power_domain {
u32 name;
};
struct trace_event_data_offsets_cpu_latency_qos_request {};
struct trace_event_data_offsets_pm_qos_update {};
struct trace_event_data_offsets_dev_pm_qos_request {
u32 name;
};
struct trace_event_data_offsets_guest_halt_poll_ns {};
typedef void (*btf_trace_cpu_idle)(void *, unsigned int, unsigned int);
typedef void (*btf_trace_cpu_idle_miss)(void *, unsigned int, unsigned int, bool);
typedef void (*btf_trace_powernv_throttle)(void *, int, const char *, int);
typedef void (*btf_trace_pstate_sample)(void *, u32, u32, u32, u32, u64, u64, u64, u32, u32);
typedef void (*btf_trace_cpu_frequency)(void *, unsigned int, unsigned int);
typedef void (*btf_trace_cpu_frequency_limits)(void *, struct cpufreq_policy *);
typedef void (*btf_trace_device_pm_callback_start)(void *, struct device *, const char *, int);
typedef void (*btf_trace_device_pm_callback_end)(void *, struct device *, int);
typedef void (*btf_trace_suspend_resume)(void *, const char *, int, bool);
typedef void (*btf_trace_wakeup_source_activate)(void *, const char *, unsigned int);
typedef void (*btf_trace_wakeup_source_deactivate)(void *, const char *, unsigned int);
typedef void (*btf_trace_clock_enable)(void *, const char *, unsigned int, unsigned int);
typedef void (*btf_trace_clock_disable)(void *, const char *, unsigned int, unsigned int);
typedef void (*btf_trace_clock_set_rate)(void *, const char *, unsigned int, unsigned int);
typedef void (*btf_trace_power_domain_target)(void *, const char *, unsigned int, unsigned int);
typedef void (*btf_trace_pm_qos_add_request)(void *, s32);
typedef void (*btf_trace_pm_qos_update_request)(void *, s32);
typedef void (*btf_trace_pm_qos_remove_request)(void *, s32);
typedef void (*btf_trace_pm_qos_update_target)(void *, enum pm_qos_req_action, int, int);
typedef void (*btf_trace_pm_qos_update_flags)(void *, enum pm_qos_req_action, int, int);
typedef void (*btf_trace_dev_pm_qos_add_request)(void *, const char *, enum dev_pm_qos_req_type, s32);
typedef void (*btf_trace_dev_pm_qos_update_request)(void *, const char *, enum dev_pm_qos_req_type, s32);
typedef void (*btf_trace_dev_pm_qos_remove_request)(void *, const char *, enum dev_pm_qos_req_type, s32);
typedef void (*btf_trace_guest_halt_poll_ns)(void *, bool, unsigned int, unsigned int);
struct bpf_iter_seq_array_map_info {
struct bpf_map *map;
void *percpu_value_buf;
u32 index;
};
struct prog_poke_elem {
struct list_head list;
struct bpf_prog_aux *aux;
};
struct slab {
long unsigned int __page_flags;
union {
struct list_head slab_list;
struct callback_head callback_head;
};
struct kmem_cache *slab_cache;
void *freelist;
void *s_mem;
unsigned int active;
atomic_t __page_refcount;
};
struct array_cache {
unsigned int avail;
unsigned int limit;
unsigned int batchcount;
unsigned int touched;
void *entry[0];
};
enum slab_state {
DOWN___2 = 0,
PARTIAL = 1,
PARTIAL_NODE = 2,
UP___2 = 3,
FULL = 4,
};
struct kmalloc_info_struct {
const char *name[3];
unsigned int size;
};
struct slabinfo {
long unsigned int active_objs;
long unsigned int num_objs;
long unsigned int active_slabs;
long unsigned int num_slabs;
long unsigned int shared_avail;
unsigned int limit;
unsigned int batchcount;
unsigned int shared;
unsigned int objects_per_slab;
unsigned int cache_order;
};
struct alien_cache {
spinlock_t lock;
struct array_cache ac;
};
struct kmem_obj_info {
void *kp_ptr;
struct slab *kp_slab;
void *kp_objp;
long unsigned int kp_data_offset;
struct kmem_cache *kp_slab_cache;
void *kp_ret;
void *kp_stack[16];
void *kp_free_stack[16];
};
typedef short unsigned int freelist_idx_t;
struct inotify_event {
__s32 wd;
__u32 mask;
__u32 cookie;
__u32 len;
char name[0];
};
struct qtree_fmt_operations {
void (*mem2disk_dqblk)(void *, struct dquot *);
void (*disk2mem_dqblk)(struct dquot *, void *);
int (*is_id)(void *, struct dquot *);
};
struct qtree_mem_dqinfo {
struct super_block *dqi_sb;
int dqi_type;
unsigned int dqi_blocks;
unsigned int dqi_free_blk;
unsigned int dqi_free_entry;
unsigned int dqi_blocksize_bits;
unsigned int dqi_entry_size;
unsigned int dqi_usable_bs;
unsigned int dqi_qtree_depth;
const struct qtree_fmt_operations *dqi_ops;
};
struct v2_disk_dqheader {
__le32 dqh_magic;
__le32 dqh_version;
};
struct v2r0_disk_dqblk {
__le32 dqb_id;
__le32 dqb_ihardlimit;
__le32 dqb_isoftlimit;
__le32 dqb_curinodes;
__le32 dqb_bhardlimit;
__le32 dqb_bsoftlimit;
__le64 dqb_curspace;
__le64 dqb_btime;
__le64 dqb_itime;
};
struct v2r1_disk_dqblk {
__le32 dqb_id;
__le32 dqb_pad;
__le64 dqb_ihardlimit;
__le64 dqb_isoftlimit;
__le64 dqb_curinodes;
__le64 dqb_bhardlimit;
__le64 dqb_bsoftlimit;
__le64 dqb_curspace;
__le64 dqb_btime;
__le64 dqb_itime;
};
struct v2_disk_dqinfo {
__le32 dqi_bgrace;
__le32 dqi_igrace;
__le32 dqi_flags;
__le32 dqi_blocks;
__le32 dqi_free_blk;
__le32 dqi_free_entry;
};
struct ext4_orphan_block_tail {
__le32 ob_magic;
__le32 ob_checksum;
};
struct nfs_mount_request {
struct __kernel_sockaddr_storage *sap;
size_t salen;
char *hostname;
char *dirpath;
u32 version;
short unsigned int protocol;
struct nfs_fh *fh;
int noresvport;
unsigned int *auth_flav_len;
rpc_authflavor_t *auth_flavs;
struct net *net;
};
enum {
MOUNTPROC_NULL = 0,
MOUNTPROC_MNT = 1,
MOUNTPROC_DUMP = 2,
MOUNTPROC_UMNT = 3,
MOUNTPROC_UMNTALL = 4,
MOUNTPROC_EXPORT = 5,
};
enum {
MOUNTPROC3_NULL = 0,
MOUNTPROC3_MNT = 1,
MOUNTPROC3_DUMP = 2,
MOUNTPROC3_UMNT = 3,
MOUNTPROC3_UMNTALL = 4,
MOUNTPROC3_EXPORT = 5,
};
enum mountstat {
MNT_OK = 0,
MNT_EPERM = 1,
MNT_ENOENT = 2,
MNT_EACCES = 13,
MNT_EINVAL = 22,
};
enum mountstat3 {
MNT3_OK = 0,
MNT3ERR_PERM = 1,
MNT3ERR_NOENT = 2,
MNT3ERR_IO = 5,
MNT3ERR_ACCES = 13,
MNT3ERR_NOTDIR = 20,
MNT3ERR_INVAL = 22,
MNT3ERR_NAMETOOLONG = 63,
MNT3ERR_NOTSUPP = 10004,
MNT3ERR_SERVERFAULT = 10006,
};
struct mountres {
int errno;
struct nfs_fh *fh;
unsigned int *auth_count;
rpc_authflavor_t *auth_flavors;
};
struct nfsdfs_client {
struct kref cl_ref;
void (*cl_release)(struct kref *);
};
enum vers_op {
NFSD_SET = 0,
NFSD_CLEAR = 1,
NFSD_TEST = 2,
NFSD_AVAIL = 3,
};
enum {
NFSD_Root = 1,
NFSD_List = 2,
NFSD_Export_Stats = 3,
NFSD_Export_features = 4,
NFSD_Fh = 5,
NFSD_FO_UnlockIP = 6,
NFSD_FO_UnlockFS = 7,
NFSD_Threads = 8,
NFSD_Pool_Threads = 9,
NFSD_Pool_Stats = 10,
NFSD_Reply_Cache_Stats = 11,
NFSD_Versions = 12,
NFSD_Ports = 13,
NFSD_MaxBlkSize = 14,
NFSD_MaxConnections = 15,
NFSD_Filecache = 16,
NFSD_SupportedEnctypes = 17,
NFSD_MaxReserved = 18,
};
struct name_snapshot {
struct qstr name;
unsigned char inline_name[36];
long: 32;
};
struct debugfs_mount_opts {
kuid_t uid;
kgid_t gid;
umode_t mode;
unsigned int opts;
};
struct debugfs_fs_info {
struct debugfs_mount_opts mount_opts;
};
enum {
Opt_err___5 = 0,
Opt_enc = 1,
Opt_hash = 2,
};
struct crypto_report_comp {
char type[64];
};
struct crypto_scomp {
struct crypto_tfm base;
};
struct scomp_alg {
void * (*alloc_ctx)(struct crypto_scomp *);
void (*free_ctx)(struct crypto_scomp *, void *);
int (*compress)(struct crypto_scomp *, const u8 *, unsigned int, u8 *, unsigned int *, void *);
int (*decompress)(struct crypto_scomp *, const u8 *, unsigned int, u8 *, unsigned int *, void *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct crypto_alg base;
};
struct scomp_scratch {
spinlock_t lock;
void *src;
void *dst;
};
struct badblocks {
struct device *dev;
int count;
int unacked_exist;
int shift;
u64 *page;
int changed;
seqlock_t lock;
sector_t sector;
sector_t size;
};
struct blk_major_name {
struct blk_major_name *next;
int major;
char name[16];
void (*probe)(dev_t);
};
struct io_uring_file_index_range {
__u32 off;
__u32 len;
__u64 resv;
};
enum pci_ers_result {
PCI_ERS_RESULT_NONE = 1,
PCI_ERS_RESULT_CAN_RECOVER = 2,
PCI_ERS_RESULT_NEED_RESET = 3,
PCI_ERS_RESULT_DISCONNECT = 4,
PCI_ERS_RESULT_RECOVERED = 5,
PCI_ERS_RESULT_NO_AER_DRIVER = 6,
};
struct pciserial_board {
unsigned int flags;
unsigned int num_ports;
unsigned int base_baud;
unsigned int uart_offset;
unsigned int reg_shift;
unsigned int first_offset;
};
struct serial_private;
struct pci_serial_quirk {
u32 vendor;
u32 device;
u32 subvendor;
u32 subdevice;
int (*probe)(struct pci_dev *);
int (*init)(struct pci_dev *);
int (*setup)(struct serial_private *, const struct pciserial_board *, struct uart_8250_port *, int);
void (*exit)(struct pci_dev *);
};
struct serial_private {
struct pci_dev *dev;
unsigned int nr;
struct pci_serial_quirk *quirk;
const struct pciserial_board *board;
int line[0];
};
struct f815xxa_data {
spinlock_t lock;
int idx;
};
struct timedia_struct {
int num;
const short unsigned int *ids;
};
enum pci_board_num_t {
pbn_default = 0,
pbn_b0_1_115200 = 1,
pbn_b0_2_115200 = 2,
pbn_b0_4_115200 = 3,
pbn_b0_5_115200 = 4,
pbn_b0_8_115200 = 5,
pbn_b0_1_921600 = 6,
pbn_b0_2_921600 = 7,
pbn_b0_4_921600 = 8,
pbn_b0_2_1130000 = 9,
pbn_b0_4_1152000 = 10,
pbn_b0_4_1250000 = 11,
pbn_b0_2_1843200 = 12,
pbn_b0_4_1843200 = 13,
pbn_b0_1_15625000 = 14,
pbn_b0_bt_1_115200 = 15,
pbn_b0_bt_2_115200 = 16,
pbn_b0_bt_4_115200 = 17,
pbn_b0_bt_8_115200 = 18,
pbn_b0_bt_1_460800 = 19,
pbn_b0_bt_2_460800 = 20,
pbn_b0_bt_4_460800 = 21,
pbn_b0_bt_1_921600 = 22,
pbn_b0_bt_2_921600 = 23,
pbn_b0_bt_4_921600 = 24,
pbn_b0_bt_8_921600 = 25,
pbn_b1_1_115200 = 26,
pbn_b1_2_115200 = 27,
pbn_b1_4_115200 = 28,
pbn_b1_8_115200 = 29,
pbn_b1_16_115200 = 30,
pbn_b1_1_921600 = 31,
pbn_b1_2_921600 = 32,
pbn_b1_4_921600 = 33,
pbn_b1_8_921600 = 34,
pbn_b1_2_1250000 = 35,
pbn_b1_bt_1_115200 = 36,
pbn_b1_bt_2_115200 = 37,
pbn_b1_bt_4_115200 = 38,
pbn_b1_bt_2_921600 = 39,
pbn_b1_1_1382400 = 40,
pbn_b1_2_1382400 = 41,
pbn_b1_4_1382400 = 42,
pbn_b1_8_1382400 = 43,
pbn_b2_1_115200 = 44,
pbn_b2_2_115200 = 45,
pbn_b2_4_115200 = 46,
pbn_b2_8_115200 = 47,
pbn_b2_1_460800 = 48,
pbn_b2_4_460800 = 49,
pbn_b2_8_460800 = 50,
pbn_b2_16_460800 = 51,
pbn_b2_1_921600 = 52,
pbn_b2_4_921600 = 53,
pbn_b2_8_921600 = 54,
pbn_b2_8_1152000 = 55,
pbn_b2_bt_1_115200 = 56,
pbn_b2_bt_2_115200 = 57,
pbn_b2_bt_4_115200 = 58,
pbn_b2_bt_2_921600 = 59,
pbn_b2_bt_4_921600 = 60,
pbn_b3_2_115200 = 61,
pbn_b3_4_115200 = 62,
pbn_b3_8_115200 = 63,
pbn_b4_bt_2_921600 = 64,
pbn_b4_bt_4_921600 = 65,
pbn_b4_bt_8_921600 = 66,
pbn_panacom = 67,
pbn_panacom2 = 68,
pbn_panacom4 = 69,
pbn_plx_romulus = 70,
pbn_oxsemi = 71,
pbn_oxsemi_1_15625000 = 72,
pbn_oxsemi_2_15625000 = 73,
pbn_oxsemi_4_15625000 = 74,
pbn_oxsemi_8_15625000 = 75,
pbn_intel_i960 = 76,
pbn_sgi_ioc3 = 77,
pbn_computone_4 = 78,
pbn_computone_6 = 79,
pbn_computone_8 = 80,
pbn_sbsxrsio = 81,
pbn_pasemi_1682M = 82,
pbn_ni8430_2 = 83,
pbn_ni8430_4 = 84,
pbn_ni8430_8 = 85,
pbn_ni8430_16 = 86,
pbn_ADDIDATA_PCIe_1_3906250 = 87,
pbn_ADDIDATA_PCIe_2_3906250 = 88,
pbn_ADDIDATA_PCIe_4_3906250 = 89,
pbn_ADDIDATA_PCIe_8_3906250 = 90,
pbn_ce4100_1_115200 = 91,
pbn_omegapci = 92,
pbn_NETMOS9900_2s_115200 = 93,
pbn_brcm_trumanage = 94,
pbn_fintek_4 = 95,
pbn_fintek_8 = 96,
pbn_fintek_12 = 97,
pbn_fintek_F81504A = 98,
pbn_fintek_F81508A = 99,
pbn_fintek_F81512A = 100,
pbn_wch382_2 = 101,
pbn_wch384_4 = 102,
pbn_wch384_8 = 103,
pbn_sunix_pci_1s = 104,
pbn_sunix_pci_2s = 105,
pbn_sunix_pci_4s = 106,
pbn_sunix_pci_8s = 107,
pbn_sunix_pci_16s = 108,
pbn_titan_1_4000000 = 109,
pbn_titan_2_4000000 = 110,
pbn_titan_4_4000000 = 111,
pbn_titan_8_4000000 = 112,
pbn_moxa8250_2p = 113,
pbn_moxa8250_4p = 114,
pbn_moxa8250_8p = 115,
};
struct transport_class {
struct class class;
int (*setup)(struct transport_container *, struct device *, struct device *);
int (*configure)(struct transport_container *, struct device *, struct device *);
int (*remove)(struct transport_container *, struct device *, struct device *);
};
struct anon_transport_class {
struct transport_class tclass;
struct attribute_container container;
};
struct req {
struct req *next;
struct completion done;
int err;
const char *name;
umode_t mode;
kuid_t uid;
kgid_t gid;
struct device *dev;
};
struct cdrom_ti {
__u8 cdti_trk0;
__u8 cdti_ind0;
__u8 cdti_trk1;
__u8 cdti_ind1;
};
struct cdrom_tochdr {
__u8 cdth_trk0;
__u8 cdth_trk1;
};
struct cdrom_tocentry {
__u8 cdte_track;
__u8 cdte_adr: 4;
__u8 cdte_ctrl: 4;
__u8 cdte_format;
union cdrom_addr cdte_addr;
__u8 cdte_datamode;
};
struct cfi_pri_amdstd {
uint8_t pri[3];
uint8_t MajorVersion;
uint8_t MinorVersion;
uint8_t SiliconRevision;
uint8_t EraseSuspend;
uint8_t BlkProt;
uint8_t TmpBlkUnprotect;
uint8_t BlkProtUnprot;
uint8_t SimultaneousOps;
uint8_t BurstMode;
uint8_t PageMode;
uint8_t VppMin;
uint8_t VppMax;
uint8_t TopBottom;
uint8_t ProgramSuspend;
uint8_t UnlockBypass;
uint8_t SecureSiliconSector;
uint8_t SoftwareFeatures;
};
enum cfi_quirks {
CFI_QUIRK_DQ_TRUE_DATA = 1,
};
typedef int (*otp_op_t)(struct map_info *, struct flchip *, loff_t, size_t, u_char *, size_t);
struct ppb_lock {
struct flchip *chip;
long unsigned int adr;
int locked;
};
enum {
PBA_STRATEGY_EQUAL = 0,
PBA_STRATEGY_WEIGHTED = 1,
};
struct trackpoint_data {
u8 variant_id;
u8 firmware_id;
u8 sensitivity;
u8 speed;
u8 inertia;
u8 reach;
u8 draghys;
u8 mindrag;
u8 thresh;
u8 upthresh;
u8 ztime;
u8 jenks;
u8 drift_time;
bool press_to_select;
bool skipback;
bool ext_dev;
};
struct trackpoint_attr_data {
size_t field_offset;
u8 command;
u8 mask;
bool inverted;
u8 power_on_default;
};
struct of_endpoint {
unsigned int port;
unsigned int id;
const struct device_node *local_node;
};
struct supplier_bindings {
struct device_node * (*parse_prop)(struct device_node *, const char *, int);
bool optional;
bool node_not_dev;
};
struct pcpu_gen_cookie {
local_t nesting;
long: 32;
u64 last;
};
struct gen_cookie {
struct pcpu_gen_cookie *local;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
atomic64_t forward_last;
atomic64_t reverse_last;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum {
INET_DIAG_REQ_NONE = 0,
INET_DIAG_REQ_BYTECODE = 1,
INET_DIAG_REQ_SK_BPF_STORAGES = 2,
INET_DIAG_REQ_PROTOCOL = 3,
__INET_DIAG_REQ_MAX = 4,
};
struct sock_diag_req {
__u8 sdiag_family;
__u8 sdiag_protocol;
};
enum {
SK_MEMINFO_RMEM_ALLOC = 0,
SK_MEMINFO_RCVBUF = 1,
SK_MEMINFO_WMEM_ALLOC = 2,
SK_MEMINFO_SNDBUF = 3,
SK_MEMINFO_FWD_ALLOC = 4,
SK_MEMINFO_WMEM_QUEUED = 5,
SK_MEMINFO_OPTMEM = 6,
SK_MEMINFO_BACKLOG = 7,
SK_MEMINFO_DROPS = 8,
SK_MEMINFO_VARS = 9,
};
enum sknetlink_groups {
SKNLGRP_NONE = 0,
SKNLGRP_INET_TCP_DESTROY = 1,
SKNLGRP_INET_UDP_DESTROY = 2,
SKNLGRP_INET6_TCP_DESTROY = 3,
SKNLGRP_INET6_UDP_DESTROY = 4,
__SKNLGRP_MAX = 5,
};
struct sock_diag_handler {
__u8 family;
int (*dump)(struct sk_buff *, struct nlmsghdr *);
int (*get_info)(struct sk_buff *, struct sock *);
int (*destroy)(struct sk_buff *, struct nlmsghdr *);
};
struct broadcast_sk {
struct sock *sk;
struct work_struct work;
};
struct bpf_cg_run_ctx {
struct bpf_run_ctx run_ctx;
const struct bpf_prog_array_item *prog_item;
int retval;
};
struct trace_event_raw_bpf_test_finish {
struct trace_entry ent;
int err;
char __data[0];
};
struct trace_event_data_offsets_bpf_test_finish {};
typedef void (*btf_trace_bpf_test_finish)(void *, int *);
struct bpf_test_timer {
enum {
NO_PREEMPT = 0,
NO_MIGRATE = 1,
} mode;
u32 i;
u64 time_start;
u64 time_spent;
};
struct xdp_page_head {
struct xdp_buff orig_ctx;
struct xdp_buff ctx;
struct xdp_frame frm;
u8 data[0];
};
struct xdp_test_data {
struct xdp_buff *orig_ctx;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct xdp_rxq_info rxq;
struct net_device *dev;
struct page_pool *pp;
struct xdp_frame **frames;
struct sk_buff **skbs;
struct xdp_mem_info mem;
u32 batch_size;
u32 frame_cnt;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_fentry_test_t {
struct bpf_fentry_test_t *a;
};
struct prog_test_member1 {
int a;
};
struct prog_test_member {
struct prog_test_member1 m;
int c;
};
struct prog_test_ref_kfunc {
int a;
int b;
struct prog_test_member memb;
struct prog_test_ref_kfunc *next;
refcount_t cnt;
};
struct prog_test_pass1 {
int x0;
struct {
int x1;
struct {
int x2;
struct {
int x3;
};
};
};
};
struct prog_test_pass2 {
int len;
short int arr1[4];
struct {
char arr2[4];
long unsigned int arr3[8];
} x;
};
struct prog_test_fail1 {
void *p;
int x;
};
struct prog_test_fail2 {
int x8;
struct prog_test_pass1 x;
};
struct prog_test_fail3 {
int len;
char arr1[2];
char arr2[0];
};
struct bpf_raw_tp_test_run_info {
struct bpf_prog *prog;
void *ctx;
u32 retval;
};
struct fib_entry_notifier_info {
struct fib_notifier_info info;
u32 dst;
int dst_len;
struct fib_info *fi;
dscp_t dscp;
u8 type;
u32 tb_id;
};
typedef unsigned int t_key;
struct key_vector {
t_key key;
unsigned char pos;
unsigned char bits;
unsigned char slen;
union {
struct hlist_head leaf;
struct {
struct {} __empty_tnode;
struct key_vector *tnode[0];
};
};
};
struct tnode {
struct callback_head rcu;
t_key empty_children;
t_key full_children;
struct key_vector *parent;
struct key_vector kv[1];
};
struct trie_stat {
unsigned int totdepth;
unsigned int maxdepth;
unsigned int tnodes;
unsigned int leaves;
unsigned int nullpointers;
unsigned int prefixes;
unsigned int nodesizes[32];
};
struct trie {
struct key_vector kv[1];
};
struct fib_trie_iter {
struct seq_net_private p;
struct fib_table *tb;
struct key_vector *tnode;
unsigned int index;
unsigned int depth;
};
struct fib_route_iter {
struct seq_net_private p;
struct fib_table *main_tb;
struct key_vector *tnode;
long: 32;
loff_t pos;
t_key key;
long: 32;
};
struct raw6_frag_vec {
struct msghdr *msg;
int hlen;
char c[4];
};
struct xdr_skb_reader {
struct sk_buff *skb;
unsigned int offset;
size_t count;
__wsum csum;
};
typedef size_t (*xdr_skb_read_actor)(struct xdr_skb_reader *, void *, size_t);
enum {
LOGIC_PIO_INDIRECT = 0,
LOGIC_PIO_CPU_MMIO = 1,
};
struct logic_pio_host_ops;
struct logic_pio_hwaddr {
struct list_head list;
struct fwnode_handle *fwnode;
resource_size_t hw_start;
resource_size_t io_start;
resource_size_t size;
long unsigned int flags;
void *hostdata;
const struct logic_pio_host_ops *ops;
};
struct logic_pio_host_ops {
u32 (*in)(void *, long unsigned int, size_t);
void (*out)(void *, long unsigned int, u32, size_t);
u32 (*ins)(void *, long unsigned int, void *, size_t, unsigned int);
void (*outs)(void *, long unsigned int, const void *, size_t, unsigned int);
};
struct module_use {
struct list_head source_list;
struct list_head target_list;
struct module *source;
struct module *target;
};
enum ftrace_bug_type {
FTRACE_BUG_UNKNOWN = 0,
FTRACE_BUG_INIT = 1,
FTRACE_BUG_NOP = 2,
FTRACE_BUG_CALL = 3,
FTRACE_BUG_UPDATE = 4,
};
enum {
FTRACE_FL_ENABLED = 2147483648,
FTRACE_FL_REGS = 1073741824,
FTRACE_FL_REGS_EN = 536870912,
FTRACE_FL_TRAMP = 268435456,
FTRACE_FL_TRAMP_EN = 134217728,
FTRACE_FL_IPMODIFY = 67108864,
FTRACE_FL_DISABLED = 33554432,
FTRACE_FL_DIRECT = 16777216,
FTRACE_FL_DIRECT_EN = 8388608,
};
enum {
FTRACE_UPDATE_IGNORE = 0,
FTRACE_UPDATE_MAKE_CALL = 1,
FTRACE_UPDATE_MODIFY_CALL = 2,
FTRACE_UPDATE_MAKE_NOP = 3,
};
enum {
FTRACE_ITER_FILTER = 1,
FTRACE_ITER_NOTRACE = 2,
FTRACE_ITER_PRINTALL = 4,
FTRACE_ITER_DO_PROBES = 8,
FTRACE_ITER_PROBE = 16,
FTRACE_ITER_MOD = 32,
FTRACE_ITER_ENABLED = 64,
};
enum perf_record_ksymbol_type {
PERF_RECORD_KSYMBOL_TYPE_UNKNOWN = 0,
PERF_RECORD_KSYMBOL_TYPE_BPF = 1,
PERF_RECORD_KSYMBOL_TYPE_OOL = 2,
PERF_RECORD_KSYMBOL_TYPE_MAX = 3,
};
struct ftrace_mod_load {
struct list_head list;
char *func;
char *module;
int enable;
};
struct tracer_stat {
const char *name;
void * (*stat_start)(struct tracer_stat *);
void * (*stat_next)(void *, int);
cmp_func_t stat_cmp;
int (*stat_show)(struct seq_file *, void *);
void (*stat_release)(void *);
int (*stat_headers)(struct seq_file *);
};
enum {
FTRACE_MODIFY_ENABLE_FL = 1,
FTRACE_MODIFY_MAY_SLEEP_FL = 2,
};
struct ftrace_profile {
struct hlist_node node;
long unsigned int ip;
long unsigned int counter;
long long unsigned int time;
long long unsigned int time_squared;
};
struct ftrace_profile_page {
struct ftrace_profile_page *next;
long unsigned int index;
struct ftrace_profile records[0];
};
struct ftrace_profile_stat {
atomic_t disabled;
struct hlist_head *hash;
struct ftrace_profile_page *pages;
struct ftrace_profile_page *start;
struct tracer_stat stat;
};
struct ftrace_func_probe {
struct ftrace_probe_ops *probe_ops;
struct ftrace_ops ops;
struct trace_array *tr;
struct list_head list;
void *data;
int ref;
};
struct ftrace_page {
struct ftrace_page *next;
struct dyn_ftrace *records;
int index;
int order;
};
struct ftrace_rec_iter {
struct ftrace_page *pg;
int index;
};
struct ftrace_iterator {
loff_t pos;
loff_t func_pos;
loff_t mod_pos;
struct ftrace_page *pg;
struct dyn_ftrace *func;
struct ftrace_func_probe *probe;
struct ftrace_func_entry *probe_entry;
struct trace_parser parser;
struct ftrace_hash *hash;
struct ftrace_ops *ops;
struct trace_array *tr;
struct list_head *mod_list;
int pidx;
int idx;
unsigned int flags;
long: 32;
};
struct ftrace_glob {
char *search;
unsigned int len;
int type;
};
struct ftrace_func_map {
struct ftrace_func_entry entry;
void *data;
};
struct ftrace_func_mapper {
struct ftrace_hash hash;
};
enum graph_filter_type {
GRAPH_FILTER_NOTRACE = 0,
GRAPH_FILTER_FUNCTION = 1,
};
struct ftrace_graph_data {
struct ftrace_hash *hash;
struct ftrace_func_entry *entry;
int idx;
enum graph_filter_type type;
struct ftrace_hash *new_hash;
const struct seq_operations *seq_ops;
struct trace_parser parser;
};
struct ftrace_mod_func {
struct list_head list;
char *name;
long unsigned int ip;
unsigned int size;
};
struct ftrace_mod_map {
struct callback_head rcu;
struct list_head list;
struct module *mod;
long unsigned int start_addr;
long unsigned int end_addr;
struct list_head funcs;
unsigned int num_funcs;
};
struct ftrace_init_func {
struct list_head list;
long unsigned int ip;
};
struct kallsyms_data {
long unsigned int *addrs;
const char **syms;
size_t cnt;
size_t found;
};
struct bpf_bloom_filter {
struct bpf_map map;
u32 bitset_mask;
u32 hash_seed;
u32 aligned_u32_count;
u32 nr_hash_funcs;
long unsigned int bitset[0];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum bpf_stack_build_id_status {
BPF_STACK_BUILD_ID_EMPTY = 0,
BPF_STACK_BUILD_ID_VALID = 1,
BPF_STACK_BUILD_ID_IP = 2,
};
struct bpf_stack_build_id {
__s32 status;
unsigned char build_id[20];
union {
__u64 offset;
__u64 ip;
};
};
enum {
BPF_F_SKIP_FIELD_MASK = 255,
BPF_F_USER_STACK = 256,
BPF_F_FAST_STACK_CMP = 512,
BPF_F_REUSE_STACKID = 1024,
BPF_F_USER_BUILD_ID = 2048,
};
struct mmap_unlock_irq_work {
struct irq_work irq_work;
struct mm_struct *mm;
};
struct stack_map_bucket {
struct pcpu_freelist_node fnode;
u32 hash;
u32 nr;
long: 32;
u64 data[0];
};
struct bpf_stack_map {
struct bpf_map map;
void *elems;
struct pcpu_freelist freelist;
u32 n_buckets;
struct stack_map_bucket *buckets[0];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef u64 (*btf_bpf_get_stackid)(struct pt_regs *, struct bpf_map *, u64);
typedef u64 (*btf_bpf_get_stackid_pe)(struct bpf_perf_event_data_kern *, struct bpf_map *, u64);
typedef u64 (*btf_bpf_get_stack)(struct pt_regs *, void *, u32, u64);
typedef u64 (*btf_bpf_get_task_stack)(struct task_struct *, void *, u32, u64);
typedef u64 (*btf_bpf_get_stack_pe)(struct bpf_perf_event_data_kern *, void *, u32, u64);
struct trace_event_raw_mm_lru_insertion {
struct trace_entry ent;
struct folio *folio;
long unsigned int pfn;
enum lru_list lru;
long unsigned int flags;
char __data[0];
};
struct trace_event_raw_mm_lru_activate {
struct trace_entry ent;
struct folio *folio;
long unsigned int pfn;
char __data[0];
};
struct trace_event_data_offsets_mm_lru_insertion {};
struct trace_event_data_offsets_mm_lru_activate {};
typedef void (*btf_trace_mm_lru_insertion)(void *, struct folio *);
typedef void (*btf_trace_mm_lru_activate)(void *, struct folio *);
struct lru_rotate {
local_lock_t lock;
struct folio_batch fbatch;
};
struct cpu_fbatches {
local_lock_t lock;
struct folio_batch lru_add;
struct folio_batch lru_deactivate_file;
struct folio_batch lru_deactivate;
struct folio_batch lru_lazyfree;
struct folio_batch activate;
};
typedef void (*move_fn_t)(struct lruvec *, struct folio *);
struct trace_event_raw_vm_unmapped_area {
struct trace_entry ent;
long unsigned int addr;
long unsigned int total_vm;
long unsigned int flags;
long unsigned int length;
long unsigned int low_limit;
long unsigned int high_limit;
long unsigned int align_mask;
long unsigned int align_offset;
char __data[0];
};
struct trace_event_raw_vma_mas_szero {
struct trace_entry ent;
struct maple_tree *mt;
long unsigned int start;
long unsigned int end;
char __data[0];
};
struct trace_event_raw_vma_store {
struct trace_entry ent;
struct maple_tree *mt;
struct vm_area_struct *vma;
long unsigned int vm_start;
long unsigned int vm_end;
char __data[0];
};
struct trace_event_raw_exit_mmap {
struct trace_entry ent;
struct mm_struct *mm;
struct maple_tree *mt;
char __data[0];
};
struct trace_event_data_offsets_vm_unmapped_area {};
struct trace_event_data_offsets_vma_mas_szero {};
struct trace_event_data_offsets_vma_store {};
struct trace_event_data_offsets_exit_mmap {};
typedef void (*btf_trace_vm_unmapped_area)(void *, long unsigned int, struct vm_unmapped_area_info *);
typedef void (*btf_trace_vma_mas_szero)(void *, struct maple_tree *, long unsigned int, long unsigned int);
typedef void (*btf_trace_vma_store)(void *, struct maple_tree *, struct vm_area_struct *);
typedef void (*btf_trace_exit_mmap)(void *, struct mm_struct *);
struct user_arg_ptr {
union {
const char * const *native;
} ptr;
};
struct decrypt_bh_ctx {
struct work_struct work;
struct buffer_head *bh;
};
struct bh_lru {
struct buffer_head *bhs[16];
};
struct bh_accounting {
int nr;
int ratelimit;
};
typedef int ext2_grpblk_t;
struct nfs_open_dir_context {
struct list_head list;
atomic_t cache_hits;
atomic_t cache_misses;
long unsigned int attr_gencount;
__be32 verf[2];
long: 32;
__u64 dir_cookie;
__u64 last_cookie;
long unsigned int page_index;
unsigned int dtsize;
bool force_clear;
bool eof;
struct callback_head callback_head;
long: 32;
};
struct nfs_cache_array_entry {
u64 cookie;
u64 ino;
const char *name;
unsigned int name_len;
unsigned char d_type;
long: 32;
};
struct nfs_cache_array {
u64 change_attr;
u64 last_cookie;
unsigned int size;
unsigned char page_full: 1;
unsigned char page_is_eof: 1;
unsigned char cookies_are_ordered: 1;
struct nfs_cache_array_entry array[0];
};
struct nfs_readdir_descriptor {
struct file *file;
struct page *page;
struct dir_context *ctx;
long unsigned int page_index;
long unsigned int page_index_max;
long: 32;
u64 dir_cookie;
u64 last_cookie;
loff_t current_index;
__be32 verf[2];
long unsigned int dir_verifier;
long unsigned int timestamp;
long unsigned int gencount;
long unsigned int attr_gencount;
unsigned int cache_entry_index;
unsigned int buffer_fills;
unsigned int dtsize;
bool clear_cache;
bool plus;
bool eob;
bool eof;
};
struct lockd_net {
unsigned int nlmsvc_users;
long unsigned int next_gc;
long unsigned int nrhosts;
struct delayed_work grace_period_end;
struct lock_manager lockd_manager;
struct list_head nsm_handles;
};
struct md5_state {
u32 hash[4];
u32 block[16];
u64 byte_count;
};
enum {
IOPRIO_WHO_PROCESS = 1,
IOPRIO_WHO_PGRP = 2,
IOPRIO_WHO_USER = 3,
};
enum {
IORING_MSG_DATA = 0,
IORING_MSG_SEND_FD = 1,
};
struct io_msg {
struct file *file;
long: 32;
u64 user_data;
u32 len;
u32 cmd;
u32 src_fd;
u32 dst_fd;
u32 flags;
long: 32;
};
typedef unsigned int uInt;
typedef U32 HUF_DTable;
typedef struct {
U16 nextState;
BYTE nbAdditionalBits;
BYTE nbBits;
U32 baseValue;
} ZSTD_seqSymbol;
typedef struct {
ZSTD_seqSymbol LLTable[513];
ZSTD_seqSymbol OFTable[257];
ZSTD_seqSymbol MLTable[513];
HUF_DTable hufTable[4097];
U32 rep[3];
U32 workspace[157];
} ZSTD_entropyDTables_t;
typedef enum {
ZSTD_frame = 0,
ZSTD_skippableFrame = 1,
} ZSTD_frameType_e;
typedef struct {
long long unsigned int frameContentSize;
long long unsigned int windowSize;
unsigned int blockSizeMax;
ZSTD_frameType_e frameType;
unsigned int headerSize;
unsigned int dictID;
unsigned int checksumFlag;
long: 32;
} ZSTD_frameHeader;
typedef enum {
bt_raw = 0,
bt_rle = 1,
bt_compressed = 2,
bt_reserved = 3,
} blockType_e;
typedef enum {
ZSTDds_getFrameHeaderSize = 0,
ZSTDds_decodeFrameHeader = 1,
ZSTDds_decodeBlockHeader = 2,
ZSTDds_decompressBlock = 3,
ZSTDds_decompressLastBlock = 4,
ZSTDds_checkChecksum = 5,
ZSTDds_decodeSkippableHeader = 6,
ZSTDds_skipFrame = 7,
} ZSTD_dStage;
typedef enum {
ZSTD_f_zstd1 = 0,
ZSTD_f_zstd1_magicless = 1,
} ZSTD_format_e;
typedef enum {
ZSTD_d_validateChecksum = 0,
ZSTD_d_ignoreChecksum = 1,
} ZSTD_forceIgnoreChecksum_e;
typedef enum {
ZSTD_use_indefinitely = -1,
ZSTD_dont_use = 0,
ZSTD_use_once = 1,
} ZSTD_dictUses_e;
struct ZSTD_DDict_s;
typedef struct ZSTD_DDict_s ZSTD_DDict;
typedef struct {
const ZSTD_DDict **ddictPtrTable;
size_t ddictPtrTableSize;
size_t ddictPtrCount;
} ZSTD_DDictHashSet;
typedef enum {
ZSTD_rmd_refSingleDDict = 0,
ZSTD_rmd_refMultipleDDicts = 1,
} ZSTD_refMultipleDDicts_e;
typedef enum {
zdss_init = 0,
zdss_loadHeader = 1,
zdss_read = 2,
zdss_load = 3,
zdss_flush = 4,
} ZSTD_dStreamStage;
typedef enum {
ZSTD_bm_buffered = 0,
ZSTD_bm_stable = 1,
} ZSTD_bufferMode_e;
struct ZSTD_outBuffer_s {
void *dst;
size_t size;
size_t pos;
};
typedef struct ZSTD_outBuffer_s ZSTD_outBuffer;
struct ZSTD_DCtx_s {
const ZSTD_seqSymbol *LLTptr;
const ZSTD_seqSymbol *MLTptr;
const ZSTD_seqSymbol *OFTptr;
const HUF_DTable *HUFptr;
ZSTD_entropyDTables_t entropy;
U32 workspace[640];
const void *previousDstEnd;
const void *prefixStart;
const void *virtualStart;
const void *dictEnd;
size_t expected;
ZSTD_frameHeader fParams;
U64 processedCSize;
U64 decodedSize;
blockType_e bType;
ZSTD_dStage stage;
U32 litEntropy;
U32 fseEntropy;
struct xxh64_state xxhState;
size_t headerSize;
ZSTD_format_e format;
ZSTD_forceIgnoreChecksum_e forceIgnoreChecksum;
U32 validateChecksum;
const BYTE *litPtr;
ZSTD_customMem customMem;
size_t litSize;
size_t rleSize;
size_t staticSize;
int bmi2;
ZSTD_DDict *ddictLocal;
const ZSTD_DDict *ddict;
U32 dictID;
int ddictIsCold;
ZSTD_dictUses_e dictUses;
ZSTD_DDictHashSet *ddictSet;
ZSTD_refMultipleDDicts_e refMultipleDDicts;
ZSTD_dStreamStage streamStage;
char *inBuff;
size_t inBuffSize;
size_t inPos;
size_t maxWindowSize;
char *outBuff;
size_t outBuffSize;
size_t outStart;
size_t outEnd;
size_t lhSize;
void *legacyContext;
U32 previousLegacyVersion;
U32 legacyVersion;
U32 hostageByte;
int noForwardProgress;
ZSTD_bufferMode_e outBufferMode;
ZSTD_outBuffer expectedOutBuffer;
BYTE litBuffer[131104];
BYTE headerBuffer[18];
size_t oversizedDuration;
};
typedef struct ZSTD_DCtx_s ZSTD_DCtx;
struct ZSTD_DDict_s {
void *dictBuffer;
const void *dictContent;
size_t dictSize;
ZSTD_entropyDTables_t entropy;
U32 dictID;
U32 entropyPresent;
ZSTD_customMem cMem;
};
typedef enum {
ZSTD_dct_auto = 0,
ZSTD_dct_rawContent = 1,
ZSTD_dct_fullDict = 2,
} ZSTD_dictContentType_e;
typedef enum {
ZSTD_dlm_byCopy = 0,
ZSTD_dlm_byRef = 1,
} ZSTD_dictLoadMethod_e;
struct pci_slot_attribute {
struct attribute attr;
ssize_t (*show)(struct pci_slot *, char *);
ssize_t (*store)(struct pci_slot *, const char *, size_t);
};
struct clk_bulk_data {
const char *id;
struct clk *clk;
};
struct devm_clk_state {
struct clk *clk;
void (*exit)(struct clk *);
};
struct clk_bulk_devres {
struct clk_bulk_data *clks;
int num_clks;
};
struct miscdevice {
int minor;
const char *name;
const struct file_operations *fops;
struct list_head list;
struct device *parent;
struct device *this_device;
const struct attribute_group **groups;
const char *nodename;
umode_t mode;
};
struct auxiliary_device_id {
char name[32];
kernel_ulong_t driver_data;
};
struct auxiliary_device {
struct device dev;
const char *name;
u32 id;
};
struct auxiliary_driver {
int (*probe)(struct auxiliary_device *, const struct auxiliary_device_id *);
void (*remove)(struct auxiliary_device *);
void (*shutdown)(struct auxiliary_device *);
int (*suspend)(struct auxiliary_device *, pm_message_t);
int (*resume)(struct auxiliary_device *);
const char *name;
struct device_driver driver;
const struct auxiliary_device_id *id_table;
};
enum scsi_timeouts {
SCSI_DEFAULT_EH_TIMEOUT = 1000,
};
enum scsi_scan_mode {
SCSI_SCAN_INITIAL = 0,
SCSI_SCAN_RESCAN = 1,
SCSI_SCAN_MANUAL = 2,
};
struct async_scan_data {
struct list_head list;
struct Scsi_Host *shost;
struct completion prev_finished;
};
struct rmem_assigned_device {
struct device *dev;
struct reserved_mem *rmem;
struct list_head list;
};
struct dst_cache_pcpu {
long unsigned int refresh_ts;
struct dst_entry *dst;
u32 cookie;
union {
struct in_addr in_saddr;
struct in6_addr in6_saddr;
};
};
struct sockaddr_nl {
__kernel_sa_family_t nl_family;
short unsigned int nl_pad;
__u32 nl_pid;
__u32 nl_groups;
};
enum nlmsgerr_attrs {
NLMSGERR_ATTR_UNUSED = 0,
NLMSGERR_ATTR_MSG = 1,
NLMSGERR_ATTR_OFFS = 2,
NLMSGERR_ATTR_COOKIE = 3,
NLMSGERR_ATTR_POLICY = 4,
NLMSGERR_ATTR_MISS_TYPE = 5,
NLMSGERR_ATTR_MISS_NEST = 6,
__NLMSGERR_ATTR_MAX = 7,
NLMSGERR_ATTR_MAX = 6,
};
struct nl_pktinfo {
__u32 group;
};
enum {
NETLINK_UNCONNECTED = 0,
NETLINK_CONNECTED = 1,
};
enum netlink_skb_flags {
NETLINK_SKB_DST = 8,
};
struct netlink_notify {
struct net *net;
u32 portid;
int protocol;
};
struct netlink_tap {
struct net_device *dev;
struct module *module;
struct list_head list;
};
struct trace_event_raw_netlink_extack {
struct trace_entry ent;
u32 __data_loc_msg;
char __data[0];
};
struct trace_event_data_offsets_netlink_extack {
u32 msg;
};
typedef void (*btf_trace_netlink_extack)(void *, const char *);
struct netlink_sock {
struct sock sk;
u32 portid;
u32 dst_portid;
u32 dst_group;
u32 flags;
u32 subscriptions;
u32 ngroups;
long unsigned int *groups;
long unsigned int state;
size_t max_recvmsg_len;
wait_queue_head_t wait;
bool bound;
bool cb_running;
int dump_done_errno;
struct netlink_callback cb;
struct mutex *cb_mutex;
struct mutex cb_def_mutex;
void (*netlink_rcv)(struct sk_buff *);
int (*netlink_bind)(struct net *, int);
void (*netlink_unbind)(struct net *, int);
struct module *module;
struct rhash_head node;
struct callback_head rcu;
struct work_struct work;
};
struct listeners;
struct netlink_table {
struct rhashtable hash;
struct hlist_head mc_list;
struct listeners *listeners;
unsigned int flags;
unsigned int groups;
struct mutex *cb_mutex;
struct module *module;
int (*bind)(struct net *, int);
void (*unbind)(struct net *, int);
bool (*compare)(struct net *, struct sock *);
int registered;
};
struct listeners {
struct callback_head rcu;
long unsigned int masks[0];
};
struct netlink_tap_net {
struct list_head netlink_tap_all;
struct mutex netlink_tap_lock;
};
struct netlink_compare_arg {
possible_net_t pnet;
u32 portid;
};
struct netlink_broadcast_data {
struct sock *exclude_sk;
struct net *net;
u32 portid;
u32 group;
int failure;
int delivery_failure;
int congested;
int delivered;
gfp_t allocation;
struct sk_buff *skb;
struct sk_buff *skb2;
};
struct netlink_set_err_data {
struct sock *exclude_sk;
u32 portid;
u32 group;
int code;
};
struct nl_seq_iter {
struct seq_net_private p;
struct rhashtable_iter hti;
int link;
};
struct bpf_iter__netlink {
union {
struct bpf_iter_meta *meta;
};
union {
struct netlink_sock *sk;
};
};
enum tcp_fastopen_client_fail {
TFO_STATUS_UNSPEC = 0,
TFO_COOKIE_UNAVAILABLE = 1,
TFO_DATA_NOT_ACKED = 2,
TFO_SYN_RETRANSMITTED = 3,
};
struct fib_result_nl {
__be32 fl_addr;
u32 fl_mark;
unsigned char fl_tos;
unsigned char fl_scope;
unsigned char tb_id_in;
unsigned char tb_id;
unsigned char prefixlen;
unsigned char nh_sel;
unsigned char type;
unsigned char scope;
int err;
};
enum {
FRA_UNSPEC = 0,
FRA_DST = 1,
FRA_SRC = 2,
FRA_IIFNAME = 3,
FRA_GOTO = 4,
FRA_UNUSED2 = 5,
FRA_PRIORITY = 6,
FRA_UNUSED3 = 7,
FRA_UNUSED4 = 8,
FRA_UNUSED5 = 9,
FRA_FWMARK = 10,
FRA_FLOW = 11,
FRA_TUN_ID = 12,
FRA_SUPPRESS_IFGROUP = 13,
FRA_SUPPRESS_PREFIXLEN = 14,
FRA_TABLE = 15,
FRA_FWMASK = 16,
FRA_OIFNAME = 17,
FRA_PAD = 18,
FRA_L3MDEV = 19,
FRA_UID_RANGE = 20,
FRA_PROTOCOL = 21,
FRA_IP_PROTO = 22,
FRA_SPORT_RANGE = 23,
FRA_DPORT_RANGE = 24,
__FRA_MAX = 25,
};
enum {
FR_ACT_UNSPEC = 0,
FR_ACT_TO_TBL = 1,
FR_ACT_GOTO = 2,
FR_ACT_NOP = 3,
FR_ACT_RES3 = 4,
FR_ACT_RES4 = 5,
FR_ACT_BLACKHOLE = 6,
FR_ACT_UNREACHABLE = 7,
FR_ACT_PROHIBIT = 8,
__FR_ACT_MAX = 9,
};
struct fib4_rule {
struct fib_rule common;
u8 dst_len;
u8 src_len;
dscp_t dscp;
__be32 src;
__be32 srcmask;
__be32 dst;
__be32 dstmask;
u32 tclassid;
};
typedef void ip6_icmp_send_t(struct sk_buff *, u8, u8, __u32, const struct in6_addr *, const struct inet6_skb_parm *);
struct icmpv6_msg {
struct sk_buff *skb;
int offset;
uint8_t type;
};
struct icmp6_err {
int err;
int fatal;
};
struct rc {
long int (*fill)(void *, long unsigned int);
uint8_t *ptr;
uint8_t *buffer;
uint8_t *buffer_end;
long int buffer_size;
uint32_t code;
uint32_t range;
uint32_t bound;
void (*error)(char *);
};
struct lzma_header {
uint8_t pos;
uint32_t dict_size;
uint64_t dst_size;
} __attribute__((packed));
struct writer {
uint8_t *buffer;
uint8_t previous_byte;
size_t buffer_pos;
int bufsize;
size_t global_pos;
long int (*flush)(void *, long unsigned int);
struct lzma_header *header;
};
struct cstate {
int state;
uint32_t rep0;
uint32_t rep1;
uint32_t rep2;
uint32_t rep3;
};
enum format_type {
FORMAT_TYPE_NONE = 0,
FORMAT_TYPE_WIDTH = 1,
FORMAT_TYPE_PRECISION = 2,
FORMAT_TYPE_CHAR = 3,
FORMAT_TYPE_STR = 4,
FORMAT_TYPE_PTR = 5,
FORMAT_TYPE_PERCENT_CHAR = 6,
FORMAT_TYPE_INVALID = 7,
FORMAT_TYPE_LONG_LONG = 8,
FORMAT_TYPE_ULONG = 9,
FORMAT_TYPE_LONG = 10,
FORMAT_TYPE_UBYTE = 11,
FORMAT_TYPE_BYTE = 12,
FORMAT_TYPE_USHORT = 13,
FORMAT_TYPE_SHORT = 14,
FORMAT_TYPE_UINT = 15,
FORMAT_TYPE_INT = 16,
FORMAT_TYPE_SIZE_T = 17,
FORMAT_TYPE_PTRDIFF = 18,
};
struct printf_spec {
unsigned int type: 8;
int field_width: 24;
unsigned int flags: 8;
unsigned int base: 8;
int precision: 16;
};
struct page_flags_fields {
int width;
int shift;
int mask;
const struct printf_spec *spec;
const char *name;
};
enum mm_32a_minor_op {
mm_sll32_op = 0,
mm_ins_op = 12,
mm_sllv32_op = 16,
mm_ext_op = 44,
mm_pool32axf_op = 60,
mm_srl32_op = 64,
mm_srlv32_op = 80,
mm_sra_op = 128,
mm_srav_op = 144,
mm_rotr_op = 192,
mm_lwxs_op = 280,
mm_addu32_op = 336,
mm_subu32_op = 464,
mm_wsbh_op = 492,
mm_mul_op = 528,
mm_and_op = 592,
mm_or32_op = 656,
mm_xor32_op = 784,
mm_slt_op = 848,
mm_sltu_op = 912,
};
enum mm_32axf_minor_op {
mm_mfc0_op = 3,
mm_mtc0_op = 11,
mm_tlbp_op = 13,
mm_mfhi32_op = 53,
mm_jalr_op = 60,
mm_tlbr_op = 77,
mm_mflo32_op = 117,
mm_jalrhb_op = 124,
mm_tlbwi_op = 141,
mm_mthi32_op = 181,
mm_tlbwr_op = 205,
mm_mtlo32_op = 245,
mm_di_op = 285,
mm_jalrs_op = 316,
mm_jalrshb_op = 380,
mm_sync_op = 429,
mm_syscall_op = 557,
mm_wait_op = 589,
mm_eret_op = 973,
mm_divu_op = 1500,
};
enum mm_16c_minor_op {
mm_lwm16_op = 4,
mm_swm16_op = 5,
mm_jr16_op = 12,
mm_jrc_op = 13,
mm_jalr16_op = 14,
mm_jalrs16_op = 15,
mm_jraddiusp_op = 24,
};
enum MIPS16e_ops {
MIPS16e_jal_op = 3,
MIPS16e_ld_op = 7,
MIPS16e_i8_op = 12,
MIPS16e_sd_op = 15,
MIPS16e_lb_op = 16,
MIPS16e_lh_op = 17,
MIPS16e_lwsp_op = 18,
MIPS16e_lw_op = 19,
MIPS16e_lbu_op = 20,
MIPS16e_lhu_op = 21,
MIPS16e_lwpc_op = 22,
MIPS16e_lwu_op = 23,
MIPS16e_sb_op = 24,
MIPS16e_sh_op = 25,
MIPS16e_swsp_op = 26,
MIPS16e_sw_op = 27,
MIPS16e_rr_op = 29,
MIPS16e_extend_op = 30,
MIPS16e_i64_op = 31,
};
enum MIPS16e_rr_func {
MIPS16e_jr_func = 0,
};
struct m16e_rr {
unsigned int func: 5;
unsigned int ra: 1;
unsigned int l: 1;
unsigned int nd: 1;
unsigned int rx: 3;
unsigned int opcode: 5;
};
struct m16e_jal {
int imm25_21: 5;
unsigned int imm20_16: 5;
unsigned int x: 1;
unsigned int opcode: 5;
};
struct m16e_i64 {
unsigned int imm: 8;
unsigned int func: 3;
unsigned int opcode: 5;
};
struct m16e_ri64 {
unsigned int imm: 5;
unsigned int ry: 3;
unsigned int func: 3;
unsigned int opcode: 5;
};
struct m16e_ri {
unsigned int imm: 8;
unsigned int rx: 3;
unsigned int opcode: 5;
};
struct m16e_rri {
unsigned int imm: 5;
unsigned int ry: 3;
unsigned int rx: 3;
unsigned int opcode: 5;
};
struct m16e_i8 {
unsigned int imm: 8;
unsigned int func: 3;
unsigned int opcode: 5;
};
union mips16e_instruction {
unsigned int full: 16;
struct m16e_rr rr;
struct m16e_jal jal;
struct m16e_i64 i64;
struct m16e_ri64 ri64;
struct m16e_ri ri;
struct m16e_rri rri;
struct m16e_i8 i8;
};
enum label_id___2 {
label_clear_nopref = 1,
label_clear_pref = 2,
label_copy_nopref = 3,
label_copy_pref_both = 4,
label_copy_pref_store = 5,
};
struct clone_args {
__u64 flags;
__u64 pidfd;
__u64 child_tid;
__u64 parent_tid;
__u64 exit_signal;
__u64 stack;
__u64 stack_size;
__u64 tls;
__u64 set_tid;
__u64 set_tid_size;
__u64 cgroup;
};
struct multiprocess_signals {
sigset_t signal;
struct hlist_node node;
};
struct trace_event_raw_task_newtask {
struct trace_entry ent;
pid_t pid;
char comm[16];
long unsigned int clone_flags;
short int oom_score_adj;
char __data[0];
};
struct trace_event_raw_task_rename {
struct trace_entry ent;
pid_t pid;
char oldcomm[16];
char newcomm[16];
short int oom_score_adj;
char __data[0];
};
struct trace_event_data_offsets_task_newtask {};
struct trace_event_data_offsets_task_rename {};
typedef void (*btf_trace_task_newtask)(void *, struct task_struct *, long unsigned int);
typedef void (*btf_trace_task_rename)(void *, struct task_struct *, const char *);
struct syscall_trace_enter {
struct trace_entry ent;
int nr;
long unsigned int args[0];
};
struct syscall_trace_exit {
struct trace_entry ent;
int nr;
long int ret;
};
struct syscall_tp_t {
long long unsigned int regs;
long unsigned int syscall_nr;
long unsigned int ret;
};
struct syscall_tp_t___2 {
long long unsigned int regs;
long unsigned int syscall_nr;
long unsigned int args[6];
long: 32;
};
struct bpf_preload_info {
char link_name[16];
struct bpf_link *link;
};
struct bpf_preload_ops {
int (*preload)(struct bpf_preload_info *);
struct module *owner;
};
enum bpf_type {
BPF_TYPE_UNSPEC = 0,
BPF_TYPE_PROG = 1,
BPF_TYPE_MAP = 2,
BPF_TYPE_LINK = 3,
};
struct map_iter {
void *key;
bool done;
};
enum {
OPT_MODE = 0,
};
struct bpf_mount_opts {
umode_t mode;
};
enum {
BPF_RB_NO_WAKEUP = 1,
BPF_RB_FORCE_WAKEUP = 2,
};
enum {
BPF_RB_AVAIL_DATA = 0,
BPF_RB_RING_SIZE = 1,
BPF_RB_CONS_POS = 2,
BPF_RB_PROD_POS = 3,
};
enum {
BPF_RINGBUF_BUSY_BIT = 2147483648,
BPF_RINGBUF_DISCARD_BIT = 1073741824,
BPF_RINGBUF_HDR_SZ = 8,
};
struct bpf_ringbuf {
wait_queue_head_t waitq;
struct irq_work work;
long: 32;
u64 mask;
struct page **pages;
int nr_pages;
long: 32;
long: 32;
long: 32;
long: 32;
spinlock_t spinlock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
atomic_t busy;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long unsigned int consumer_pos;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long unsigned int producer_pos;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
char data[0];
};
struct bpf_ringbuf_map {
struct bpf_map map;
struct bpf_ringbuf *rb;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_ringbuf_hdr {
u32 len;
u32 pg_off;
};
typedef u64 (*btf_bpf_ringbuf_reserve)(struct bpf_map *, u64, u64);
typedef u64 (*btf_bpf_ringbuf_submit)(void *, u64);
typedef u64 (*btf_bpf_ringbuf_discard)(void *, u64);
typedef u64 (*btf_bpf_ringbuf_output)(struct bpf_map *, void *, u64, u64);
typedef u64 (*btf_bpf_ringbuf_query)(struct bpf_map *, u64);
typedef u64 (*btf_bpf_ringbuf_reserve_dynptr)(struct bpf_map *, u32, u64, struct bpf_dynptr_kern *);
typedef u64 (*btf_bpf_ringbuf_submit_dynptr)(struct bpf_dynptr_kern *, u64);
typedef u64 (*btf_bpf_ringbuf_discard_dynptr)(struct bpf_dynptr_kern *, u64);
typedef u64 (*btf_bpf_user_ringbuf_drain)(struct bpf_map *, void *, void *, u64);
struct bpf_devmap_val {
__u32 ifindex;
union {
int fd;
__u32 id;
} bpf_prog;
};
struct xdp_dev_bulk_queue {
struct xdp_frame *q[16];
struct list_head flush_node;
struct net_device *dev;
struct net_device *dev_rx;
struct bpf_prog *xdp_prog;
unsigned int count;
};
struct bpf_dtab;
struct bpf_dtab_netdev {
struct net_device *dev;
struct hlist_node index_hlist;
struct bpf_dtab *dtab;
struct bpf_prog *xdp_prog;
struct callback_head rcu;
unsigned int idx;
struct bpf_devmap_val val;
};
struct bpf_dtab {
struct bpf_map map;
struct bpf_dtab_netdev **netdev_map;
struct list_head list;
struct hlist_head *dev_index_head;
spinlock_t index_lock;
unsigned int items;
u32 n_buckets;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct swap_iocb {
struct kiocb iocb;
struct bio_vec bvec[32];
int pages;
int len;
};
typedef struct {
long unsigned int fds_bits[32];
} __kernel_fd_set;
typedef __kernel_fd_set fd_set;
struct poll_table_entry {
struct file *filp;
__poll_t key;
wait_queue_entry_t wait;
wait_queue_head_t *wait_address;
};
struct poll_table_page;
struct poll_wqueues {
poll_table pt;
struct poll_table_page *table;
struct task_struct *polling_task;
int triggered;
int error;
int inline_index;
struct poll_table_entry inline_entries[18];
};
struct poll_table_page {
struct poll_table_page *next;
struct poll_table_entry *entry;
struct poll_table_entry entries[0];
};
enum poll_time_type {
PT_TIMEVAL = 0,
PT_OLD_TIMEVAL = 1,
PT_TIMESPEC = 2,
PT_OLD_TIMESPEC = 3,
};
typedef struct {
long unsigned int *in;
long unsigned int *out;
long unsigned int *ex;
long unsigned int *res_in;
long unsigned int *res_out;
long unsigned int *res_ex;
} fd_set_bits;
struct sigset_argpack {
sigset_t *p;
size_t size;
};
struct poll_list {
struct poll_list *next;
int len;
struct pollfd entries[0];
};
struct timerfd_ctx {
union {
struct hrtimer tmr;
struct alarm alarm;
} t;
ktime_t tintv;
ktime_t moffs;
wait_queue_head_t wqh;
long: 32;
u64 ticks;
int clockid;
short unsigned int expired;
short unsigned int settime_flags;
struct callback_head rcu;
struct list_head clist;
spinlock_t cancel_lock;
bool might_cancel;
};
struct fs_disk_quota {
__s8 d_version;
__s8 d_flags;
__u16 d_fieldmask;
__u32 d_id;
__u64 d_blk_hardlimit;
__u64 d_blk_softlimit;
__u64 d_ino_hardlimit;
__u64 d_ino_softlimit;
__u64 d_bcount;
__u64 d_icount;
__s32 d_itimer;
__s32 d_btimer;
__u16 d_iwarns;
__u16 d_bwarns;
__s8 d_itimer_hi;
__s8 d_btimer_hi;
__s8 d_rtbtimer_hi;
__s8 d_padding2;
__u64 d_rtb_hardlimit;
__u64 d_rtb_softlimit;
__u64 d_rtbcount;
__s32 d_rtbtimer;
__u16 d_rtbwarns;
__s16 d_padding3;
char d_padding4[8];
};
struct fs_qfilestat {
__u64 qfs_ino;
__u64 qfs_nblks;
__u32 qfs_nextents;
long: 32;
};
typedef struct fs_qfilestat fs_qfilestat_t;
struct fs_quota_stat {
__s8 qs_version;
__u16 qs_flags;
__s8 qs_pad;
fs_qfilestat_t qs_uquota;
fs_qfilestat_t qs_gquota;
__u32 qs_incoredqs;
__s32 qs_btimelimit;
__s32 qs_itimelimit;
__s32 qs_rtbtimelimit;
__u16 qs_bwarnlimit;
__u16 qs_iwarnlimit;
long: 32;
};
struct fs_qfilestatv {
__u64 qfs_ino;
__u64 qfs_nblks;
__u32 qfs_nextents;
__u32 qfs_pad;
};
struct fs_quota_statv {
__s8 qs_version;
__u8 qs_pad1;
__u16 qs_flags;
__u32 qs_incoredqs;
struct fs_qfilestatv qs_uquota;
struct fs_qfilestatv qs_gquota;
struct fs_qfilestatv qs_pquota;
__s32 qs_btimelimit;
__s32 qs_itimelimit;
__s32 qs_rtbtimelimit;
__u16 qs_bwarnlimit;
__u16 qs_iwarnlimit;
__u16 qs_rtbwarnlimit;
__u16 qs_pad3;
__u32 qs_pad4;
__u64 qs_pad2[7];
};
struct if_dqblk {
__u64 dqb_bhardlimit;
__u64 dqb_bsoftlimit;
__u64 dqb_curspace;
__u64 dqb_ihardlimit;
__u64 dqb_isoftlimit;
__u64 dqb_curinodes;
__u64 dqb_btime;
__u64 dqb_itime;
__u32 dqb_valid;
long: 32;
};
struct if_nextdqblk {
__u64 dqb_bhardlimit;
__u64 dqb_bsoftlimit;
__u64 dqb_curspace;
__u64 dqb_ihardlimit;
__u64 dqb_isoftlimit;
__u64 dqb_curinodes;
__u64 dqb_btime;
__u64 dqb_itime;
__u32 dqb_valid;
__u32 dqb_id;
};
struct if_dqinfo {
__u64 dqi_bgrace;
__u64 dqi_igrace;
__u32 dqi_flags;
__u32 dqi_valid;
};
typedef u64 compat_u64;
struct compat_if_dqblk {
compat_u64 dqb_bhardlimit;
compat_u64 dqb_bsoftlimit;
compat_u64 dqb_curspace;
compat_u64 dqb_ihardlimit;
compat_u64 dqb_isoftlimit;
compat_u64 dqb_curinodes;
compat_u64 dqb_btime;
compat_u64 dqb_itime;
compat_uint_t dqb_valid;
long: 32;
};
enum {
BLOCK_BITMAP = 0,
INODE_BITMAP = 1,
INODE_TABLE = 2,
GROUP_TABLE_COUNT = 3,
};
struct ext4_rcu_ptr {
struct callback_head rcu;
void *ptr;
};
struct ext4_new_flex_group_data {
struct ext4_new_group_data *groups;
__u16 *bg_flags;
ext4_group_t count;
};
struct ext2_mount_options {
long unsigned int s_mount_opt;
kuid_t s_resuid;
kgid_t s_resgid;
};
enum {
Opt_bsd_df___2 = 0,
Opt_minix_df___2 = 1,
Opt_grpid___2 = 2,
Opt_nogrpid___2 = 3,
Opt_resgid___2 = 4,
Opt_resuid___2 = 5,
Opt_sb___2 = 6,
Opt_err_cont = 7,
Opt_err_panic = 8,
Opt_err_ro = 9,
Opt_nouid32___2 = 10,
Opt_debug___2 = 11,
Opt_oldalloc = 12,
Opt_orlov = 13,
Opt_nobh = 14,
Opt_user_xattr___2 = 15,
Opt_nouser_xattr = 16,
Opt_acl___3 = 17,
Opt_noacl = 18,
Opt_xip = 19,
Opt_dax___2 = 20,
Opt_ignore___2 = 21,
Opt_err___6 = 22,
Opt_quota___2 = 23,
Opt_usrquota___2 = 24,
Opt_grpquota___2 = 25,
Opt_reservation = 26,
Opt_noreservation = 27,
};
enum nfs2_ftype {
NF2NON = 0,
NF2REG = 1,
NF2DIR = 2,
NF2BLK = 3,
NF2CHR = 4,
NF2LNK = 5,
NF2SOCK = 6,
NF2BAD = 7,
NF2FIFO = 8,
};
struct nfs2_fsstat {
__u32 tsize;
__u32 bsize;
__u32 blocks;
__u32 bfree;
__u32 bavail;
};
struct nfs_sattrargs {
struct nfs_fh *fh;
struct iattr *sattr;
};
struct nfs_diropargs {
struct nfs_fh *fh;
const char *name;
unsigned int len;
};
struct nfs_createargs {
struct nfs_fh *fh;
const char *name;
unsigned int len;
struct iattr *sattr;
};
struct nfs_linkargs {
struct nfs_fh *fromfh;
struct nfs_fh *tofh;
const char *toname;
unsigned int tolen;
};
struct nfs_symlinkargs {
struct nfs_fh *fromfh;
const char *fromname;
unsigned int fromlen;
struct page **pages;
unsigned int pathlen;
struct iattr *sattr;
};
struct nfs_readdirargs {
struct nfs_fh *fh;
__u32 cookie;
unsigned int count;
struct page **pages;
};
struct nfs_diropok {
struct nfs_fh *fh;
struct nfs_fattr *fattr;
};
struct nfs_readlinkargs {
struct nfs_fh *fh;
unsigned int pgbase;
unsigned int pglen;
struct page **pages;
};
struct nlmclnt_initdata {
const char *hostname;
const struct sockaddr *address;
size_t addrlen;
short unsigned int protocol;
u32 nfs_version;
int noresvport;
struct net *net;
const struct nlmclnt_operations *nlmclnt_ops;
const struct cred *cred;
};
struct nlm_wait {
struct list_head b_list;
wait_queue_head_t b_wait;
struct nlm_host *b_host;
struct file_lock *b_lock;
short unsigned int b_reclaim;
__be32 b_status;
};
enum {
AUTOFS_IOC_READY_CMD = 96,
AUTOFS_IOC_FAIL_CMD = 97,
AUTOFS_IOC_CATATONIC_CMD = 98,
AUTOFS_IOC_PROTOVER_CMD = 99,
AUTOFS_IOC_SETTIMEOUT_CMD = 100,
AUTOFS_IOC_EXPIRE_CMD = 101,
};
enum {
AUTOFS_IOC_EXPIRE_MULTI_CMD = 102,
AUTOFS_IOC_PROTOSUBVER_CMD = 103,
AUTOFS_IOC_ASKUMOUNT_CMD = 112,
};
enum x509_actions {
ACT_x509_extract_key_data = 0,
ACT_x509_extract_name_segment = 1,
ACT_x509_note_OID = 2,
ACT_x509_note_issuer = 3,
ACT_x509_note_not_after = 4,
ACT_x509_note_not_before = 5,
ACT_x509_note_params = 6,
ACT_x509_note_serial = 7,
ACT_x509_note_sig_algo = 8,
ACT_x509_note_signature = 9,
ACT_x509_note_subject = 10,
ACT_x509_note_tbs_certificate = 11,
ACT_x509_process_extension = 12,
NR__x509_actions = 13,
};
enum x509_akid_actions {
ACT_x509_akid_note_kid = 0,
ACT_x509_akid_note_name = 1,
ACT_x509_akid_note_serial = 2,
ACT_x509_extract_name_segment___2 = 3,
ACT_x509_note_OID___2 = 4,
NR__x509_akid_actions = 5,
};
struct x509_parse_context {
struct x509_certificate *cert;
long unsigned int data;
const void *key;
size_t key_size;
const void *params;
size_t params_size;
enum OID key_algo;
enum OID last_oid;
enum OID sig_algo;
u8 o_size;
u8 cn_size;
u8 email_size;
u16 o_offset;
u16 cn_offset;
u16 email_offset;
unsigned int raw_akid_size;
const void *raw_akid;
const void *akid_raw_issuer;
unsigned int akid_raw_issuer_size;
};
struct bio_map_data {
bool is_our_pages: 1;
bool is_null_mapped: 1;
long: 32;
struct iov_iter iter;
struct iovec iov[0];
};
struct bsg_job;
typedef int bsg_job_fn(struct bsg_job *);
struct bsg_buffer {
unsigned int payload_len;
int sg_cnt;
struct scatterlist *sg_list;
};
struct bsg_job {
struct device *dev;
struct kref kref;
unsigned int timeout;
void *request;
void *reply;
unsigned int request_len;
unsigned int reply_len;
struct bsg_buffer request_payload;
struct bsg_buffer reply_payload;
int result;
unsigned int reply_payload_rcv_len;
struct request *bidi_rq;
struct bio *bidi_bio;
void *dd_data;
};
typedef enum blk_eh_timer_return bsg_timeout_fn(struct request *);
struct bsg_set {
struct blk_mq_tag_set tag_set;
struct bsg_device *bd;
bsg_job_fn *job_fn;
bsg_timeout_fn *timeout_fn;
};
struct io_timeout_data {
struct io_kiocb *req;
long: 32;
struct hrtimer timer;
struct timespec64 ts;
enum hrtimer_mode mode;
u32 flags;
};
struct io_timeout {
struct file *file;
u32 off;
u32 target_seq;
struct list_head list;
struct io_kiocb *head;
struct io_kiocb *prev;
};
struct io_timeout_rem {
struct file *file;
long: 32;
u64 addr;
struct timespec64 ts;
u32 flags;
bool ltimeout;
};
struct once_work {
struct work_struct work;
struct static_key_true *key;
struct module *module;
};
struct ZSTD_inBuffer_s {
const void *src;
size_t size;
size_t pos;
};
typedef struct ZSTD_inBuffer_s ZSTD_inBuffer;
typedef ZSTD_DCtx ZSTD_DStream;
typedef ZSTD_ErrorCode zstd_error_code;
typedef ZSTD_DCtx zstd_dctx;
typedef ZSTD_inBuffer zstd_in_buffer;
typedef ZSTD_outBuffer zstd_out_buffer;
typedef ZSTD_DStream zstd_dstream;
typedef ZSTD_frameHeader zstd_frame_header;
struct vga_device {
struct list_head list;
struct pci_dev *pdev;
unsigned int decodes;
unsigned int owns;
unsigned int locks;
unsigned int io_lock_cnt;
unsigned int mem_lock_cnt;
unsigned int io_norm_cnt;
unsigned int mem_norm_cnt;
bool bridge_has_one_vga;
bool is_firmware_default;
unsigned int (*set_decode)(struct pci_dev *, bool);
};
struct vga_arb_user_card {
struct pci_dev *pdev;
unsigned int mem_cnt;
unsigned int io_cnt;
};
struct vga_arb_private {
struct list_head list;
struct pci_dev *target;
struct vga_arb_user_card cards[16];
spinlock_t lock;
};
struct clk_fixed_factor {
struct clk_hw hw;
unsigned int mult;
unsigned int div;
};
struct ldsem_waiter {
struct list_head list;
struct task_struct *task;
};
struct fwnode_link {
struct fwnode_handle *supplier;
struct list_head s_hook;
struct fwnode_handle *consumer;
struct list_head c_hook;
};
struct dev_printk_info {
char subsystem[16];
char device[48];
};
enum dpm_order {
DPM_ORDER_NONE = 0,
DPM_ORDER_DEV_AFTER_PARENT = 1,
DPM_ORDER_PARENT_BEFORE_DEV = 2,
DPM_ORDER_DEV_LAST = 3,
};
union device_attr_group_devres {
const struct attribute_group *group;
const struct attribute_group **groups;
};
struct class_dir {
struct kobject kobj;
struct class *class;
};
struct root_device {
struct device dev;
struct module *owner;
long: 32;
};
enum rpm_status {
RPM_INVALID = -1,
RPM_ACTIVE = 0,
RPM_RESUMING = 1,
RPM_SUSPENDED = 2,
RPM_SUSPENDING = 3,
};
struct ata_internal {
struct scsi_transport_template t;
struct device_attribute private_port_attrs[3];
struct device_attribute private_link_attrs[3];
struct device_attribute private_dev_attrs[9];
struct transport_container link_attr_cont;
struct transport_container dev_attr_cont;
struct device_attribute *link_attrs[4];
struct device_attribute *port_attrs[4];
struct device_attribute *dev_attrs[10];
};
struct ata_show_ering_arg {
char *buf;
int written;
};
struct cdrom_msf {
__u8 cdmsf_min0;
__u8 cdmsf_sec0;
__u8 cdmsf_frame0;
__u8 cdmsf_min1;
__u8 cdmsf_sec1;
__u8 cdmsf_frame1;
};
struct cdrom_volctrl {
__u8 channel0;
__u8 channel1;
__u8 channel2;
__u8 channel3;
};
struct cdrom_subchnl {
__u8 cdsc_format;
__u8 cdsc_audiostatus;
__u8 cdsc_adr: 4;
__u8 cdsc_ctrl: 4;
__u8 cdsc_trk;
__u8 cdsc_ind;
union cdrom_addr cdsc_absaddr;
union cdrom_addr cdsc_reladdr;
};
struct cdrom_read_audio {
union cdrom_addr addr;
__u8 addr_format;
int nframes;
__u8 *buf;
};
struct cdrom_blk {
unsigned int from;
short unsigned int len;
};
struct cdrom_timed_media_change_info {
__s64 last_media_change;
__u64 media_flags;
};
struct dvd_layer {
__u8 book_version: 4;
__u8 book_type: 4;
__u8 min_rate: 4;
__u8 disc_size: 4;
__u8 layer_type: 4;
__u8 track_path: 1;
__u8 nlayers: 2;
char: 1;
__u8 track_density: 4;
__u8 linear_density: 4;
__u8 bca: 1;
__u32 start_sector;
__u32 end_sector;
__u32 end_sector_l0;
};
struct dvd_physical {
__u8 type;
__u8 layer_num;
struct dvd_layer layer[4];
};
struct dvd_copyright {
__u8 type;
__u8 layer_num;
__u8 cpst;
__u8 rmi;
};
struct dvd_disckey {
__u8 type;
unsigned int agid: 2;
__u8 value[2048];
};
struct dvd_bca {
__u8 type;
int len;
__u8 value[188];
};
struct dvd_manufact {
__u8 type;
__u8 layer_num;
int len;
__u8 value[2048];
};
typedef union {
__u8 type;
struct dvd_physical physical;
struct dvd_copyright copyright;
struct dvd_disckey disckey;
struct dvd_bca bca;
struct dvd_manufact manufact;
} dvd_struct;
typedef __u8 dvd_key[5];
typedef __u8 dvd_challenge[10];
struct dvd_lu_send_agid {
__u8 type;
unsigned int agid: 2;
};
struct dvd_host_send_challenge {
__u8 type;
unsigned int agid: 2;
dvd_challenge chal;
};
struct dvd_send_key {
__u8 type;
unsigned int agid: 2;
dvd_key key;
};
struct dvd_lu_send_challenge {
__u8 type;
unsigned int agid: 2;
dvd_challenge chal;
};
struct dvd_lu_send_title_key {
__u8 type;
unsigned int agid: 2;
dvd_key title_key;
int lba;
unsigned int cpm: 1;
unsigned int cp_sec: 1;
unsigned int cgms: 2;
};
struct dvd_lu_send_asf {
__u8 type;
unsigned int agid: 2;
unsigned int asf: 1;
};
struct dvd_host_send_rpcstate {
__u8 type;
__u8 pdrc;
};
struct dvd_lu_send_rpcstate {
__u8 type: 2;
__u8 vra: 3;
__u8 ucca: 3;
__u8 region_mask;
__u8 rpc_scheme;
};
typedef union {
__u8 type;
struct dvd_lu_send_agid lsa;
struct dvd_host_send_challenge hsc;
struct dvd_send_key lsk;
struct dvd_lu_send_challenge lsc;
struct dvd_send_key hsk;
struct dvd_lu_send_title_key lstk;
struct dvd_lu_send_asf lsasf;
struct dvd_host_send_rpcstate hrpcs;
struct dvd_lu_send_rpcstate lrpcs;
} dvd_authinfo;
struct mrw_feature_desc {
__be16 feature_code;
__u8 curr: 1;
__u8 persistent: 1;
__u8 feature_version: 4;
__u8 reserved1: 2;
__u8 add_len;
__u8 write: 1;
__u8 reserved2: 7;
__u8 reserved3;
__u8 reserved4;
__u8 reserved5;
};
struct rwrt_feature_desc {
__be16 feature_code;
__u8 curr: 1;
__u8 persistent: 1;
__u8 feature_version: 4;
__u8 reserved1: 2;
__u8 add_len;
__u32 last_lba;
__u32 block_size;
__u16 blocking;
__u8 page_present: 1;
__u8 reserved2: 7;
__u8 reserved3;
};
typedef struct {
__be16 disc_information_length;
__u8 disc_status: 2;
__u8 border_status: 2;
__u8 erasable: 1;
__u8 reserved1: 3;
__u8 n_first_track;
__u8 n_sessions_lsb;
__u8 first_track_lsb;
__u8 last_track_lsb;
__u8 mrw_status: 2;
__u8 dbit: 1;
__u8 reserved2: 2;
__u8 uru: 1;
__u8 dbc_v: 1;
__u8 did_v: 1;
__u8 disc_type;
__u8 n_sessions_msb;
__u8 first_track_msb;
__u8 last_track_msb;
__u32 disc_id;
__u32 lead_in;
__u32 lead_out;
__u8 disc_bar_code[8];
__u8 reserved3;
__u8 n_opc;
} disc_information;
typedef struct {
__be16 track_information_length;
__u8 track_lsb;
__u8 session_lsb;
__u8 reserved1;
__u8 track_mode: 4;
__u8 copy: 1;
__u8 damage: 1;
__u8 reserved2: 2;
__u8 data_mode: 4;
__u8 fp: 1;
__u8 packet: 1;
__u8 blank: 1;
__u8 rt: 1;
__u8 nwa_v: 1;
__u8 lra_v: 1;
__u8 reserved3: 6;
__be32 track_start;
__be32 next_writable;
__be32 free_blocks;
__be32 fixed_packet_size;
__be32 track_size;
__be32 last_rec_address;
} track_information;
struct mode_page_header {
__be16 mode_data_length;
__u8 medium_type;
__u8 reserved1;
__u8 reserved2;
__u8 reserved3;
__be16 desc_length;
};
typedef struct {
int data;
int audio;
int cdi;
int xa;
long int error;
} tracktype;
struct cdrom_mechstat_header {
__u8 curslot: 5;
__u8 changer_state: 2;
__u8 fault: 1;
__u8 reserved1: 4;
__u8 door_open: 1;
__u8 mech_state: 3;
__u8 curlba[3];
__u8 nslots;
__u16 slot_tablelen;
};
struct cdrom_slot {
__u8 change: 1;
__u8 reserved1: 6;
__u8 disc_present: 1;
__u8 reserved2[3];
};
struct cdrom_changer_info {
struct cdrom_mechstat_header hdr;
struct cdrom_slot slots[256];
};
struct modesel_head {
__u8 reserved1;
__u8 medium;
__u8 reserved2;
__u8 block_desc_length;
__u8 density;
__u8 number_of_blocks_hi;
__u8 number_of_blocks_med;
__u8 number_of_blocks_lo;
__u8 reserved3;
__u8 block_length_hi;
__u8 block_length_med;
__u8 block_length_lo;
};
typedef struct {
__u16 report_key_length;
__u8 reserved1;
__u8 reserved2;
__u8 ucca: 3;
__u8 vra: 3;
__u8 type_code: 2;
__u8 region_mask;
__u8 rpc_scheme;
__u8 reserved3;
} rpc_state_t;
struct cdrom_sysctl_settings {
char info[1000];
int autoclose;
int autoeject;
int debug;
int lock;
int check;
};
enum cdrom_print_option {
CTL_NAME = 0,
CTL_SPEED = 1,
CTL_SLOTS = 2,
CTL_CAPABILITY = 3,
};
enum SS4_PACKET_ID {
SS4_PACKET_ID_IDLE = 0,
SS4_PACKET_ID_ONE = 1,
SS4_PACKET_ID_TWO = 2,
SS4_PACKET_ID_MULTI = 3,
SS4_PACKET_ID_STICK = 4,
};
enum V7_PACKET_ID {
V7_PACKET_ID_IDLE = 0,
V7_PACKET_ID_TWO = 1,
V7_PACKET_ID_MULTI = 2,
V7_PACKET_ID_NEW = 3,
V7_PACKET_ID_UNKNOWN = 4,
};
struct alps_protocol_info {
u16 version;
u8 byte0;
u8 mask0;
unsigned int flags;
};
struct alps_model_info {
u8 signature[3];
struct alps_protocol_info protocol_info;
};
struct alps_nibble_commands {
int command;
unsigned char data;
};
struct alps_bitmap_point {
int start_bit;
int num_bits;
};
struct alps_fields {
unsigned int x_map;
unsigned int y_map;
unsigned int fingers;
int pressure;
struct input_mt_pos st;
struct input_mt_pos mt[4];
unsigned int first_mp: 1;
unsigned int is_mp: 1;
unsigned int left: 1;
unsigned int right: 1;
unsigned int middle: 1;
unsigned int ts_left: 1;
unsigned int ts_right: 1;
unsigned int ts_middle: 1;
};
struct alps_data {
struct psmouse *psmouse;
struct input_dev *dev2;
struct input_dev *dev3;
char phys2[32];
char phys3[32];
struct delayed_work dev3_register_work;
const struct alps_nibble_commands *nibble_commands;
int addr_command;
u16 proto_version;
u8 byte0;
u8 mask0;
u8 dev_id[3];
u8 fw_ver[3];
int flags;
int x_max;
int y_max;
int x_bits;
int y_bits;
unsigned int x_res;
unsigned int y_res;
int (*hw_init)(struct psmouse *);
void (*process_packet)(struct psmouse *);
int (*decode_fields)(struct alps_fields *, unsigned char *, struct psmouse *);
void (*set_abs_params)(struct alps_data *, struct input_dev *);
int prev_fin;
int multi_packet;
int second_touch;
unsigned char multi_data[6];
struct alps_fields f;
u8 quirks;
struct timer_list timer;
};
struct of_bus___2 {
void (*count_cells)(const void *, int, int *, int *);
u64 (*map)(__be32 *, const __be32 *, int, int, int);
int (*translate)(__be32 *, u64, int);
};
struct linger {
int l_onoff;
int l_linger;
};
struct so_timestamping {
int flags;
int bind_phc;
};
enum txtime_flags {
SOF_TXTIME_DEADLINE_MODE = 1,
SOF_TXTIME_REPORT_ERRORS = 2,
SOF_TXTIME_FLAGS_LAST = 2,
SOF_TXTIME_FLAGS_MASK = 3,
};
struct sock_txtime {
__kernel_clockid_t clockid;
__u32 flags;
};
enum xfrm_ae_ftype_t {
XFRM_AE_UNSPEC = 0,
XFRM_AE_RTHR = 1,
XFRM_AE_RVAL = 2,
XFRM_AE_LVAL = 4,
XFRM_AE_ETHR = 8,
XFRM_AE_CR = 16,
XFRM_AE_CE = 32,
XFRM_AE_CU = 64,
__XFRM_AE_MAX = 65,
};
enum xfrm_nlgroups {
XFRMNLGRP_NONE = 0,
XFRMNLGRP_ACQUIRE = 1,
XFRMNLGRP_EXPIRE = 2,
XFRMNLGRP_SA = 3,
XFRMNLGRP_POLICY = 4,
XFRMNLGRP_AEVENTS = 5,
XFRMNLGRP_REPORT = 6,
XFRMNLGRP_MIGRATE = 7,
XFRMNLGRP_MAPPING = 8,
__XFRMNLGRP_MAX = 9,
};
struct km_event {
union {
u32 hard;
u32 proto;
u32 byid;
u32 aevent;
u32 type;
} data;
u32 seq;
u32 portid;
u32 event;
struct net *net;
};
enum ip6_defrag_users {
IP6_DEFRAG_LOCAL_DELIVER = 0,
IP6_DEFRAG_CONNTRACK_IN = 1,
__IP6_DEFRAG_CONNTRACK_IN = 65536,
IP6_DEFRAG_CONNTRACK_OUT = 65537,
__IP6_DEFRAG_CONNTRACK_OUT = 131072,
IP6_DEFRAG_CONNTRACK_BRIDGE_IN = 131073,
__IP6_DEFRAG_CONNTRACK_BRIDGE_IN = 196608,
};
struct frag_queue {
struct inet_frag_queue q;
int iif;
__u16 nhoffset;
u8 ecn;
};
struct xfrm6_protocol {
int (*handler)(struct sk_buff *);
int (*input_handler)(struct sk_buff *, int, __be32, int);
int (*cb_handler)(struct sk_buff *, int);
int (*err_handler)(struct sk_buff *, struct inet6_skb_parm *, u8, u8, int, __be32);
struct xfrm6_protocol *next;
int priority;
};
struct sadb_msg {
__u8 sadb_msg_version;
__u8 sadb_msg_type;
__u8 sadb_msg_errno;
__u8 sadb_msg_satype;
__u16 sadb_msg_len;
__u16 sadb_msg_reserved;
__u32 sadb_msg_seq;
__u32 sadb_msg_pid;
};
struct sadb_ext {
__u16 sadb_ext_len;
__u16 sadb_ext_type;
};
struct sadb_sa {
__u16 sadb_sa_len;
__u16 sadb_sa_exttype;
__be32 sadb_sa_spi;
__u8 sadb_sa_replay;
__u8 sadb_sa_state;
__u8 sadb_sa_auth;
__u8 sadb_sa_encrypt;
__u32 sadb_sa_flags;
};
struct sadb_lifetime {
__u16 sadb_lifetime_len;
__u16 sadb_lifetime_exttype;
__u32 sadb_lifetime_allocations;
__u64 sadb_lifetime_bytes;
__u64 sadb_lifetime_addtime;
__u64 sadb_lifetime_usetime;
};
struct sadb_address {
__u16 sadb_address_len;
__u16 sadb_address_exttype;
__u8 sadb_address_proto;
__u8 sadb_address_prefixlen;
__u16 sadb_address_reserved;
};
struct sadb_key {
__u16 sadb_key_len;
__u16 sadb_key_exttype;
__u16 sadb_key_bits;
__u16 sadb_key_reserved;
};
struct sadb_prop {
__u16 sadb_prop_len;
__u16 sadb_prop_exttype;
__u8 sadb_prop_replay;
__u8 sadb_prop_reserved[3];
};
struct sadb_comb {
__u8 sadb_comb_auth;
__u8 sadb_comb_encrypt;
__u16 sadb_comb_flags;
__u16 sadb_comb_auth_minbits;
__u16 sadb_comb_auth_maxbits;
__u16 sadb_comb_encrypt_minbits;
__u16 sadb_comb_encrypt_maxbits;
__u32 sadb_comb_reserved;
__u32 sadb_comb_soft_allocations;
__u32 sadb_comb_hard_allocations;
__u64 sadb_comb_soft_bytes;
__u64 sadb_comb_hard_bytes;
__u64 sadb_comb_soft_addtime;
__u64 sadb_comb_hard_addtime;
__u64 sadb_comb_soft_usetime;
__u64 sadb_comb_hard_usetime;
};
struct sadb_supported {
__u16 sadb_supported_len;
__u16 sadb_supported_exttype;
__u32 sadb_supported_reserved;
};
struct sadb_spirange {
__u16 sadb_spirange_len;
__u16 sadb_spirange_exttype;
__u32 sadb_spirange_min;
__u32 sadb_spirange_max;
__u32 sadb_spirange_reserved;
};
struct sadb_x_sa2 {
__u16 sadb_x_sa2_len;
__u16 sadb_x_sa2_exttype;
__u8 sadb_x_sa2_mode;
__u8 sadb_x_sa2_reserved1;
__u16 sadb_x_sa2_reserved2;
__u32 sadb_x_sa2_sequence;
__u32 sadb_x_sa2_reqid;
};
struct sadb_x_policy {
__u16 sadb_x_policy_len;
__u16 sadb_x_policy_exttype;
__u16 sadb_x_policy_type;
__u8 sadb_x_policy_dir;
__u8 sadb_x_policy_reserved;
__u32 sadb_x_policy_id;
__u32 sadb_x_policy_priority;
};
struct sadb_x_ipsecrequest {
__u16 sadb_x_ipsecrequest_len;
__u16 sadb_x_ipsecrequest_proto;
__u8 sadb_x_ipsecrequest_mode;
__u8 sadb_x_ipsecrequest_level;
__u16 sadb_x_ipsecrequest_reserved1;
__u32 sadb_x_ipsecrequest_reqid;
__u32 sadb_x_ipsecrequest_reserved2;
};
struct sadb_x_nat_t_type {
__u16 sadb_x_nat_t_type_len;
__u16 sadb_x_nat_t_type_exttype;
__u8 sadb_x_nat_t_type_type;
__u8 sadb_x_nat_t_type_reserved[3];
};
struct sadb_x_nat_t_port {
__u16 sadb_x_nat_t_port_len;
__u16 sadb_x_nat_t_port_exttype;
__be16 sadb_x_nat_t_port_port;
__u16 sadb_x_nat_t_port_reserved;
};
struct sadb_x_sec_ctx {
__u16 sadb_x_sec_len;
__u16 sadb_x_sec_exttype;
__u8 sadb_x_ctx_alg;
__u8 sadb_x_ctx_doi;
__u16 sadb_x_ctx_len;
};
struct sadb_x_kmaddress {
__u16 sadb_x_kmaddress_len;
__u16 sadb_x_kmaddress_exttype;
__u32 sadb_x_kmaddress_reserved;
};
struct sadb_x_filter {
__u16 sadb_x_filter_len;
__u16 sadb_x_filter_exttype;
__u32 sadb_x_filter_saddr[4];
__u32 sadb_x_filter_daddr[4];
__u16 sadb_x_filter_family;
__u8 sadb_x_filter_splen;
__u8 sadb_x_filter_dplen;
};
enum {
IPSEC_MODE_ANY = 0,
IPSEC_MODE_TRANSPORT = 1,
IPSEC_MODE_TUNNEL = 2,
IPSEC_MODE_BEET = 3,
};
enum {
IPSEC_DIR_ANY = 0,
IPSEC_DIR_INBOUND = 1,
IPSEC_DIR_OUTBOUND = 2,
IPSEC_DIR_FWD = 3,
IPSEC_DIR_MAX = 4,
IPSEC_DIR_INVALID = 5,
};
enum {
IPSEC_POLICY_DISCARD = 0,
IPSEC_POLICY_NONE = 1,
IPSEC_POLICY_IPSEC = 2,
IPSEC_POLICY_ENTRUST = 3,
IPSEC_POLICY_BYPASS = 4,
};
enum {
IPSEC_LEVEL_DEFAULT = 0,
IPSEC_LEVEL_USE = 1,
IPSEC_LEVEL_REQUIRE = 2,
IPSEC_LEVEL_UNIQUE = 3,
};
struct xfrm_user_sec_ctx {
__u16 len;
__u16 exttype;
__u8 ctx_alg;
__u8 ctx_doi;
__u16 ctx_len;
};
struct xfrm_mgr {
struct list_head list;
int (*notify)(struct xfrm_state *, const struct km_event *);
int (*acquire)(struct xfrm_state *, struct xfrm_tmpl *, struct xfrm_policy *);
struct xfrm_policy * (*compile_policy)(struct sock *, int, u8 *, int, int *);
int (*new_mapping)(struct xfrm_state *, xfrm_address_t *, __be16);
int (*notify_policy)(struct xfrm_policy *, int, const struct km_event *);
int (*report)(struct net *, u8, struct xfrm_selector *, xfrm_address_t *);
int (*migrate)(const struct xfrm_selector *, u8, u8, const struct xfrm_migrate *, int, const struct xfrm_kmaddress *, const struct xfrm_encap_tmpl *);
bool (*is_alive)(const struct km_event *);
};
struct netns_pfkey {
struct hlist_head table;
atomic_t socks_nr;
};
struct pfkey_sock {
struct sock sk;
int registered;
int promisc;
struct {
uint8_t msg_version;
uint32_t msg_portid;
int (*dump)(struct pfkey_sock *);
void (*done)(struct pfkey_sock *);
union {
struct xfrm_policy_walk policy;
struct xfrm_state_walk state;
} u;
struct sk_buff *skb;
} dump;
struct mutex dump_lock;
};
typedef int (*pfkey_handler)(struct sock *, struct sk_buff *, const struct sadb_msg *, void * const *);
typedef struct rpc_xprt * (*xprt_switch_find_xprt_t)(struct rpc_xprt_switch *, const struct rpc_xprt *);
enum {
KERNEL_PARAM_OPS_FL_NOARG = 1,
};
struct param_attribute {
struct module_attribute mattr;
const struct kernel_param *param;
};
struct module_param_attrs {
unsigned int num;
struct attribute_group grp;
struct param_attribute attrs[0];
};
struct kmalloced_param {
struct list_head list;
char val[0];
};
struct smpboot_thread_data {
unsigned int cpu;
unsigned int status;
struct smp_hotplug_thread *ht;
};
enum {
HP_THREAD_NONE = 0,
HP_THREAD_ACTIVE = 1,
HP_THREAD_PARKED = 2,
};
struct semaphore_waiter {
struct list_head list;
struct task_struct *task;
bool up;
};
struct rt_mutex {
struct rt_mutex_base rtmutex;
};
enum rtmutex_chainwalk {
RT_MUTEX_MIN_CHAINWALK = 0,
RT_MUTEX_FULL_CHAINWALK = 1,
};
struct rcu_gp_oldstate {
long unsigned int rgos_norm;
long unsigned int rgos_exp;
};
struct sysrq_key_op {
void (* const handler)(int);
const char * const help_msg;
const char * const action_msg;
const int enable_mask;
};
struct rcu_exp_work {
long unsigned int rew_s;
struct work_struct rew_work;
};
struct rcu_node {
raw_spinlock_t lock;
long unsigned int gp_seq;
long unsigned int gp_seq_needed;
long unsigned int completedqs;
long unsigned int qsmask;
long unsigned int rcu_gp_init_mask;
long unsigned int qsmaskinit;
long unsigned int qsmaskinitnext;
long unsigned int expmask;
long unsigned int expmaskinit;
long unsigned int expmaskinitnext;
long unsigned int cbovldmask;
long unsigned int ffmask;
long unsigned int grpmask;
int grplo;
int grphi;
u8 grpnum;
u8 level;
bool wait_blkd_tasks;
struct rcu_node *parent;
struct list_head blkd_tasks;
struct list_head *gp_tasks;
struct list_head *exp_tasks;
struct list_head *boost_tasks;
struct rt_mutex boost_mtx;
long unsigned int boost_time;
struct mutex boost_kthread_mutex;
struct task_struct *boost_kthread_task;
unsigned int boost_kthread_status;
long unsigned int n_boosts;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
raw_spinlock_t fqslock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
spinlock_t exp_lock;
long unsigned int exp_seq_rq;
wait_queue_head_t exp_wq[4];
struct rcu_exp_work rew;
bool exp_need_flush;
raw_spinlock_t exp_poll_lock;
long unsigned int exp_seq_poll_rq;
struct work_struct exp_poll_wq;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
union rcu_noqs {
struct {
u8 norm;
u8 exp;
} b;
u16 s;
};
struct rcu_data {
long unsigned int gp_seq;
long unsigned int gp_seq_needed;
union rcu_noqs cpu_no_qs;
bool core_needs_qs;
bool beenonline;
bool gpwrap;
bool cpu_started;
struct rcu_node *mynode;
long unsigned int grpmask;
long unsigned int ticks_this_gp;
struct irq_work defer_qs_iw;
bool defer_qs_iw_pending;
struct work_struct strict_work;
struct rcu_segcblist cblist;
long int qlen_last_fqs_check;
long unsigned int n_cbs_invoked;
long unsigned int n_force_qs_snap;
long int blimit;
int dynticks_snap;
bool rcu_need_heavy_qs;
bool rcu_urgent_qs;
bool rcu_forced_tick;
bool rcu_forced_tick_exp;
long unsigned int barrier_seq_snap;
struct callback_head barrier_head;
int exp_dynticks_snap;
struct task_struct *rcu_cpu_kthread_task;
unsigned int rcu_cpu_kthread_status;
char rcu_cpu_has_work;
long unsigned int rcuc_activity;
unsigned int softirq_snap;
struct irq_work rcu_iw;
bool rcu_iw_pending;
long unsigned int rcu_iw_gp_seq;
long unsigned int rcu_ofl_gp_seq;
short int rcu_ofl_gp_flags;
long unsigned int rcu_onl_gp_seq;
short int rcu_onl_gp_flags;
long unsigned int last_fqs_resched;
long unsigned int last_sched_clock;
int cpu;
};
struct rcu_state {
struct rcu_node node[1];
struct rcu_node *level[2];
int ncpus;
int n_online_cpus;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long unsigned int gp_seq;
long unsigned int gp_max;
struct task_struct *gp_kthread;
struct swait_queue_head gp_wq;
short int gp_flags;
short int gp_state;
long unsigned int gp_wake_time;
long unsigned int gp_wake_seq;
long unsigned int gp_seq_polled;
long unsigned int gp_seq_polled_snap;
long unsigned int gp_seq_polled_exp_snap;
struct mutex barrier_mutex;
atomic_t barrier_cpu_count;
struct completion barrier_completion;
long unsigned int barrier_sequence;
raw_spinlock_t barrier_lock;
struct mutex exp_mutex;
struct mutex exp_wake_mutex;
long unsigned int expedited_sequence;
atomic_t expedited_need_qs;
struct swait_queue_head expedited_wq;
int ncpus_snap;
u8 cbovld;
u8 cbovldnext;
long unsigned int jiffies_force_qs;
long unsigned int jiffies_kick_kthreads;
long unsigned int n_force_qs;
long unsigned int gp_start;
long unsigned int gp_end;
long unsigned int gp_activity;
long unsigned int gp_req_activity;
long unsigned int jiffies_stall;
long unsigned int jiffies_resched;
long unsigned int n_force_qs_gpstart;
const char *name;
char abbr;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
arch_spinlock_t ofl_lock;
int nocb_is_setup;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum rcutorture_type {
RCU_FLAVOR = 0,
RCU_TASKS_FLAVOR = 1,
RCU_TASKS_RUDE_FLAVOR = 2,
RCU_TASKS_TRACING_FLAVOR = 3,
RCU_TRIVIAL_FLAVOR = 4,
SRCU_FLAVOR = 5,
INVALID_RCU_FLAVOR = 6,
};
struct kvfree_rcu_bulk_data {
long unsigned int nr_records;
struct kvfree_rcu_bulk_data *next;
void *records[0];
};
struct kfree_rcu_cpu;
struct kfree_rcu_cpu_work {
struct rcu_work rcu_work;
struct callback_head *head_free;
struct kvfree_rcu_bulk_data *bkvhead_free[2];
struct kfree_rcu_cpu *krcp;
};
struct kfree_rcu_cpu {
struct callback_head *head;
struct kvfree_rcu_bulk_data *bkvhead[2];
struct kfree_rcu_cpu_work krw_arr[2];
raw_spinlock_t lock;
struct delayed_work monitor_work;
bool initialized;
int count;
struct delayed_work page_cache_work;
atomic_t backoff_page_cache_fill;
atomic_t work_in_progress;
struct hrtimer hrtimer;
struct llist_head bkvcache;
int nr_bkv_objs;
};
enum rseq_cpu_id_state {
RSEQ_CPU_ID_UNINITIALIZED = -1,
RSEQ_CPU_ID_REGISTRATION_FAILED = -2,
};
enum rseq_flags {
RSEQ_FLAG_UNREGISTER = 1,
};
enum rseq_cs_flags {
RSEQ_CS_FLAG_NO_RESTART_ON_PREEMPT = 1,
RSEQ_CS_FLAG_NO_RESTART_ON_SIGNAL = 2,
RSEQ_CS_FLAG_NO_RESTART_ON_MIGRATE = 4,
};
struct rseq_cs {
__u32 version;
__u32 flags;
__u64 start_ip;
__u64 post_commit_offset;
__u64 abort_ip;
};
struct trace_event_raw_rseq_update {
struct trace_entry ent;
s32 cpu_id;
char __data[0];
};
struct trace_event_raw_rseq_ip_fixup {
struct trace_entry ent;
long unsigned int regs_ip;
long unsigned int start_ip;
long unsigned int post_commit_offset;
long unsigned int abort_ip;
char __data[0];
};
struct trace_event_data_offsets_rseq_update {};
struct trace_event_data_offsets_rseq_ip_fixup {};
typedef void (*btf_trace_rseq_update)(void *, struct task_struct *);
typedef void (*btf_trace_rseq_ip_fixup)(void *, long unsigned int, long unsigned int, long unsigned int, long unsigned int);
struct shmem_sb_info {
long unsigned int max_blocks;
long: 32;
struct percpu_counter used_blocks;
long unsigned int max_inodes;
long unsigned int free_inodes;
raw_spinlock_t stat_lock;
umode_t mode;
unsigned char huge;
kuid_t uid;
kgid_t gid;
bool full_inums;
ino_t next_ino;
ino_t *ino_batch;
struct mempolicy *mpol;
spinlock_t shrinklist_lock;
struct list_head shrinklist;
long unsigned int shrinklist_len;
};
enum sgp_type {
SGP_READ = 0,
SGP_NOALLOC = 1,
SGP_CACHE = 2,
SGP_WRITE = 3,
SGP_FALLOC = 4,
};
struct shmem_falloc {
wait_queue_head_t *waitq;
long unsigned int start;
long unsigned int next;
long unsigned int nr_falloced;
long unsigned int nr_unswapped;
};
struct shmem_options {
long long unsigned int blocks;
long long unsigned int inodes;
struct mempolicy *mpol;
kuid_t uid;
kgid_t gid;
umode_t mode;
bool full_inums;
int huge;
int seen;
};
enum shmem_param {
Opt_gid___5 = 0,
Opt_huge = 1,
Opt_mode___4 = 2,
Opt_mpol = 3,
Opt_nr_blocks = 4,
Opt_nr_inodes = 5,
Opt_size = 6,
Opt_uid___4 = 7,
Opt_inode32 = 8,
Opt_inode64 = 9,
};
struct saved {
struct path link;
struct delayed_call done;
const char *name;
unsigned int seq;
};
struct nameidata {
struct path path;
struct qstr last;
struct path root;
struct inode *inode;
unsigned int flags;
unsigned int state;
unsigned int seq;
unsigned int next_seq;
unsigned int m_seq;
unsigned int r_seq;
int last_type;
unsigned int depth;
int total_link_count;
struct saved *stack;
struct saved internal[2];
struct filename *name;
struct nameidata *saved;
unsigned int root_seq;
int dfd;
kuid_t dir_uid;
umode_t dir_mode;
long: 32;
};
enum {
LAST_NORM = 0,
LAST_ROOT = 1,
LAST_DOT = 2,
LAST_DOTDOT = 3,
};
enum {
WALK_TRAILING = 1,
WALK_MORE = 2,
WALK_NOFOLLOW = 4,
};
struct wake_irq;
struct wakeup_source {
const char *name;
int id;
struct list_head entry;
spinlock_t lock;
struct wake_irq *wakeirq;
struct timer_list timer;
long unsigned int timer_expires;
ktime_t total_time;
ktime_t max_time;
ktime_t last_time;
ktime_t start_prevent_time;
ktime_t prevent_sleep_time;
long unsigned int event_count;
long unsigned int active_count;
long unsigned int relax_count;
long unsigned int expire_count;
long unsigned int wakeup_count;
struct device *dev;
bool active: 1;
bool autosleep_enabled: 1;
long: 32;
};
struct epoll_filefd {
struct file *file;
int fd;
};
struct epitem;
struct eppoll_entry {
struct eppoll_entry *next;
struct epitem *base;
wait_queue_entry_t wait;
wait_queue_head_t *whead;
};
struct eventpoll;
struct epitem {
union {
struct rb_node rbn;
struct callback_head rcu;
};
struct list_head rdllink;
struct epitem *next;
struct epoll_filefd ffd;
struct eppoll_entry *pwqlist;
struct eventpoll *ep;
struct hlist_node fllink;
struct wakeup_source *ws;
long: 32;
struct epoll_event event;
};
struct eventpoll {
struct mutex mtx;
wait_queue_head_t wq;
wait_queue_head_t poll_wait;
struct list_head rdllist;
rwlock_t lock;
struct rb_root_cached rbr;
struct epitem *ovflist;
struct wakeup_source *ws;
struct user_struct *user;
struct file *file;
u64 gen;
struct hlist_head refs;
unsigned int napi_id;
};
struct ep_pqueue {
poll_table pt;
struct epitem *epi;
};
struct epitems_head {
struct hlist_head epitems;
struct epitems_head *next;
};
struct kernfs_open_node {
struct callback_head callback_head;
atomic_t event;
wait_queue_head_t poll;
struct list_head files;
unsigned int nr_mmapped;
unsigned int nr_to_release;
};
typedef __kernel_mode_t mode_t;
struct dx_hash_info {
u32 hash;
u32 minor_hash;
int hash_version;
u32 *seed;
};
struct orlov_stats {
__u64 free_clusters;
__u32 free_inodes;
__u32 used_dirs;
};
struct proc_nfs_info {
int flag;
const char *str;
const char *nostr;
};
struct getdents_callback___2 {
struct dir_context ctx;
char *name;
long: 32;
u64 ino;
int found;
int sequence;
};
struct nlm_lookup_host_info {
const int server;
const struct sockaddr *sap;
const size_t salen;
const short unsigned int protocol;
const u32 version;
const char *hostname;
const size_t hostname_len;
const int noresvport;
struct net *net;
const struct cred *cred;
};
struct ipc_proc_iface {
const char *path;
const char *header;
int ids;
int (*show)(struct seq_file *, void *);
};
struct ipc_proc_iter {
struct ipc_namespace *ns;
struct pid_namespace *pid_ns;
struct ipc_proc_iface *iface;
};
struct crypto_comp {
struct crypto_tfm base;
};
struct crypto_attr_alg {
char name[128];
};
struct crypto_attr_type {
u32 type;
u32 mask;
};
enum {
CRYPTOA_UNSPEC = 0,
CRYPTOA_ALG = 1,
CRYPTOA_TYPE = 2,
__CRYPTOA_MAX = 3,
};
struct cryptomgr_param {
struct rtattr *tb[34];
struct {
struct rtattr attr;
struct crypto_attr_type data;
} type;
struct {
struct rtattr attr;
struct crypto_attr_alg data;
} attrs[32];
char template[128];
struct crypto_larval *larval;
u32 otype;
u32 omask;
};
struct crypto_test_param {
char driver[128];
char alg[128];
u32 type;
};
struct show_busy_params {
struct seq_file *m;
struct blk_mq_hw_ctx *hctx;
};
struct io_uring_rsrc_update {
__u32 offset;
__u32 resv;
__u64 data;
};
enum lzma_state {
STATE_LIT_LIT = 0,
STATE_MATCH_LIT_LIT = 1,
STATE_REP_LIT_LIT = 2,
STATE_SHORTREP_LIT_LIT = 3,
STATE_MATCH_LIT = 4,
STATE_REP_LIT = 5,
STATE_SHORTREP_LIT = 6,
STATE_LIT_MATCH = 7,
STATE_LIT_LONGREP = 8,
STATE_LIT_SHORTREP = 9,
STATE_NONLIT_MATCH = 10,
STATE_NONLIT_REP = 11,
};
struct dictionary {
uint8_t *buf;
size_t start;
size_t pos;
size_t full;
size_t limit;
size_t end;
uint32_t size;
uint32_t size_max;
uint32_t allocated;
enum xz_mode mode;
};
struct rc_dec {
uint32_t range;
uint32_t code;
uint32_t init_bytes_left;
const uint8_t *in;
size_t in_pos;
size_t in_limit;
};
struct lzma_len_dec {
uint16_t choice;
uint16_t choice2;
uint16_t low[128];
uint16_t mid[128];
uint16_t high[256];
};
struct lzma_dec {
uint32_t rep0;
uint32_t rep1;
uint32_t rep2;
uint32_t rep3;
enum lzma_state state;
uint32_t len;
uint32_t lc;
uint32_t literal_pos_mask;
uint32_t pos_mask;
uint16_t is_match[192];
uint16_t is_rep[12];
uint16_t is_rep0[12];
uint16_t is_rep1[12];
uint16_t is_rep2[12];
uint16_t is_rep0_long[192];
uint16_t dist_slot[256];
uint16_t dist_special[114];
uint16_t dist_align[16];
struct lzma_len_dec match_len_dec;
struct lzma_len_dec rep_len_dec;
uint16_t literal[12288];
};
enum lzma2_seq {
SEQ_CONTROL = 0,
SEQ_UNCOMPRESSED_1 = 1,
SEQ_UNCOMPRESSED_2 = 2,
SEQ_COMPRESSED_0 = 3,
SEQ_COMPRESSED_1 = 4,
SEQ_PROPERTIES = 5,
SEQ_LZMA_PREPARE = 6,
SEQ_LZMA_RUN = 7,
SEQ_COPY = 8,
};
struct lzma2_dec {
enum lzma2_seq sequence;
enum lzma2_seq next_sequence;
uint32_t uncompressed;
uint32_t compressed;
bool need_dict_reset;
bool need_props;
};
struct xz_dec_lzma2 {
struct rc_dec rc;
struct dictionary dict;
struct lzma2_dec lzma2;
struct lzma_dec lzma;
struct {
uint32_t size;
uint8_t buf[63];
} temp;
};
struct gcry_mpi_point {
MPI x;
MPI y;
MPI z;
};
typedef struct gcry_mpi_point *MPI_POINT;
enum gcry_mpi_ec_models {
MPI_EC_WEIERSTRASS = 0,
MPI_EC_MONTGOMERY = 1,
MPI_EC_EDWARDS = 2,
};
enum ecc_dialects {
ECC_DIALECT_STANDARD = 0,
ECC_DIALECT_ED25519 = 1,
ECC_DIALECT_SAFECURVE = 2,
};
struct mpi_ec_ctx {
enum gcry_mpi_ec_models model;
enum ecc_dialects dialect;
int flags;
unsigned int nbits;
MPI p;
MPI a;
MPI b;
MPI_POINT G;
MPI n;
unsigned int h;
MPI_POINT Q;
MPI d;
const char *name;
struct {
struct {
unsigned int a_is_pminus3: 1;
unsigned int two_inv_p: 1;
} valid;
int a_is_pminus3;
MPI two_inv_p;
mpi_barrett_t p_barrett;
MPI scratch[11];
} t;
void (*addm)(MPI, MPI, MPI, struct mpi_ec_ctx *);
void (*subm)(MPI, MPI, MPI, struct mpi_ec_ctx *);
void (*mulm)(MPI, MPI, MPI, struct mpi_ec_ctx *);
void (*pow2)(MPI, const MPI, struct mpi_ec_ctx *);
void (*mul2)(MPI, MPI, struct mpi_ec_ctx *);
};
struct field_table {
const char *p;
void (*addm)(MPI, MPI, MPI, struct mpi_ec_ctx *);
void (*subm)(MPI, MPI, MPI, struct mpi_ec_ctx *);
void (*mulm)(MPI, MPI, MPI, struct mpi_ec_ctx *);
void (*mul2)(MPI, MPI, struct mpi_ec_ctx *);
void (*pow2)(MPI, const MPI, struct mpi_ec_ctx *);
};
struct pci_bus_resource {
struct list_head list;
struct resource *res;
unsigned int flags;
};
struct clk_composite {
struct clk_hw hw;
struct clk_ops ops;
struct clk_hw *mux_hw;
struct clk_hw *rate_hw;
struct clk_hw *gate_hw;
const struct clk_ops *mux_ops;
const struct clk_ops *rate_ops;
const struct clk_ops *gate_ops;
};
struct memdev {
const char *name;
umode_t mode;
const struct file_operations *fops;
fmode_t fmode;
};
struct container_dev {
struct device dev;
int (*offline)(struct container_dev *);
long: 32;
};
struct request_sense;
struct cdrom_generic_command {
unsigned char cmd[12];
unsigned char *buffer;
unsigned int buflen;
int stat;
struct request_sense *sense;
unsigned char data_direction;
int quiet;
int timeout;
union {
void *reserved[1];
void *unused;
};
};
struct request_sense {
__u8 error_code: 7;
__u8 valid: 1;
__u8 segment_number;
__u8 sense_key: 4;
__u8 reserved2: 1;
__u8 ili: 1;
__u8 reserved1: 2;
__u8 information[4];
__u8 add_sense_len;
__u8 command_info[4];
__u8 asc;
__u8 ascq;
__u8 fruc;
__u8 sks[3];
__u8 asb[46];
};
enum scsi_msg_byte {
COMMAND_COMPLETE = 0,
EXTENDED_MESSAGE = 1,
SAVE_POINTERS = 2,
RESTORE_POINTERS = 3,
DISCONNECT = 4,
INITIATOR_ERROR = 5,
ABORT_TASK_SET = 6,
MESSAGE_REJECT = 7,
NOP = 8,
MSG_PARITY_ERROR = 9,
LINKED_CMD_COMPLETE = 10,
LINKED_FLG_CMD_COMPLETE = 11,
TARGET_RESET = 12,
ABORT_TASK = 13,
CLEAR_TASK_SET = 14,
INITIATE_RECOVERY = 15,
RELEASE_RECOVERY = 16,
TERMINATE_IO_PROC = 17,
CLEAR_ACA = 22,
LOGICAL_UNIT_RESET = 23,
SIMPLE_QUEUE_TAG = 32,
HEAD_OF_QUEUE_TAG = 33,
ORDERED_QUEUE_TAG = 34,
IGNORE_WIDE_RESIDUE = 35,
ACA = 36,
QAS_REQUEST = 85,
BUS_DEVICE_RESET = 12,
ABORT = 6,
};
struct scsi_ioctl_command {
unsigned int inlen;
unsigned int outlen;
unsigned char data[0];
};
struct scsi_idlun {
__u32 dev_id;
__u32 host_unique_id;
};
struct sg_io_hdr {
int interface_id;
int dxfer_direction;
unsigned char cmd_len;
unsigned char mx_sb_len;
short unsigned int iovec_count;
unsigned int dxfer_len;
void *dxferp;
unsigned char *cmdp;
void *sbp;
unsigned int timeout;
unsigned int flags;
int pack_id;
void *usr_ptr;
unsigned char status;
unsigned char masked_status;
unsigned char msg_status;
unsigned char sb_len_wr;
short unsigned int host_status;
short unsigned int driver_status;
int resid;
unsigned int duration;
unsigned int info;
};
struct pci_bits {
unsigned int reg;
unsigned int width;
long unsigned int mask;
long unsigned int val;
};
enum {
PIIX_IOCFG = 84,
ICH5_PMR = 144,
ICH5_PCS = 146,
PIIX_SIDPR_BAR = 5,
PIIX_SIDPR_LEN = 16,
PIIX_SIDPR_IDX = 0,
PIIX_SIDPR_DATA = 4,
PIIX_FLAG_CHECKINTR = 268435456,
PIIX_FLAG_SIDPR = 536870912,
PIIX_PATA_FLAGS = 1,
PIIX_SATA_FLAGS = 268435458,
PIIX_FLAG_PIO16 = 1073741824,
PIIX_80C_PRI = 48,
PIIX_80C_SEC = 192,
P0 = 0,
P1 = 1,
P2 = 2,
P3 = 3,
IDE = -1,
NA = -2,
RV = -3,
PIIX_AHCI_DEVICE = 6,
PIIX_HOST_BROKEN_SUSPEND = 16777216,
};
enum piix_controller_ids {
piix_pata_mwdma = 0,
piix_pata_33 = 1,
ich_pata_33 = 2,
ich_pata_66 = 3,
ich_pata_100 = 4,
ich_pata_100_nomwdma1 = 5,
ich5_sata = 6,
ich6_sata = 7,
ich6m_sata = 8,
ich8_sata = 9,
ich8_2port_sata = 10,
ich8m_apple_sata = 11,
tolapai_sata = 12,
piix_pata_vmw = 13,
ich8_sata_snb = 14,
ich8_2port_sata_snb = 15,
ich8_2port_sata_byt = 16,
};
struct piix_map_db {
const u32 mask;
const u16 port_enable;
const int map[0];
};
struct piix_host_priv {
const int *map;
u32 saved_iocfg;
void *sidpr;
};
struct ich_laptop {
u16 device;
u16 subvendor;
u16 subdevice;
};
struct finger_pos {
unsigned int x;
unsigned int y;
};
struct elantech_device_info {
unsigned char capabilities[3];
unsigned char samples[3];
unsigned char debug;
unsigned char hw_version;
unsigned char pattern;
unsigned int fw_version;
unsigned int ic_version;
unsigned int product_id;
unsigned int x_min;
unsigned int y_min;
unsigned int x_max;
unsigned int y_max;
unsigned int x_res;
unsigned int y_res;
unsigned int x_traces;
unsigned int y_traces;
unsigned int width;
unsigned int bus;
bool paritycheck;
bool jumpy_cursor;
bool reports_pressure;
bool crc_enabled;
bool set_hw_resolution;
bool has_trackpoint;
bool has_middle_button;
int (*send_cmd)(struct psmouse *, unsigned char, unsigned char *);
};
struct elantech_data {
struct input_dev *tp_dev;
char tp_phys[32];
unsigned char reg_07;
unsigned char reg_10;
unsigned char reg_11;
unsigned char reg_20;
unsigned char reg_21;
unsigned char reg_22;
unsigned char reg_23;
unsigned char reg_24;
unsigned char reg_25;
unsigned char reg_26;
unsigned int single_finger_reports;
unsigned int y_max;
unsigned int width;
struct finger_pos mt[5];
unsigned char parity[256];
struct elantech_device_info info;
void (*original_set_rate)(struct psmouse *, unsigned int);
};
struct elantech_attr_data {
size_t field_offset;
unsigned char reg;
};
struct gnet_estimator {
signed char interval;
unsigned char ewma_log;
};
struct net_rate_estimator {
struct gnet_stats_basic_sync *bstats;
spinlock_t *stats_lock;
bool running;
struct gnet_stats_basic_sync *cpu_bstats;
u8 ewma_log;
u8 intvl_log;
seqcount_t seq;
u64 last_packets;
u64 last_bytes;
u64 avpps;
u64 avbps;
long unsigned int next_jiffies;
struct timer_list timer;
struct callback_head rcu;
};
struct tso_t {
int next_frag_idx;
int size;
void *data;
u16 ip_id;
u8 tlen;
bool ipv6;
u32 tcp_seq;
};
struct ethtool_value {
__u32 cmd;
__u32 data;
};
enum tunable_type_id {
ETHTOOL_TUNABLE_UNSPEC = 0,
ETHTOOL_TUNABLE_U8 = 1,
ETHTOOL_TUNABLE_U16 = 2,
ETHTOOL_TUNABLE_U32 = 3,
ETHTOOL_TUNABLE_U64 = 4,
ETHTOOL_TUNABLE_STRING = 5,
ETHTOOL_TUNABLE_S8 = 6,
ETHTOOL_TUNABLE_S16 = 7,
ETHTOOL_TUNABLE_S32 = 8,
ETHTOOL_TUNABLE_S64 = 9,
};
struct ethtool_gstrings {
__u32 cmd;
__u32 string_set;
__u32 len;
__u8 data[0];
};
struct ethtool_sset_info {
__u32 cmd;
__u32 reserved;
__u64 sset_mask;
__u32 data[0];
};
struct ethtool_perm_addr {
__u32 cmd;
__u32 size;
__u8 data[0];
};
enum ethtool_flags {
ETH_FLAG_TXVLAN = 128,
ETH_FLAG_RXVLAN = 256,
ETH_FLAG_LRO = 32768,
ETH_FLAG_NTUPLE = 134217728,
ETH_FLAG_RXHASH = 268435456,
};
struct ethtool_rxfh {
__u32 cmd;
__u32 rss_context;
__u32 indir_size;
__u32 key_size;
__u8 hfunc;
__u8 rsvd8[3];
__u32 rsvd32;
__u32 rss_config[0];
};
struct ethtool_get_features_block {
__u32 available;
__u32 requested;
__u32 active;
__u32 never_changed;
};
struct ethtool_gfeatures {
__u32 cmd;
__u32 size;
struct ethtool_get_features_block features[0];
};
struct ethtool_set_features_block {
__u32 valid;
__u32 requested;
};
struct ethtool_sfeatures {
__u32 cmd;
__u32 size;
struct ethtool_set_features_block features[0];
};
enum ethtool_sfeatures_retval_bits {
ETHTOOL_F_UNSUPPORTED__BIT = 0,
ETHTOOL_F_WISH__BIT = 1,
ETHTOOL_F_COMPAT__BIT = 2,
};
struct ethtool_per_queue_op {
__u32 cmd;
__u32 sub_command;
__u32 queue_mask[128];
char data[0];
};
enum ethtool_fec_config_bits {
ETHTOOL_FEC_NONE_BIT = 0,
ETHTOOL_FEC_AUTO_BIT = 1,
ETHTOOL_FEC_OFF_BIT = 2,
ETHTOOL_FEC_RS_BIT = 3,
ETHTOOL_FEC_BASER_BIT = 4,
ETHTOOL_FEC_LLRS_BIT = 5,
};
struct flow_rule;
struct ethtool_rx_flow_rule {
struct flow_rule *rule;
long unsigned int priv[0];
};
struct flow_match {
struct flow_dissector *dissector;
void *mask;
void *key;
};
struct flow_rule {
struct flow_match match;
long: 32;
struct flow_action action;
};
struct ethtool_rx_flow_spec_input {
const struct ethtool_rx_flow_spec *fs;
u32 rss_ctx;
};
struct ethtool_devlink_compat {
struct devlink *devlink;
union {
struct ethtool_flash efl;
struct ethtool_drvinfo info;
};
};
struct ethtool_link_usettings {
struct ethtool_link_settings base;
struct {
__u32 supported[3];
__u32 advertising[3];
__u32 lp_advertising[3];
} link_modes;
};
struct ethtool_rx_flow_key {
struct flow_dissector_key_basic basic;
union {
struct flow_dissector_key_ipv4_addrs ipv4;
struct flow_dissector_key_ipv6_addrs ipv6;
};
struct flow_dissector_key_ports tp;
struct flow_dissector_key_ip ip;
struct flow_dissector_key_vlan vlan;
struct flow_dissector_key_eth_addrs eth_addrs;
};
struct ethtool_rx_flow_match {
struct flow_dissector dissector;
struct ethtool_rx_flow_key key;
struct ethtool_rx_flow_key mask;
};
enum tunnel_encap_types {
TUNNEL_ENCAP_NONE = 0,
TUNNEL_ENCAP_FOU = 1,
TUNNEL_ENCAP_GUE = 2,
TUNNEL_ENCAP_MPLS = 3,
};
struct tnl_ptk_info {
__be16 flags;
__be16 proto;
__be32 key;
__be32 seq;
int hdr_len;
};
struct ip_tunnel_net {
struct net_device *fb_tunnel_dev;
struct rtnl_link_ops *rtnl_link_ops;
struct hlist_head tunnels[128];
struct ip_tunnel *collect_md_tun;
int type;
};
struct xfrmk_sadinfo {
u32 sadhcnt;
u32 sadhmcnt;
u32 sadcnt;
};
struct xfrm_translator {
int (*alloc_compat)(struct sk_buff *, const struct nlmsghdr *);
struct nlmsghdr * (*rcv_msg_compat)(const struct nlmsghdr *, int, const struct nla_policy *, struct netlink_ext_ack *);
int (*xlate_user_policy_sockptr)(u8 **, int);
struct module *owner;
};
struct rpc_cred_cache {
struct hlist_head *hashtable;
unsigned int hashbits;
spinlock_t lock;
};
struct mips_elf_abiflags_v0 {
uint16_t version;
uint8_t isa_level;
uint8_t isa_rev;
uint8_t gpr_size;
uint8_t cpr1_size;
uint8_t cpr2_size;
uint8_t fp_abi;
uint32_t isa_ext;
uint32_t ases;
uint32_t flags1;
uint32_t flags2;
};
enum {
FP_FRE = 0,
FP_FR0 = 1,
FP_FR1 = 2,
};
struct mode_req {
bool single;
bool soft;
bool fr1;
bool frdefault;
bool fre;
};
enum perf_sample_regs_abi {
PERF_SAMPLE_REGS_ABI_NONE = 0,
PERF_SAMPLE_REGS_ABI_32 = 1,
PERF_SAMPLE_REGS_ABI_64 = 2,
};
enum perf_event_mips_regs {
PERF_REG_MIPS_PC = 0,
PERF_REG_MIPS_R1 = 1,
PERF_REG_MIPS_R2 = 2,
PERF_REG_MIPS_R3 = 3,
PERF_REG_MIPS_R4 = 4,
PERF_REG_MIPS_R5 = 5,
PERF_REG_MIPS_R6 = 6,
PERF_REG_MIPS_R7 = 7,
PERF_REG_MIPS_R8 = 8,
PERF_REG_MIPS_R9 = 9,
PERF_REG_MIPS_R10 = 10,
PERF_REG_MIPS_R11 = 11,
PERF_REG_MIPS_R12 = 12,
PERF_REG_MIPS_R13 = 13,
PERF_REG_MIPS_R14 = 14,
PERF_REG_MIPS_R15 = 15,
PERF_REG_MIPS_R16 = 16,
PERF_REG_MIPS_R17 = 17,
PERF_REG_MIPS_R18 = 18,
PERF_REG_MIPS_R19 = 19,
PERF_REG_MIPS_R20 = 20,
PERF_REG_MIPS_R21 = 21,
PERF_REG_MIPS_R22 = 22,
PERF_REG_MIPS_R23 = 23,
PERF_REG_MIPS_R24 = 24,
PERF_REG_MIPS_R25 = 25,
PERF_REG_MIPS_R26 = 26,
PERF_REG_MIPS_R27 = 27,
PERF_REG_MIPS_R28 = 28,
PERF_REG_MIPS_R29 = 29,
PERF_REG_MIPS_R30 = 30,
PERF_REG_MIPS_R31 = 31,
PERF_REG_MIPS_MAX = 32,
};
struct trace_event_raw_cpuhp_enter {
struct trace_entry ent;
unsigned int cpu;
int target;
int idx;
void *fun;
char __data[0];
};
struct trace_event_raw_cpuhp_multi_enter {
struct trace_entry ent;
unsigned int cpu;
int target;
int idx;
void *fun;
char __data[0];
};
struct trace_event_raw_cpuhp_exit {
struct trace_entry ent;
unsigned int cpu;
int state;
int idx;
int ret;
char __data[0];
};
struct trace_event_data_offsets_cpuhp_enter {};
struct trace_event_data_offsets_cpuhp_multi_enter {};
struct trace_event_data_offsets_cpuhp_exit {};
typedef void (*btf_trace_cpuhp_enter)(void *, unsigned int, int, int, int (*)(unsigned int));
typedef void (*btf_trace_cpuhp_multi_enter)(void *, unsigned int, int, int, int (*)(unsigned int, struct hlist_node *), struct hlist_node *);
typedef void (*btf_trace_cpuhp_exit)(void *, unsigned int, int, int, int);
struct cpuhp_cpu_state {
enum cpuhp_state state;
enum cpuhp_state target;
enum cpuhp_state fail;
struct task_struct *thread;
bool should_run;
bool rollback;
bool single;
bool bringup;
struct hlist_node *node;
struct hlist_node *last;
enum cpuhp_state cb_state;
int result;
struct completion done_up;
struct completion done_down;
};
struct cpuhp_step {
const char *name;
union {
int (*single)(unsigned int);
int (*multi)(unsigned int, struct hlist_node *);
} startup;
union {
int (*single)(unsigned int);
int (*multi)(unsigned int, struct hlist_node *);
} teardown;
struct hlist_head list;
bool cant_stop;
bool multi_instance;
};
enum cpu_mitigations {
CPU_MITIGATIONS_OFF = 0,
CPU_MITIGATIONS_AUTO = 1,
CPU_MITIGATIONS_AUTO_NOSMT = 2,
};
struct kmsg_dump_iter {
u64 cur_seq;
u64 next_seq;
};
struct kmsg_dumper {
struct list_head list;
void (*dump)(struct kmsg_dumper *, enum kmsg_dump_reason);
enum kmsg_dump_reason max_reason;
bool registered;
};
struct trace_event_raw_console {
struct trace_entry ent;
u32 __data_loc_msg;
char __data[0];
};
struct trace_event_data_offsets_console {
u32 msg;
};
typedef void (*btf_trace_console)(void *, const char *, size_t);
struct printk_info {
u64 seq;
u64 ts_nsec;
u16 text_len;
u8 facility;
u8 flags: 5;
u8 level: 3;
u32 caller_id;
struct dev_printk_info dev_info;
};
struct printk_record {
struct printk_info *info;
char *text_buf;
unsigned int text_buf_size;
};
struct prb_data_blk_lpos {
long unsigned int begin;
long unsigned int next;
};
struct prb_desc {
atomic_long_t state_var;
struct prb_data_blk_lpos text_blk_lpos;
};
struct prb_data_ring {
unsigned int size_bits;
char *data;
atomic_long_t head_lpos;
atomic_long_t tail_lpos;
};
struct prb_desc_ring {
unsigned int count_bits;
struct prb_desc *descs;
struct printk_info *infos;
atomic_long_t head_id;
atomic_long_t tail_id;
atomic_long_t last_finalized_id;
};
struct printk_ringbuffer {
struct prb_desc_ring desc_ring;
struct prb_data_ring text_data_ring;
atomic_long_t fail;
};
struct prb_reserved_entry {
struct printk_ringbuffer *rb;
long unsigned int irqflags;
long unsigned int id;
unsigned int text_space;
};
enum desc_state {
desc_miss = -1,
desc_reserved = 0,
desc_committed = 1,
desc_finalized = 2,
desc_reusable = 3,
};
struct console_cmdline {
char name[16];
int index;
bool user_specified;
char *options;
};
enum printk_info_flags {
LOG_NEWLINE = 2,
LOG_CONT = 8,
};
enum devkmsg_log_bits {
__DEVKMSG_LOG_BIT_ON = 0,
__DEVKMSG_LOG_BIT_OFF = 1,
__DEVKMSG_LOG_BIT_LOCK = 2,
};
enum devkmsg_log_masks {
DEVKMSG_LOG_MASK_ON = 1,
DEVKMSG_LOG_MASK_OFF = 2,
DEVKMSG_LOG_MASK_LOCK = 4,
};
enum con_msg_format_flags {
MSG_FORMAT_DEFAULT = 0,
MSG_FORMAT_SYSLOG = 1,
};
struct latched_seq {
seqcount_latch_t latch;
long: 32;
u64 val[2];
};
struct devkmsg_user {
atomic64_t seq;
struct ratelimit_state rs;
struct mutex lock;
char buf[8192];
long: 32;
struct printk_info info;
char text_buf[8192];
struct printk_record record;
long: 32;
};
enum {
Q_REQUEUE_PI_NONE = 0,
Q_REQUEUE_PI_IGNORE = 1,
Q_REQUEUE_PI_IN_PROGRESS = 2,
Q_REQUEUE_PI_WAIT = 3,
Q_REQUEUE_PI_DONE = 4,
Q_REQUEUE_PI_LOCKED = 5,
};
struct cpu_stop_done {
atomic_t nr_todo;
int ret;
struct completion completion;
};
struct cpu_stopper {
struct task_struct *thread;
raw_spinlock_t lock;
bool enabled;
struct list_head works;
struct cpu_stop_work stop_work;
long unsigned int caller;
cpu_stop_fn_t fn;
};
enum multi_stop_state {
MULTI_STOP_NONE = 0,
MULTI_STOP_PREPARE = 1,
MULTI_STOP_DISABLE_IRQ = 2,
MULTI_STOP_RUN = 3,
MULTI_STOP_EXIT = 4,
};
struct multi_stop_data {
cpu_stop_fn_t fn;
void *data;
unsigned int num_threads;
const struct cpumask *active_cpus;
enum multi_stop_state state;
atomic_t thread_ack;
};
struct stat_node {
struct rb_node node;
void *stat;
};
struct stat_session {
struct list_head session_list;
struct tracer_stat *ts;
struct rb_root stat_root;
struct mutex stat_mutex;
struct dentry *file;
};
enum dynevent_type {
DYNEVENT_TYPE_SYNTH = 1,
DYNEVENT_TYPE_KPROBE = 2,
DYNEVENT_TYPE_NONE = 3,
};
struct dynevent_cmd;
typedef int (*dynevent_create_fn_t)(struct dynevent_cmd *);
struct dynevent_cmd {
struct seq_buf seq;
const char *event_name;
unsigned int n_fields;
enum dynevent_type type;
dynevent_create_fn_t run_command;
void *private_data;
long: 32;
};
typedef int (*dynevent_check_arg_fn_t)(void *);
struct dynevent_arg {
const char *str;
char separator;
};
struct dynevent_arg_pair {
const char *lhs;
const char *rhs;
char operator;
char separator;
};
struct bpf_spin_lock {
__u32 val;
};
struct bpf_timer {
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_dynptr {
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_pidns_info {
__u32 pid;
__u32 tgid;
};
typedef u64 (*btf_bpf_map_lookup_elem)(struct bpf_map *, void *);
typedef u64 (*btf_bpf_map_update_elem)(struct bpf_map *, void *, void *, u64);
typedef u64 (*btf_bpf_map_delete_elem)(struct bpf_map *, void *);
typedef u64 (*btf_bpf_map_push_elem)(struct bpf_map *, void *, u64);
typedef u64 (*btf_bpf_map_pop_elem)(struct bpf_map *, void *);
typedef u64 (*btf_bpf_map_peek_elem)(struct bpf_map *, void *);
typedef u64 (*btf_bpf_map_lookup_percpu_elem)(struct bpf_map *, void *, u32);
typedef u64 (*btf_bpf_get_smp_processor_id)();
typedef u64 (*btf_bpf_get_numa_node_id)();
typedef u64 (*btf_bpf_ktime_get_ns)();
typedef u64 (*btf_bpf_ktime_get_boot_ns)();
typedef u64 (*btf_bpf_ktime_get_coarse_ns)();
typedef u64 (*btf_bpf_ktime_get_tai_ns)();
typedef u64 (*btf_bpf_get_current_pid_tgid)();
typedef u64 (*btf_bpf_get_current_uid_gid)();
typedef u64 (*btf_bpf_get_current_comm)(char *, u32);
typedef u64 (*btf_bpf_spin_lock)(struct bpf_spin_lock *);
typedef u64 (*btf_bpf_spin_unlock)(struct bpf_spin_lock *);
typedef u64 (*btf_bpf_jiffies64)();
typedef u64 (*btf_bpf_get_current_cgroup_id)();
typedef u64 (*btf_bpf_get_current_ancestor_cgroup_id)(int);
typedef u64 (*btf_bpf_strtol)(const char *, size_t, u64, long int *);
typedef u64 (*btf_bpf_strtoul)(const char *, size_t, u64, long unsigned int *);
typedef u64 (*btf_bpf_strncmp)(const char *, u32, const char *);
typedef u64 (*btf_bpf_get_ns_current_pid_tgid)(u64, u64, struct bpf_pidns_info *, u32);
typedef u64 (*btf_bpf_event_output_data)(void *, struct bpf_map *, u64, void *, u64);
typedef u64 (*btf_bpf_copy_from_user)(void *, u32, const void *);
typedef u64 (*btf_bpf_copy_from_user_task)(void *, u32, const void *, struct task_struct *, u64);
typedef u64 (*btf_bpf_per_cpu_ptr)(const void *, u32);
typedef u64 (*btf_bpf_this_cpu_ptr)(const void *);
struct bpf_bprintf_buffers {
char tmp_bufs[1536];
};
typedef u64 (*btf_bpf_snprintf)(char *, u32, char *, const void *, u32);
struct bpf_hrtimer {
struct hrtimer timer;
struct bpf_map *map;
struct bpf_prog *prog;
void *callback_fn;
void *value;
};
struct bpf_timer_kern {
struct bpf_hrtimer *timer;
struct bpf_spin_lock lock;
};
typedef u64 (*btf_bpf_timer_init)(struct bpf_timer_kern *, struct bpf_map *, u64);
typedef u64 (*btf_bpf_timer_set_callback)(struct bpf_timer_kern *, void *, struct bpf_prog_aux *);
typedef u64 (*btf_bpf_timer_start)(struct bpf_timer_kern *, u64, u64);
typedef u64 (*btf_bpf_timer_cancel)(struct bpf_timer_kern *);
typedef u64 (*btf_bpf_kptr_xchg)(void *, void *);
typedef u64 (*btf_bpf_dynptr_from_mem)(void *, u32, u64, struct bpf_dynptr_kern *);
typedef u64 (*btf_bpf_dynptr_read)(void *, u32, struct bpf_dynptr_kern *, u32, u64);
typedef u64 (*btf_bpf_dynptr_write)(struct bpf_dynptr_kern *, u32, void *, u32, u64);
typedef u64 (*btf_bpf_dynptr_data)(struct bpf_dynptr_kern *, u32, u32);
struct wb_lock_cookie {
bool locked;
long unsigned int flags;
};
struct dirty_throttle_control {
struct bdi_writeback *wb;
struct fprop_local_percpu *wb_completions;
long unsigned int avail;
long unsigned int dirty;
long unsigned int thresh;
long unsigned int bg_thresh;
long unsigned int wb_dirty;
long unsigned int wb_thresh;
long unsigned int wb_bg_thresh;
long unsigned int pos_ratio;
};
enum tlb_flush_reason {
TLB_FLUSH_ON_TASK_SWITCH = 0,
TLB_REMOTE_SHOOTDOWN = 1,
TLB_LOCAL_SHOOTDOWN = 2,
TLB_LOCAL_MM_SHOOTDOWN = 3,
TLB_REMOTE_SEND_IPI = 4,
NR_TLB_FLUSH_REASONS = 5,
};
struct trace_event_raw_tlb_flush {
struct trace_entry ent;
int reason;
long unsigned int pages;
char __data[0];
};
struct trace_event_data_offsets_tlb_flush {};
typedef void (*btf_trace_tlb_flush)(void *, int, long unsigned int);
struct trace_event_raw_mm_migrate_pages {
struct trace_entry ent;
long unsigned int succeeded;
long unsigned int failed;
long unsigned int thp_succeeded;
long unsigned int thp_failed;
long unsigned int thp_split;
enum migrate_mode mode;
int reason;
char __data[0];
};
struct trace_event_raw_mm_migrate_pages_start {
struct trace_entry ent;
enum migrate_mode mode;
int reason;
char __data[0];
};
struct trace_event_raw_migration_pte {
struct trace_entry ent;
long unsigned int addr;
long unsigned int pte;
int order;
char __data[0];
};
struct trace_event_data_offsets_mm_migrate_pages {};
struct trace_event_data_offsets_mm_migrate_pages_start {};
struct trace_event_data_offsets_migration_pte {};
typedef void (*btf_trace_mm_migrate_pages)(void *, long unsigned int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, enum migrate_mode, int);
typedef void (*btf_trace_mm_migrate_pages_start)(void *, enum migrate_mode, int);
typedef void (*btf_trace_set_migration_pte)(void *, long unsigned int, long unsigned int, int);
typedef void (*btf_trace_remove_migration_pte)(void *, long unsigned int, long unsigned int, int);
struct folio_referenced_arg {
int mapcount;
int referenced;
long unsigned int vm_flags;
struct mem_cgroup *memcg;
};
struct file_clone_range {
__s64 src_fd;
__u64 src_offset;
__u64 src_length;
__u64 dest_offset;
};
struct fsxattr {
__u32 fsx_xflags;
__u32 fsx_extsize;
__u32 fsx_nextents;
__u32 fsx_projid;
__u32 fsx_cowextsize;
unsigned char fsx_pad[8];
};
struct space_resv {
__s16 l_type;
__s16 l_whence;
long: 32;
__s64 l_start;
__s64 l_len;
__s32 l_sysid;
__u32 l_pid;
__s32 l_pad[4];
};
typedef long int __kernel_daddr_t;
struct ustat {
__kernel_daddr_t f_tfree;
long unsigned int f_tinode;
char f_fname[6];
char f_fpack[6];
};
struct statfs {
long int f_type;
long int f_bsize;
long int f_frsize;
long int f_blocks;
long int f_bfree;
long int f_files;
long int f_ffree;
long int f_bavail;
__kernel_fsid_t f_fsid;
long int f_namelen;
long int f_flags;
long int f_spare[5];
};
struct statfs64 {
__u32 f_type;
__u32 f_bsize;
__u32 f_frsize;
__u32 __pad;
__u64 f_blocks;
__u64 f_bfree;
__u64 f_files;
__u64 f_ffree;
__u64 f_bavail;
__kernel_fsid_t f_fsid;
__u32 f_namelen;
__u32 f_flags;
__u32 f_spare[5];
long: 32;
};
struct flock {
short int l_type;
short int l_whence;
__kernel_off_t l_start;
__kernel_off_t l_len;
__kernel_pid_t l_pid;
long int l_sysid;
long int pad[4];
};
struct flock64 {
short int l_type;
short int l_whence;
long: 32;
__kernel_loff_t l_start;
__kernel_loff_t l_len;
__kernel_pid_t l_pid;
long: 32;
};
struct trace_event_raw_locks_get_lock_context {
struct trace_entry ent;
long unsigned int i_ino;
dev_t s_dev;
unsigned char type;
struct file_lock_context *ctx;
char __data[0];
};
struct trace_event_raw_filelock_lock {
struct trace_entry ent;
struct file_lock *fl;
long unsigned int i_ino;
dev_t s_dev;
struct file_lock *fl_blocker;
fl_owner_t fl_owner;
unsigned int fl_pid;
unsigned int fl_flags;
unsigned char fl_type;
loff_t fl_start;
loff_t fl_end;
int ret;
char __data[0];
long: 32;
};
struct trace_event_raw_filelock_lease {
struct trace_entry ent;
struct file_lock *fl;
long unsigned int i_ino;
dev_t s_dev;
struct file_lock *fl_blocker;
fl_owner_t fl_owner;
unsigned int fl_flags;
unsigned char fl_type;
long unsigned int fl_break_time;
long unsigned int fl_downgrade_time;
char __data[0];
};
struct trace_event_raw_generic_add_lease {
struct trace_entry ent;
long unsigned int i_ino;
int wcount;
int rcount;
int icount;
dev_t s_dev;
fl_owner_t fl_owner;
unsigned int fl_flags;
unsigned char fl_type;
char __data[0];
};
struct trace_event_raw_leases_conflict {
struct trace_entry ent;
void *lease;
void *breaker;
unsigned int l_fl_flags;
unsigned int b_fl_flags;
unsigned char l_fl_type;
unsigned char b_fl_type;
bool conflict;
char __data[0];
};
struct trace_event_data_offsets_locks_get_lock_context {};
struct trace_event_data_offsets_filelock_lock {};
struct trace_event_data_offsets_filelock_lease {};
struct trace_event_data_offsets_generic_add_lease {};
struct trace_event_data_offsets_leases_conflict {};
typedef void (*btf_trace_locks_get_lock_context)(void *, struct inode *, int, struct file_lock_context *);
typedef void (*btf_trace_posix_lock_inode)(void *, struct inode *, struct file_lock *, int);
typedef void (*btf_trace_fcntl_setlk)(void *, struct inode *, struct file_lock *, int);
typedef void (*btf_trace_locks_remove_posix)(void *, struct inode *, struct file_lock *, int);
typedef void (*btf_trace_flock_lock_inode)(void *, struct inode *, struct file_lock *, int);
typedef void (*btf_trace_break_lease_noblock)(void *, struct inode *, struct file_lock *);
typedef void (*btf_trace_break_lease_block)(void *, struct inode *, struct file_lock *);
typedef void (*btf_trace_break_lease_unblock)(void *, struct inode *, struct file_lock *);
typedef void (*btf_trace_generic_delete_lease)(void *, struct inode *, struct file_lock *);
typedef void (*btf_trace_time_out_leases)(void *, struct inode *, struct file_lock *);
typedef void (*btf_trace_generic_add_lease)(void *, struct inode *, struct file_lock *);
typedef void (*btf_trace_leases_conflict)(void *, bool, struct file_lock *, struct file_lock *);
struct file_lock_list_struct {
spinlock_t lock;
struct hlist_head hlist;
};
struct locks_iterator {
int li_cpu;
long: 32;
loff_t li_pos;
};
struct ext4_io_submit {
struct writeback_control *io_wbc;
struct bio *io_bio;
ext4_io_end_t *io_end;
long: 32;
sector_t io_next_block;
};
struct mpage_da_data {
struct inode *inode;
struct writeback_control *wbc;
long unsigned int first_page;
long unsigned int next_page;
long unsigned int last_page;
long: 32;
struct ext4_map_blocks map;
struct ext4_io_submit io_submit;
unsigned int do_map: 1;
unsigned int scanned_until_end: 1;
long: 32;
};
struct fscrypt_info;
enum {
RC_DROPIT = 0,
RC_REPLY = 1,
RC_DOIT = 2,
};
enum {
NSMPROC_NULL = 0,
NSMPROC_STAT = 1,
NSMPROC_MON = 2,
NSMPROC_UNMON = 3,
NSMPROC_UNMON_ALL = 4,
NSMPROC_SIMU_CRASH = 5,
NSMPROC_NOTIFY = 6,
};
struct nsm_args {
struct nsm_private *priv;
u32 prog;
u32 vers;
u32 proc;
char *mon_name;
const char *nodename;
};
struct nsm_res {
u32 status;
u32 state;
};
struct crypto_report_aead {
char type[64];
char geniv[64];
unsigned int blocksize;
unsigned int maxauthsize;
unsigned int ivsize;
};
struct mq_inflight {
struct block_device *part;
unsigned int inflight[2];
};
struct blk_rq_wait {
struct completion done;
blk_status_t ret;
};
struct flush_busy_ctx_data {
struct blk_mq_hw_ctx *hctx;
struct list_head *list;
};
struct dispatch_rq_data {
struct blk_mq_hw_ctx *hctx;
struct request *rq;
};
enum prep_dispatch {
PREP_DISPATCH_OK = 0,
PREP_DISPATCH_NO_TAG = 1,
PREP_DISPATCH_NO_BUDGET = 2,
};
struct rq_iter_data {
struct blk_mq_hw_ctx *hctx;
bool has_rq;
};
struct blk_mq_qe_pair {
struct list_head node;
struct request_queue *q;
struct elevator_type *type;
};
struct io_sqring_offsets {
__u32 head;
__u32 tail;
__u32 ring_mask;
__u32 ring_entries;
__u32 flags;
__u32 dropped;
__u32 array;
__u32 resv1;
__u64 resv2;
};
struct io_cqring_offsets {
__u32 head;
__u32 tail;
__u32 ring_mask;
__u32 ring_entries;
__u32 overflow;
__u32 cqes;
__u32 flags;
__u32 resv1;
__u64 resv2;
};
struct io_uring_params {
__u32 sq_entries;
__u32 cq_entries;
__u32 flags;
__u32 sq_thread_cpu;
__u32 sq_thread_idle;
__u32 features;
__u32 wq_fd;
__u32 resv[3];
struct io_sqring_offsets sq_off;
struct io_cqring_offsets cq_off;
};
enum {
IO_SQ_THREAD_SHOULD_STOP = 0,
IO_SQ_THREAD_SHOULD_PARK = 1,
};
typedef struct {
BYTE maxTableLog;
BYTE tableType;
BYTE tableLog;
BYTE reserved;
} DTableDesc;
typedef struct {
BYTE byte;
BYTE nbBits;
} HUF_DEltX1;
typedef struct {
U32 rankVal[16];
U32 rankStart[16];
U32 statsWksp[218];
BYTE symbols[256];
BYTE huffWeight[256];
} HUF_ReadDTableX1_Workspace;
typedef struct {
U16 sequence;
BYTE nbBits;
BYTE length;
} HUF_DEltX2;
typedef struct {
BYTE symbol;
BYTE weight;
} sortedSymbol_t;
typedef U32 rankValCol_t[13];
typedef struct {
U32 rankVal[156];
U32 rankStats[13];
U32 rankStart0[14];
sortedSymbol_t sortedSymbol[256];
BYTE weightList[256];
U32 calleeWksp[218];
} HUF_ReadDTableX2_Workspace;
typedef struct {
U32 tableTime;
U32 decode256Time;
} algo_time_t;
typedef long int mpi_limb_signed_t;
struct clk_lookup {
struct list_head node;
const char *dev_id;
const char *con_id;
struct clk *clk;
struct clk_hw *clk_hw;
};
struct clk_lookup_alloc {
struct clk_lookup cl;
char dev_id[20];
char con_id[16];
};
struct serial8250_config {
const char *name;
short unsigned int fifo_size;
short unsigned int tx_loadsz;
unsigned char fcr;
unsigned char rxtrig_bytes[4];
unsigned int flags;
};
struct scsi_eh_save {
int result;
unsigned int resid_len;
int eh_eflags;
enum dma_data_direction data_direction;
unsigned int underflow;
unsigned char cmd_len;
unsigned char prot_op;
unsigned char cmnd[32];
struct scsi_data_buffer sdb;
struct scatterlist sense_sgl;
};
struct mtdblk_dev {
struct mtd_blktrans_dev mbd;
int count;
struct mutex cache_mutex;
unsigned char *cache_data;
long unsigned int cache_offset;
unsigned int cache_size;
enum {
STATE_EMPTY = 0,
STATE_CLEAN = 1,
STATE_DIRTY = 2,
} cache_state;
};
struct focaltech_finger_state {
bool active;
bool valid;
unsigned int x;
unsigned int y;
};
struct focaltech_hw_state {
struct focaltech_finger_state fingers[5];
unsigned int width;
bool pressed;
};
struct focaltech_data {
unsigned int x_max;
unsigned int y_max;
struct focaltech_hw_state state;
};
enum {
NETNSA_NONE = 0,
NETNSA_NSID = 1,
NETNSA_PID = 2,
NETNSA_FD = 3,
NETNSA_TARGET_NSID = 4,
NETNSA_CURRENT_NSID = 5,
__NETNSA_MAX = 6,
};
struct net_fill_args {
u32 portid;
u32 seq;
int flags;
int cmd;
int nsid;
bool add_ref;
int ref_nsid;
};
struct rtnl_net_dump_cb {
struct net *tgt_net;
struct net *ref_net;
struct sk_buff *skb;
struct net_fill_args fillargs;
int idx;
int s_idx;
};
enum gro_result {
GRO_MERGED = 0,
GRO_MERGED_FREE = 1,
GRO_HELD = 2,
GRO_NORMAL = 3,
GRO_CONSUMED = 4,
};
typedef enum gro_result gro_result_t;
struct gro_cell {
struct sk_buff_head napi_skbs;
struct napi_struct napi;
};
struct percpu_free_defer {
struct callback_head rcu;
void *ptr;
};
struct wol_reply_data {
struct ethnl_reply_data base;
struct ethtool_wolinfo wol;
bool show_sopass;
};
struct eeprom_req_info {
struct ethnl_req_info base;
u32 offset;
u32 length;
u8 page;
u8 bank;
u8 i2c_address;
};
struct eeprom_reply_data {
struct ethnl_reply_data base;
u32 length;
u8 *data;
};
struct ip_fraglist_iter {
struct sk_buff *frag;
struct iphdr *iph;
int offset;
unsigned int hlen;
};
struct ip_frag_state {
bool DF;
unsigned int hlen;
unsigned int ll_rs;
unsigned int mtu;
unsigned int left;
int offset;
int ptr;
__be16 not_last_frag;
};
struct inet_diag_sockid {
__be16 idiag_sport;
__be16 idiag_dport;
__be32 idiag_src[4];
__be32 idiag_dst[4];
__u32 idiag_if;
__u32 idiag_cookie[2];
};
struct inet_diag_req_v2 {
__u8 sdiag_family;
__u8 sdiag_protocol;
__u8 idiag_ext;
__u8 pad;
__u32 idiag_states;
struct inet_diag_sockid id;
};
struct inet_diag_msg {
__u8 idiag_family;
__u8 idiag_state;
__u8 idiag_timer;
__u8 idiag_retrans;
struct inet_diag_sockid id;
__u32 idiag_expires;
__u32 idiag_rqueue;
__u32 idiag_wqueue;
__u32 idiag_uid;
__u32 idiag_inode;
};
enum {
INET_DIAG_NONE = 0,
INET_DIAG_MEMINFO = 1,
INET_DIAG_INFO = 2,
INET_DIAG_VEGASINFO = 3,
INET_DIAG_CONG = 4,
INET_DIAG_TOS = 5,
INET_DIAG_TCLASS = 6,
INET_DIAG_SKMEMINFO = 7,
INET_DIAG_SHUTDOWN = 8,
INET_DIAG_DCTCPINFO = 9,
INET_DIAG_PROTOCOL = 10,
INET_DIAG_SKV6ONLY = 11,
INET_DIAG_LOCALS = 12,
INET_DIAG_PEERS = 13,
INET_DIAG_PAD = 14,
INET_DIAG_MARK = 15,
INET_DIAG_BBRINFO = 16,
INET_DIAG_CLASS_ID = 17,
INET_DIAG_MD5SIG = 18,
INET_DIAG_ULP_INFO = 19,
INET_DIAG_SK_BPF_STORAGES = 20,
INET_DIAG_CGROUP_ID = 21,
INET_DIAG_SOCKOPT = 22,
__INET_DIAG_MAX = 23,
};
enum {
INET_ULP_INFO_UNSPEC = 0,
INET_ULP_INFO_NAME = 1,
INET_ULP_INFO_TLS = 2,
INET_ULP_INFO_MPTCP = 3,
__INET_ULP_INFO_MAX = 4,
};
struct inet_diag_handler {
void (*dump)(struct sk_buff *, struct netlink_callback *, const struct inet_diag_req_v2 *);
int (*dump_one)(struct netlink_callback *, const struct inet_diag_req_v2 *);
void (*idiag_get_info)(struct sock *, struct inet_diag_msg *, void *);
int (*idiag_get_aux)(struct sock *, bool, struct sk_buff *);
size_t (*idiag_get_aux_size)(struct sock *, bool);
int (*destroy)(struct sk_buff *, const struct inet_diag_req_v2 *);
__u16 idiag_type;
__u16 idiag_info_size;
};
struct tcp_diag_md5sig {
__u8 tcpm_family;
__u8 tcpm_prefixlen;
__u16 tcpm_keylen;
__be32 tcpm_addr[4];
__u8 tcpm_key[80];
};
struct rpc_inode {
struct inode vfs_inode;
void *private;
struct rpc_pipe *pipe;
wait_queue_head_t waitq;
long: 32;
};
struct thread_deferred_req {
struct cache_deferred_req handle;
struct completion completion;
};
struct cache_queue {
struct list_head list;
int reader;
};
struct cache_request {
struct cache_queue q;
struct cache_head *item;
char *buf;
int len;
int readers;
};
struct cache_reader {
struct cache_queue q;
int offset;
};
enum spec3_op {
ext_op = 0,
dextm_op = 1,
dextu_op = 2,
dext_op = 3,
ins_op = 4,
dinsm_op = 5,
dinsu_op = 6,
dins_op = 7,
yield_op = 9,
lx_op = 10,
lwle_op = 25,
lwre_op = 26,
cachee_op = 27,
sbe_op = 28,
she_op = 29,
sce_op = 30,
swe_op = 31,
bshfl_op = 32,
swle_op = 33,
swre_op = 34,
prefe_op = 35,
dbshfl_op = 36,
cache6_op = 37,
sc6_op = 38,
scd6_op = 39,
lbue_op = 40,
lhue_op = 41,
lbe_op = 44,
lhe_op = 45,
lle_op = 46,
lwe_op = 47,
pref6_op = 53,
ll6_op = 54,
lld6_op = 55,
rdhwr_op = 59,
};
enum lx_func {
lwx_op = 0,
lhx_op = 4,
lbux_op = 6,
ldx_op = 8,
lwux_op = 16,
lhux_op = 20,
lbx_op = 22,
};
enum mm_32b_func {
mm_lwc2_func = 0,
mm_lwp_func = 1,
mm_ldc2_func = 2,
mm_ldp_func = 4,
mm_lwm32_func = 5,
mm_cache_func = 6,
mm_ldm_func = 7,
mm_swc2_func = 8,
mm_swp_func = 9,
mm_sdc2_func = 10,
mm_sdp_func = 12,
mm_swm32_func = 13,
mm_sdm_func = 15,
};
enum mm_32c_func {
mm_pref_func = 2,
mm_ll_func = 3,
mm_swr_func = 9,
mm_sc_func = 11,
mm_lwu_func = 14,
};
enum mm_32f_func {
mm_lwxc1_func = 72,
mm_swxc1_func = 136,
mm_ldxc1_func = 200,
mm_sdxc1_func = 264,
};
enum MIPS16e_i64_func {
MIPS16e_ldsp_func = 0,
MIPS16e_sdsp_func = 1,
MIPS16e_sdrasp_func = 2,
MIPS16e_dadjsp_func = 3,
MIPS16e_ldpc_func = 4,
};
enum MIPS6e_i8_func {
MIPS16e_swrasp_func = 2,
};
enum {
UNALIGNED_ACTION_QUIET = 0,
UNALIGNED_ACTION_SIGNAL = 1,
UNALIGNED_ACTION_SHOW = 2,
};
struct sched_attr {
__u32 size;
__u32 sched_policy;
__u64 sched_flags;
__s32 sched_nice;
__u32 sched_priority;
__u64 sched_runtime;
__u64 sched_deadline;
__u64 sched_period;
__u32 sched_util_min;
__u32 sched_util_max;
};
struct rt_bandwidth {
raw_spinlock_t rt_runtime_lock;
long: 32;
ktime_t rt_period;
u64 rt_runtime;
struct hrtimer rt_period_timer;
unsigned int rt_period_active;
long: 32;
};
struct dl_bandwidth {
raw_spinlock_t dl_runtime_lock;
long: 32;
u64 dl_runtime;
u64 dl_period;
};
struct idle_timer {
struct hrtimer timer;
int done;
long: 32;
};
typedef struct rt_rq *rt_rq_iter_t;
enum writeback_stat_item {
NR_DIRTY_THRESHOLD = 0,
NR_DIRTY_BG_THRESHOLD = 1,
NR_VM_WRITEBACK_STAT_ITEMS = 2,
};
struct contig_page_info {
long unsigned int free_pages;
long unsigned int free_blocks_total;
long unsigned int free_blocks_suitable;
};
struct swap_slots_cache {
bool lock_initialized;
struct mutex alloc_lock;
swp_entry_t *slots;
int nr;
int cur;
spinlock_t free_lock;
swp_entry_t *slots_ret;
int n_ret;
};
struct simple_transaction_argresp {
ssize_t size;
char data[0];
};
struct simple_attr {
int (*get)(void *, u64 *);
int (*set)(void *, u64);
char get_buf[24];
char set_buf[24];
void *data;
const char *fmt;
struct mutex mutex;
};
struct proc_maps_private {
struct inode *inode;
struct task_struct *task;
struct mm_struct *mm;
struct vma_iterator iter;
};
struct mem_size_stats {
long unsigned int resident;
long unsigned int shared_clean;
long unsigned int shared_dirty;
long unsigned int private_clean;
long unsigned int private_dirty;
long unsigned int referenced;
long unsigned int anonymous;
long unsigned int lazyfree;
long unsigned int anonymous_thp;
long unsigned int shmem_thp;
long unsigned int file_thp;
long unsigned int swap;
long unsigned int shared_hugetlb;
long unsigned int private_hugetlb;
u64 pss;
u64 pss_anon;
u64 pss_file;
u64 pss_shmem;
u64 pss_dirty;
u64 pss_locked;
u64 swap_pss;
};
enum clear_refs_types {
CLEAR_REFS_ALL = 1,
CLEAR_REFS_ANON = 2,
CLEAR_REFS_MAPPED = 3,
CLEAR_REFS_SOFT_DIRTY = 4,
CLEAR_REFS_MM_HIWATER_RSS = 5,
CLEAR_REFS_LAST = 6,
};
struct clear_refs_private {
enum clear_refs_types type;
};
typedef struct {
u64 pme;
} pagemap_entry_t;
struct pagemapread {
int pos;
int len;
pagemap_entry_t *buffer;
bool show_pfn;
};
struct commit_header {
__be32 h_magic;
__be32 h_blocktype;
__be32 h_sequence;
unsigned char h_chksum_type;
unsigned char h_chksum_size;
unsigned char h_padding[2];
__be32 h_chksum[8];
__be64 h_commit_sec;
__be32 h_commit_nsec;
long: 32;
};
struct journal_block_tag3_s {
__be32 t_blocknr;
__be32 t_flags;
__be32 t_blocknr_high;
__be32 t_checksum;
};
typedef struct journal_block_tag3_s journal_block_tag3_t;
struct journal_block_tag_s {
__be32 t_blocknr;
__be16 t_checksum;
__be16 t_flags;
__be32 t_blocknr_high;
};
typedef struct journal_block_tag_s journal_block_tag_t;
enum {
FILEID_HIGH_OFF = 0,
FILEID_LOW_OFF = 1,
FILE_I_TYPE_OFF = 2,
EMBED_FH_OFF = 3,
};
struct nfsd_drc_bucket {
struct rb_root rb_head;
struct list_head lru_head;
spinlock_t cache_lock;
};
enum {
RC_UNUSED = 0,
RC_INPROG = 1,
RC_DONE = 2,
};
struct blk_plug_cb;
typedef void (*blk_plug_cb_fn)(struct blk_plug_cb *, bool);
struct blk_plug_cb {
struct list_head list;
blk_plug_cb_fn callback;
void *data;
};
struct trace_event_raw_block_buffer {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
size_t size;
char __data[0];
long: 32;
};
struct trace_event_raw_block_rq_requeue {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
unsigned int nr_sector;
char rwbs[8];
u32 __data_loc_cmd;
char __data[0];
};
struct trace_event_raw_block_rq_completion {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
unsigned int nr_sector;
int error;
char rwbs[8];
u32 __data_loc_cmd;
char __data[0];
long: 32;
};
struct trace_event_raw_block_rq {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
unsigned int nr_sector;
unsigned int bytes;
char rwbs[8];
char comm[16];
u32 __data_loc_cmd;
char __data[0];
long: 32;
};
struct trace_event_raw_block_bio_complete {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
unsigned int nr_sector;
int error;
char rwbs[8];
char __data[0];
};
struct trace_event_raw_block_bio {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
unsigned int nr_sector;
char rwbs[8];
char comm[16];
char __data[0];
long: 32;
};
struct trace_event_raw_block_plug {
struct trace_entry ent;
char comm[16];
char __data[0];
};
struct trace_event_raw_block_unplug {
struct trace_entry ent;
int nr_rq;
char comm[16];
char __data[0];
};
struct trace_event_raw_block_split {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
sector_t new_sector;
char rwbs[8];
char comm[16];
char __data[0];
};
struct trace_event_raw_block_bio_remap {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
unsigned int nr_sector;
dev_t old_dev;
sector_t old_sector;
char rwbs[8];
char __data[0];
};
struct trace_event_raw_block_rq_remap {
struct trace_entry ent;
dev_t dev;
long: 32;
sector_t sector;
unsigned int nr_sector;
dev_t old_dev;
sector_t old_sector;
unsigned int nr_bios;
char rwbs[8];
char __data[0];
long: 32;
};
struct trace_event_data_offsets_block_buffer {};
struct trace_event_data_offsets_block_rq_requeue {
u32 cmd;
};
struct trace_event_data_offsets_block_rq_completion {
u32 cmd;
};
struct trace_event_data_offsets_block_rq {
u32 cmd;
};
struct trace_event_data_offsets_block_bio_complete {};
struct trace_event_data_offsets_block_bio {};
struct trace_event_data_offsets_block_plug {};
struct trace_event_data_offsets_block_unplug {};
struct trace_event_data_offsets_block_split {};
struct trace_event_data_offsets_block_bio_remap {};
struct trace_event_data_offsets_block_rq_remap {};
typedef void (*btf_trace_block_touch_buffer)(void *, struct buffer_head *);
typedef void (*btf_trace_block_dirty_buffer)(void *, struct buffer_head *);
typedef void (*btf_trace_block_rq_requeue)(void *, struct request *);
typedef void (*btf_trace_block_rq_complete)(void *, struct request *, blk_status_t, unsigned int);
typedef void (*btf_trace_block_rq_error)(void *, struct request *, blk_status_t, unsigned int);
typedef void (*btf_trace_block_rq_insert)(void *, struct request *);
typedef void (*btf_trace_block_rq_issue)(void *, struct request *);
typedef void (*btf_trace_block_rq_merge)(void *, struct request *);
typedef void (*btf_trace_block_bio_complete)(void *, struct request_queue *, struct bio *);
typedef void (*btf_trace_block_bio_bounce)(void *, struct bio *);
typedef void (*btf_trace_block_bio_backmerge)(void *, struct bio *);
typedef void (*btf_trace_block_bio_frontmerge)(void *, struct bio *);
typedef void (*btf_trace_block_bio_queue)(void *, struct bio *);
typedef void (*btf_trace_block_getrq)(void *, struct bio *);
typedef void (*btf_trace_block_plug)(void *, struct request_queue *);
typedef void (*btf_trace_block_unplug)(void *, struct request_queue *, unsigned int, bool);
typedef void (*btf_trace_block_split)(void *, struct bio *, unsigned int);
typedef void (*btf_trace_block_bio_remap)(void *, struct bio *, dev_t, sector_t);
typedef void (*btf_trace_block_rq_remap)(void *, struct request *, dev_t, sector_t);
struct reciprocal_value_adv {
u32 m;
u8 sh;
u8 exp;
bool is_wide_m;
};
struct ts_linear_state {
unsigned int len;
const void *data;
};
enum pcie_link_width {
PCIE_LNK_WIDTH_RESRV = 0,
PCIE_LNK_X1 = 1,
PCIE_LNK_X2 = 2,
PCIE_LNK_X4 = 4,
PCIE_LNK_X8 = 8,
PCIE_LNK_X12 = 12,
PCIE_LNK_X16 = 16,
PCIE_LNK_X32 = 32,
PCIE_LNK_WIDTH_UNKNOWN = 255,
};
enum cirrus_board {
BT_NONE = 0,
BT_SD64 = 1,
BT_PICCOLO = 2,
BT_PICASSO = 3,
BT_SPECTRUM = 4,
BT_PICASSO4 = 5,
BT_ALPINE = 6,
BT_GD5480 = 7,
BT_LAGUNA = 8,
BT_LAGUNAB = 9,
};
struct cirrusfb_board_info_rec {
char *name;
long int maxclock[5];
bool init_sr07: 1;
bool init_sr1f: 1;
bool scrn_start_bit19: 1;
unsigned char sr07;
unsigned char sr07_1bpp;
unsigned char sr07_1bpp_mux;
unsigned char sr07_8bpp;
unsigned char sr07_8bpp_mux;
unsigned char sr1f;
};
struct cirrusfb_info {
u8 *regbase;
u8 *laguna_mmio;
enum cirrus_board btype;
unsigned char SFR;
int multiplexing;
int doubleVCLK;
int blank_mode;
u32 pseudo_palette[16];
void (*unmap)(struct fb_info *);
};
enum hwparam_type {
hwparam_ioport = 0,
hwparam_iomem = 1,
hwparam_ioport_or_iomem = 2,
hwparam_irq = 3,
hwparam_dma = 4,
hwparam_dma_addr = 5,
hwparam_other = 6,
};
struct old_serial_port {
unsigned int uart;
unsigned int baud_base;
unsigned int port;
unsigned int irq;
upf_t flags;
unsigned char io_type;
unsigned char *iomem_base;
short unsigned int iomem_reg_shift;
long: 32;
};
struct irq_info {
struct hlist_node node;
int irq;
spinlock_t lock;
struct list_head *head;
};
struct regmap_debugfs_off_cache {
struct list_head list;
off_t min;
off_t max;
unsigned int base_reg;
unsigned int max_reg;
};
struct regmap_debugfs_node {
struct regmap *map;
struct list_head link;
};
struct mtd_part_parser {
struct list_head list;
struct module *owner;
const char *name;
const struct of_device_id *of_match_table;
int (*parse_fn)(struct mtd_info *, const struct mtd_partition **, struct mtd_part_parser_data *);
void (*cleanup)(const struct mtd_partition *, int);
};
struct mtd_partitions {
const struct mtd_partition *parts;
int nr_parts;
const struct mtd_part_parser *parser;
};
enum macvlan_mode {
MACVLAN_MODE_PRIVATE = 1,
MACVLAN_MODE_VEPA = 2,
MACVLAN_MODE_BRIDGE = 4,
MACVLAN_MODE_PASSTHRU = 8,
MACVLAN_MODE_SOURCE = 16,
};
enum {
TC_MQPRIO_HW_OFFLOAD_NONE = 0,
TC_MQPRIO_HW_OFFLOAD_TCS = 1,
__TC_MQPRIO_HW_OFFLOAD_MAX = 2,
};
struct tc_mqprio_qopt {
__u8 num_tc;
__u8 prio_tc_map[16];
__u8 hw;
__u16 count[16];
__u16 offset[16];
};
struct tc_u32_key {
__be32 mask;
__be32 val;
int off;
int offmask;
};
struct tc_u32_sel {
unsigned char flags;
unsigned char offshift;
unsigned char nkeys;
__be16 offmask;
__u16 off;
short int offoff;
short int hoff;
__be32 hmask;
struct tc_u32_key keys[0];
};
struct vlan_pcpu_stats {
u64_stats_t rx_packets;
u64_stats_t rx_bytes;
u64_stats_t rx_multicast;
u64_stats_t tx_packets;
u64_stats_t tx_bytes;
struct u64_stats_sync syncp;
u32 rx_errors;
u32 tx_dropped;
long: 32;
};
struct macvlan_port;
struct macvlan_dev {
struct net_device *dev;
struct list_head list;
struct hlist_node hlist;
struct macvlan_port *port;
struct net_device *lowerdev;
netdevice_tracker dev_tracker;
void *accel_priv;
struct vlan_pcpu_stats *pcpu_stats;
long unsigned int mc_filter[8];
long: 32;
netdev_features_t set_features;
enum macvlan_mode mode;
u16 flags;
unsigned int macaddr_count;
u32 bc_queue_len_req;
struct netpoll *netpoll;
long: 32;
};
enum flow_block_command {
FLOW_BLOCK_BIND = 0,
FLOW_BLOCK_UNBIND = 1,
};
enum flow_block_binder_type {
FLOW_BLOCK_BINDER_TYPE_UNSPEC = 0,
FLOW_BLOCK_BINDER_TYPE_CLSACT_INGRESS = 1,
FLOW_BLOCK_BINDER_TYPE_CLSACT_EGRESS = 2,
FLOW_BLOCK_BINDER_TYPE_RED_EARLY_DROP = 3,
FLOW_BLOCK_BINDER_TYPE_RED_MARK = 4,
};
struct flow_block_offload {
enum flow_block_command command;
enum flow_block_binder_type binder_type;
bool block_shared;
bool unlocked_driver_cb;
struct net *net;
struct flow_block *block;
struct list_head cb_list;
struct list_head *driver_block_list;
struct netlink_ext_ack *extack;
struct Qdisc *sch;
struct list_head *cb_list_head;
};
struct flow_cls_common_offload {
u32 chain_index;
__be16 protocol;
u32 prio;
struct netlink_ext_ack *extack;
};
struct tcf_exts {
__u32 type;
int nr_actions;
struct tc_action **actions;
struct net *net;
netns_tracker ns_tracker;
int action;
int police;
};
struct tc_cls_u32_knode {
struct tcf_exts *exts;
struct tcf_result *res;
struct tc_u32_sel *sel;
u32 handle;
u32 val;
u32 mask;
u32 link_handle;
u8 fshift;
};
struct tc_cls_u32_hnode {
u32 handle;
u32 prio;
unsigned int divisor;
};
enum tc_clsu32_command {
TC_CLSU32_NEW_KNODE = 0,
TC_CLSU32_REPLACE_KNODE = 1,
TC_CLSU32_DELETE_KNODE = 2,
TC_CLSU32_NEW_HNODE = 3,
TC_CLSU32_REPLACE_HNODE = 4,
TC_CLSU32_DELETE_HNODE = 5,
};
struct tc_cls_u32_offload {
struct flow_cls_common_offload common;
enum tc_clsu32_command command;
union {
struct tc_cls_u32_knode knode;
struct tc_cls_u32_hnode hnode;
};
};
struct tcf_gact {
struct tc_action common;
u16 tcfg_ptype;
u16 tcfg_pval;
int tcfg_paction;
atomic_t packets;
long: 32;
};
struct tcf_mirred {
struct tc_action common;
int tcfm_eaction;
bool tcfm_mac_header_xmit;
struct net_device *tcfm_dev;
netdevice_tracker tcfm_dev_tracker;
struct list_head tcfm_list;
long: 32;
long: 32;
long: 32;
};
struct ixgbe_nvm_version {
u32 etk_id;
u8 nvm_major;
u16 nvm_minor;
u8 nvm_id;
bool oem_valid;
u8 oem_major;
u8 oem_minor;
u16 oem_release;
bool or_valid;
u8 or_major;
u16 or_build;
u8 or_patch;
};
enum ixgbe_fdir_pballoc_type {
IXGBE_FDIR_PBALLOC_NONE = 0,
IXGBE_FDIR_PBALLOC_64K = 1,
IXGBE_FDIR_PBALLOC_128K = 2,
IXGBE_FDIR_PBALLOC_256K = 3,
};
struct ixgbe_ipsec_tx_data {
u32 flags;
u16 trailer_len;
u16 sa_idx;
};
enum ixgbe_tx_flags {
IXGBE_TX_FLAGS_HW_VLAN = 1,
IXGBE_TX_FLAGS_TSO = 2,
IXGBE_TX_FLAGS_TSTAMP = 4,
IXGBE_TX_FLAGS_CC = 8,
IXGBE_TX_FLAGS_IPV4 = 16,
IXGBE_TX_FLAGS_CSUM = 32,
IXGBE_TX_FLAGS_IPSEC = 64,
IXGBE_TX_FLAGS_SW_VLAN = 128,
IXGBE_TX_FLAGS_FCOE = 256,
};
struct ixgbe_fwd_adapter {
long unsigned int active_vlans[128];
struct net_device *netdev;
unsigned int tx_base_queue;
unsigned int rx_base_queue;
int pool;
};
struct ixgbe_mat_field;
struct ixgbe_jump_table {
struct ixgbe_mat_field *mat;
struct ixgbe_fdir_filter *input;
union ixgbe_atr_input *mask;
u32 link_hdl;
long unsigned int child_loc_map[32];
};
struct ixgbe_cb {
union {
struct sk_buff *head;
struct sk_buff *tail;
};
dma_addr_t dma;
u16 append_cnt;
bool page_released;
};
enum ixgbe_boards {
board_82598 = 0,
board_82599 = 1,
board_X540 = 2,
board_X550 = 3,
board_X550EM_x = 4,
board_x550em_x_fw = 5,
board_x550em_a = 6,
board_x550em_a_fw = 7,
};
struct ixgbe_mat_field {
unsigned int off;
int (*val)(struct ixgbe_fdir_filter *, union ixgbe_atr_input *, u32, u32);
unsigned int type;
};
struct ixgbe_nexthdr {
unsigned int o;
u32 s;
u32 m;
unsigned int off;
u32 val;
u32 mask;
struct ixgbe_mat_field *jump;
};
struct ixgbe_reg_info {
u32 ofs;
char *name;
};
struct upper_walk_data {
struct ixgbe_adapter *adapter;
long: 32;
u64 action;
int ifindex;
u8 queue;
};
struct my_u0 {
u64 a;
u64 b;
};
struct ip_mreq_source {
__be32 imr_multiaddr;
__be32 imr_interface;
__be32 imr_sourceaddr;
};
struct ip_msfilter {
__be32 imsf_multiaddr;
__be32 imsf_interface;
__u32 imsf_fmode;
__u32 imsf_numsrc;
union {
__be32 imsf_slist[1];
struct {
struct {} __empty_imsf_slist_flex;
__be32 imsf_slist_flex[0];
};
};
};
struct group_filter {
union {
struct {
__u32 gf_interface_aux;
struct __kernel_sockaddr_storage gf_group_aux;
__u32 gf_fmode_aux;
__u32 gf_numsrc_aux;
struct __kernel_sockaddr_storage gf_slist[1];
};
struct {
__u32 gf_interface;
struct __kernel_sockaddr_storage gf_group;
__u32 gf_fmode;
__u32 gf_numsrc;
struct __kernel_sockaddr_storage gf_slist_flex[0];
};
};
};
struct igmpv3_grec {
__u8 grec_type;
__u8 grec_auxwords;
__be16 grec_nsrcs;
__be32 grec_mca;
__be32 grec_src[0];
};
struct igmpv3_report {
__u8 type;
__u8 resv1;
__sum16 csum;
__be16 resv2;
__be16 ngrec;
struct igmpv3_grec grec[0];
};
struct igmpv3_query {
__u8 type;
__u8 code;
__sum16 csum;
__be32 group;
__u8 qrv: 3;
__u8 suppress: 1;
__u8 resv: 4;
__u8 qqic;
__be16 nsrcs;
__be32 srcs[0];
};
struct igmp_mc_iter_state {
struct seq_net_private p;
struct net_device *dev;
struct in_device *in_dev;
};
struct igmp_mcf_iter_state {
struct seq_net_private p;
struct net_device *dev;
struct in_device *idev;
struct ip_mc_list *im;
};
struct rta_mfc_stats {
__u64 mfcs_packets;
__u64 mfcs_bytes;
__u64 mfcs_wrong_if;
};
struct xfrm4_protocol {
int (*handler)(struct sk_buff *);
int (*input_handler)(struct sk_buff *, int, __be32, int);
int (*cb_handler)(struct sk_buff *, int);
int (*err_handler)(struct sk_buff *, u32);
struct xfrm4_protocol *next;
int priority;
};
struct fprop_local_single {
long unsigned int events;
unsigned int period;
raw_spinlock_t lock;
};
typedef long unsigned int old_sigset_t;
struct sigaltstack {
void *ss_sp;
__kernel_size_t ss_size;
int ss_flags;
};
typedef struct sigaltstack stack_t;
struct sigcontext {
unsigned int sc_regmask;
unsigned int sc_status;
long long unsigned int sc_pc;
long long unsigned int sc_regs[32];
long long unsigned int sc_fpregs[32];
unsigned int sc_acx;
unsigned int sc_fpc_csr;
unsigned int sc_fpc_eir;
unsigned int sc_used_math;
unsigned int sc_dsp;
long: 32;
long long unsigned int sc_mdhi;
long long unsigned int sc_mdlo;
long unsigned int sc_hi1;
long unsigned int sc_lo1;
long unsigned int sc_hi2;
long unsigned int sc_lo2;
long unsigned int sc_hi3;
long unsigned int sc_lo3;
};
struct extcontext {
unsigned int magic;
unsigned int size;
};
struct ucontext {
long unsigned int uc_flags;
struct ucontext *uc_link;
stack_t uc_stack;
long: 32;
struct sigcontext uc_mcontext;
sigset_t uc_sigmask;
long long unsigned int uc_extcontext[0];
};
struct sigframe {
u32 sf_ass[4];
u32 sf_pad[2];
struct sigcontext sf_sc;
sigset_t sf_mask;
long long unsigned int sf_extcontext[0];
};
struct rt_sigframe {
u32 rs_ass[4];
u32 rs_pad[2];
struct siginfo rs_info;
struct ucontext rs_uc;
};
struct trace_event_raw_sched_kthread_stop {
struct trace_entry ent;
char comm[16];
pid_t pid;
char __data[0];
};
struct trace_event_raw_sched_kthread_stop_ret {
struct trace_entry ent;
int ret;
char __data[0];
};
struct trace_event_raw_sched_kthread_work_queue_work {
struct trace_entry ent;
void *work;
void *function;
void *worker;
char __data[0];
};
struct trace_event_raw_sched_kthread_work_execute_start {
struct trace_entry ent;
void *work;
void *function;
char __data[0];
};
struct trace_event_raw_sched_kthread_work_execute_end {
struct trace_entry ent;
void *work;
void *function;
char __data[0];
};
struct trace_event_raw_sched_wakeup_template {
struct trace_entry ent;
char comm[16];
pid_t pid;
int prio;
int target_cpu;
char __data[0];
};
struct trace_event_raw_sched_switch {
struct trace_entry ent;
char prev_comm[16];
pid_t prev_pid;
int prev_prio;
long int prev_state;
char next_comm[16];
pid_t next_pid;
int next_prio;
char __data[0];
};
struct trace_event_raw_sched_migrate_task {
struct trace_entry ent;
char comm[16];
pid_t pid;
int prio;
int orig_cpu;
int dest_cpu;
char __data[0];
};
struct trace_event_raw_sched_process_template {
struct trace_entry ent;
char comm[16];
pid_t pid;
int prio;
char __data[0];
};
struct trace_event_raw_sched_process_wait {
struct trace_entry ent;
char comm[16];
pid_t pid;
int prio;
char __data[0];
};
struct trace_event_raw_sched_process_fork {
struct trace_entry ent;
char parent_comm[16];
pid_t parent_pid;
char child_comm[16];
pid_t child_pid;
char __data[0];
};
struct trace_event_raw_sched_process_exec {
struct trace_entry ent;
u32 __data_loc_filename;
pid_t pid;
pid_t old_pid;
char __data[0];
};
struct trace_event_raw_sched_stat_runtime {
struct trace_entry ent;
char comm[16];
pid_t pid;
long: 32;
u64 runtime;
u64 vruntime;
char __data[0];
};
struct trace_event_raw_sched_pi_setprio {
struct trace_entry ent;
char comm[16];
pid_t pid;
int oldprio;
int newprio;
char __data[0];
};
struct trace_event_raw_sched_move_numa {
struct trace_entry ent;
pid_t pid;
pid_t tgid;
pid_t ngid;
int src_cpu;
int src_nid;
int dst_cpu;
int dst_nid;
char __data[0];
};
struct trace_event_raw_sched_numa_pair_template {
struct trace_entry ent;
pid_t src_pid;
pid_t src_tgid;
pid_t src_ngid;
int src_cpu;
int src_nid;
pid_t dst_pid;
pid_t dst_tgid;
pid_t dst_ngid;
int dst_cpu;
int dst_nid;
char __data[0];
};
struct trace_event_raw_sched_wake_idle_without_ipi {
struct trace_entry ent;
int cpu;
char __data[0];
};
struct trace_event_data_offsets_sched_kthread_stop {};
struct trace_event_data_offsets_sched_kthread_stop_ret {};
struct trace_event_data_offsets_sched_kthread_work_queue_work {};
struct trace_event_data_offsets_sched_kthread_work_execute_start {};
struct trace_event_data_offsets_sched_kthread_work_execute_end {};
struct trace_event_data_offsets_sched_wakeup_template {};
struct trace_event_data_offsets_sched_switch {};
struct trace_event_data_offsets_sched_migrate_task {};
struct trace_event_data_offsets_sched_process_template {};
struct trace_event_data_offsets_sched_process_wait {};
struct trace_event_data_offsets_sched_process_fork {};
struct trace_event_data_offsets_sched_process_exec {
u32 filename;
};
struct trace_event_data_offsets_sched_stat_runtime {};
struct trace_event_data_offsets_sched_pi_setprio {};
struct trace_event_data_offsets_sched_move_numa {};
struct trace_event_data_offsets_sched_numa_pair_template {};
struct trace_event_data_offsets_sched_wake_idle_without_ipi {};
typedef void (*btf_trace_sched_kthread_stop)(void *, struct task_struct *);
typedef void (*btf_trace_sched_kthread_stop_ret)(void *, int);
typedef void (*btf_trace_sched_kthread_work_queue_work)(void *, struct kthread_worker *, struct kthread_work *);
typedef void (*btf_trace_sched_kthread_work_execute_start)(void *, struct kthread_work *);
typedef void (*btf_trace_sched_kthread_work_execute_end)(void *, struct kthread_work *, kthread_work_func_t);
typedef void (*btf_trace_sched_waking)(void *, struct task_struct *);
typedef void (*btf_trace_sched_wakeup)(void *, struct task_struct *);
typedef void (*btf_trace_sched_wakeup_new)(void *, struct task_struct *);
typedef void (*btf_trace_sched_switch)(void *, bool, struct task_struct *, struct task_struct *, unsigned int);
typedef void (*btf_trace_sched_migrate_task)(void *, struct task_struct *, int);
typedef void (*btf_trace_sched_process_free)(void *, struct task_struct *);
typedef void (*btf_trace_sched_process_exit)(void *, struct task_struct *);
typedef void (*btf_trace_sched_wait_task)(void *, struct task_struct *);
typedef void (*btf_trace_sched_process_wait)(void *, struct pid *);
typedef void (*btf_trace_sched_process_fork)(void *, struct task_struct *, struct task_struct *);
typedef void (*btf_trace_sched_process_exec)(void *, struct task_struct *, pid_t, struct linux_binprm *);
typedef void (*btf_trace_sched_stat_runtime)(void *, struct task_struct *, u64, u64);
typedef void (*btf_trace_sched_pi_setprio)(void *, struct task_struct *, struct task_struct *);
typedef void (*btf_trace_sched_move_numa)(void *, struct task_struct *, int, int);
typedef void (*btf_trace_sched_stick_numa)(void *, struct task_struct *, int, struct task_struct *, int);
typedef void (*btf_trace_sched_swap_numa)(void *, struct task_struct *, int, struct task_struct *, int);
typedef void (*btf_trace_sched_wake_idle_without_ipi)(void *, int);
typedef void (*btf_trace_pelt_cfs_tp)(void *, struct cfs_rq *);
typedef void (*btf_trace_pelt_rt_tp)(void *, struct rq *);
typedef void (*btf_trace_pelt_dl_tp)(void *, struct rq *);
typedef void (*btf_trace_pelt_thermal_tp)(void *, struct rq *);
typedef void (*btf_trace_pelt_irq_tp)(void *, struct rq *);
typedef void (*btf_trace_pelt_se_tp)(void *, struct sched_entity *);
typedef void (*btf_trace_sched_cpu_capacity_tp)(void *, struct rq *);
typedef void (*btf_trace_sched_overutilized_tp)(void *, struct root_domain *, bool);
typedef void (*btf_trace_sched_util_est_cfs_tp)(void *, struct cfs_rq *);
typedef void (*btf_trace_sched_util_est_se_tp)(void *, struct sched_entity *);
typedef void (*btf_trace_sched_update_nr_running_tp)(void *, struct rq *, int);
struct set_affinity_pending;
struct migration_arg {
struct task_struct *task;
int dest_cpu;
struct set_affinity_pending *pending;
};
struct set_affinity_pending {
refcount_t refs;
unsigned int stop_pending;
struct completion done;
struct cpu_stop_work stop_work;
struct migration_arg arg;
};
enum {
cpuset = 0,
possible = 1,
fail = 2,
};
typedef struct {
u64 val;
} pfn_t;
typedef unsigned int pgtbl_mod_mask;
typedef int (*pte_fn_t)(pte_t *, long unsigned int, void *);
typedef long unsigned int pte_marker;
struct dentry_stat_t {
long int nr_dentry;
long int nr_unused;
long int age_limit;
long int want_pages;
long int nr_negative;
long int dummy;
};
struct external_name {
union {
atomic_t count;
struct callback_head head;
} u;
unsigned char name[0];
};
enum d_walk_ret {
D_WALK_CONTINUE = 0,
D_WALK_QUIT = 1,
D_WALK_NORETRY = 2,
D_WALK_SKIP = 3,
};
struct check_mount {
struct vfsmount *mnt;
unsigned int mounted;
};
struct select_data {
struct dentry *start;
union {
long int found;
struct dentry *victim;
};
struct list_head dispose;
};
enum legacy_fs_param {
LEGACY_FS_UNSET_PARAMS = 0,
LEGACY_FS_MONOLITHIC_PARAMS = 1,
LEGACY_FS_INDIVIDUAL_PARAMS = 2,
};
struct legacy_fs_context {
char *legacy_data;
size_t data_size;
enum legacy_fs_param param_type;
};
struct qt_disk_dqdbheader {
__le32 dqdh_next_free;
__le32 dqdh_prev_free;
__le16 dqdh_entries;
__le16 dqdh_pad1;
__le32 dqdh_pad2;
};
typedef unsigned int cycles_t;
struct ext4_free_data {
struct list_head efd_list;
struct rb_node efd_node;
ext4_group_t efd_group;
ext4_grpblk_t efd_start_cluster;
ext4_grpblk_t efd_count;
tid_t efd_tid;
};
enum {
MB_INODE_PA = 0,
MB_GROUP_PA = 1,
};
struct ext4_buddy {
struct page *bd_buddy_page;
void *bd_buddy;
struct page *bd_bitmap_page;
void *bd_bitmap;
struct ext4_group_info *bd_info;
struct super_block *bd_sb;
__u16 bd_blkbits;
ext4_group_t bd_group;
};
struct sg {
struct ext4_group_info info;
ext4_grpblk_t counters[18];
};
struct crypto_queue {
struct list_head list;
struct list_head *backlog;
unsigned int qlen;
unsigned int max_qlen;
};
enum {
REQ_FSEQ_PREFLUSH = 1,
REQ_FSEQ_DATA = 2,
REQ_FSEQ_POSTFLUSH = 4,
REQ_FSEQ_DONE = 8,
REQ_FSEQ_ACTIONS = 7,
FLUSH_PENDING_TIMEOUT = 500,
};
typedef guid_t efi_guid_t;
struct _gpt_header {
__le64 signature;
__le32 revision;
__le32 header_size;
__le32 header_crc32;
__le32 reserved1;
__le64 my_lba;
__le64 alternate_lba;
__le64 first_usable_lba;
__le64 last_usable_lba;
efi_guid_t disk_guid;
__le64 partition_entry_lba;
__le32 num_partition_entries;
__le32 sizeof_partition_entry;
__le32 partition_entry_array_crc32;
};
typedef struct _gpt_header gpt_header;
struct _gpt_entry_attributes {
u64 required_to_function: 1;
u64 reserved: 47;
u64 type_guid_specific: 16;
};
typedef struct _gpt_entry_attributes gpt_entry_attributes;
struct _gpt_entry {
efi_guid_t partition_type_guid;
efi_guid_t unique_partition_guid;
__le64 starting_lba;
__le64 ending_lba;
gpt_entry_attributes attributes;
__le16 partition_name[36];
};
typedef struct _gpt_entry gpt_entry;
struct _gpt_mbr_record {
u8 boot_indicator;
u8 start_head;
u8 start_sector;
u8 start_track;
u8 os_type;
u8 end_head;
u8 end_sector;
u8 end_track;
__le32 starting_lba;
__le32 size_in_lba;
};
typedef struct _gpt_mbr_record gpt_mbr_record;
struct _legacy_mbr {
u8 boot_code[440];
__le32 unique_mbr_signature;
__le16 unknown;
gpt_mbr_record partition_record[4];
__le16 signature;
} __attribute__((packed));
typedef struct _legacy_mbr legacy_mbr;
enum {
IORING_CQE_BUFFER_SHIFT = 16,
};
struct io_uring_buf_reg {
__u64 ring_addr;
__u32 ring_entries;
__u16 bgid;
__u16 pad;
__u64 resv[3];
};
struct io_provide_buf {
struct file *file;
long: 32;
__u64 addr;
__u32 len;
__u32 bgid;
__u16 nbufs;
__u16 bid;
long: 32;
};
typedef struct {
U32 f1c;
U32 f1d;
U32 f7b;
U32 f7c;
} ZSTD_cpuid_t;
typedef struct {
size_t error;
int lowerBound;
int upperBound;
} ZSTD_bounds;
typedef enum {
ZSTD_reset_session_only = 1,
ZSTD_reset_parameters = 2,
ZSTD_reset_session_and_parameters = 3,
} ZSTD_ResetDirective;
typedef enum {
ZSTD_d_windowLogMax = 100,
ZSTD_d_experimentalParam1 = 1000,
ZSTD_d_experimentalParam2 = 1001,
ZSTD_d_experimentalParam3 = 1002,
ZSTD_d_experimentalParam4 = 1003,
} ZSTD_dParameter;
typedef enum {
ZSTDnit_frameHeader = 0,
ZSTDnit_blockHeader = 1,
ZSTDnit_block = 2,
ZSTDnit_lastBlock = 3,
ZSTDnit_checksum = 4,
ZSTDnit_skippableFrame = 5,
} ZSTD_nextInputType_e;
typedef struct {
size_t compressedSize;
long: 32;
long long unsigned int decompressedBound;
} ZSTD_frameSizeInfo;
typedef struct {
blockType_e blockType;
U32 lastBlock;
U32 origSize;
} blockProperties_t;
enum pcie_reset_state {
pcie_deassert_reset = 1,
pcie_warm_reset = 2,
pcie_hot_reset = 3,
};
typedef int (*arch_set_vga_state_t)(struct pci_dev *, bool, unsigned int, u32);
struct pci_reset_fn_method {
int (*reset_fn)(struct pci_dev *, bool);
char *name;
};
struct pci_pme_device {
struct list_head list;
struct pci_dev *dev;
};
struct pci_saved_state {
u32 config_space[16];
struct pci_cap_saved_data cap[0];
};
struct pci_devres {
unsigned int enabled: 1;
unsigned int pinned: 1;
unsigned int orig_intx: 1;
unsigned int restore_intx: 1;
unsigned int mwi: 1;
u32 region_mask;
};
struct clk_div_table {
unsigned int val;
unsigned int div;
};
struct clk_divider {
struct clk_hw hw;
void *reg;
u8 shift;
u8 width;
u8 flags;
const struct clk_div_table *table;
spinlock_t *lock;
};
struct builtin_fw {
char *name;
void *data;
long unsigned int size;
};
struct scsi_varlen_cdb_hdr {
__u8 opcode;
__u8 control;
__u8 misc[5];
__u8 additional_cdb_length;
__be16 service_action;
};
struct fixed_partitions_quirks {
int (*post_parse)(struct mtd_info *, struct mtd_partition *, int);
};
typedef struct mtd_info *cfi_cmdset_fn_t(struct map_info *, int);
struct ixgbe_adv_tx_context_desc {
__le32 vlan_macip_lens;
__le32 fceof_saidx;
__le32 type_tucmd_mlhl;
__le32 mss_l4len_idx;
};
struct trace_event_raw_rtc_time_alarm_class {
struct trace_entry ent;
time64_t secs;
int err;
char __data[0];
long: 32;
};
struct trace_event_raw_rtc_irq_set_freq {
struct trace_entry ent;
int freq;
int err;
char __data[0];
};
struct trace_event_raw_rtc_irq_set_state {
struct trace_entry ent;
int enabled;
int err;
char __data[0];
};
struct trace_event_raw_rtc_alarm_irq_enable {
struct trace_entry ent;
unsigned int enabled;
int err;
char __data[0];
};
struct trace_event_raw_rtc_offset_class {
struct trace_entry ent;
long int offset;
int err;
char __data[0];
};
struct trace_event_raw_rtc_timer_class {
struct trace_entry ent;
struct rtc_timer *timer;
long: 32;
ktime_t expires;
ktime_t period;
char __data[0];
};
struct trace_event_data_offsets_rtc_time_alarm_class {};
struct trace_event_data_offsets_rtc_irq_set_freq {};
struct trace_event_data_offsets_rtc_irq_set_state {};
struct trace_event_data_offsets_rtc_alarm_irq_enable {};
struct trace_event_data_offsets_rtc_offset_class {};
struct trace_event_data_offsets_rtc_timer_class {};
typedef void (*btf_trace_rtc_set_time)(void *, time64_t, int);
typedef void (*btf_trace_rtc_read_time)(void *, time64_t, int);
typedef void (*btf_trace_rtc_set_alarm)(void *, time64_t, int);
typedef void (*btf_trace_rtc_read_alarm)(void *, time64_t, int);
typedef void (*btf_trace_rtc_irq_set_freq)(void *, int, int);
typedef void (*btf_trace_rtc_irq_set_state)(void *, int, int);
typedef void (*btf_trace_rtc_alarm_irq_enable)(void *, unsigned int, int);
typedef void (*btf_trace_rtc_set_offset)(void *, long int, int);
typedef void (*btf_trace_rtc_read_offset)(void *, long int, int);
typedef void (*btf_trace_rtc_timer_enqueue)(void *, struct rtc_timer *);
typedef void (*btf_trace_rtc_timer_dequeue)(void *, struct rtc_timer *);
typedef void (*btf_trace_rtc_timer_fired)(void *, struct rtc_timer *);
enum {
none = 0,
day = 1,
month = 2,
year = 3,
};
struct fib_notifier_net {
struct list_head fib_notifier_ops;
struct atomic_notifier_head fib_chain;
};
struct net_packet_attrs {
const unsigned char *src;
const unsigned char *dst;
u32 ip_src;
u32 ip_dst;
bool tcp;
u16 sport;
u16 dport;
int timeout;
int size;
int max_size;
u8 id;
u16 queue_mapping;
};
struct net_test_priv {
struct net_packet_attrs *packet;
struct packet_type pt;
struct completion comp;
int double_vlan;
int vlan_id;
int ok;
};
struct netsfhdr {
__be32 version;
__be64 magic;
u8 id;
} __attribute__((packed));
struct net_test {
char name[32];
int (*fn)(struct net_device *);
};
enum net_xmit_qdisc_t {
__NET_XMIT_STOLEN = 65536,
__NET_XMIT_BYPASS = 131072,
};
struct linkmodes_reply_data {
struct ethnl_reply_data base;
struct ethtool_link_ksettings ksettings;
struct ethtool_link_settings *lsettings;
bool peer_empty;
};
struct coalesce_reply_data {
struct ethnl_reply_data base;
struct ethtool_coalesce coalesce;
struct kernel_ethtool_coalesce kernel_coalesce;
u32 supported_params;
};
struct nf_queue_handler {
int (*outfn)(struct nf_queue_entry *, unsigned int);
void (*nf_hook_drop)(struct net *);
};
struct tx_work {
struct delayed_work work;
struct sock *sk;
};
struct tls_rec;
struct tls_sw_context_tx {
struct crypto_aead *aead_send;
struct crypto_wait async_wait;
struct tx_work tx_work;
struct tls_rec *open_rec;
struct list_head tx_list;
atomic_t encrypt_pending;
spinlock_t encrypt_compl_lock;
int async_notify;
u8 async_capable: 1;
long unsigned int tx_bitmask;
};
enum {
TCP_BPF_IPV4 = 0,
TCP_BPF_IPV6 = 1,
TCP_BPF_NUM_PROTS = 2,
};
enum {
TCP_BPF_BASE = 0,
TCP_BPF_TX = 1,
TCP_BPF_RX = 2,
TCP_BPF_TXRX = 3,
TCP_BPF_NUM_CFGS = 4,
};
struct sr6_tlv {
__u8 type;
__u8 len;
__u8 data[0];
};
enum {
SEG6_ATTR_UNSPEC = 0,
SEG6_ATTR_DST = 1,
SEG6_ATTR_DSTLEN = 2,
SEG6_ATTR_HMACKEYID = 3,
SEG6_ATTR_SECRET = 4,
SEG6_ATTR_SECRETLEN = 5,
SEG6_ATTR_ALGID = 6,
SEG6_ATTR_HMACINFO = 7,
__SEG6_ATTR_MAX = 8,
};
enum {
SEG6_CMD_UNSPEC = 0,
SEG6_CMD_SETHMAC = 1,
SEG6_CMD_DUMPHMAC = 2,
SEG6_CMD_SET_TUNSRC = 3,
SEG6_CMD_GET_TUNSRC = 4,
__SEG6_CMD_MAX = 5,
};
struct rpc_pipe_dir_object_ops;
struct rpc_pipe_dir_object {
struct list_head pdo_head;
const struct rpc_pipe_dir_object_ops *pdo_ops;
void *pdo_data;
};
struct rpc_pipe_dir_object_ops {
int (*create)(struct dentry *, struct rpc_pipe_dir_object *);
void (*destroy)(struct dentry *, struct rpc_pipe_dir_object *);
};
struct rpc_filelist {
const char *name;
const struct file_operations *i_fop;
umode_t mode;
};
enum {
RPCAUTH_info = 0,
RPCAUTH_EOF = 1,
};
enum {
RPCAUTH_lockd = 0,
RPCAUTH_mount = 1,
RPCAUTH_nfs = 2,
RPCAUTH_portmap = 3,
RPCAUTH_statd = 4,
RPCAUTH_nfsd4_cb = 5,
RPCAUTH_cache = 6,
RPCAUTH_nfsd = 7,
RPCAUTH_gssd = 8,
RPCAUTH_RootEOF = 9,
};
struct proc_cpuinfo_notifier_args {
struct seq_file *m;
long unsigned int n;
};
enum spec2_op {
madd_op = 0,
maddu_op = 1,
mul_op = 2,
spec2_3_unused_op = 3,
msub_op = 4,
msubu_op = 5,
clz_op = 32,
clo_op = 33,
dclz_op = 36,
dclo_op = 37,
sdbpp_op = 63,
};
enum multu_op {
multu_multu_op = 0,
multu_mulu_op = 2,
multu_muhu_op = 3,
};
enum divu_op {
divu_divu_op = 0,
divu_divu6_op = 2,
divu_modu_op = 3,
};
enum dmultu_op {
dmultu_dmultu_op = 0,
dmultu_dmulu_op = 2,
dmultu_dmuhu_op = 3,
};
enum ddivu_op {
ddivu_ddivu_op = 0,
ddivu_ddivu6_op = 2,
ddivu_dmodu_op = 3,
};
enum cop0_coi_func {
tlbr_op = 1,
tlbwi_op = 2,
tlbwr_op = 6,
tlbp_op = 8,
rfe_op = 16,
eret_op = 24,
wait_op = 32,
hypcall_op = 40,
};
enum ptw_func {
lwdir_op = 0,
lwpte_op = 1,
lddir_op = 2,
ldpte_op = 3,
};
enum bshfl_func {
wsbh_op = 2,
seb_op = 16,
seh_op = 24,
};
enum dbshfl_func {
dsbh_op = 2,
dshd_op = 5,
};
enum msa_func {
msa_elm_op = 25,
};
enum msa_elm {
msa_ctc_op = 62,
msa_cfc_op = 126,
};
enum fields {
RS = 1,
RT = 2,
RD = 4,
RE = 8,
SIMM = 16,
UIMM = 32,
BIMM = 64,
JIMM = 128,
FUNC = 256,
SET = 512,
SCIMM = 1024,
SIMM9 = 2048,
};
enum opcode {
insn_addiu = 0,
insn_addu = 1,
insn_and = 2,
insn_andi = 3,
insn_bbit0 = 4,
insn_bbit1 = 5,
insn_beq = 6,
insn_beql = 7,
insn_bgez = 8,
insn_bgezl = 9,
insn_bgtz = 10,
insn_blez = 11,
insn_bltz = 12,
insn_bltzl = 13,
insn_bne = 14,
insn_break = 15,
insn_cache = 16,
insn_cfc1 = 17,
insn_cfcmsa = 18,
insn_ctc1 = 19,
insn_ctcmsa = 20,
insn_daddiu = 21,
insn_daddu = 22,
insn_ddivu = 23,
insn_ddivu_r6 = 24,
insn_di = 25,
insn_dins = 26,
insn_dinsm = 27,
insn_dinsu = 28,
insn_divu = 29,
insn_divu_r6 = 30,
insn_dmfc0 = 31,
insn_dmodu = 32,
insn_dmtc0 = 33,
insn_dmultu = 34,
insn_dmulu = 35,
insn_drotr = 36,
insn_drotr32 = 37,
insn_dsbh = 38,
insn_dshd = 39,
insn_dsll = 40,
insn_dsll32 = 41,
insn_dsllv = 42,
insn_dsra = 43,
insn_dsra32 = 44,
insn_dsrav = 45,
insn_dsrl = 46,
insn_dsrl32 = 47,
insn_dsrlv = 48,
insn_dsubu = 49,
insn_eret = 50,
insn_ext = 51,
insn_ins = 52,
insn_j = 53,
insn_jal = 54,
insn_jalr = 55,
insn_jr = 56,
insn_lb = 57,
insn_lbu = 58,
insn_ld = 59,
insn_lddir = 60,
insn_ldpte = 61,
insn_ldx = 62,
insn_lh = 63,
insn_lhu = 64,
insn_ll = 65,
insn_lld = 66,
insn_lui = 67,
insn_lw = 68,
insn_lwu = 69,
insn_lwx = 70,
insn_mfc0 = 71,
insn_mfhc0 = 72,
insn_mfhi = 73,
insn_mflo = 74,
insn_modu = 75,
insn_movn = 76,
insn_movz = 77,
insn_mtc0 = 78,
insn_mthc0 = 79,
insn_mthi = 80,
insn_mtlo = 81,
insn_mul = 82,
insn_multu = 83,
insn_mulu = 84,
insn_muhu = 85,
insn_nor = 86,
insn_or = 87,
insn_ori = 88,
insn_pref = 89,
insn_rfe = 90,
insn_rotr = 91,
insn_sb = 92,
insn_sc = 93,
insn_scd = 94,
insn_seleqz = 95,
insn_selnez = 96,
insn_sd = 97,
insn_sh = 98,
insn_sll = 99,
insn_sllv = 100,
insn_slt = 101,
insn_slti = 102,
insn_sltiu = 103,
insn_sltu = 104,
insn_sra = 105,
insn_srav = 106,
insn_srl = 107,
insn_srlv = 108,
insn_subu = 109,
insn_sw = 110,
insn_sync = 111,
insn_syscall = 112,
insn_tlbp = 113,
insn_tlbr = 114,
insn_tlbwi = 115,
insn_tlbwr = 116,
insn_wait = 117,
insn_wsbh = 118,
insn_xor = 119,
insn_xori = 120,
insn_yield = 121,
insn_invalid = 122,
};
struct insn {
u32 match;
enum fields fields;
};
struct resource_constraint {
resource_size_t min;
resource_size_t max;
resource_size_t align;
resource_size_t (*alignf)(void *, const struct resource *, resource_size_t, resource_size_t);
void *alignf_data;
};
enum {
MAX_IORES_LEVEL = 5,
};
struct region_devres {
struct resource *parent;
resource_size_t start;
resource_size_t n;
};
enum what {
PROC_EVENT_NONE = 0,
PROC_EVENT_FORK = 1,
PROC_EVENT_EXEC = 2,
PROC_EVENT_UID = 4,
PROC_EVENT_GID = 64,
PROC_EVENT_SID = 128,
PROC_EVENT_PTRACE = 256,
PROC_EVENT_COMM = 512,
PROC_EVENT_COREDUMP = 1073741824,
PROC_EVENT_EXIT = 2147483648,
};
enum {
AFFINITY = 0,
AFFINITY_LIST = 1,
EFFECTIVE = 2,
EFFECTIVE_LIST = 3,
};
struct trace_event_raw_module_load {
struct trace_entry ent;
unsigned int taints;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_module_free {
struct trace_entry ent;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_module_refcnt {
struct trace_entry ent;
long unsigned int ip;
int refcnt;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_module_request {
struct trace_entry ent;
long unsigned int ip;
bool wait;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_data_offsets_module_load {
u32 name;
};
struct trace_event_data_offsets_module_free {
u32 name;
};
struct trace_event_data_offsets_module_refcnt {
u32 name;
};
struct trace_event_data_offsets_module_request {
u32 name;
};
typedef void (*btf_trace_module_load)(void *, struct module *);
typedef void (*btf_trace_module_free)(void *, struct module *);
typedef void (*btf_trace_module_get)(void *, struct module *, long unsigned int);
typedef void (*btf_trace_module_put)(void *, struct module *, long unsigned int);
typedef void (*btf_trace_module_request)(void *, char *, bool, long unsigned int);
struct symsearch {
const struct kernel_symbol *start;
const struct kernel_symbol *stop;
const s32 *crcs;
enum mod_license license;
};
struct mod_initfree {
struct llist_node node;
void *module_init;
};
struct trace_probe_log {
const char *subsystem;
const char **argv;
int argc;
int index;
};
struct bpf_lpm_trie_key {
__u32 prefixlen;
__u8 data[0];
};
struct lpm_trie_node {
struct callback_head rcu;
struct lpm_trie_node *child[2];
u32 prefixlen;
u32 flags;
u8 data[0];
};
struct lpm_trie {
struct bpf_map map;
struct lpm_trie_node *root;
size_t n_entries;
size_t max_prefixlen;
size_t data_size;
spinlock_t lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct bpf_mem_cache {
struct llist_head free_llist;
local_t active;
struct llist_head free_llist_extra;
struct irq_work refill_work;
struct obj_cgroup *objcg;
int unit_size;
int free_cnt;
int low_watermark;
int high_watermark;
int batch;
int percpu_size;
struct callback_head rcu;
struct llist_head free_by_rcu;
struct llist_head waiting_for_gp;
atomic_t call_rcu_in_progress;
};
struct bpf_mem_caches {
struct bpf_mem_cache cache[11];
};
struct trace_event_raw_kmem_cache_alloc {
struct trace_entry ent;
long unsigned int call_site;
const void *ptr;
size_t bytes_req;
size_t bytes_alloc;
long unsigned int gfp_flags;
int node;
bool accounted;
char __data[0];
};
struct trace_event_raw_kmalloc {
struct trace_entry ent;
long unsigned int call_site;
const void *ptr;
size_t bytes_req;
size_t bytes_alloc;
long unsigned int gfp_flags;
int node;
char __data[0];
};
struct trace_event_raw_kfree {
struct trace_entry ent;
long unsigned int call_site;
const void *ptr;
char __data[0];
};
struct trace_event_raw_kmem_cache_free {
struct trace_entry ent;
long unsigned int call_site;
const void *ptr;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_mm_page_free {
struct trace_entry ent;
long unsigned int pfn;
unsigned int order;
char __data[0];
};
struct trace_event_raw_mm_page_free_batched {
struct trace_entry ent;
long unsigned int pfn;
char __data[0];
};
struct trace_event_raw_mm_page_alloc {
struct trace_entry ent;
long unsigned int pfn;
unsigned int order;
long unsigned int gfp_flags;
int migratetype;
char __data[0];
};
struct trace_event_raw_mm_page {
struct trace_entry ent;
long unsigned int pfn;
unsigned int order;
int migratetype;
int percpu_refill;
char __data[0];
};
struct trace_event_raw_mm_page_pcpu_drain {
struct trace_entry ent;
long unsigned int pfn;
unsigned int order;
int migratetype;
char __data[0];
};
struct trace_event_raw_mm_page_alloc_extfrag {
struct trace_entry ent;
long unsigned int pfn;
int alloc_order;
int fallback_order;
int alloc_migratetype;
int fallback_migratetype;
int change_ownership;
char __data[0];
};
struct trace_event_raw_rss_stat {
struct trace_entry ent;
unsigned int mm_id;
unsigned int curr;
int member;
long int size;
char __data[0];
};
struct trace_event_data_offsets_kmem_cache_alloc {};
struct trace_event_data_offsets_kmalloc {};
struct trace_event_data_offsets_kfree {};
struct trace_event_data_offsets_kmem_cache_free {
u32 name;
};
struct trace_event_data_offsets_mm_page_free {};
struct trace_event_data_offsets_mm_page_free_batched {};
struct trace_event_data_offsets_mm_page_alloc {};
struct trace_event_data_offsets_mm_page {};
struct trace_event_data_offsets_mm_page_pcpu_drain {};
struct trace_event_data_offsets_mm_page_alloc_extfrag {};
struct trace_event_data_offsets_rss_stat {};
typedef void (*btf_trace_kmem_cache_alloc)(void *, long unsigned int, const void *, struct kmem_cache *, gfp_t, int);
typedef void (*btf_trace_kmalloc)(void *, long unsigned int, const void *, size_t, size_t, gfp_t, int);
typedef void (*btf_trace_kfree)(void *, long unsigned int, const void *);
typedef void (*btf_trace_kmem_cache_free)(void *, long unsigned int, const void *, const struct kmem_cache *);
typedef void (*btf_trace_mm_page_free)(void *, struct page *, unsigned int);
typedef void (*btf_trace_mm_page_free_batched)(void *, struct page *);
typedef void (*btf_trace_mm_page_alloc)(void *, struct page *, unsigned int, gfp_t, int);
typedef void (*btf_trace_mm_page_alloc_zone_locked)(void *, struct page *, unsigned int, int, int);
typedef void (*btf_trace_mm_page_pcpu_drain)(void *, struct page *, unsigned int, int);
typedef void (*btf_trace_mm_page_alloc_extfrag)(void *, struct page *, int, int, int, int);
typedef void (*btf_trace_rss_stat)(void *, struct mm_struct *, int, long int);
struct vmap_area {
long unsigned int va_start;
long unsigned int va_end;
struct rb_node rb_node;
struct list_head list;
union {
long unsigned int subtree_max_size;
struct vm_struct *vm;
};
};
typedef unsigned int kasan_vmalloc_flags_t;
enum memcg_stat_item {
MEMCG_SWAP = 41,
MEMCG_SOCK = 42,
MEMCG_PERCPU_B = 43,
MEMCG_VMALLOC = 44,
MEMCG_KMEM = 45,
MEMCG_ZSWAP_B = 46,
MEMCG_ZSWAPPED = 47,
MEMCG_NR_STAT = 48,
};
struct vfree_deferred {
struct llist_head list;
struct work_struct wq;
};
enum fit_type {
NOTHING_FIT = 0,
FL_FIT_TYPE = 1,
LE_FIT_TYPE = 2,
RE_FIT_TYPE = 3,
NE_FIT_TYPE = 4,
};
struct vmap_block_queue {
spinlock_t lock;
struct list_head free;
};
struct vmap_block {
spinlock_t lock;
struct vmap_area *va;
long unsigned int free;
long unsigned int dirty;
long unsigned int dirty_min;
long unsigned int dirty_max;
struct list_head free_list;
struct callback_head callback_head;
struct list_head purge;
};
struct f_owner_ex {
int type;
__kernel_pid_t pid;
};
struct trace_event_raw_iomap_readpage_class {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 ino;
int nr_pages;
char __data[0];
long: 32;
};
struct trace_event_raw_iomap_range_class {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 ino;
loff_t size;
loff_t offset;
u64 length;
char __data[0];
};
struct trace_event_raw_iomap_class {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 ino;
u64 addr;
loff_t offset;
u64 length;
u16 type;
u16 flags;
dev_t bdev;
char __data[0];
};
struct trace_event_raw_iomap_iter {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 ino;
loff_t pos;
u64 length;
unsigned int flags;
const void *ops;
long unsigned int caller;
char __data[0];
long: 32;
};
struct trace_event_data_offsets_iomap_readpage_class {};
struct trace_event_data_offsets_iomap_range_class {};
struct trace_event_data_offsets_iomap_class {};
struct trace_event_data_offsets_iomap_iter {};
typedef void (*btf_trace_iomap_readpage)(void *, struct inode *, int);
typedef void (*btf_trace_iomap_readahead)(void *, struct inode *, int);
typedef void (*btf_trace_iomap_writepage)(void *, struct inode *, loff_t, u64);
typedef void (*btf_trace_iomap_release_folio)(void *, struct inode *, loff_t, u64);
typedef void (*btf_trace_iomap_invalidate_folio)(void *, struct inode *, loff_t, u64);
typedef void (*btf_trace_iomap_dio_invalidate_fail)(void *, struct inode *, loff_t, u64);
typedef void (*btf_trace_iomap_iter_dstmap)(void *, struct inode *, struct iomap *);
typedef void (*btf_trace_iomap_iter_srcmap)(void *, struct inode *, struct iomap *);
typedef void (*btf_trace_iomap_writepage_map)(void *, struct inode *, struct iomap *);
typedef void (*btf_trace_iomap_iter)(void *, struct iomap_iter *, const void *, long unsigned int);
struct recovery_info {
tid_t start_transaction;
tid_t end_transaction;
int nr_replays;
int nr_revokes;
int nr_revoke_hits;
};
enum pnfs_iomode {
IOMODE_READ = 1,
IOMODE_RW = 2,
IOMODE_ANY = 3,
};
struct trace_event_raw_nfs_inode_event {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
u64 version;
char __data[0];
};
struct trace_event_raw_nfs_inode_event_done {
struct trace_entry ent;
long unsigned int error;
dev_t dev;
u32 fhandle;
unsigned char type;
u64 fileid;
u64 version;
loff_t size;
long unsigned int nfsi_flags;
long unsigned int cache_validity;
char __data[0];
};
struct trace_event_raw_nfs_access_exit {
struct trace_entry ent;
long unsigned int error;
dev_t dev;
u32 fhandle;
unsigned char type;
u64 fileid;
u64 version;
loff_t size;
long unsigned int nfsi_flags;
long unsigned int cache_validity;
unsigned int mask;
unsigned int permitted;
char __data[0];
};
struct trace_event_raw_nfs_update_size_class {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
u64 version;
loff_t cur_size;
loff_t new_size;
char __data[0];
};
struct trace_event_raw_nfs_inode_range_event {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
u64 version;
loff_t range_start;
loff_t range_end;
char __data[0];
};
struct trace_event_raw_nfs_readdir_event {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
u64 version;
char verifier[8];
u64 cookie;
long unsigned int index;
unsigned int dtsize;
char __data[0];
};
struct trace_event_raw_nfs_lookup_event {
struct trace_entry ent;
long unsigned int flags;
dev_t dev;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_lookup_event_done {
struct trace_entry ent;
long unsigned int error;
long unsigned int flags;
dev_t dev;
long: 32;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_atomic_open_enter {
struct trace_entry ent;
long unsigned int flags;
long unsigned int fmode;
dev_t dev;
long: 32;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_atomic_open_exit {
struct trace_entry ent;
long unsigned int error;
long unsigned int flags;
long unsigned int fmode;
dev_t dev;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_create_enter {
struct trace_entry ent;
long unsigned int flags;
dev_t dev;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_create_exit {
struct trace_entry ent;
long unsigned int error;
long unsigned int flags;
dev_t dev;
long: 32;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_directory_event {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_directory_event_done {
struct trace_entry ent;
long unsigned int error;
dev_t dev;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_link_enter {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 fileid;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_link_exit {
struct trace_entry ent;
long unsigned int error;
dev_t dev;
u64 fileid;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_rename_event {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 old_dir;
u64 new_dir;
u32 __data_loc_old_name;
u32 __data_loc_new_name;
char __data[0];
};
struct trace_event_raw_nfs_rename_event_done {
struct trace_entry ent;
dev_t dev;
long unsigned int error;
u64 old_dir;
u32 __data_loc_old_name;
long: 32;
u64 new_dir;
u32 __data_loc_new_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_sillyrename_unlink {
struct trace_entry ent;
dev_t dev;
long unsigned int error;
u64 dir;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_aop_readpage {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
u64 version;
loff_t offset;
char __data[0];
};
struct trace_event_raw_nfs_aop_readpage_done {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
int ret;
long: 32;
u64 fileid;
u64 version;
loff_t offset;
char __data[0];
};
struct trace_event_raw_nfs_aop_readahead {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
u64 version;
loff_t offset;
unsigned int nr_pages;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_aop_readahead_done {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
int ret;
long: 32;
u64 fileid;
u64 version;
loff_t offset;
unsigned int nr_pages;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_initiate_read {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
u32 count;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_readpage_done {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
u32 arg_count;
u32 res_count;
bool eof;
int error;
char __data[0];
};
struct trace_event_raw_nfs_readpage_short {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
u32 arg_count;
u32 res_count;
bool eof;
int error;
char __data[0];
};
struct trace_event_raw_nfs_fscache_page_event {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
char __data[0];
};
struct trace_event_raw_nfs_fscache_page_event_done {
struct trace_entry ent;
int error;
dev_t dev;
u32 fhandle;
long: 32;
u64 fileid;
loff_t offset;
char __data[0];
};
struct trace_event_raw_nfs_pgio_error {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
u32 arg_count;
u32 res_count;
loff_t pos;
int error;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_initiate_write {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
u32 count;
long unsigned int stable;
char __data[0];
};
struct trace_event_raw_nfs_writeback_done {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
u32 arg_count;
u32 res_count;
int error;
long unsigned int stable;
char verifier[8];
char __data[0];
};
struct trace_event_raw_nfs_page_error_class {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
unsigned int count;
int error;
char __data[0];
};
struct trace_event_raw_nfs_initiate_commit {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
u32 count;
char __data[0];
long: 32;
};
struct trace_event_raw_nfs_commit_done {
struct trace_entry ent;
dev_t dev;
u32 fhandle;
u64 fileid;
loff_t offset;
int error;
long unsigned int stable;
char verifier[8];
char __data[0];
};
struct trace_event_raw_nfs_direct_req_class {
struct trace_entry ent;
dev_t dev;
long: 32;
u64 fileid;
u32 fhandle;
long: 32;
loff_t offset;
ssize_t count;
ssize_t bytes_left;
ssize_t error;
int flags;
char __data[0];
};
struct trace_event_raw_nfs_fh_to_dentry {
struct trace_entry ent;
int error;
dev_t dev;
u32 fhandle;
long: 32;
u64 fileid;
char __data[0];
};
struct trace_event_raw_nfs_mount_assign {
struct trace_entry ent;
u32 __data_loc_option;
u32 __data_loc_value;
char __data[0];
};
struct trace_event_raw_nfs_mount_option {
struct trace_entry ent;
u32 __data_loc_option;
char __data[0];
};
struct trace_event_raw_nfs_mount_path {
struct trace_entry ent;
u32 __data_loc_path;
char __data[0];
};
struct trace_event_raw_nfs_xdr_event {
struct trace_entry ent;
unsigned int task_id;
unsigned int client_id;
u32 xid;
int version;
long unsigned int error;
u32 __data_loc_program;
u32 __data_loc_procedure;
char __data[0];
};
struct trace_event_data_offsets_nfs_inode_event {};
struct trace_event_data_offsets_nfs_inode_event_done {};
struct trace_event_data_offsets_nfs_access_exit {};
struct trace_event_data_offsets_nfs_update_size_class {};
struct trace_event_data_offsets_nfs_inode_range_event {};
struct trace_event_data_offsets_nfs_readdir_event {};
struct trace_event_data_offsets_nfs_lookup_event {
u32 name;
};
struct trace_event_data_offsets_nfs_lookup_event_done {
u32 name;
};
struct trace_event_data_offsets_nfs_atomic_open_enter {
u32 name;
};
struct trace_event_data_offsets_nfs_atomic_open_exit {
u32 name;
};
struct trace_event_data_offsets_nfs_create_enter {
u32 name;
};
struct trace_event_data_offsets_nfs_create_exit {
u32 name;
};
struct trace_event_data_offsets_nfs_directory_event {
u32 name;
};
struct trace_event_data_offsets_nfs_directory_event_done {
u32 name;
};
struct trace_event_data_offsets_nfs_link_enter {
u32 name;
};
struct trace_event_data_offsets_nfs_link_exit {
u32 name;
};
struct trace_event_data_offsets_nfs_rename_event {
u32 old_name;
u32 new_name;
};
struct trace_event_data_offsets_nfs_rename_event_done {
u32 old_name;
u32 new_name;
};
struct trace_event_data_offsets_nfs_sillyrename_unlink {
u32 name;
};
struct trace_event_data_offsets_nfs_aop_readpage {};
struct trace_event_data_offsets_nfs_aop_readpage_done {};
struct trace_event_data_offsets_nfs_aop_readahead {};
struct trace_event_data_offsets_nfs_aop_readahead_done {};
struct trace_event_data_offsets_nfs_initiate_read {};
struct trace_event_data_offsets_nfs_readpage_done {};
struct trace_event_data_offsets_nfs_readpage_short {};
struct trace_event_data_offsets_nfs_fscache_page_event {};
struct trace_event_data_offsets_nfs_fscache_page_event_done {};
struct trace_event_data_offsets_nfs_pgio_error {};
struct trace_event_data_offsets_nfs_initiate_write {};
struct trace_event_data_offsets_nfs_writeback_done {};
struct trace_event_data_offsets_nfs_page_error_class {};
struct trace_event_data_offsets_nfs_initiate_commit {};
struct trace_event_data_offsets_nfs_commit_done {};
struct trace_event_data_offsets_nfs_direct_req_class {};
struct trace_event_data_offsets_nfs_fh_to_dentry {};
struct trace_event_data_offsets_nfs_mount_assign {
u32 option;
u32 value;
};
struct trace_event_data_offsets_nfs_mount_option {
u32 option;
};
struct trace_event_data_offsets_nfs_mount_path {
u32 path;
};
struct trace_event_data_offsets_nfs_xdr_event {
u32 program;
u32 procedure;
};
typedef void (*btf_trace_nfs_set_inode_stale)(void *, const struct inode *);
typedef void (*btf_trace_nfs_refresh_inode_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_refresh_inode_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_revalidate_inode_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_revalidate_inode_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_invalidate_mapping_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_invalidate_mapping_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_getattr_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_getattr_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_setattr_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_setattr_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_writeback_page_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_writeback_page_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_writeback_inode_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_writeback_inode_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_fsync_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_fsync_exit)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_access_enter)(void *, const struct inode *);
typedef void (*btf_trace_nfs_set_cache_invalid)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_readdir_force_readdirplus)(void *, const struct inode *);
typedef void (*btf_trace_nfs_readdir_cache_fill_done)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_readdir_uncached_done)(void *, const struct inode *, int);
typedef void (*btf_trace_nfs_access_exit)(void *, const struct inode *, unsigned int, unsigned int, int);
typedef void (*btf_trace_nfs_size_truncate)(void *, const struct inode *, loff_t);
typedef void (*btf_trace_nfs_size_wcc)(void *, const struct inode *, loff_t);
typedef void (*btf_trace_nfs_size_update)(void *, const struct inode *, loff_t);
typedef void (*btf_trace_nfs_size_grow)(void *, const struct inode *, loff_t);
typedef void (*btf_trace_nfs_readdir_invalidate_cache_range)(void *, const struct inode *, loff_t, loff_t);
typedef void (*btf_trace_nfs_readdir_cache_fill)(void *, const struct file *, const __be32 *, u64, long unsigned int, unsigned int);
typedef void (*btf_trace_nfs_readdir_uncached)(void *, const struct file *, const __be32 *, u64, long unsigned int, unsigned int);
typedef void (*btf_trace_nfs_lookup_enter)(void *, const struct inode *, const struct dentry *, unsigned int);
typedef void (*btf_trace_nfs_lookup_exit)(void *, const struct inode *, const struct dentry *, unsigned int, int);
typedef void (*btf_trace_nfs_lookup_revalidate_enter)(void *, const struct inode *, const struct dentry *, unsigned int);
typedef void (*btf_trace_nfs_lookup_revalidate_exit)(void *, const struct inode *, const struct dentry *, unsigned int, int);
typedef void (*btf_trace_nfs_readdir_lookup)(void *, const struct inode *, const struct dentry *, unsigned int);
typedef void (*btf_trace_nfs_readdir_lookup_revalidate_failed)(void *, const struct inode *, const struct dentry *, unsigned int);
typedef void (*btf_trace_nfs_readdir_lookup_revalidate)(void *, const struct inode *, const struct dentry *, unsigned int, int);
typedef void (*btf_trace_nfs_atomic_open_enter)(void *, const struct inode *, const struct nfs_open_context *, unsigned int);
typedef void (*btf_trace_nfs_atomic_open_exit)(void *, const struct inode *, const struct nfs_open_context *, unsigned int, int);
typedef void (*btf_trace_nfs_create_enter)(void *, const struct inode *, const struct dentry *, unsigned int);
typedef void (*btf_trace_nfs_create_exit)(void *, const struct inode *, const struct dentry *, unsigned int, int);
typedef void (*btf_trace_nfs_mknod_enter)(void *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_mknod_exit)(void *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_mkdir_enter)(void *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_mkdir_exit)(void *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_rmdir_enter)(void *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_rmdir_exit)(void *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_remove_enter)(void *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_remove_exit)(void *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_unlink_enter)(void *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_unlink_exit)(void *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_symlink_enter)(void *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_symlink_exit)(void *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_link_enter)(void *, const struct inode *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_link_exit)(void *, const struct inode *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_rename_enter)(void *, const struct inode *, const struct dentry *, const struct inode *, const struct dentry *);
typedef void (*btf_trace_nfs_rename_exit)(void *, const struct inode *, const struct dentry *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_sillyrename_rename)(void *, const struct inode *, const struct dentry *, const struct inode *, const struct dentry *, int);
typedef void (*btf_trace_nfs_sillyrename_unlink)(void *, const struct nfs_unlinkdata *, int);
typedef void (*btf_trace_nfs_aop_readpage)(void *, const struct inode *, struct page *);
typedef void (*btf_trace_nfs_aop_readpage_done)(void *, const struct inode *, struct page *, int);
typedef void (*btf_trace_nfs_aop_readahead)(void *, const struct inode *, loff_t, unsigned int);
typedef void (*btf_trace_nfs_aop_readahead_done)(void *, const struct inode *, unsigned int, int);
typedef void (*btf_trace_nfs_initiate_read)(void *, const struct nfs_pgio_header *);
typedef void (*btf_trace_nfs_readpage_done)(void *, const struct rpc_task *, const struct nfs_pgio_header *);
typedef void (*btf_trace_nfs_readpage_short)(void *, const struct rpc_task *, const struct nfs_pgio_header *);
typedef void (*btf_trace_nfs_fscache_read_page)(void *, const struct inode *, struct page *);
typedef void (*btf_trace_nfs_fscache_read_page_exit)(void *, const struct inode *, struct page *, int);
typedef void (*btf_trace_nfs_fscache_write_page)(void *, const struct inode *, struct page *);
typedef void (*btf_trace_nfs_fscache_write_page_exit)(void *, const struct inode *, struct page *, int);
typedef void (*btf_trace_nfs_pgio_error)(void *, const struct nfs_pgio_header *, int, loff_t);
typedef void (*btf_trace_nfs_initiate_write)(void *, const struct nfs_pgio_header *);
typedef void (*btf_trace_nfs_writeback_done)(void *, const struct rpc_task *, const struct nfs_pgio_header *);
typedef void (*btf_trace_nfs_write_error)(void *, const struct inode *, const struct nfs_page *, int);
typedef void (*btf_trace_nfs_comp_error)(void *, const struct inode *, const struct nfs_page *, int);
typedef void (*btf_trace_nfs_commit_error)(void *, const struct inode *, const struct nfs_page *, int);
typedef void (*btf_trace_nfs_initiate_commit)(void *, const struct nfs_commit_data *);
typedef void (*btf_trace_nfs_commit_done)(void *, const struct rpc_task *, const struct nfs_commit_data *);
typedef void (*btf_trace_nfs_direct_commit_complete)(void *, const struct nfs_direct_req *);
typedef void (*btf_trace_nfs_direct_resched_write)(void *, const struct nfs_direct_req *);
typedef void (*btf_trace_nfs_direct_write_complete)(void *, const struct nfs_direct_req *);
typedef void (*btf_trace_nfs_direct_write_completion)(void *, const struct nfs_direct_req *);
typedef void (*btf_trace_nfs_direct_write_schedule_iovec)(void *, const struct nfs_direct_req *);
typedef void (*btf_trace_nfs_direct_write_reschedule_io)(void *, const struct nfs_direct_req *);
typedef void (*btf_trace_nfs_fh_to_dentry)(void *, const struct super_block *, const struct nfs_fh *, u64, int);
typedef void (*btf_trace_nfs_mount_assign)(void *, const char *, const char *);
typedef void (*btf_trace_nfs_mount_option)(void *, const struct fs_parameter *);
typedef void (*btf_trace_nfs_mount_path)(void *, const char *);
typedef void (*btf_trace_nfs_xdr_status)(void *, const struct xdr_stream *, int);
typedef void (*btf_trace_nfs_xdr_bad_filehandle)(void *, const struct xdr_stream *, int);
struct fb_event {
struct fb_info *info;
void *data;
};
struct clk_mux {
struct clk_hw hw;
void *reg;
const u32 *table;
u32 mask;
u8 shift;
u8 flags;
spinlock_t *lock;
};
struct kbdiacr {
unsigned char diacr;
unsigned char base;
unsigned char result;
};
struct kbdiacrs {
unsigned int kb_cnt;
struct kbdiacr kbdiacr[256];
};
struct kbdiacrsuc {
unsigned int kb_cnt;
struct kbdiacruc kbdiacruc[256];
};
struct keyboard_notifier_param {
struct vc_data *vc;
int down;
int shift;
int ledstate;
unsigned int value;
};
struct kbd_struct {
unsigned char lockstate;
unsigned char slockstate;
unsigned char ledmode: 1;
unsigned char ledflagstate: 4;
char: 3;
unsigned char default_ledflagstate: 4;
unsigned char kbdmode: 3;
long: 1;
unsigned char modeflags: 5;
};
typedef void k_handler_fn(struct vc_data *, unsigned char, char);
typedef void fn_handler_fn(struct vc_data *);
struct getset_keycode_data {
struct input_keymap_entry ke;
int error;
};
struct cpu_attr {
struct device_attribute attr;
const struct cpumask * const map;
};
struct scsi_host_busy_iter_data {
bool (*fn)(struct scsi_cmnd *, void *);
void *priv;
};
struct fixed_mdio_bus {
struct mii_bus *mii_bus;
struct list_head phys;
};
struct fixed_phy {
int addr;
struct phy_device *phydev;
struct fixed_phy_status status;
bool no_carrier;
int (*link_update)(struct net_device *, struct fixed_phy_status *);
struct list_head node;
struct gpio_desc *link_gpiod;
};
enum i8042_controller_reset_mode {
I8042_RESET_NEVER = 0,
I8042_RESET_ALWAYS = 1,
I8042_RESET_ON_S2RAM = 2,
};
struct i8042_port {
struct serio *serio;
int irq;
bool exists;
bool driver_bound;
signed char mux;
};
struct ps2pp_info {
u8 model;
u8 kind;
u16 features;
};
struct i2c_board_info {
char type[20];
short unsigned int flags;
short unsigned int addr;
const char *dev_name;
void *platform_data;
struct device_node *of_node;
struct fwnode_handle *fwnode;
const struct software_node *swnode;
const struct resource *resources;
unsigned int num_resources;
int irq;
};
struct i2c_devinfo {
struct list_head list;
int busnum;
struct i2c_board_info board_info;
};
struct of_bus {
const char *name;
const char *addresses;
int (*match)(struct device_node *);
void (*count_cells)(struct device_node *, int *, int *);
u64 (*map)(__be32 *, const __be32 *, int, int, int);
int (*translate)(__be32 *, u64, int);
bool has_flags;
unsigned int (*get_flags)(const __be32 *);
};
struct rx_queue_attribute {
struct attribute attr;
ssize_t (*show)(struct netdev_rx_queue *, char *);
ssize_t (*store)(struct netdev_rx_queue *, const char *, size_t);
};
struct netdev_queue_attribute {
struct attribute attr;
ssize_t (*show)(struct netdev_queue *, char *);
ssize_t (*store)(struct netdev_queue *, const char *, size_t);
};
struct bpf_stab {
struct bpf_map map;
struct sock **sks;
struct sk_psock_progs progs;
raw_spinlock_t lock;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef u64 (*btf_bpf_sock_map_update)(struct bpf_sock_ops_kern *, struct bpf_map *, void *, u64);
typedef u64 (*btf_bpf_sk_redirect_map)(struct sk_buff *, struct bpf_map *, u32, u64);
typedef u64 (*btf_bpf_msg_redirect_map)(struct sk_msg *, struct bpf_map *, u32, u64);
struct sock_map_seq_info {
struct bpf_map *map;
struct sock *sk;
u32 index;
};
struct bpf_iter__sockmap {
union {
struct bpf_iter_meta *meta;
};
union {
struct bpf_map *map;
};
union {
void *key;
};
union {
struct sock *sk;
};
};
struct bpf_shtab_elem {
struct callback_head rcu;
u32 hash;
struct sock *sk;
struct hlist_node node;
u8 key[0];
};
struct bpf_shtab_bucket {
struct hlist_head head;
raw_spinlock_t lock;
};
struct bpf_shtab {
struct bpf_map map;
struct bpf_shtab_bucket *buckets;
u32 buckets_num;
u32 elem_size;
struct sk_psock_progs progs;
atomic_t count;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
typedef u64 (*btf_bpf_sock_hash_update)(struct bpf_sock_ops_kern *, struct bpf_map *, void *, u64);
typedef u64 (*btf_bpf_sk_redirect_hash)(struct sk_buff *, struct bpf_map *, void *, u64);
typedef u64 (*btf_bpf_msg_redirect_hash)(struct sk_msg *, struct bpf_map *, void *, u64);
struct sock_hash_seq_info {
struct bpf_map *map;
struct bpf_shtab *htab;
u32 bucket_id;
};
enum {
ETHTOOL_A_STRING_UNSPEC = 0,
ETHTOOL_A_STRING_INDEX = 1,
ETHTOOL_A_STRING_VALUE = 2,
__ETHTOOL_A_STRING_CNT = 3,
ETHTOOL_A_STRING_MAX = 2,
};
enum {
ETHTOOL_A_STRINGS_UNSPEC = 0,
ETHTOOL_A_STRINGS_STRING = 1,
__ETHTOOL_A_STRINGS_CNT = 2,
ETHTOOL_A_STRINGS_MAX = 1,
};
enum {
ETHTOOL_A_STRINGSET_UNSPEC = 0,
ETHTOOL_A_STRINGSET_ID = 1,
ETHTOOL_A_STRINGSET_COUNT = 2,
ETHTOOL_A_STRINGSET_STRINGS = 3,
__ETHTOOL_A_STRINGSET_CNT = 4,
ETHTOOL_A_STRINGSET_MAX = 3,
};
enum {
ETHTOOL_A_STRINGSETS_UNSPEC = 0,
ETHTOOL_A_STRINGSETS_STRINGSET = 1,
__ETHTOOL_A_STRINGSETS_CNT = 2,
ETHTOOL_A_STRINGSETS_MAX = 1,
};
struct strset_info {
bool per_dev;
bool free_strings;
unsigned int count;
const char (*strings)[32];
};
struct strset_req_info {
struct ethnl_req_info base;
u32 req_ids;
bool counts_only;
};
struct strset_reply_data {
struct ethnl_reply_data base;
struct strset_info sets[21];
};
struct privflags_reply_data {
struct ethnl_reply_data base;
const char (*priv_flag_names)[32];
unsigned int n_priv_flags;
u32 priv_flags;
};
struct icmp_ext_hdr {
__u8 reserved1: 4;
__u8 version: 4;
__u8 reserved2;
__sum16 checksum;
};
struct icmp_extobj_hdr {
__be16 length;
__u8 class_num;
__u8 class_type;
};
struct icmp_ext_echo_ctype3_hdr {
__be16 afi;
__u8 addrlen;
__u8 reserved;
};
struct icmp_ext_echo_iio {
struct icmp_extobj_hdr extobj_hdr;
union {
char name[16];
__be32 ifindex;
struct {
struct icmp_ext_echo_ctype3_hdr ctype3_hdr;
union {
__be32 ipv4_addr;
struct in6_addr ipv6_addr;
} ip_addr;
} addr;
} ident;
};
struct icmp_bxm {
struct sk_buff *skb;
int offset;
int data_len;
struct {
struct icmphdr icmph;
__be32 times[3];
} data;
int head_len;
struct ip_options_data replyopts;
};
struct icmp_control {
enum skb_drop_reason (*handler)(struct sk_buff *);
short int error;
};
struct ipv6_mreq {
struct in6_addr ipv6mr_multiaddr;
int ipv6mr_ifindex;
};
struct group_req {
__u32 gr_interface;
struct __kernel_sockaddr_storage gr_group;
};
struct group_source_req {
__u32 gsr_interface;
struct __kernel_sockaddr_storage gsr_group;
struct __kernel_sockaddr_storage gsr_source;
};
struct compat_group_req {
__u32 gr_interface;
struct __kernel_sockaddr_storage gr_group;
};
struct compat_group_source_req {
__u32 gsr_interface;
struct __kernel_sockaddr_storage gsr_group;
struct __kernel_sockaddr_storage gsr_source;
};
struct compat_group_filter {
union {
struct {
__u32 gf_interface_aux;
struct __kernel_sockaddr_storage gf_group_aux;
__u32 gf_fmode_aux;
__u32 gf_numsrc_aux;
struct __kernel_sockaddr_storage gf_slist[1];
};
struct {
__u32 gf_interface;
struct __kernel_sockaddr_storage gf_group;
__u32 gf_fmode;
__u32 gf_numsrc;
struct __kernel_sockaddr_storage gf_slist_flex[0];
};
};
};
struct sockaddr_pkt {
short unsigned int spkt_family;
unsigned char spkt_device[14];
__be16 spkt_protocol;
};
struct sockaddr_ll {
short unsigned int sll_family;
__be16 sll_protocol;
int sll_ifindex;
short unsigned int sll_hatype;
unsigned char sll_pkttype;
unsigned char sll_halen;
unsigned char sll_addr[8];
};
struct tpacket_stats {
unsigned int tp_packets;
unsigned int tp_drops;
};
struct tpacket_stats_v3 {
unsigned int tp_packets;
unsigned int tp_drops;
unsigned int tp_freeze_q_cnt;
};
struct tpacket_rollover_stats {
__u64 tp_all;
__u64 tp_huge;
__u64 tp_failed;
};
union tpacket_stats_u {
struct tpacket_stats stats1;
struct tpacket_stats_v3 stats3;
};
struct tpacket_auxdata {
__u32 tp_status;
__u32 tp_len;
__u32 tp_snaplen;
__u16 tp_mac;
__u16 tp_net;
__u16 tp_vlan_tci;
__u16 tp_vlan_tpid;
};
struct tpacket_hdr {
long unsigned int tp_status;
unsigned int tp_len;
unsigned int tp_snaplen;
short unsigned int tp_mac;
short unsigned int tp_net;
unsigned int tp_sec;
unsigned int tp_usec;
};
struct tpacket2_hdr {
__u32 tp_status;
__u32 tp_len;
__u32 tp_snaplen;
__u16 tp_mac;
__u16 tp_net;
__u32 tp_sec;
__u32 tp_nsec;
__u16 tp_vlan_tci;
__u16 tp_vlan_tpid;
__u8 tp_padding[4];
};
struct tpacket_hdr_variant1 {
__u32 tp_rxhash;
__u32 tp_vlan_tci;
__u16 tp_vlan_tpid;
__u16 tp_padding;
};
struct tpacket3_hdr {
__u32 tp_next_offset;
__u32 tp_sec;
__u32 tp_nsec;
__u32 tp_snaplen;
__u32 tp_len;
__u32 tp_status;
__u16 tp_mac;
__u16 tp_net;
union {
struct tpacket_hdr_variant1 hv1;
};
__u8 tp_padding[8];
};
struct tpacket_bd_ts {
unsigned int ts_sec;
union {
unsigned int ts_usec;
unsigned int ts_nsec;
};
};
struct tpacket_hdr_v1 {
__u32 block_status;
__u32 num_pkts;
__u32 offset_to_first_pkt;
__u32 blk_len;
__u64 seq_num;
struct tpacket_bd_ts ts_first_pkt;
struct tpacket_bd_ts ts_last_pkt;
};
union tpacket_bd_header_u {
struct tpacket_hdr_v1 bh1;
};
struct tpacket_block_desc {
__u32 version;
__u32 offset_to_priv;
union tpacket_bd_header_u hdr;
};
enum tpacket_versions {
TPACKET_V1 = 0,
TPACKET_V2 = 1,
TPACKET_V3 = 2,
};
struct tpacket_req {
unsigned int tp_block_size;
unsigned int tp_block_nr;
unsigned int tp_frame_size;
unsigned int tp_frame_nr;
};
struct tpacket_req3 {
unsigned int tp_block_size;
unsigned int tp_block_nr;
unsigned int tp_frame_size;
unsigned int tp_frame_nr;
unsigned int tp_retire_blk_tov;
unsigned int tp_sizeof_priv;
unsigned int tp_feature_req_word;
};
union tpacket_req_u {
struct tpacket_req req;
struct tpacket_req3 req3;
};
struct fanout_args {
__u16 id;
__u16 type_flags;
__u32 max_num_members;
};
typedef __u16 __virtio16;
struct virtio_net_hdr {
__u8 flags;
__u8 gso_type;
__virtio16 hdr_len;
__virtio16 gso_size;
__virtio16 csum_start;
__virtio16 csum_offset;
};
struct packet_mclist {
struct packet_mclist *next;
int ifindex;
int count;
short unsigned int type;
short unsigned int alen;
unsigned char addr[32];
};
struct pgv;
struct tpacket_kbdq_core {
struct pgv *pkbdq;
unsigned int feature_req_word;
unsigned int hdrlen;
unsigned char reset_pending_on_curr_blk;
unsigned char delete_blk_timer;
short unsigned int kactive_blk_num;
short unsigned int blk_sizeof_priv;
short unsigned int last_kactive_blk_num;
char *pkblk_start;
char *pkblk_end;
int kblk_size;
unsigned int max_frame_len;
unsigned int knum_blocks;
uint64_t knxt_seq_num;
char *prev;
char *nxt_offset;
struct sk_buff *skb;
rwlock_t blk_fill_in_prog_lock;
short unsigned int retire_blk_tov;
short unsigned int version;
long unsigned int tov_in_jiffies;
struct timer_list retire_blk_timer;
};
struct pgv {
char *buffer;
};
struct packet_ring_buffer {
struct pgv *pg_vec;
unsigned int head;
unsigned int frames_per_block;
unsigned int frame_size;
unsigned int frame_max;
unsigned int pg_vec_order;
unsigned int pg_vec_pages;
unsigned int pg_vec_len;
unsigned int *pending_refcnt;
long: 32;
union {
long unsigned int *rx_owner_map;
struct tpacket_kbdq_core prb_bdqc;
};
};
struct packet_fanout {
possible_net_t net;
unsigned int num_members;
u32 max_num_members;
u16 id;
u8 type;
u8 flags;
union {
atomic_t rr_cur;
struct bpf_prog *bpf_prog;
};
struct list_head list;
spinlock_t lock;
refcount_t sk_ref;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct packet_type prot_hook;
struct sock *arr[0];
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct packet_rollover {
int sock;
atomic_long_t num;
atomic_long_t num_huge;
atomic_long_t num_failed;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
u32 history[16];
};
struct packet_sock {
struct sock sk;
struct packet_fanout *fanout;
union tpacket_stats_u stats;
struct packet_ring_buffer rx_ring;
struct packet_ring_buffer tx_ring;
int copy_thresh;
spinlock_t bind_lock;
struct mutex pg_vec_lock;
unsigned int running;
unsigned int auxdata: 1;
unsigned int origdev: 1;
unsigned int has_vnet_hdr: 1;
unsigned int tp_loss: 1;
unsigned int tp_tx_has_off: 1;
int pressure;
int ifindex;
__be16 num;
struct packet_rollover *rollover;
struct packet_mclist *mclist;
atomic_t mapped;
enum tpacket_versions tp_version;
unsigned int tp_hdrlen;
unsigned int tp_reserve;
unsigned int tp_tstamp;
struct completion skb_completion;
struct net_device *cached_dev;
int (*xmit)(struct sk_buff *);
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct packet_type prot_hook;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
atomic_t tp_drops;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct packet_mreq_max {
int mr_ifindex;
short unsigned int mr_type;
short unsigned int mr_alen;
unsigned char mr_address[32];
};
union tpacket_uhdr {
struct tpacket_hdr *h1;
struct tpacket2_hdr *h2;
struct tpacket3_hdr *h3;
void *raw;
};
struct packet_skb_cb {
union {
struct sockaddr_pkt pkt;
union {
unsigned int origlen;
struct sockaddr_ll ll;
};
} sa;
};
struct uevent_sock {
struct list_head list;
struct sock *sk;
};
enum ftlb_flags {
FTLB_EN = 1,
FTLB_SET_PROB = 2,
};
enum perf_hw_id {
PERF_COUNT_HW_CPU_CYCLES = 0,
PERF_COUNT_HW_INSTRUCTIONS = 1,
PERF_COUNT_HW_CACHE_REFERENCES = 2,
PERF_COUNT_HW_CACHE_MISSES = 3,
PERF_COUNT_HW_BRANCH_INSTRUCTIONS = 4,
PERF_COUNT_HW_BRANCH_MISSES = 5,
PERF_COUNT_HW_BUS_CYCLES = 6,
PERF_COUNT_HW_STALLED_CYCLES_FRONTEND = 7,
PERF_COUNT_HW_STALLED_CYCLES_BACKEND = 8,
PERF_COUNT_HW_REF_CPU_CYCLES = 9,
PERF_COUNT_HW_MAX = 10,
};
enum perf_hw_cache_id {
PERF_COUNT_HW_CACHE_L1D = 0,
PERF_COUNT_HW_CACHE_L1I = 1,
PERF_COUNT_HW_CACHE_LL = 2,
PERF_COUNT_HW_CACHE_DTLB = 3,
PERF_COUNT_HW_CACHE_ITLB = 4,
PERF_COUNT_HW_CACHE_BPU = 5,
PERF_COUNT_HW_CACHE_NODE = 6,
PERF_COUNT_HW_CACHE_MAX = 7,
};
enum perf_hw_cache_op_id {
PERF_COUNT_HW_CACHE_OP_READ = 0,
PERF_COUNT_HW_CACHE_OP_WRITE = 1,
PERF_COUNT_HW_CACHE_OP_PREFETCH = 2,
PERF_COUNT_HW_CACHE_OP_MAX = 3,
};
enum perf_hw_cache_op_result_id {
PERF_COUNT_HW_CACHE_RESULT_ACCESS = 0,
PERF_COUNT_HW_CACHE_RESULT_MISS = 1,
PERF_COUNT_HW_CACHE_RESULT_MAX = 2,
};
struct cpu_hw_events {
struct perf_event *events[4];
long unsigned int used_mask[1];
unsigned int saved_ctrl[4];
};
struct mips_perf_event {
unsigned int event_id;
unsigned int cntr_mask;
enum {
T = 0,
V = 1,
P = 2,
} range;
};
struct mips_pmu {
u64 max_period;
u64 valid_count;
u64 overflow;
const char *name;
int irq;
u64 (*read_counter)(unsigned int);
void (*write_counter)(unsigned int, u64);
const struct mips_perf_event * (*map_raw_event)(u64);
const struct mips_perf_event (*general_event_map)[10];
const struct mips_perf_event (*cache_event_map)[42];
unsigned int num_counters;
};
struct prb_data_block {
long unsigned int id;
char data[0];
};
enum audit_ntp_type {
AUDIT_NTP_OFFSET = 0,
AUDIT_NTP_FREQ = 1,
AUDIT_NTP_STATUS = 2,
AUDIT_NTP_TAI = 3,
AUDIT_NTP_TICK = 4,
AUDIT_NTP_ADJUST = 5,
AUDIT_NTP_NVALS = 6,
};
enum ring_buffer_type {
RINGBUF_TYPE_DATA_TYPE_LEN_MAX = 28,
RINGBUF_TYPE_PADDING = 29,
RINGBUF_TYPE_TIME_EXTEND = 30,
RINGBUF_TYPE_TIME_STAMP = 31,
};
struct ring_buffer_per_cpu;
struct buffer_page;
struct ring_buffer_iter {
struct ring_buffer_per_cpu *cpu_buffer;
long unsigned int head;
long unsigned int next_event;
struct buffer_page *head_page;
struct buffer_page *cache_reader_page;
long unsigned int cache_read;
u64 read_stamp;
u64 page_stamp;
struct ring_buffer_event *event;
int missed_events;
};
struct rb_irq_work {
struct irq_work work;
wait_queue_head_t waiters;
wait_queue_head_t full_waiters;
long int wait_index;
bool waiters_pending;
bool full_waiters_pending;
bool wakeup_full;
};
struct trace_buffer {
unsigned int flags;
int cpus;
atomic_t record_disabled;
cpumask_var_t cpumask;
struct lock_class_key *reader_lock_key;
struct mutex mutex;
struct ring_buffer_per_cpu **buffers;
struct hlist_node node;
u64 (*clock)();
struct rb_irq_work irq_work;
bool time_stamp_abs;
};
enum {
RB_LEN_TIME_EXTEND = 8,
RB_LEN_TIME_STAMP = 8,
};
struct buffer_data_page {
u64 time_stamp;
local_t commit;
unsigned char data[0];
long: 32;
};
struct buffer_page {
struct list_head list;
local_t write;
unsigned int read;
local_t entries;
long unsigned int real_end;
struct buffer_data_page *page;
};
struct rb_event_info {
u64 ts;
u64 delta;
u64 before;
u64 after;
long unsigned int length;
struct buffer_page *tail_page;
int add_timestamp;
long: 32;
};
enum {
RB_ADD_STAMP_NONE = 0,
RB_ADD_STAMP_EXTEND = 2,
RB_ADD_STAMP_ABSOLUTE = 4,
RB_ADD_STAMP_FORCE = 8,
};
enum {
RB_CTX_TRANSITION = 0,
RB_CTX_NMI = 1,
RB_CTX_IRQ = 2,
RB_CTX_SOFTIRQ = 3,
RB_CTX_NORMAL = 4,
RB_CTX_MAX = 5,
};
struct rb_time_struct {
local_t cnt;
local_t top;
local_t bottom;
local_t msb;
};
typedef struct rb_time_struct rb_time_t;
struct ring_buffer_per_cpu {
int cpu;
atomic_t record_disabled;
atomic_t resize_disabled;
struct trace_buffer *buffer;
raw_spinlock_t reader_lock;
arch_spinlock_t lock;
struct lock_class_key lock_key;
struct buffer_data_page *free_page;
long unsigned int nr_pages;
unsigned int current_context;
struct list_head *pages;
struct buffer_page *head_page;
struct buffer_page *tail_page;
struct buffer_page *commit_page;
struct buffer_page *reader_page;
long unsigned int lost_events;
long unsigned int last_overrun;
long unsigned int nest;
local_t entries_bytes;
local_t entries;
local_t overrun;
local_t commit_overrun;
local_t dropped_events;
local_t committing;
local_t commits;
local_t pages_touched;
local_t pages_lost;
local_t pages_read;
long int last_pages_touch;
size_t shortest_full;
long unsigned int read;
long unsigned int read_bytes;
rb_time_t write_stamp;
rb_time_t before_stamp;
long: 32;
u64 event_stamp[5];
u64 read_stamp;
long int nr_pages_to_update;
struct list_head new_pages;
struct work_struct update_pages_work;
struct completion update_done;
struct rb_irq_work irq_work;
long: 32;
};
enum bpf_lru_list_type {
BPF_LRU_LIST_T_ACTIVE = 0,
BPF_LRU_LIST_T_INACTIVE = 1,
BPF_LRU_LIST_T_FREE = 2,
BPF_LRU_LOCAL_LIST_T_FREE = 3,
BPF_LRU_LOCAL_LIST_T_PENDING = 4,
};
enum perf_branch_sample_type {
PERF_SAMPLE_BRANCH_USER = 1,
PERF_SAMPLE_BRANCH_KERNEL = 2,
PERF_SAMPLE_BRANCH_HV = 4,
PERF_SAMPLE_BRANCH_ANY = 8,
PERF_SAMPLE_BRANCH_ANY_CALL = 16,
PERF_SAMPLE_BRANCH_ANY_RETURN = 32,
PERF_SAMPLE_BRANCH_IND_CALL = 64,
PERF_SAMPLE_BRANCH_ABORT_TX = 128,
PERF_SAMPLE_BRANCH_IN_TX = 256,
PERF_SAMPLE_BRANCH_NO_TX = 512,
PERF_SAMPLE_BRANCH_COND = 1024,
PERF_SAMPLE_BRANCH_CALL_STACK = 2048,
PERF_SAMPLE_BRANCH_IND_JUMP = 4096,
PERF_SAMPLE_BRANCH_CALL = 8192,
PERF_SAMPLE_BRANCH_NO_FLAGS = 16384,
PERF_SAMPLE_BRANCH_NO_CYCLES = 32768,
PERF_SAMPLE_BRANCH_TYPE_SAVE = 65536,
PERF_SAMPLE_BRANCH_HW_INDEX = 131072,
PERF_SAMPLE_BRANCH_PRIV_SAVE = 262144,
PERF_SAMPLE_BRANCH_MAX = 524288,
};
enum perf_event_read_format {
PERF_FORMAT_TOTAL_TIME_ENABLED = 1,
PERF_FORMAT_TOTAL_TIME_RUNNING = 2,
PERF_FORMAT_ID = 4,
PERF_FORMAT_GROUP = 8,
PERF_FORMAT_LOST = 16,
PERF_FORMAT_MAX = 32,
};
enum perf_event_ioc_flags {
PERF_IOC_FLAG_GROUP = 1,
};
struct perf_event_header {
__u32 type;
__u16 misc;
__u16 size;
};
struct perf_ns_link_info {
__u64 dev;
__u64 ino;
};
enum {
NET_NS_INDEX = 0,
UTS_NS_INDEX = 1,
IPC_NS_INDEX = 2,
PID_NS_INDEX = 3,
USER_NS_INDEX = 4,
MNT_NS_INDEX = 5,
CGROUP_NS_INDEX = 6,
NR_NAMESPACES = 7,
};
enum perf_event_type {
PERF_RECORD_MMAP = 1,
PERF_RECORD_LOST = 2,
PERF_RECORD_COMM = 3,
PERF_RECORD_EXIT = 4,
PERF_RECORD_THROTTLE = 5,
PERF_RECORD_UNTHROTTLE = 6,
PERF_RECORD_FORK = 7,
PERF_RECORD_READ = 8,
PERF_RECORD_SAMPLE = 9,
PERF_RECORD_MMAP2 = 10,
PERF_RECORD_AUX = 11,
PERF_RECORD_ITRACE_START = 12,
PERF_RECORD_LOST_SAMPLES = 13,
PERF_RECORD_SWITCH = 14,
PERF_RECORD_SWITCH_CPU_WIDE = 15,
PERF_RECORD_NAMESPACES = 16,
PERF_RECORD_KSYMBOL = 17,
PERF_RECORD_BPF_EVENT = 18,
PERF_RECORD_CGROUP = 19,
PERF_RECORD_TEXT_POKE = 20,
PERF_RECORD_AUX_OUTPUT_HW_ID = 21,
PERF_RECORD_MAX = 22,
};
enum perf_addr_filter_action_t {
PERF_ADDR_FILTER_ACTION_STOP = 0,
PERF_ADDR_FILTER_ACTION_START = 1,
PERF_ADDR_FILTER_ACTION_FILTER = 2,
};
struct perf_addr_filter {
struct list_head entry;
struct path path;
long unsigned int offset;
long unsigned int size;
enum perf_addr_filter_action_t action;
};
struct swevent_hlist {
struct hlist_head heads[256];
struct callback_head callback_head;
};
struct pmu_event_list {
raw_spinlock_t lock;
struct list_head list;
};
struct perf_pmu_events_attr {
struct device_attribute attr;
u64 id;
const char *event_str;
long: 32;
};
struct min_heap {
void *data;
int nr;
int size;
};
struct min_heap_callbacks {
int elem_size;
bool (*less)(const void *, const void *);
void (*swp)(void *, void *);
};
typedef int (*remote_function_f)(void *);
struct remote_function_call {
struct task_struct *p;
remote_function_f func;
void *info;
int ret;
};
typedef void (*event_f)(struct perf_event *, struct perf_cpu_context *, struct perf_event_context *, void *);
struct event_function_struct {
struct perf_event *event;
event_f func;
void *data;
};
enum event_type_t {
EVENT_FLEXIBLE = 1,
EVENT_PINNED = 2,
EVENT_TIME = 4,
EVENT_CPU = 8,
EVENT_ALL = 3,
};
struct __group_key {
int cpu;
struct cgroup *cgroup;
};
struct stop_event_data {
struct perf_event *event;
unsigned int restart;
};
struct perf_read_data {
struct perf_event *event;
bool group;
int ret;
};
struct perf_read_event {
struct perf_event_header header;
u32 pid;
u32 tid;
};
typedef void perf_iterate_f(struct perf_event *, void *);
struct remote_output {
struct perf_buffer *rb;
int err;
};
struct perf_task_event {
struct task_struct *task;
struct perf_event_context *task_ctx;
struct {
struct perf_event_header header;
u32 pid;
u32 ppid;
u32 tid;
u32 ptid;
u64 time;
} event_id;
};
struct perf_comm_event {
struct task_struct *task;
char *comm;
int comm_size;
struct {
struct perf_event_header header;
u32 pid;
u32 tid;
} event_id;
};
struct perf_namespaces_event {
struct task_struct *task;
long: 32;
struct {
struct perf_event_header header;
u32 pid;
u32 tid;
u64 nr_namespaces;
struct perf_ns_link_info link_info[7];
} event_id;
};
struct perf_mmap_event {
struct vm_area_struct *vma;
const char *file_name;
int file_size;
int maj;
int min;
long: 32;
u64 ino;
u64 ino_generation;
u32 prot;
u32 flags;
u8 build_id[20];
u32 build_id_size;
struct {
struct perf_event_header header;
u32 pid;
u32 tid;
u64 start;
u64 len;
u64 pgoff;
} event_id;
};
struct perf_switch_event {
struct task_struct *task;
struct task_struct *next_prev;
struct {
struct perf_event_header header;
u32 next_prev_pid;
u32 next_prev_tid;
} event_id;
};
struct perf_ksymbol_event {
const char *name;
int name_len;
struct {
struct perf_event_header header;
u64 addr;
u32 len;
u16 ksym_type;
u16 flags;
} event_id;
};
struct perf_bpf_event {
struct bpf_prog *prog;
struct {
struct perf_event_header header;
u16 type;
u16 flags;
u32 id;
u8 tag[8];
} event_id;
};
struct perf_text_poke_event {
const void *old_bytes;
const void *new_bytes;
size_t pad;
u16 old_len;
u16 new_len;
struct {
struct perf_event_header header;
u64 addr;
} event_id;
};
struct swevent_htable {
struct swevent_hlist *swevent_hlist;
struct mutex hlist_mutex;
int hlist_refcount;
int recursion[4];
};
enum perf_probe_config {
PERF_PROBE_CONFIG_IS_RETPROBE = 1,
PERF_UPROBE_REF_CTR_OFFSET_BITS = 32,
PERF_UPROBE_REF_CTR_OFFSET_SHIFT = 32,
};
enum {
IF_ACT_NONE = -1,
IF_ACT_FILTER = 0,
IF_ACT_START = 1,
IF_ACT_STOP = 2,
IF_SRC_FILE = 3,
IF_SRC_KERNEL = 4,
IF_SRC_FILEADDR = 5,
IF_SRC_KERNELADDR = 6,
};
enum {
IF_STATE_ACTION = 0,
IF_STATE_SOURCE = 1,
IF_STATE_END = 2,
};
struct perf_aux_event {
struct perf_event_header header;
u64 hw_id;
};
struct perf_aux_event___2 {
struct perf_event_header header;
u32 pid;
u32 tid;
};
struct perf_aux_event___3 {
struct perf_event_header header;
u64 offset;
u64 size;
u64 flags;
};
struct msgbuf {
__kernel_long_t mtype;
char mtext[1];
};
struct msg;
struct msqid_ds {
struct ipc_perm msg_perm;
struct msg *msg_first;
struct msg *msg_last;
__kernel_old_time_t msg_stime;
__kernel_old_time_t msg_rtime;
__kernel_old_time_t msg_ctime;
long unsigned int msg_lcbytes;
long unsigned int msg_lqbytes;
short unsigned int msg_cbytes;
short unsigned int msg_qnum;
short unsigned int msg_qbytes;
__kernel_ipc_pid_t msg_lspid;
__kernel_ipc_pid_t msg_lrpid;
};
struct msqid64_ds {
struct ipc64_perm msg_perm;
long unsigned int msg_stime;
long unsigned int msg_stime_high;
long unsigned int msg_rtime;
long unsigned int msg_rtime_high;
long unsigned int msg_ctime;
long unsigned int msg_ctime_high;
long unsigned int msg_cbytes;
long unsigned int msg_qnum;
long unsigned int msg_qbytes;
__kernel_pid_t msg_lspid;
__kernel_pid_t msg_lrpid;
long unsigned int __unused4;
long unsigned int __unused5;
};
struct msginfo {
int msgpool;
int msgmap;
int msgmax;
int msgmnb;
int msgmni;
int msgssz;
int msgtql;
short unsigned int msgseg;
};
struct msg_queue {
struct kern_ipc_perm q_perm;
time64_t q_stime;
time64_t q_rtime;
time64_t q_ctime;
long unsigned int q_cbytes;
long unsigned int q_qnum;
long unsigned int q_qbytes;
struct pid *q_lspid;
struct pid *q_lrpid;
struct list_head q_messages;
struct list_head q_receivers;
struct list_head q_senders;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct msg_receiver {
struct list_head r_list;
struct task_struct *r_tsk;
int r_mode;
long int r_msgtype;
long int r_maxsize;
struct msg_msg *r_msg;
};
struct msg_sender {
struct list_head list;
struct task_struct *tsk;
size_t msgsz;
};
struct io_rename {
struct file *file;
int old_dfd;
int new_dfd;
struct filename *oldpath;
struct filename *newpath;
int flags;
};
struct io_unlink {
struct file *file;
int dfd;
int flags;
struct filename *filename;
};
struct io_mkdir {
struct file *file;
int dfd;
umode_t mode;
struct filename *filename;
};
struct io_link {
struct file *file;
int old_dfd;
int new_dfd;
struct filename *oldpath;
struct filename *newpath;
int flags;
};
struct io_rw_state {
struct iov_iter iter;
struct iov_iter_state iter_state;
struct iovec fast_iov[8];
long: 32;
};
struct io_async_rw {
struct io_rw_state s;
const struct iovec *free_iovec;
size_t bytes_done;
struct wait_page_queue wpq;
long: 32;
};
struct io_rw {
struct kiocb kiocb;
u64 addr;
u32 len;
rwf_t flags;
};
struct internal_state {
int dummy;
};
struct pci_dev_resource {
struct list_head list;
struct resource *res;
struct pci_dev *dev;
resource_size_t start;
resource_size_t end;
resource_size_t add_size;
resource_size_t min_align;
long unsigned int flags;
};
enum release_type {
leaf_only = 0,
whole_subtree = 1,
};
enum enable_type {
undefined = -1,
user_disabled = 0,
auto_disabled = 1,
user_enabled = 2,
auto_enabled = 3,
};
struct component_ops {
int (*bind)(struct device *, struct device *, void *);
void (*unbind)(struct device *, struct device *, void *);
};
struct component_master_ops {
int (*bind)(struct device *);
void (*unbind)(struct device *);
};
struct component;
struct component_match_array {
void *data;
int (*compare)(struct device *, void *);
int (*compare_typed)(struct device *, int, void *);
void (*release)(struct device *, void *);
struct component *component;
bool duplicate;
};
struct aggregate_device;
struct component {
struct list_head node;
struct aggregate_device *adev;
bool bound;
const struct component_ops *ops;
int subcomponent;
struct device *dev;
};
struct component_match {
size_t alloc;
size_t num;
struct component_match_array *compare;
};
struct aggregate_device {
struct list_head node;
bool bound;
const struct component_master_ops *ops;
struct device *parent;
struct component_match *match;
};
struct software_node_ref_args {
const struct software_node *node;
unsigned int nargs;
u64 args[8];
};
struct swnode {
struct kobject kobj;
struct fwnode_handle fwnode;
const struct software_node *node;
int id;
struct ida child_ids;
struct list_head entry;
struct list_head children;
struct swnode *parent;
unsigned int allocated: 1;
unsigned int managed: 1;
};
struct mdio_board_entry {
struct list_head list;
struct mdio_board_info board_info;
};
struct ixgbe_hic_drv_info {
struct ixgbe_hic_hdr hdr;
u8 port_num;
u8 ver_sub;
u8 ver_build;
u8 ver_min;
u8 ver_maj;
u8 pad;
u16 pad2;
};
struct byd_data {
struct timer_list timer;
struct psmouse *psmouse;
s32 abs_x;
s32 abs_y;
volatile long unsigned int last_touch_time;
bool btn_left;
bool btn_right;
bool touch;
};
enum hwtstamp_flags {
HWTSTAMP_FLAG_BONDED_PHC_INDEX = 1,
HWTSTAMP_FLAG_LAST = 1,
HWTSTAMP_FLAG_MASK = 1,
};
struct compat_ifconf {
compat_int_t ifc_len;
compat_caddr_t ifcbuf;
};
struct tc_fifo_qopt {
__u32 limit;
};
enum tc_fifo_command {
TC_FIFO_REPLACE = 0,
TC_FIFO_DESTROY = 1,
TC_FIFO_STATS = 2,
};
struct tc_fifo_qopt_offload {
enum tc_fifo_command command;
u32 handle;
u32 parent;
union {
struct tc_qopt_offload_stats stats;
};
};
struct linkinfo_reply_data {
struct ethnl_reply_data base;
struct ethtool_link_ksettings ksettings;
struct ethtool_link_settings *lsettings;
};
enum {
ETHTOOL_A_PAUSE_STAT_UNSPEC = 0,
ETHTOOL_A_PAUSE_STAT_PAD = 1,
ETHTOOL_A_PAUSE_STAT_TX_FRAMES = 2,
ETHTOOL_A_PAUSE_STAT_RX_FRAMES = 3,
__ETHTOOL_A_PAUSE_STAT_CNT = 4,
ETHTOOL_A_PAUSE_STAT_MAX = 3,
};
struct pause_reply_data {
struct ethnl_reply_data base;
struct ethtool_pauseparam pauseparam;
long: 32;
struct ethtool_pause_stats pausestat;
};
struct module_reply_data {
struct ethnl_reply_data base;
struct ethtool_module_power_mode_params power;
};
struct tcp_sack_block_wire {
__be32 start_seq;
__be32 end_seq;
};
enum tcp_ca_ack_event_flags {
CA_ACK_SLOWPATH = 1,
CA_ACK_WIN_UPDATE = 2,
CA_ACK_ECE = 4,
};
struct tcp_sacktag_state {
u64 first_sackt;
u64 last_sackt;
u32 reord;
u32 sack_delivered;
int flag;
unsigned int mss_now;
struct rate_sample *rate;
long: 32;
};
enum {
STRICT = 0,
LEGACY = 1,
STD2008 = 2,
RELAXED = 3,
};
struct maar_config {
phys_addr_t lower;
phys_addr_t upper;
unsigned int attrs;
};
struct maar_walk_info {
struct maar_config cfg[16];
unsigned int num_cfg;
};
struct __user_cap_header_struct {
__u32 version;
int pid;
};
typedef struct __user_cap_header_struct *cap_user_header_t;
struct __user_cap_data_struct {
__u32 effective;
__u32 permitted;
__u32 inheritable;
};
typedef struct __user_cap_data_struct *cap_user_data_t;
struct node_vectors {
unsigned int id;
union {
unsigned int nvectors;
unsigned int ncpus;
};
};
struct module_sect_attr {
struct bin_attribute battr;
long unsigned int address;
};
struct module_sect_attrs {
struct attribute_group grp;
unsigned int nsections;
struct module_sect_attr attrs[0];
};
struct module_notes_attrs {
struct kobject *dir;
unsigned int notes;
struct bin_attribute attrs[0];
};
struct __kernel_old_itimerval {
struct __kernel_old_timeval it_interval;
struct __kernel_old_timeval it_value;
};
enum {
EVENT_TRIGGER_FL_PROBE = 1,
};
struct event_trigger_ops;
struct event_command;
struct event_trigger_data {
long unsigned int count;
int ref;
int flags;
struct event_trigger_ops *ops;
struct event_command *cmd_ops;
struct event_filter *filter;
char *filter_str;
void *private_data;
bool paused;
bool paused_tmp;
struct list_head list;
char *name;
struct list_head named_list;
struct event_trigger_data *named_data;
};
struct event_trigger_ops {
void (*trigger)(struct event_trigger_data *, struct trace_buffer *, void *, struct ring_buffer_event *);
int (*init)(struct event_trigger_data *);
void (*free)(struct event_trigger_data *);
int (*print)(struct seq_file *, struct event_trigger_data *);
};
struct event_command {
struct list_head list;
char *name;
enum event_trigger_type trigger_type;
int flags;
int (*parse)(struct event_command *, struct trace_event_file *, char *, char *, char *);
int (*reg)(char *, struct event_trigger_data *, struct trace_event_file *);
void (*unreg)(char *, struct event_trigger_data *, struct trace_event_file *);
void (*unreg_all)(struct trace_event_file *);
int (*set_filter)(char *, struct event_trigger_data *, struct trace_event_file *);
struct event_trigger_ops * (*get_trigger_ops)(char *, char *);
};
struct enable_trigger_data {
struct trace_event_file *file;
bool enable;
bool hist;
};
enum event_command_flags {
EVENT_CMD_FL_POST_TRIGGER = 1,
EVENT_CMD_FL_NEEDS_REC = 2,
};
struct bpf_iter_target_info {
struct list_head list;
const struct bpf_iter_reg *reg_info;
u32 btf_id;
};
struct bpf_iter_link {
struct bpf_link link;
struct bpf_iter_aux_info aux;
struct bpf_iter_target_info *tinfo;
};
struct bpf_iter_priv_data {
struct bpf_iter_target_info *tinfo;
const struct bpf_iter_seq_info *seq_info;
struct bpf_prog *prog;
long: 32;
u64 session_id;
u64 seq_num;
bool done_stop;
long: 32;
u8 target_private[0];
};
typedef u64 (*btf_bpf_for_each_map_elem)(struct bpf_map *, void *, void *, u64);
typedef u64 (*btf_bpf_loop)(u32, void *, void *, u64);
struct bpf_netns_link {
struct bpf_link link;
enum bpf_attach_type type;
enum netns_bpf_attach_type netns_type;
struct net *net;
struct list_head node;
long: 32;
};
struct uprobe {
struct rb_node rb_node;
refcount_t ref;
struct rw_semaphore register_rwsem;
struct rw_semaphore consumer_rwsem;
struct list_head pending_list;
struct uprobe_consumer *consumers;
struct inode *inode;
loff_t offset;
loff_t ref_ctr_offset;
long unsigned int flags;
struct arch_uprobe arch;
};
enum rp_check {
RP_CHECK_CALL = 0,
RP_CHECK_CHAIN_CALL = 1,
RP_CHECK_RET = 2,
};
struct xol_area {
wait_queue_head_t wq;
atomic_t slot_count;
long unsigned int *bitmap;
struct vm_special_mapping xol_mapping;
struct page *pages[2];
long unsigned int vaddr;
};
struct delayed_uprobe {
struct list_head list;
struct uprobe *uprobe;
struct mm_struct *mm;
};
struct __uprobe_key {
struct inode *inode;
long: 32;
loff_t offset;
};
struct map_info___2 {
struct map_info___2 *next;
struct mm_struct *mm;
long unsigned int vaddr;
};
struct trace_event_raw_mm_compaction_isolate_template {
struct trace_entry ent;
long unsigned int start_pfn;
long unsigned int end_pfn;
long unsigned int nr_scanned;
long unsigned int nr_taken;
char __data[0];
};
struct trace_event_raw_mm_compaction_migratepages {
struct trace_entry ent;
long unsigned int nr_migrated;
long unsigned int nr_failed;
char __data[0];
};
struct trace_event_raw_mm_compaction_begin {
struct trace_entry ent;
long unsigned int zone_start;
long unsigned int migrate_pfn;
long unsigned int free_pfn;
long unsigned int zone_end;
bool sync;
char __data[0];
};
struct trace_event_raw_mm_compaction_end {
struct trace_entry ent;
long unsigned int zone_start;
long unsigned int migrate_pfn;
long unsigned int free_pfn;
long unsigned int zone_end;
bool sync;
int status;
char __data[0];
};
struct trace_event_raw_mm_compaction_try_to_compact_pages {
struct trace_entry ent;
int order;
long unsigned int gfp_mask;
int prio;
char __data[0];
};
struct trace_event_raw_mm_compaction_suitable_template {
struct trace_entry ent;
int nid;
enum zone_type idx;
int order;
int ret;
char __data[0];
};
struct trace_event_raw_mm_compaction_defer_template {
struct trace_entry ent;
int nid;
enum zone_type idx;
int order;
unsigned int considered;
unsigned int defer_shift;
int order_failed;
char __data[0];
};
struct trace_event_raw_mm_compaction_kcompactd_sleep {
struct trace_entry ent;
int nid;
char __data[0];
};
struct trace_event_raw_kcompactd_wake_template {
struct trace_entry ent;
int nid;
int order;
enum zone_type highest_zoneidx;
char __data[0];
};
struct trace_event_data_offsets_mm_compaction_isolate_template {};
struct trace_event_data_offsets_mm_compaction_migratepages {};
struct trace_event_data_offsets_mm_compaction_begin {};
struct trace_event_data_offsets_mm_compaction_end {};
struct trace_event_data_offsets_mm_compaction_try_to_compact_pages {};
struct trace_event_data_offsets_mm_compaction_suitable_template {};
struct trace_event_data_offsets_mm_compaction_defer_template {};
struct trace_event_data_offsets_mm_compaction_kcompactd_sleep {};
struct trace_event_data_offsets_kcompactd_wake_template {};
typedef void (*btf_trace_mm_compaction_isolate_migratepages)(void *, long unsigned int, long unsigned int, long unsigned int, long unsigned int);
typedef void (*btf_trace_mm_compaction_isolate_freepages)(void *, long unsigned int, long unsigned int, long unsigned int, long unsigned int);
typedef void (*btf_trace_mm_compaction_migratepages)(void *, struct compact_control *, unsigned int);
typedef void (*btf_trace_mm_compaction_begin)(void *, struct compact_control *, long unsigned int, long unsigned int, bool);
typedef void (*btf_trace_mm_compaction_end)(void *, struct compact_control *, long unsigned int, long unsigned int, bool, int);
typedef void (*btf_trace_mm_compaction_try_to_compact_pages)(void *, int, gfp_t, int);
typedef void (*btf_trace_mm_compaction_finished)(void *, struct zone *, int, int);
typedef void (*btf_trace_mm_compaction_suitable)(void *, struct zone *, int, int);
typedef void (*btf_trace_mm_compaction_deferred)(void *, struct zone *, int);
typedef void (*btf_trace_mm_compaction_defer_compaction)(void *, struct zone *, int);
typedef void (*btf_trace_mm_compaction_defer_reset)(void *, struct zone *, int);
typedef void (*btf_trace_mm_compaction_kcompactd_sleep)(void *, int);
typedef void (*btf_trace_mm_compaction_wakeup_kcompactd)(void *, int, int, enum zone_type);
typedef void (*btf_trace_mm_compaction_kcompactd_wake)(void *, int, int, enum zone_type);
typedef enum {
ISOLATE_ABORT = 0,
ISOLATE_NONE = 1,
ISOLATE_SUCCESS = 2,
} isolate_migrate_t;
typedef __kernel_ulong_t __kernel_ino_t;
struct stat {
unsigned int st_dev;
long int st_pad1[3];
__kernel_ino_t st_ino;
__kernel_mode_t st_mode;
__u32 st_nlink;
__kernel_uid32_t st_uid;
__kernel_gid32_t st_gid;
unsigned int st_rdev;
long int st_pad2[2];
long int st_size;
long int st_pad3;
long int st_atime;
long int st_atime_nsec;
long int st_mtime;
long int st_mtime_nsec;
long int st_ctime;
long int st_ctime_nsec;
long int st_blksize;
long int st_blocks;
long int st_pad4[14];
};
struct stat64 {
long unsigned int st_dev;
long unsigned int st_pad0[3];
long long unsigned int st_ino;
__kernel_mode_t st_mode;
__u32 st_nlink;
__kernel_uid32_t st_uid;
__kernel_gid32_t st_gid;
long unsigned int st_rdev;
long unsigned int st_pad1[3];
long long int st_size;
long int st_atime;
long unsigned int st_atime_nsec;
long int st_mtime;
long unsigned int st_mtime_nsec;
long int st_ctime;
long unsigned int st_ctime_nsec;
long unsigned int st_blksize;
long unsigned int st_pad2;
long long int st_blocks;
};
struct proc_fs_opts {
int flag;
const char *str;
};
struct ext4_filename {
const struct qstr *usr_fname;
struct fscrypt_str disk_name;
struct dx_hash_info hinfo;
};
typedef struct {
char data[8];
} nfs4_verifier;
struct nfs4_sessionid {
unsigned char data[16];
};
struct nfs4_op_map {
union {
long unsigned int longs[3];
u32 words[3];
} u;
};
typedef struct {
u32 cl_boot;
u32 cl_id;
} clientid_t;
typedef struct {
clientid_t so_clid;
u32 so_id;
} stateid_opaque_t;
typedef struct {
u32 si_generation;
stateid_opaque_t si_opaque;
} stateid_t;
struct nfs4_client;
struct nfsd4_callback_ops;
struct nfsd4_callback {
struct nfs4_client *cb_clp;
struct rpc_message cb_msg;
const struct nfsd4_callback_ops *cb_ops;
struct work_struct cb_work;
int cb_seq_status;
int cb_status;
bool cb_need_restart;
bool cb_holds_slot;
};
struct nfs4_cb_conn {
struct __kernel_sockaddr_storage cb_addr;
struct __kernel_sockaddr_storage cb_saddr;
size_t cb_addrlen;
u32 cb_prog;
u32 cb_ident;
struct svc_xprt *cb_xprt;
};
struct nfsd4_channel_attrs {
u32 headerpadsz;
u32 maxreq_sz;
u32 maxresp_sz;
u32 maxresp_cached;
u32 maxops;
u32 maxreqs;
u32 nr_rdma_attrs;
u32 rdma_attrs;
};
struct nfsd4_cb_sec {
u32 flavor;
kuid_t uid;
kgid_t gid;
};
struct nfsd4_create_session {
clientid_t clientid;
struct nfs4_sessionid sessionid;
u32 seqid;
u32 flags;
struct nfsd4_channel_attrs fore_channel;
struct nfsd4_channel_attrs back_channel;
u32 callback_prog;
struct nfsd4_cb_sec cb_sec;
};
struct nfsd4_clid_slot {
u32 sl_seqid;
__be32 sl_status;
struct nfsd4_create_session sl_cr_ses;
};
struct nfsd4_session;
struct nfs4_client {
struct list_head cl_idhash;
struct rb_node cl_namenode;
struct list_head *cl_ownerstr_hashtbl;
struct list_head cl_openowners;
struct idr cl_stateids;
struct list_head cl_delegations;
struct list_head cl_revoked;
struct list_head cl_lru;
struct xdr_netobj cl_name;
nfs4_verifier cl_verifier;
long: 32;
time64_t cl_time;
struct __kernel_sockaddr_storage cl_addr;
bool cl_mach_cred;
struct svc_cred cl_cred;
clientid_t cl_clientid;
nfs4_verifier cl_confirm;
u32 cl_minorversion;
struct xdr_netobj cl_nii_domain;
struct xdr_netobj cl_nii_name;
struct timespec64 cl_nii_time;
struct nfs4_cb_conn cl_cb_conn;
long unsigned int cl_flags;
const struct cred *cl_cb_cred;
struct rpc_clnt *cl_cb_client;
u32 cl_cb_ident;
int cl_cb_state;
struct nfsd4_callback cl_cb_null;
struct nfsd4_session *cl_cb_session;
spinlock_t cl_lock;
struct list_head cl_sessions;
struct nfsd4_clid_slot cl_cs_slot;
u32 cl_exchange_flags;
atomic_t cl_rpc_users;
struct nfsdfs_client cl_nfsdfs;
struct nfs4_op_map cl_spo_must_allow;
struct dentry *cl_nfsd_dentry;
struct dentry *cl_nfsd_info_dentry;
long unsigned int cl_cb_slot_busy;
struct rpc_wait_queue cl_cb_waitq;
struct net *net;
struct list_head async_copies;
spinlock_t async_lock;
atomic_t cl_cb_inflight;
unsigned int cl_state;
atomic_t cl_delegs_in_recall;
long: 32;
};
struct nfsd4_callback_ops {
void (*prepare)(struct nfsd4_callback *);
int (*done)(struct nfsd4_callback *, struct rpc_task *);
void (*release)(struct nfsd4_callback *);
};
struct nfs4_file;
struct nfs4_stid {
refcount_t sc_count;
struct list_head sc_cp_list;
unsigned char sc_type;
stateid_t sc_stateid;
spinlock_t sc_lock;
struct nfs4_client *sc_client;
struct nfs4_file *sc_file;
void (*sc_free)(struct nfs4_stid *);
};
struct nfs4_file {
refcount_t fi_ref;
struct inode *fi_inode;
bool fi_aliased;
spinlock_t fi_lock;
struct hlist_node fi_hash;
struct list_head fi_stateids;
union {
struct list_head fi_delegations;
struct callback_head fi_rcu;
};
struct list_head fi_clnt_odstate;
struct nfsd_file *fi_fds[3];
atomic_t fi_access[2];
u32 fi_share_deny;
struct nfsd_file *fi_deleg_file;
int fi_delegees;
struct knfsd_fh fi_fhandle;
bool fi_had_conflict;
};
struct nfsd4_slot {
u32 sl_seqid;
__be32 sl_status;
struct svc_cred sl_cred;
u32 sl_datalen;
u16 sl_opcnt;
u8 sl_flags;
char sl_data[0];
};
struct nfsd4_session {
atomic_t se_ref;
struct list_head se_hash;
struct list_head se_perclnt;
u32 se_flags;
struct nfs4_client *se_client;
struct nfs4_sessionid se_sessionid;
struct nfsd4_channel_attrs se_fchannel;
struct nfsd4_channel_attrs se_bchannel;
struct nfsd4_cb_sec se_cb_sec;
struct list_head se_conns;
u32 se_cb_prog;
u32 se_cb_seq_nr;
struct nfsd4_slot *se_slots[0];
};
struct nfs4_replay {
__be32 rp_status;
unsigned int rp_buflen;
char *rp_buf;
struct knfsd_fh rp_openfh;
struct mutex rp_mutex;
char rp_ibuf[112];
};
struct nfs4_stateowner;
struct nfs4_stateowner_operations {
void (*so_unhash)(struct nfs4_stateowner *);
void (*so_free)(struct nfs4_stateowner *);
};
struct nfs4_stateowner {
struct list_head so_strhash;
struct list_head so_stateids;
struct nfs4_client *so_client;
const struct nfs4_stateowner_operations *so_ops;
atomic_t so_count;
u32 so_seqid;
struct xdr_netobj so_owner;
struct nfs4_replay so_replay;
bool so_is_open_owner;
};
struct nfs4_lockowner {
struct nfs4_stateowner lo_owner;
struct list_head lo_blocked;
};
struct nfsd4_blocked_lock {
struct list_head nbl_list;
struct list_head nbl_lru;
time64_t nbl_time;
struct file_lock nbl_lock;
struct knfsd_fh nbl_fh;
struct nfsd4_callback nbl_cb;
struct kref nbl_kref;
long: 32;
};
struct trace_event_raw_nfsd_xdr_err_class {
struct trace_entry ent;
unsigned int netns_ino;
u32 xid;
u32 vers;
u32 proc;
u32 __data_loc_server;
u32 __data_loc_client;
char __data[0];
};
struct trace_event_raw_nfsd_compound {
struct trace_entry ent;
u32 xid;
u32 opcnt;
u32 __data_loc_tag;
char __data[0];
};
struct trace_event_raw_nfsd_compound_status {
struct trace_entry ent;
u32 args_opcnt;
u32 resp_opcnt;
int status;
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_nfsd_compound_decode_err {
struct trace_entry ent;
unsigned int netns_ino;
u32 xid;
long unsigned int status;
unsigned char server[28];
unsigned char client[28];
u32 args_opcnt;
u32 resp_opcnt;
u32 opnum;
char __data[0];
};
struct trace_event_raw_nfsd_compound_encode_err {
struct trace_entry ent;
unsigned int netns_ino;
u32 xid;
long unsigned int status;
unsigned char server[28];
unsigned char client[28];
u32 opnum;
char __data[0];
};
struct trace_event_raw_nfsd_fh_verify {
struct trace_entry ent;
unsigned int netns_ino;
u32 __data_loc_server;
u32 __data_loc_client;
u32 xid;
u32 fh_hash;
const void *inode;
long unsigned int type;
long unsigned int access;
char __data[0];
};
struct trace_event_raw_nfsd_fh_verify_err {
struct trace_entry ent;
unsigned int netns_ino;
u32 __data_loc_server;
u32 __data_loc_client;
u32 xid;
u32 fh_hash;
const void *inode;
long unsigned int type;
long unsigned int access;
int error;
char __data[0];
};
struct trace_event_raw_nfsd_fh_err_class {
struct trace_entry ent;
u32 xid;
u32 fh_hash;
int status;
char __data[0];
};
struct trace_event_raw_nfsd_exp_find_key {
struct trace_entry ent;
int fsidtype;
u32 fsid[6];
u32 __data_loc_auth_domain;
int status;
char __data[0];
};
struct trace_event_raw_nfsd_expkey_update {
struct trace_entry ent;
int fsidtype;
u32 fsid[6];
u32 __data_loc_auth_domain;
u32 __data_loc_path;
bool cache;
char __data[0];
};
struct trace_event_raw_nfsd_exp_get_by_name {
struct trace_entry ent;
u32 __data_loc_path;
u32 __data_loc_auth_domain;
int status;
char __data[0];
};
struct trace_event_raw_nfsd_export_update {
struct trace_entry ent;
u32 __data_loc_path;
u32 __data_loc_auth_domain;
bool cache;
char __data[0];
};
struct trace_event_raw_nfsd_io_class {
struct trace_entry ent;
u32 xid;
u32 fh_hash;
u64 offset;
u32 len;
char __data[0];
long: 32;
};
struct trace_event_raw_nfsd_err_class {
struct trace_entry ent;
u32 xid;
u32 fh_hash;
loff_t offset;
int status;
char __data[0];
long: 32;
};
struct trace_event_raw_nfsd_dirent {
struct trace_entry ent;
u32 fh_hash;
long: 32;
u64 ino;
u32 __data_loc_name;
char __data[0];
long: 32;
};
struct trace_event_raw_nfsd_copy_err_class {
struct trace_entry ent;
u32 xid;
u32 src_fh_hash;
loff_t src_offset;
u32 dst_fh_hash;
long: 32;
loff_t dst_offset;
u64 count;
int status;
char __data[0];
long: 32;
};
struct trace_event_raw_nfsd_delegret_wakeup {
struct trace_entry ent;
u32 xid;
const void *inode;
long int timeo;
char __data[0];
};
struct trace_event_raw_nfsd_stateid_class {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
u32 si_id;
u32 si_generation;
char __data[0];
};
struct trace_event_raw_nfsd_stateseqid_class {
struct trace_entry ent;
u32 seqid;
u32 cl_boot;
u32 cl_id;
u32 si_id;
u32 si_generation;
char __data[0];
};
struct trace_event_raw_nfsd_clientid_class {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
char __data[0];
};
struct trace_event_raw_nfsd_net_class {
struct trace_entry ent;
long long unsigned int boot_time;
char __data[0];
};
struct trace_event_raw_nfsd_writeverf_reset {
struct trace_entry ent;
long long unsigned int boot_time;
u32 xid;
int error;
unsigned char verifier[8];
char __data[0];
};
struct trace_event_raw_nfsd_clid_cred_mismatch {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
long unsigned int cl_flavor;
long unsigned int new_flavor;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_nfsd_clid_verf_mismatch {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
unsigned char cl_verifier[8];
unsigned char new_verifier[8];
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_nfsd_clid_class {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
unsigned char addr[28];
long unsigned int flavor;
unsigned char verifier[8];
u32 __data_loc_name;
char __data[0];
};
struct trace_event_raw_nfsd_file_class {
struct trace_entry ent;
void *nf_inode;
int nf_ref;
long unsigned int nf_flags;
unsigned char nf_may;
struct file *nf_file;
char __data[0];
};
struct trace_event_raw_nfsd_file_alloc {
struct trace_entry ent;
const void *nf_inode;
long unsigned int nf_flags;
long unsigned int nf_may;
unsigned int nf_ref;
char __data[0];
};
struct trace_event_raw_nfsd_file_acquire {
struct trace_entry ent;
u32 xid;
const void *inode;
long unsigned int may_flags;
unsigned int nf_ref;
long unsigned int nf_flags;
long unsigned int nf_may;
const void *nf_file;
u32 status;
char __data[0];
};
struct trace_event_raw_nfsd_file_create {
struct trace_entry ent;
const void *nf_inode;
const void *nf_file;
long unsigned int may_flags;
long unsigned int nf_flags;
long unsigned int nf_may;
unsigned int nf_ref;
u32 xid;
char __data[0];
};
struct trace_event_raw_nfsd_file_insert_err {
struct trace_entry ent;
u32 xid;
const void *inode;
long unsigned int may_flags;
long int error;
char __data[0];
};
struct trace_event_raw_nfsd_file_cons_err {
struct trace_entry ent;
u32 xid;
const void *inode;
long unsigned int may_flags;
unsigned int nf_ref;
long unsigned int nf_flags;
long unsigned int nf_may;
const void *nf_file;
char __data[0];
};
struct trace_event_raw_nfsd_file_open {
struct trace_entry ent;
void *nf_inode;
int nf_ref;
long unsigned int nf_flags;
long unsigned int nf_may;
void *nf_file;
char __data[0];
};
struct trace_event_raw_nfsd_file_search_class {
struct trace_entry ent;
const struct inode *inode;
unsigned int count;
char __data[0];
};
struct trace_event_raw_nfsd_file_is_cached {
struct trace_entry ent;
const struct inode *inode;
int found;
char __data[0];
};
struct trace_event_raw_nfsd_file_fsnotify_handle_event {
struct trace_entry ent;
struct inode *inode;
unsigned int nlink;
umode_t mode;
u32 mask;
char __data[0];
};
struct trace_event_raw_nfsd_file_gc_class {
struct trace_entry ent;
void *nf_inode;
void *nf_file;
int nf_ref;
long unsigned int nf_flags;
char __data[0];
};
struct trace_event_raw_nfsd_file_lruwalk_class {
struct trace_entry ent;
long unsigned int removed;
long unsigned int remaining;
char __data[0];
};
struct trace_event_raw_nfsd_drc_found {
struct trace_entry ent;
long long unsigned int boot_time;
long unsigned int result;
u32 xid;
char __data[0];
};
struct trace_event_raw_nfsd_drc_mismatch {
struct trace_entry ent;
long long unsigned int boot_time;
u32 xid;
u32 cached;
u32 ingress;
char __data[0];
long: 32;
};
struct trace_event_raw_nfsd_cb_args {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
u32 prog;
u32 ident;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_nfsd_cb_nodelegs {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
char __data[0];
};
struct trace_event_raw_nfsd_cb_class {
struct trace_entry ent;
long unsigned int state;
u32 cl_boot;
u32 cl_id;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_nfsd_cb_setup {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
long unsigned int authflavor;
u32 __data_loc_addr;
unsigned char netid[8];
char __data[0];
};
struct trace_event_raw_nfsd_cb_setup_err {
struct trace_entry ent;
long int error;
u32 cl_boot;
u32 cl_id;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_nfsd_cb_recall {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
u32 si_id;
u32 si_generation;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_nfsd_cb_notify_lock {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
u32 fh_hash;
u32 __data_loc_addr;
char __data[0];
};
struct trace_event_raw_nfsd_cb_offload {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
u32 si_id;
u32 si_generation;
u32 fh_hash;
int status;
u64 count;
u32 __data_loc_addr;
char __data[0];
long: 32;
};
struct trace_event_raw_nfsd_cb_done_class {
struct trace_entry ent;
u32 cl_boot;
u32 cl_id;
u32 si_id;
u32 si_generation;
int status;
char __data[0];
};
struct trace_event_data_offsets_nfsd_xdr_err_class {
u32 server;
u32 client;
};
struct trace_event_data_offsets_nfsd_compound {
u32 tag;
};
struct trace_event_data_offsets_nfsd_compound_status {
u32 name;
};
struct trace_event_data_offsets_nfsd_compound_decode_err {};
struct trace_event_data_offsets_nfsd_compound_encode_err {};
struct trace_event_data_offsets_nfsd_fh_verify {
u32 server;
u32 client;
};
struct trace_event_data_offsets_nfsd_fh_verify_err {
u32 server;
u32 client;
};
struct trace_event_data_offsets_nfsd_fh_err_class {};
struct trace_event_data_offsets_nfsd_exp_find_key {
u32 auth_domain;
};
struct trace_event_data_offsets_nfsd_expkey_update {
u32 auth_domain;
u32 path;
};
struct trace_event_data_offsets_nfsd_exp_get_by_name {
u32 path;
u32 auth_domain;
};
struct trace_event_data_offsets_nfsd_export_update {
u32 path;
u32 auth_domain;
};
struct trace_event_data_offsets_nfsd_io_class {};
struct trace_event_data_offsets_nfsd_err_class {};
struct trace_event_data_offsets_nfsd_dirent {
u32 name;
};
struct trace_event_data_offsets_nfsd_copy_err_class {};
struct trace_event_data_offsets_nfsd_delegret_wakeup {};
struct trace_event_data_offsets_nfsd_stateid_class {};
struct trace_event_data_offsets_nfsd_stateseqid_class {};
struct trace_event_data_offsets_nfsd_clientid_class {};
struct trace_event_data_offsets_nfsd_net_class {};
struct trace_event_data_offsets_nfsd_writeverf_reset {};
struct trace_event_data_offsets_nfsd_clid_cred_mismatch {
u32 addr;
};
struct trace_event_data_offsets_nfsd_clid_verf_mismatch {
u32 addr;
};
struct trace_event_data_offsets_nfsd_clid_class {
u32 name;
};
struct trace_event_data_offsets_nfsd_file_class {};
struct trace_event_data_offsets_nfsd_file_alloc {};
struct trace_event_data_offsets_nfsd_file_acquire {};
struct trace_event_data_offsets_nfsd_file_create {};
struct trace_event_data_offsets_nfsd_file_insert_err {};
struct trace_event_data_offsets_nfsd_file_cons_err {};
struct trace_event_data_offsets_nfsd_file_open {};
struct trace_event_data_offsets_nfsd_file_search_class {};
struct trace_event_data_offsets_nfsd_file_is_cached {};
struct trace_event_data_offsets_nfsd_file_fsnotify_handle_event {};
struct trace_event_data_offsets_nfsd_file_gc_class {};
struct trace_event_data_offsets_nfsd_file_lruwalk_class {};
struct trace_event_data_offsets_nfsd_drc_found {};
struct trace_event_data_offsets_nfsd_drc_mismatch {};
struct trace_event_data_offsets_nfsd_cb_args {
u32 addr;
};
struct trace_event_data_offsets_nfsd_cb_nodelegs {};
struct trace_event_data_offsets_nfsd_cb_class {
u32 addr;
};
struct trace_event_data_offsets_nfsd_cb_setup {
u32 addr;
};
struct trace_event_data_offsets_nfsd_cb_setup_err {
u32 addr;
};
struct trace_event_data_offsets_nfsd_cb_recall {
u32 addr;
};
struct trace_event_data_offsets_nfsd_cb_notify_lock {
u32 addr;
};
struct trace_event_data_offsets_nfsd_cb_offload {
u32 addr;
};
struct trace_event_data_offsets_nfsd_cb_done_class {};
typedef void (*btf_trace_nfsd_garbage_args_err)(void *, const struct svc_rqst *);
typedef void (*btf_trace_nfsd_cant_encode_err)(void *, const struct svc_rqst *);
typedef void (*btf_trace_nfsd_compound)(void *, const struct svc_rqst *, const char *, u32, u32);
typedef void (*btf_trace_nfsd_compound_status)(void *, u32, u32, __be32, const char *);
typedef void (*btf_trace_nfsd_compound_decode_err)(void *, const struct svc_rqst *, u32, u32, u32, __be32);
typedef void (*btf_trace_nfsd_compound_encode_err)(void *, const struct svc_rqst *, u32, __be32);
typedef void (*btf_trace_nfsd_fh_verify)(void *, const struct svc_rqst *, const struct svc_fh *, umode_t, int);
typedef void (*btf_trace_nfsd_fh_verify_err)(void *, const struct svc_rqst *, const struct svc_fh *, umode_t, int, __be32);
typedef void (*btf_trace_nfsd_set_fh_dentry_badexport)(void *, struct svc_rqst *, struct svc_fh *, int);
typedef void (*btf_trace_nfsd_set_fh_dentry_badhandle)(void *, struct svc_rqst *, struct svc_fh *, int);
typedef void (*btf_trace_nfsd_exp_find_key)(void *, const struct svc_expkey *, int);
typedef void (*btf_trace_nfsd_expkey_update)(void *, const struct svc_expkey *, const char *);
typedef void (*btf_trace_nfsd_exp_get_by_name)(void *, const struct svc_export *, int);
typedef void (*btf_trace_nfsd_export_update)(void *, const struct svc_export *);
typedef void (*btf_trace_nfsd_read_start)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_read_splice)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_read_vector)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_read_io_done)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_read_done)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_write_start)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_write_opened)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_write_io_done)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_write_done)(void *, struct svc_rqst *, struct svc_fh *, u64, u32);
typedef void (*btf_trace_nfsd_read_err)(void *, struct svc_rqst *, struct svc_fh *, loff_t, int);
typedef void (*btf_trace_nfsd_write_err)(void *, struct svc_rqst *, struct svc_fh *, loff_t, int);
typedef void (*btf_trace_nfsd_dirent)(void *, struct svc_fh *, u64, const char *, int);
typedef void (*btf_trace_nfsd_clone_file_range_err)(void *, struct svc_rqst *, struct svc_fh *, loff_t, struct svc_fh *, loff_t, u64, int);
typedef void (*btf_trace_nfsd_delegret_wakeup)(void *, const struct svc_rqst *, const struct inode *, long int);
typedef void (*btf_trace_nfsd_layoutstate_alloc)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layoutstate_unhash)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layoutstate_free)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layout_get_lookup_fail)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layout_commit_lookup_fail)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layout_return_lookup_fail)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layout_recall)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layout_recall_done)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layout_recall_fail)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_layout_recall_release)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_open)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_deleg_read)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_deleg_recall)(void *, stateid_t *);
typedef void (*btf_trace_nfsd_preprocess)(void *, u32, const stateid_t *);
typedef void (*btf_trace_nfsd_open_confirm)(void *, u32, const stateid_t *);
typedef void (*btf_trace_nfsd_clid_expire_unconf)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_reclaim_complete)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_confirmed)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_destroyed)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_admin_expired)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_replaced)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_purged)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_renew)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_clid_stale)(void *, const clientid_t *);
typedef void (*btf_trace_nfsd_grace_start)(void *, const struct nfsd_net *);
typedef void (*btf_trace_nfsd_grace_complete)(void *, const struct nfsd_net *);
typedef void (*btf_trace_nfsd_writeverf_reset)(void *, const struct nfsd_net *, const struct svc_rqst *, int);
typedef void (*btf_trace_nfsd_clid_cred_mismatch)(void *, const struct nfs4_client *, const struct svc_rqst *);
typedef void (*btf_trace_nfsd_clid_verf_mismatch)(void *, const struct nfs4_client *, const struct svc_rqst *, const nfs4_verifier *);
typedef void (*btf_trace_nfsd_clid_fresh)(void *, const struct nfs4_client *);
typedef void (*btf_trace_nfsd_clid_confirmed_r)(void *, const struct nfs4_client *);
typedef void (*btf_trace_nfsd_file_put_final)(void *, struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_unhash)(void *, struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_put)(void *, struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_unhash_and_dispose)(void *, struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_alloc)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_acquire)(void *, const struct svc_rqst *, const struct inode *, unsigned int, const struct nfsd_file *, __be32);
typedef void (*btf_trace_nfsd_file_create)(void *, const struct svc_rqst *, unsigned int, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_insert_err)(void *, const struct svc_rqst *, const struct inode *, unsigned int, long int);
typedef void (*btf_trace_nfsd_file_cons_err)(void *, const struct svc_rqst *, const struct inode *, unsigned int, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_open)(void *, struct nfsd_file *, __be32);
typedef void (*btf_trace_nfsd_file_close_inode_sync)(void *, const struct inode *, unsigned int);
typedef void (*btf_trace_nfsd_file_close_inode)(void *, const struct inode *, unsigned int);
typedef void (*btf_trace_nfsd_file_is_cached)(void *, const struct inode *, int);
typedef void (*btf_trace_nfsd_file_fsnotify_handle_event)(void *, struct inode *, u32);
typedef void (*btf_trace_nfsd_file_lru_add)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_lru_add_disposed)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_lru_del)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_lru_del_disposed)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_gc_in_use)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_gc_writeback)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_gc_referenced)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_gc_hashed)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_gc_disposed)(void *, const struct nfsd_file *);
typedef void (*btf_trace_nfsd_file_gc_removed)(void *, long unsigned int, long unsigned int);
typedef void (*btf_trace_nfsd_file_shrinker_removed)(void *, long unsigned int, long unsigned int);
typedef void (*btf_trace_nfsd_drc_found)(void *, const struct nfsd_net *, const struct svc_rqst *, int);
typedef void (*btf_trace_nfsd_drc_mismatch)(void *, const struct nfsd_net *, const struct svc_cacherep *, const struct svc_cacherep *);
typedef void (*btf_trace_nfsd_cb_args)(void *, const struct nfs4_client *, const struct nfs4_cb_conn *);
typedef void (*btf_trace_nfsd_cb_nodelegs)(void *, const struct nfs4_client *);
typedef void (*btf_trace_nfsd_cb_state)(void *, const struct nfs4_client *);
typedef void (*btf_trace_nfsd_cb_probe)(void *, const struct nfs4_client *);
typedef void (*btf_trace_nfsd_cb_lost)(void *, const struct nfs4_client *);
typedef void (*btf_trace_nfsd_cb_shutdown)(void *, const struct nfs4_client *);
typedef void (*btf_trace_nfsd_cb_setup)(void *, const struct nfs4_client *, const char *, rpc_authflavor_t);
typedef void (*btf_trace_nfsd_cb_setup_err)(void *, const struct nfs4_client *, long int);
typedef void (*btf_trace_nfsd_cb_recall)(void *, const struct nfs4_stid *);
typedef void (*btf_trace_nfsd_cb_notify_lock)(void *, const struct nfs4_lockowner *, const struct nfsd4_blocked_lock *);
typedef void (*btf_trace_nfsd_cb_offload)(void *, const struct nfs4_client *, const stateid_t *, const struct knfsd_fh *, u64, __be32);
typedef void (*btf_trace_nfsd_cb_recall_done)(void *, const stateid_t *, const struct rpc_task *);
typedef void (*btf_trace_nfsd_cb_notify_lock_done)(void *, const stateid_t *, const struct rpc_task *);
typedef void (*btf_trace_nfsd_cb_layout_done)(void *, const stateid_t *, const struct rpc_task *);
typedef void (*btf_trace_nfsd_cb_offload_done)(void *, const stateid_t *, const struct rpc_task *);
struct genradix_iter {
size_t offset;
size_t pos;
};
struct genradix_node {
union {
struct genradix_node *children[4096];
u8 data[16384];
};
};
struct strarray {
char **array;
size_t n;
};
typedef enum {
set_basic = 0,
set_rle = 1,
set_compressed = 2,
set_repeat = 3,
} symbolEncodingType_e;
typedef enum {
ZSTD_no_overlap = 0,
ZSTD_overlap_src_before_dst = 1,
} ZSTD_overlap_e;
typedef struct {
U32 fastMode;
U32 tableLog;
} ZSTD_seqSymbol_header;
typedef struct {
size_t litLength;
size_t matchLength;
size_t offset;
const BYTE *match;
} seq_t;
typedef struct {
size_t state;
const ZSTD_seqSymbol *table;
} ZSTD_fseState;
typedef struct {
BIT_DStream_t DStream;
ZSTD_fseState stateLL;
ZSTD_fseState stateOffb;
ZSTD_fseState stateML;
size_t prevOffset[3];
const BYTE *prefixStart;
const BYTE *dictEnd;
size_t pos;
} seqState_t;
typedef enum {
ZSTD_lo_isRegularOffset = 0,
ZSTD_lo_isLongOffset = 1,
} ZSTD_longOffset_e;
typedef enum {
ZSTD_p_noPrefetch = 0,
ZSTD_p_prefetch = 1,
} ZSTD_prefetch_e;
struct probe {
struct probe *next;
dev_t dev;
long unsigned int range;
struct module *owner;
kobj_probe_t *get;
int (*lock)(dev_t, void *);
void *data;
};
struct kobj_map {
struct probe *probes[255];
struct mutex *lock;
};
enum ata_xfer_mask {
ATA_MASK_PIO = 127,
ATA_MASK_MWDMA = 3968,
ATA_MASK_UDMA = 1044480,
};
struct trace_event_raw_ata_qc_issue_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int ata_dev;
unsigned int tag;
unsigned char cmd;
unsigned char dev;
unsigned char lbal;
unsigned char lbam;
unsigned char lbah;
unsigned char nsect;
unsigned char feature;
unsigned char hob_lbal;
unsigned char hob_lbam;
unsigned char hob_lbah;
unsigned char hob_nsect;
unsigned char hob_feature;
unsigned char ctl;
unsigned char proto;
long unsigned int flags;
char __data[0];
};
struct trace_event_raw_ata_qc_complete_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int ata_dev;
unsigned int tag;
unsigned char status;
unsigned char dev;
unsigned char lbal;
unsigned char lbam;
unsigned char lbah;
unsigned char nsect;
unsigned char error;
unsigned char hob_lbal;
unsigned char hob_lbam;
unsigned char hob_lbah;
unsigned char hob_nsect;
unsigned char hob_feature;
unsigned char ctl;
long unsigned int flags;
char __data[0];
};
struct trace_event_raw_ata_tf_load {
struct trace_entry ent;
unsigned int ata_port;
unsigned char cmd;
unsigned char dev;
unsigned char lbal;
unsigned char lbam;
unsigned char lbah;
unsigned char nsect;
unsigned char feature;
unsigned char hob_lbal;
unsigned char hob_lbam;
unsigned char hob_lbah;
unsigned char hob_nsect;
unsigned char hob_feature;
unsigned char proto;
char __data[0];
};
struct trace_event_raw_ata_exec_command_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int tag;
unsigned char cmd;
unsigned char feature;
unsigned char hob_nsect;
unsigned char proto;
char __data[0];
};
struct trace_event_raw_ata_bmdma_status {
struct trace_entry ent;
unsigned int ata_port;
unsigned int tag;
unsigned char host_stat;
char __data[0];
};
struct trace_event_raw_ata_eh_link_autopsy {
struct trace_entry ent;
unsigned int ata_port;
unsigned int ata_dev;
unsigned int eh_action;
unsigned int eh_err_mask;
char __data[0];
};
struct trace_event_raw_ata_eh_link_autopsy_qc {
struct trace_entry ent;
unsigned int ata_port;
unsigned int ata_dev;
unsigned int tag;
unsigned int qc_flags;
unsigned int eh_err_mask;
char __data[0];
};
struct trace_event_raw_ata_eh_action_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int ata_dev;
unsigned int eh_action;
char __data[0];
};
struct trace_event_raw_ata_link_reset_begin_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int class[2];
long unsigned int deadline;
char __data[0];
};
struct trace_event_raw_ata_link_reset_end_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int class[2];
int rc;
char __data[0];
};
struct trace_event_raw_ata_port_eh_begin_template {
struct trace_entry ent;
unsigned int ata_port;
char __data[0];
};
struct trace_event_raw_ata_sff_hsm_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int ata_dev;
unsigned int tag;
unsigned int qc_flags;
unsigned int protocol;
unsigned int hsm_state;
unsigned char dev_state;
char __data[0];
};
struct trace_event_raw_ata_transfer_data_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned int ata_dev;
unsigned int tag;
unsigned int flags;
unsigned int offset;
unsigned int bytes;
char __data[0];
};
struct trace_event_raw_ata_sff_template {
struct trace_entry ent;
unsigned int ata_port;
unsigned char hsm_state;
char __data[0];
};
struct trace_event_data_offsets_ata_qc_issue_template {};
struct trace_event_data_offsets_ata_qc_complete_template {};
struct trace_event_data_offsets_ata_tf_load {};
struct trace_event_data_offsets_ata_exec_command_template {};
struct trace_event_data_offsets_ata_bmdma_status {};
struct trace_event_data_offsets_ata_eh_link_autopsy {};
struct trace_event_data_offsets_ata_eh_link_autopsy_qc {};
struct trace_event_data_offsets_ata_eh_action_template {};
struct trace_event_data_offsets_ata_link_reset_begin_template {};
struct trace_event_data_offsets_ata_link_reset_end_template {};
struct trace_event_data_offsets_ata_port_eh_begin_template {};
struct trace_event_data_offsets_ata_sff_hsm_template {};
struct trace_event_data_offsets_ata_transfer_data_template {};
struct trace_event_data_offsets_ata_sff_template {};
typedef void (*btf_trace_ata_qc_prep)(void *, struct ata_queued_cmd *);
typedef void (*btf_trace_ata_qc_issue)(void *, struct ata_queued_cmd *);
typedef void (*btf_trace_ata_qc_complete_internal)(void *, struct ata_queued_cmd *);
typedef void (*btf_trace_ata_qc_complete_failed)(void *, struct ata_queued_cmd *);
typedef void (*btf_trace_ata_qc_complete_done)(void *, struct ata_queued_cmd *);
typedef void (*btf_trace_ata_tf_load)(void *, struct ata_port *, const struct ata_taskfile *);
typedef void (*btf_trace_ata_exec_command)(void *, struct ata_port *, const struct ata_taskfile *, unsigned int);
typedef void (*btf_trace_ata_bmdma_setup)(void *, struct ata_port *, const struct ata_taskfile *, unsigned int);
typedef void (*btf_trace_ata_bmdma_start)(void *, struct ata_port *, const struct ata_taskfile *, unsigned int);
typedef void (*btf_trace_ata_bmdma_stop)(void *, struct ata_port *, const struct ata_taskfile *, unsigned int);
typedef void (*btf_trace_ata_bmdma_status)(void *, struct ata_port *, unsigned int);
typedef void (*btf_trace_ata_eh_link_autopsy)(void *, struct ata_device *, unsigned int, unsigned int);
typedef void (*btf_trace_ata_eh_link_autopsy_qc)(void *, struct ata_queued_cmd *);
typedef void (*btf_trace_ata_eh_about_to_do)(void *, struct ata_link *, unsigned int, unsigned int);
typedef void (*btf_trace_ata_eh_done)(void *, struct ata_link *, unsigned int, unsigned int);
typedef void (*btf_trace_ata_link_hardreset_begin)(void *, struct ata_link *, unsigned int *, long unsigned int);
typedef void (*btf_trace_ata_slave_hardreset_begin)(void *, struct ata_link *, unsigned int *, long unsigned int);
typedef void (*btf_trace_ata_link_softreset_begin)(void *, struct ata_link *, unsigned int *, long unsigned int);
typedef void (*btf_trace_ata_link_hardreset_end)(void *, struct ata_link *, unsigned int *, int);
typedef void (*btf_trace_ata_slave_hardreset_end)(void *, struct ata_link *, unsigned int *, int);
typedef void (*btf_trace_ata_link_softreset_end)(void *, struct ata_link *, unsigned int *, int);
typedef void (*btf_trace_ata_link_postreset)(void *, struct ata_link *, unsigned int *, int);
typedef void (*btf_trace_ata_slave_postreset)(void *, struct ata_link *, unsigned int *, int);
typedef void (*btf_trace_ata_std_sched_eh)(void *, struct ata_port *);
typedef void (*btf_trace_ata_port_freeze)(void *, struct ata_port *);
typedef void (*btf_trace_ata_port_thaw)(void *, struct ata_port *);
typedef void (*btf_trace_ata_sff_hsm_state)(void *, struct ata_queued_cmd *, unsigned char);
typedef void (*btf_trace_ata_sff_hsm_command_complete)(void *, struct ata_queued_cmd *, unsigned char);
typedef void (*btf_trace_ata_sff_port_intr)(void *, struct ata_queued_cmd *, unsigned char);
typedef void (*btf_trace_ata_sff_pio_transfer_data)(void *, struct ata_queued_cmd *, unsigned int, unsigned int);
typedef void (*btf_trace_atapi_pio_transfer_data)(void *, struct ata_queued_cmd *, unsigned int, unsigned int);
typedef void (*btf_trace_atapi_send_cdb)(void *, struct ata_queued_cmd *, unsigned int, unsigned int);
typedef void (*btf_trace_ata_sff_flush_pio_task)(void *, struct ata_port *);
enum {
ATA_READID_POSTRESET = 1,
ATA_DNXFER_PIO = 0,
ATA_DNXFER_DMA = 1,
ATA_DNXFER_40C = 2,
ATA_DNXFER_FORCE_PIO = 3,
ATA_DNXFER_FORCE_PIO0 = 4,
ATA_DNXFER_QUIET = -2147483648,
};
struct ata_force_param {
const char *name;
u8 cbl;
u8 spd_limit;
unsigned int xfer_mask;
unsigned int horkage_on;
unsigned int horkage_off;
u16 lflags_on;
u16 lflags_off;
};
struct ata_force_ent {
int port;
int device;
struct ata_force_param param;
};
struct ata_xfer_ent {
int shift;
int bits;
u8 base;
};
struct ata_blacklist_entry {
const char *model_num;
const char *model_rev;
long unsigned int horkage;
};
struct input_dev_poller {
void (*poll)(struct input_dev *);
unsigned int poll_interval;
unsigned int poll_interval_max;
unsigned int poll_interval_min;
struct input_dev *input;
struct delayed_work work;
};
struct of_timer_irq {
int irq;
int index;
int percpu;
const char *name;
long unsigned int flags;
irq_handler_t handler;
};
struct of_timer_base {
void *base;
const char *name;
int index;
};
struct of_timer_clk {
struct clk *clk;
const char *name;
int index;
long unsigned int rate;
long unsigned int period;
};
struct timer_of {
unsigned int flags;
struct device_node *np;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct clock_event_device clkevt;
struct of_timer_base of_base;
struct of_timer_irq of_irq;
struct of_timer_clk of_clk;
void *private_data;
long: 32;
};
struct nvmem_cell_lookup {
const char *nvmem_name;
const char *cell_name;
const char *dev_id;
const char *con_id;
struct list_head node;
};
enum {
NVMEM_ADD = 1,
NVMEM_REMOVE = 2,
NVMEM_CELL_ADD = 3,
NVMEM_CELL_REMOVE = 4,
};
struct nvmem_cell_table {
const char *nvmem_name;
const struct nvmem_cell_info *cells;
size_t ncells;
struct list_head node;
};
struct nvmem_device {
struct module *owner;
long: 32;
struct device dev;
int stride;
int word_size;
int id;
struct kref refcnt;
size_t size;
bool read_only;
bool root_only;
int flags;
enum nvmem_type type;
struct bin_attribute eeprom;
struct device *base_dev;
struct list_head cells;
const struct nvmem_keepout *keepout;
unsigned int nkeepout;
nvmem_reg_read_t reg_read;
nvmem_reg_write_t reg_write;
nvmem_cell_post_process_t cell_post_process;
struct gpio_desc *wp_gpio;
void *priv;
};
struct nvmem_cell_entry {
const char *name;
int offset;
int bytes;
int bit_offset;
int nbits;
struct device_node *np;
struct nvmem_device *nvmem;
struct list_head node;
};
struct nvmem_cell {
struct nvmem_cell_entry *entry;
const char *id;
};
struct flow_dissector_key_ports_range {
union {
struct flow_dissector_key_ports tp;
struct {
struct flow_dissector_key_ports tp_min;
struct flow_dissector_key_ports tp_max;
};
};
};
struct flow_match_meta {
struct flow_dissector_key_meta *key;
struct flow_dissector_key_meta *mask;
};
struct flow_match_basic {
struct flow_dissector_key_basic *key;
struct flow_dissector_key_basic *mask;
};
struct flow_match_control {
struct flow_dissector_key_control *key;
struct flow_dissector_key_control *mask;
};
struct flow_match_eth_addrs {
struct flow_dissector_key_eth_addrs *key;
struct flow_dissector_key_eth_addrs *mask;
};
struct flow_match_vlan {
struct flow_dissector_key_vlan *key;
struct flow_dissector_key_vlan *mask;
};
struct flow_match_ipv4_addrs {
struct flow_dissector_key_ipv4_addrs *key;
struct flow_dissector_key_ipv4_addrs *mask;
};
struct flow_match_ipv6_addrs {
struct flow_dissector_key_ipv6_addrs *key;
struct flow_dissector_key_ipv6_addrs *mask;
};
struct flow_match_ip {
struct flow_dissector_key_ip *key;
struct flow_dissector_key_ip *mask;
};
struct flow_match_ports {
struct flow_dissector_key_ports *key;
struct flow_dissector_key_ports *mask;
};
struct flow_match_ports_range {
struct flow_dissector_key_ports_range *key;
struct flow_dissector_key_ports_range *mask;
};
struct flow_match_icmp {
struct flow_dissector_key_icmp *key;
struct flow_dissector_key_icmp *mask;
};
struct flow_match_tcp {
struct flow_dissector_key_tcp *key;
struct flow_dissector_key_tcp *mask;
};
struct flow_match_mpls {
struct flow_dissector_key_mpls *key;
struct flow_dissector_key_mpls *mask;
};
struct flow_match_enc_keyid {
struct flow_dissector_key_keyid *key;
struct flow_dissector_key_keyid *mask;
};
struct flow_match_enc_opts {
struct flow_dissector_key_enc_opts *key;
struct flow_dissector_key_enc_opts *mask;
};
struct flow_match_ct {
struct flow_dissector_key_ct *key;
struct flow_dissector_key_ct *mask;
};
struct flow_match_pppoe {
struct flow_dissector_key_pppoe *key;
struct flow_dissector_key_pppoe *mask;
};
struct flow_match_l2tpv3 {
struct flow_dissector_key_l2tpv3 *key;
struct flow_dissector_key_l2tpv3 *mask;
};
struct flow_block_cb;
struct flow_block_indr {
struct list_head list;
struct net_device *dev;
struct Qdisc *sch;
enum flow_block_binder_type binder_type;
void *data;
void *cb_priv;
void (*cleanup)(struct flow_block_cb *);
};
struct flow_block_cb {
struct list_head driver_list;
struct list_head list;
flow_setup_cb_t *cb;
void *cb_ident;
void *cb_priv;
void (*release)(void *);
struct flow_block_indr indr;
unsigned int refcnt;
};
typedef int flow_indr_block_bind_cb_t(struct net_device *, struct Qdisc *, void *, enum tc_setup_type, void *, void *, void (*)(struct flow_block_cb *));
struct flow_indr_dev {
struct list_head list;
flow_indr_block_bind_cb_t *cb;
void *cb_priv;
refcount_t refcnt;
};
struct flow_indir_dev_info {
void *data;
struct net_device *dev;
struct Qdisc *sch;
enum tc_setup_type type;
void (*cleanup)(struct flow_block_cb *);
struct list_head list;
enum flow_block_command command;
enum flow_block_binder_type binder_type;
struct list_head *cb_list;
};
struct fib_rule_uid_range {
__u32 start;
__u32 end;
};
struct fib_rule_notifier_info {
struct fib_notifier_info info;
struct fib_rule *rule;
};
enum {
TCA_ACT_UNSPEC = 0,
TCA_ACT_KIND = 1,
TCA_ACT_OPTIONS = 2,
TCA_ACT_INDEX = 3,
TCA_ACT_STATS = 4,
TCA_ACT_PAD = 5,
TCA_ACT_COOKIE = 6,
TCA_ACT_FLAGS = 7,
TCA_ACT_HW_STATS = 8,
TCA_ACT_USED_HW_STATS = 9,
TCA_ACT_IN_HW_COUNT = 10,
__TCA_ACT_MAX = 11,
};
struct tcamsg {
unsigned char tca_family;
unsigned char tca__pad1;
short unsigned int tca__pad2;
};
enum {
TCA_ROOT_UNSPEC = 0,
TCA_ROOT_TAB = 1,
TCA_ROOT_FLAGS = 2,
TCA_ROOT_COUNT = 3,
TCA_ROOT_TIME_DELTA = 4,
__TCA_ROOT_MAX = 5,
};
enum pedit_header_type {
TCA_PEDIT_KEY_EX_HDR_TYPE_NETWORK = 0,
TCA_PEDIT_KEY_EX_HDR_TYPE_ETH = 1,
TCA_PEDIT_KEY_EX_HDR_TYPE_IP4 = 2,
TCA_PEDIT_KEY_EX_HDR_TYPE_IP6 = 3,
TCA_PEDIT_KEY_EX_HDR_TYPE_TCP = 4,
TCA_PEDIT_KEY_EX_HDR_TYPE_UDP = 5,
__PEDIT_HDR_TYPE_MAX = 6,
};
enum pedit_cmd {
TCA_PEDIT_KEY_EX_CMD_SET = 0,
TCA_PEDIT_KEY_EX_CMD_ADD = 1,
__PEDIT_CMD_MAX = 2,
};
struct tc_pedit_key {
__u32 mask;
__u32 val;
__u32 off;
__u32 at;
__u32 offmask;
__u32 shift;
};
struct tcf_pedit_key_ex {
enum pedit_header_type htype;
enum pedit_cmd cmd;
};
struct tcf_pedit {
struct tc_action common;
unsigned char tcfp_nkeys;
unsigned char tcfp_flags;
u32 tcfp_off_max_hint;
struct tc_pedit_key *tcfp_keys;
struct tcf_pedit_key_ex *tcfp_keys_ex;
};
struct tc_act_pernet_id {
struct list_head list;
unsigned int id;
};
struct tsinfo_reply_data {
struct ethnl_reply_data base;
struct ethtool_ts_info ts_info;
};
enum tsq_flags {
TSQF_THROTTLED = 1,
TSQF_QUEUED = 2,
TCPF_TSQ_DEFERRED = 4,
TCPF_WRITE_TIMER_DEFERRED = 8,
TCPF_DELACK_TIMER_DEFERRED = 16,
TCPF_MTU_REDUCED_DEFERRED = 32,
};
struct mptcp_out_options {};
struct tcp_out_options {
u16 options;
u16 mss;
u8 ws;
u8 num_sack_blocks;
u8 hash_size;
u8 bpf_opt_len;
__u8 *hash_location;
__u32 tsval;
__u32 tsecr;
struct tcp_fastopen_cookie *fastopen_cookie;
struct mptcp_out_options mptcp;
};
struct tsq_tasklet {
struct tasklet_struct tasklet;
struct list_head head;
};
enum xprt_xid_rb_cmp {
XID_RB_EQUAL = 0,
XID_RB_LEFT = 1,
XID_RB_RIGHT = 2,
};
struct vlan_group {
unsigned int nr_vlan_devs;
struct hlist_node hlist;
struct net_device **vlan_devices_arrays[16];
};
struct vlan_info {
struct net_device *real_dev;
struct vlan_group grp;
struct list_head vid_list;
unsigned int nr_vids;
struct callback_head rcu;
};
enum vlan_flags {
VLAN_FLAG_REORDER_HDR = 1,
VLAN_FLAG_GVRP = 2,
VLAN_FLAG_LOOSE_BINDING = 4,
VLAN_FLAG_MVRP = 8,
VLAN_FLAG_BRIDGE_BINDING = 16,
};
struct vlan_priority_tci_mapping {
u32 priority;
u16 vlan_qos;
struct vlan_priority_tci_mapping *next;
};
struct vlan_dev_priv {
unsigned int nr_ingress_mappings;
u32 ingress_priority_map[8];
unsigned int nr_egress_mappings;
struct vlan_priority_tci_mapping *egress_priority_map[16];
__be16 vlan_proto;
u16 vlan_id;
u16 flags;
struct net_device *real_dev;
netdevice_tracker dev_tracker;
unsigned char real_dev_addr[6];
struct proc_dir_entry *dent;
struct vlan_pcpu_stats *vlan_pcpu_stats;
struct netpoll *netpoll;
};
enum vlan_protos {
VLAN_PROTO_8021Q = 0,
VLAN_PROTO_8021AD = 1,
VLAN_PROTO_NUM = 2,
};
struct vlan_vid_info {
struct list_head list;
__be16 proto;
u16 vid;
int refcount;
};
struct fdt_errtabent {
const char *str;
};
struct klist_waiter {
struct list_head list;
struct klist_node *node;
struct task_struct *process;
int woken;
};
struct mips_frame_info {
void *func;
long unsigned int func_size;
int frame_size;
int pc_offset;
};
struct flush_cache_page_args {
struct vm_area_struct *vma;
long unsigned int addr;
long unsigned int pfn;
};
struct flush_icache_range_args {
long unsigned int start;
long unsigned int end;
unsigned int type;
bool user;
};
struct flush_kernel_vmap_range_args {
long unsigned int vaddr;
int size;
};
enum {
TRACE_SIGNAL_DELIVERED = 0,
TRACE_SIGNAL_IGNORED = 1,
TRACE_SIGNAL_ALREADY_PENDING = 2,
TRACE_SIGNAL_OVERFLOW_FAIL = 3,
TRACE_SIGNAL_LOSE_INFO = 4,
};
struct trace_event_raw_signal_generate {
struct trace_entry ent;
int sig;
int errno;
int code;
char comm[16];
pid_t pid;
int group;
int result;
char __data[0];
};
struct trace_event_raw_signal_deliver {
struct trace_entry ent;
int sig;
int errno;
int code;
long unsigned int sa_handler;
long unsigned int sa_flags;
char __data[0];
};
struct trace_event_data_offsets_signal_generate {};
struct trace_event_data_offsets_signal_deliver {};
typedef void (*btf_trace_signal_generate)(void *, int, struct kernel_siginfo *, struct task_struct *, int, int);
typedef void (*btf_trace_signal_deliver)(void *, int, struct kernel_siginfo *, struct k_sigaction *);
enum sig_handler {
HANDLER_CURRENT = 0,
HANDLER_SIG_DFL = 1,
HANDLER_EXIT = 2,
};
struct ce_unbind {
struct clock_event_device *ce;
int res;
};
struct kallsym_iter {
loff_t pos;
loff_t pos_arch_end;
loff_t pos_mod_end;
loff_t pos_ftrace_mod_end;
loff_t pos_bpf_end;
long unsigned int value;
unsigned int nameoff;
char type;
char name[512];
char module_name[60];
int exported;
int show_value;
};
struct bpf_iter__ksym {
union {
struct bpf_iter_meta *meta;
};
union {
struct kallsym_iter *ksym;
};
};
struct trace_event_raw_error_report_template {
struct trace_entry ent;
enum error_detector error_detector;
long unsigned int id;
char __data[0];
};
struct trace_event_data_offsets_error_report_template {};
typedef void (*btf_trace_error_report_end)(void *, enum error_detector, long unsigned int);
struct bpf_iter_seq_task_common {
struct pid_namespace *ns;
enum bpf_iter_task_type type;
u32 pid;
u32 pid_visiting;
};
struct bpf_iter_seq_task_info {
struct bpf_iter_seq_task_common common;
u32 tid;
};
struct bpf_iter__task {
union {
struct bpf_iter_meta *meta;
};
union {
struct task_struct *task;
};
};
struct bpf_iter_seq_task_file_info {
struct bpf_iter_seq_task_common common;
struct task_struct *task;
u32 tid;
u32 fd;
};
struct bpf_iter__task_file {
union {
struct bpf_iter_meta *meta;
};
union {
struct task_struct *task;
};
u32 fd;
long: 32;
union {
struct file *file;
};
};
struct bpf_iter_seq_task_vma_info {
struct bpf_iter_seq_task_common common;
struct task_struct *task;
struct vm_area_struct *vma;
u32 tid;
long unsigned int prev_vm_start;
long unsigned int prev_vm_end;
};
enum bpf_task_vma_iter_find_op {
task_vma_iter_first_vma = 0,
task_vma_iter_next_vma = 1,
task_vma_iter_find_vma = 2,
};
struct bpf_iter__task_vma {
union {
struct bpf_iter_meta *meta;
};
union {
struct task_struct *task;
};
union {
struct vm_area_struct *vma;
};
};
typedef u64 (*btf_bpf_find_vma)(struct task_struct *, u64, bpf_callback_t, void *, u64);
struct bpf_cpumap_val {
__u32 qsize;
union {
int fd;
__u32 id;
} bpf_prog;
};
struct bpf_cpu_map_entry;
struct xdp_bulk_queue {
void *q[8];
struct list_head flush_node;
struct bpf_cpu_map_entry *obj;
unsigned int count;
};
struct bpf_cpu_map;
struct bpf_cpu_map_entry {
u32 cpu;
int map_id;
struct xdp_bulk_queue *bulkq;
struct bpf_cpu_map *cmap;
struct ptr_ring *queue;
struct task_struct *kthread;
struct bpf_cpumap_val value;
struct bpf_prog *prog;
atomic_t refcnt;
struct callback_head rcu;
struct work_struct kthread_stop_wq;
};
struct bpf_cpu_map {
struct bpf_map map;
struct bpf_cpu_map_entry **cpu_map;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
enum lruvec_flags {
LRUVEC_CONGESTED = 0,
};
enum pgdat_flags {
PGDAT_DIRTY = 0,
PGDAT_WRITEBACK = 1,
PGDAT_RECLAIM_LOCKED = 2,
};
struct reclaim_stat {
unsigned int nr_dirty;
unsigned int nr_unqueued_dirty;
unsigned int nr_congested;
unsigned int nr_writeback;
unsigned int nr_immediate;
unsigned int nr_pageout;
unsigned int nr_activate[2];
unsigned int nr_ref_keep;
unsigned int nr_unmap_fail;
unsigned int nr_lazyfree_fail;
};
struct mem_cgroup_reclaim_cookie {
pg_data_t *pgdat;
unsigned int generation;
};
struct trace_event_raw_mm_vmscan_kswapd_sleep {
struct trace_entry ent;
int nid;
char __data[0];
};
struct trace_event_raw_mm_vmscan_kswapd_wake {
struct trace_entry ent;
int nid;
int zid;
int order;
char __data[0];
};
struct trace_event_raw_mm_vmscan_wakeup_kswapd {
struct trace_entry ent;
int nid;
int zid;
int order;
long unsigned int gfp_flags;
char __data[0];
};
struct trace_event_raw_mm_vmscan_direct_reclaim_begin_template {
struct trace_entry ent;
int order;
long unsigned int gfp_flags;
char __data[0];
};
struct trace_event_raw_mm_vmscan_direct_reclaim_end_template {
struct trace_entry ent;
long unsigned int nr_reclaimed;
char __data[0];
};
struct trace_event_raw_mm_shrink_slab_start {
struct trace_entry ent;
struct shrinker *shr;
void *shrink;
int nid;
long int nr_objects_to_shrink;
long unsigned int gfp_flags;
long unsigned int cache_items;
long long unsigned int delta;
long unsigned int total_scan;
int priority;
char __data[0];
};
struct trace_event_raw_mm_shrink_slab_end {
struct trace_entry ent;
struct shrinker *shr;
int nid;
void *shrink;
long int unused_scan;
long int new_scan;
int retval;
long int total_scan;
char __data[0];
};
struct trace_event_raw_mm_vmscan_lru_isolate {
struct trace_entry ent;
int highest_zoneidx;
int order;
long unsigned int nr_requested;
long unsigned int nr_scanned;
long unsigned int nr_skipped;
long unsigned int nr_taken;
unsigned int isolate_mode;
int lru;
char __data[0];
};
struct trace_event_raw_mm_vmscan_write_folio {
struct trace_entry ent;
long unsigned int pfn;
int reclaim_flags;
char __data[0];
};
struct trace_event_raw_mm_vmscan_lru_shrink_inactive {
struct trace_entry ent;
int nid;
long unsigned int nr_scanned;
long unsigned int nr_reclaimed;
long unsigned int nr_dirty;
long unsigned int nr_writeback;
long unsigned int nr_congested;
long unsigned int nr_immediate;
unsigned int nr_activate0;
unsigned int nr_activate1;
long unsigned int nr_ref_keep;
long unsigned int nr_unmap_fail;
int priority;
int reclaim_flags;
char __data[0];
};
struct trace_event_raw_mm_vmscan_lru_shrink_active {
struct trace_entry ent;
int nid;
long unsigned int nr_taken;
long unsigned int nr_active;
long unsigned int nr_deactivated;
long unsigned int nr_referenced;
int priority;
int reclaim_flags;
char __data[0];
};
struct trace_event_raw_mm_vmscan_node_reclaim_begin {
struct trace_entry ent;
int nid;
int order;
long unsigned int gfp_flags;
char __data[0];
};
struct trace_event_raw_mm_vmscan_throttled {
struct trace_entry ent;
int nid;
int usec_timeout;
int usec_delayed;
int reason;
char __data[0];
};
struct trace_event_data_offsets_mm_vmscan_kswapd_sleep {};
struct trace_event_data_offsets_mm_vmscan_kswapd_wake {};
struct trace_event_data_offsets_mm_vmscan_wakeup_kswapd {};
struct trace_event_data_offsets_mm_vmscan_direct_reclaim_begin_template {};
struct trace_event_data_offsets_mm_vmscan_direct_reclaim_end_template {};
struct trace_event_data_offsets_mm_shrink_slab_start {};
struct trace_event_data_offsets_mm_shrink_slab_end {};
struct trace_event_data_offsets_mm_vmscan_lru_isolate {};
struct trace_event_data_offsets_mm_vmscan_write_folio {};
struct trace_event_data_offsets_mm_vmscan_lru_shrink_inactive {};
struct trace_event_data_offsets_mm_vmscan_lru_shrink_active {};
struct trace_event_data_offsets_mm_vmscan_node_reclaim_begin {};
struct trace_event_data_offsets_mm_vmscan_throttled {};
typedef void (*btf_trace_mm_vmscan_kswapd_sleep)(void *, int);
typedef void (*btf_trace_mm_vmscan_kswapd_wake)(void *, int, int, int);
typedef void (*btf_trace_mm_vmscan_wakeup_kswapd)(void *, int, int, int, gfp_t);
typedef void (*btf_trace_mm_vmscan_direct_reclaim_begin)(void *, int, gfp_t);
typedef void (*btf_trace_mm_vmscan_direct_reclaim_end)(void *, long unsigned int);
typedef void (*btf_trace_mm_shrink_slab_start)(void *, struct shrinker *, struct shrink_control *, long int, long unsigned int, long long unsigned int, long unsigned int, int);
typedef void (*btf_trace_mm_shrink_slab_end)(void *, struct shrinker *, int, int, long int, long int, long int);
typedef void (*btf_trace_mm_vmscan_lru_isolate)(void *, int, int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, isolate_mode_t, int);
typedef void (*btf_trace_mm_vmscan_write_folio)(void *, struct folio *);
typedef void (*btf_trace_mm_vmscan_lru_shrink_inactive)(void *, int, long unsigned int, long unsigned int, struct reclaim_stat *, int, int);
typedef void (*btf_trace_mm_vmscan_lru_shrink_active)(void *, int, long unsigned int, long unsigned int, long unsigned int, long unsigned int, int, int);
typedef void (*btf_trace_mm_vmscan_node_reclaim_begin)(void *, int, int, gfp_t);
typedef void (*btf_trace_mm_vmscan_node_reclaim_end)(void *, long unsigned int);
typedef void (*btf_trace_mm_vmscan_throttled)(void *, int, int, int, int);
struct scan_control {
long unsigned int nr_to_reclaim;
nodemask_t *nodemask;
struct mem_cgroup *target_mem_cgroup;
long unsigned int anon_cost;
long unsigned int file_cost;
unsigned int may_deactivate: 2;
unsigned int force_deactivate: 1;
unsigned int skipped_deactivate: 1;
unsigned int may_writepage: 1;
unsigned int may_unmap: 1;
unsigned int may_swap: 1;
unsigned int proactive: 1;
unsigned int memcg_low_reclaim: 1;
unsigned int memcg_low_skipped: 1;
unsigned int hibernation_mode: 1;
unsigned int compaction_ready: 1;
unsigned int cache_trim_mode: 1;
unsigned int file_is_tiny: 1;
unsigned int no_demotion: 1;
s8 order;
s8 priority;
s8 reclaim_idx;
gfp_t gfp_mask;
long unsigned int nr_scanned;
long unsigned int nr_reclaimed;
struct {
unsigned int dirty;
unsigned int unqueued_dirty;
unsigned int congested;
unsigned int writeback;
unsigned int immediate;
unsigned int file_taken;
unsigned int taken;
} nr;
struct reclaim_state reclaim_state;
};
typedef enum {
PAGE_KEEP = 0,
PAGE_ACTIVATE = 1,
PAGE_SUCCESS = 2,
PAGE_CLEAN = 3,
} pageout_t;
enum folio_references {
FOLIOREF_RECLAIM = 0,
FOLIOREF_RECLAIM_CLEAN = 1,
FOLIOREF_KEEP = 2,
FOLIOREF_ACTIVATE = 3,
};
enum scan_balance {
SCAN_EQUAL = 0,
SCAN_FRACT = 1,
SCAN_ANON = 2,
SCAN_FILE = 3,
};
struct files_stat_struct {
long unsigned int nr_files;
long unsigned int nr_free_files;
long unsigned int max_files;
};
struct dio_submit {
struct bio *bio;
unsigned int blkbits;
unsigned int blkfactor;
unsigned int start_zero_done;
int pages_in_io;
long: 32;
sector_t block_in_file;
unsigned int blocks_available;
int reap_counter;
sector_t final_block_in_request;
int boundary;
get_block_t *get_block;
dio_submit_t *submit_io;
long: 32;
loff_t logical_offset_in_bio;
sector_t final_block_in_bio;
sector_t next_block_for_io;
struct page *cur_page;
unsigned int cur_page_offset;
unsigned int cur_page_len;
long: 32;
sector_t cur_page_block;
loff_t cur_page_fs_offset;
struct iov_iter *iter;
unsigned int head;
unsigned int tail;
size_t from;
size_t to;
long: 32;
};
struct dio {
int flags;
blk_opf_t opf;
struct gendisk *bio_disk;
struct inode *inode;
loff_t i_size;
dio_iodone_t *end_io;
void *private;
spinlock_t bio_lock;
int page_errors;
int is_async;
bool defer_completion;
bool should_dirty;
int io_error;
long unsigned int refcount;
struct bio *bio_list;
struct task_struct *waiter;
struct kiocb *iocb;
ssize_t result;
union {
struct page *pages[64];
struct work_struct complete_work;
};
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
};
struct iomap_swapfile_info {
struct iomap iomap;
struct swap_info_struct *sis;
long: 32;
uint64_t lowest_ppage;
uint64_t highest_ppage;
long unsigned int nr_pages;
int nr_extents;
struct file *file;
long: 32;
};
struct fscrypt_name {
const struct qstr *usr_fname;
struct fscrypt_str disk_name;
u32 hash;
u32 minor_hash;
struct fscrypt_str crypto_buf;
bool is_nokey_name;
};
struct ext4_dir_entry {
__le32 inode;
__le16 rec_len;
__le16 name_len;
char name[255];
};
struct ext4_dir_entry_tail {
__le32 det_reserved_zero1;
__le16 det_rec_len;
__u8 det_reserved_zero2;
__u8 det_reserved_ft;
__le32 det_checksum;
};
typedef enum {
EITHER = 0,
INDEX = 1,
DIRENT = 2,
DIRENT_HTREE = 3,
} dirblock_type_t;
struct fake_dirent {
__le32 inode;
__le16 rec_len;
u8 name_len;
u8 file_type;
};
struct dx_countlimit {
__le16 limit;
__le16 count;
};
struct dx_entry {
__le32 hash;
__le32 block;
};
struct dx_root_info {
__le32 reserved_zero;
u8 hash_version;
u8 info_length;
u8 indirect_levels;
u8 unused_flags;
};
struct dx_root {
struct fake_dirent dot;
char dot_name[4];
struct fake_dirent dotdot;
char dotdot_name[4];
struct dx_root_info info;
struct dx_entry entries[0];
};
struct dx_node {
struct fake_dirent fake;
struct dx_entry entries[0];
};
struct dx_frame {
struct buffer_head *bh;
struct dx_entry *entries;
struct dx_entry *at;
};
struct dx_map_entry {
u32 hash;
u16 offs;
u16 size;
};
struct dx_tail {
u32 dt_reserved;
__le32 dt_checksum;
};
struct ext4_renament {
struct inode *dir;
struct dentry *dentry;
struct inode *inode;
bool is_dir;
int dir_nlink_delta;
struct buffer_head *bh;
struct ext4_dir_entry_2 *de;
int inlined;
struct buffer_head *dir_bh;
struct ext4_dir_entry_2 *parent_de;
int dir_inlined;
};
struct crypto_report_rng {
char type[64];
unsigned int seedsize;
};
struct rq_wait {
wait_queue_head_t wait;
atomic_t inflight;
};
struct rq_depth {
unsigned int max_depth;
int scale_step;
bool scaled_max;
unsigned int queue_depth;
unsigned int default_depth;
};
typedef bool acquire_inflight_cb_t(struct rq_wait *, void *);
typedef void cleanup_cb_t(struct rq_wait *, void *);
struct rq_qos_wait_data {
struct wait_queue_entry wq;
struct task_struct *task;
struct rq_wait *rqw;
acquire_inflight_cb_t *cb;
void *private_data;
bool got_token;
};
struct io_open {
struct file *file;
int dfd;
u32 file_slot;
struct filename *filename;
struct open_how how;
long unsigned int nofile;
long: 32;
};
struct io_close {
struct file *file;
int fd;
u32 file_slot;
};
typedef mpi_limb_t UWtype;
struct cpu_ipi_domain_state {
long unsigned int allocated[1];
};
struct cytp_contact {
int x;
int y;
int z;
};
struct cytp_report_data {
int contact_cnt;
struct cytp_contact contacts[2];
unsigned int left: 1;
unsigned int right: 1;
unsigned int middle: 1;
unsigned int tap: 1;
};
struct cytp_data {
int fw_version;
int pkt_size;
int mode;
int tp_min_pressure;
int tp_max_pressure;
int tp_width;
int tp_high;
int tp_max_abs_x;
int tp_max_abs_y;
int tp_res_x;
int tp_res_y;
int tp_metrics_supported;
};
enum piix4_pm_io_reg {
PIIX4_FUNC3IO_PMSTS = 0,
PIIX4_FUNC3IO_PMCNTRL = 4,
};
struct scm_timestamping {
struct __kernel_old_timespec ts[3];
};
struct scm_timestamping64 {
struct __kernel_timespec ts[3];
};
struct psample_group {
struct list_head list;
struct net *net;
u32 group_num;
u32 refcount;
u32 seq;
struct callback_head rcu;
};
struct action_gate_entry {
u8 gate_state;
u32 interval;
s32 ipv;
s32 maxoctets;
};
enum qdisc_class_ops_flags {
QDISC_CLASS_OPS_DOIT_UNLOCKED = 1,
};
enum tcf_proto_ops_flags {
TCF_PROTO_OPS_DOIT_UNLOCKED = 1,
};
typedef void tcf_chain_head_change_t(struct tcf_proto *, void *);
struct tcf_block_ext_info {
enum flow_block_binder_type binder_type;
tcf_chain_head_change_t *chain_head_change;
void *chain_head_change_priv;
u32 block_index;
};
struct tcf_qevent {
struct tcf_block *block;
struct tcf_block_ext_info info;
struct tcf_proto *filter_chain;
};
struct tcf_filter_chain_list_item {
struct list_head list;
tcf_chain_head_change_t *chain_head_change;
void *chain_head_change_priv;
};
struct tcf_net {
spinlock_t idr_lock;
struct idr idr;
};
struct tcf_block_owner_item {
struct list_head list;
struct Qdisc *q;
enum flow_block_binder_type binder_type;
};
struct tcf_chain_info {
struct tcf_proto **pprev;
struct tcf_proto *next;
};
struct tcf_dump_args {
struct tcf_walker w;
struct sk_buff *skb;
struct netlink_callback *cb;
struct tcf_block *block;
struct Qdisc *q;
u32 parent;
bool terse_dump;
};
struct udp_dev_scratch {
u32 _tsize_state;
};
struct bpf_iter__udp {
union {
struct bpf_iter_meta *meta;
};
union {
struct udp_sock *udp_sk;
};
uid_t uid;
long: 32;
int bucket;
long: 32;
};
struct unix_domain {
struct auth_domain h;
};
struct ip_map {
struct cache_head h;
char m_class[8];
struct in6_addr m_addr;
struct unix_domain *m_client;
struct callback_head m_rcu;
long: 32;
};
struct unix_gid {
struct cache_head h;
kuid_t uid;
struct group_info *gi;
struct callback_head rcu;
};
struct user_pt_regs {
__u64 regs[32];
__u64 lo;
__u64 hi;
__u64 cp0_epc;
__u64 cp0_badvaddr;
__u64 cp0_status;
__u64 cp0_cause;
};
enum pt_watch_style {
pt_watch_style_mips32 = 0,
pt_watch_style_mips64 = 1,
};
struct mips32_watch_regs {
unsigned int watchlo[8];
short unsigned int watchhi[8];
short unsigned int watch_masks[8];
unsigned int num_valid;
long: 32;
};
struct mips64_watch_regs {
long long unsigned int watchlo[8];
short unsigned int watchhi[8];
short unsigned int watch_masks[8];
unsigned int num_valid;
long: 32;
};
struct pt_watch_regs {
enum pt_watch_style style;
long: 32;
union {
struct mips32_watch_regs mips32;
struct mips64_watch_regs mips64;
};
};
struct trace_event_raw_sys_enter {
struct trace_entry ent;
long int id;
long unsigned int args[6];
char __data[0];
};
struct trace_event_raw_sys_exit {
struct trace_entry ent;
long int id;
long int ret;
char __data[0];
};
struct trace_event_data_offsets_sys_enter {};
struct trace_event_data_offsets_sys_exit {};
typedef void (*btf_trace_sys_enter)(void *, struct pt_regs *, long int);
typedef void (*btf_trace_sys_exit)(void *, struct pt_regs *, long int);
enum mips_regset {
REGSET_GPR = 0,
REGSET_DSP = 1,
REGSET_FPR = 2,
REGSET_FP_MODE = 3,
};
struct pt_regs_offset {
const char *name;
int offset;
};
enum reboot_type {
BOOT_TRIPLE = 116,
BOOT_KBD = 107,
BOOT_BIOS = 98,
BOOT_ACPI = 97,
BOOT_EFI = 101,
BOOT_CF9_FORCE = 112,
BOOT_CF9_SAFE = 113,
};
enum sys_off_mode {
SYS_OFF_MODE_POWER_OFF_PREPARE = 0,
SYS_OFF_MODE_POWER_OFF = 1,
SYS_OFF_MODE_RESTART_PREPARE = 2,
SYS_OFF_MODE_RESTART = 3,
};
struct sys_off_data {
int mode;
void *cb_data;
const char *cmd;
};
struct sys_off_handler {
struct notifier_block nb;
int (*sys_off_cb)(struct sys_off_data *);
void *cb_data;
enum sys_off_mode mode;
bool blocking;
void *list;
};
enum rwsem_waiter_type {
RWSEM_WAITING_FOR_WRITE = 0,
RWSEM_WAITING_FOR_READ = 1,
};
struct rwsem_waiter {
struct list_head list;
struct task_struct *task;
enum rwsem_waiter_type type;
long unsigned int timeout;
bool handoff_set;
};
enum rwsem_wake_type {
RWSEM_WAKE_ANY = 0,
RWSEM_WAKE_READERS = 1,
RWSEM_WAKE_READ_OWNED = 2,
};
enum owner_state {
OWNER_NULL = 1,
OWNER_WRITER = 2,
OWNER_READER = 4,
OWNER_NONSPINNABLE = 8,
};
typedef __kernel_long_t __kernel_suseconds_t;
typedef __kernel_suseconds_t suseconds_t;
struct eprobe_trace_entry_head {
struct trace_entry ent;
};
struct trace_eprobe {
const char *event_system;
const char *event_name;
char *filter_str;
struct trace_event_call *event;
struct dyn_event devent;
struct trace_probe tp;
};
struct eprobe_data {
struct trace_event_file *file;
struct trace_eprobe *ep;
};
struct bpf_iter_seq_map_info {
u32 map_id;
};
struct bpf_iter__bpf_map {
union {
struct bpf_iter_meta *meta;
};
union {
struct bpf_map *map;
};
};
struct vma_swap_readahead {
short unsigned int win;
short unsigned int offset;
short unsigned int nr_pte;
pte_t ptes[8];
};
struct ns_get_path_task_args {
const struct proc_ns_operations *ns_ops;
struct task_struct *task;
};
struct fd_data {
fmode_t mode;
unsigned int fd;
};
struct sysctl_alias {
const char *kernel_param;
const char *sysctl_param;
};
struct nfs_createdata {
struct nfs_createargs arg;
struct nfs_diropok res;
struct nfs_fh fhandle;
long: 32;
struct nfs_fattr fattr;
};
enum nfs3_time_how {
DONT_CHANGE = 0,
SET_TO_SERVER_TIME = 1,
SET_TO_CLIENT_TIME = 2,
};
struct nfsd3_fhandle_pair {
__u32 dummy;
long: 32;
struct svc_fh fh1;
struct svc_fh fh2;
};
struct args_protover {
__u32 version;
};
struct args_protosubver {
__u32 sub_version;
};
struct args_openmount {
__u32 devid;
};
struct args_ready {
__u32 token;
};
struct args_fail {
__u32 token;
__s32 status;
};
struct args_setpipefd {
__s32 pipefd;
};
struct args_timeout {
__u64 timeout;
};
struct args_requester {
__u32 uid;
__u32 gid;
};
struct args_expire {
__u32 how;
};
struct args_askumount {
__u32 may_umount;
};
struct args_in {
__u32 type;
};
struct args_out {
__u32 devid;
__u32 magic;
};
struct args_ismountpoint {
union {
struct args_in in;
struct args_out out;
};
};
struct autofs_dev_ioctl {
__u32 ver_major;
__u32 ver_minor;
__u32 size;
__s32 ioctlfd;
union {
struct args_protover protover;
struct args_protosubver protosubver;
struct args_openmount openmount;
struct args_ready ready;
struct args_fail fail;
struct args_setpipefd setpipefd;
struct args_timeout timeout;
struct args_requester requester;
struct args_expire expire;
struct args_askumount askumount;
struct args_ismountpoint ismountpoint;
};
char path[0];
};
enum {
AUTOFS_DEV_IOCTL_VERSION_CMD = 113,
AUTOFS_DEV_IOCTL_PROTOVER_CMD = 114,
AUTOFS_DEV_IOCTL_PROTOSUBVER_CMD = 115,
AUTOFS_DEV_IOCTL_OPENMOUNT_CMD = 116,
AUTOFS_DEV_IOCTL_CLOSEMOUNT_CMD = 117,
AUTOFS_DEV_IOCTL_READY_CMD = 118,
AUTOFS_DEV_IOCTL_FAIL_CMD = 119,
AUTOFS_DEV_IOCTL_SETPIPEFD_CMD = 120,
AUTOFS_DEV_IOCTL_CATATONIC_CMD = 121,
AUTOFS_DEV_IOCTL_TIMEOUT_CMD = 122,
AUTOFS_DEV_IOCTL_REQUESTER_CMD = 123,
AUTOFS_DEV_IOCTL_EXPIRE_CMD = 124,
AUTOFS_DEV_IOCTL_ASKUMOUNT_CMD = 125,
AUTOFS_DEV_IOCTL_ISMOUNTPOINT_CMD = 126,
};
typedef int (*ioctl_fn)(struct file *, struct autofs_sb_info *, struct autofs_dev_ioctl *);
struct rsa_asn1_template {
const char *name;
const u8 *data;
size_t size;
};
struct pkcs1pad_ctx {
struct crypto_akcipher *child;
unsigned int key_size;
};
struct pkcs1pad_inst_ctx {
struct crypto_akcipher_spawn spawn;
const struct rsa_asn1_template *digest_info;
};
struct pkcs1pad_request {
struct scatterlist in_sg[2];
struct scatterlist out_sg[1];
uint8_t *in_buf;
uint8_t *out_buf;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
long: 32;
struct akcipher_request child_req;
};
struct pkcs7_parse_context {
struct pkcs7_message *msg;
struct pkcs7_signed_info *sinfo;
struct pkcs7_signed_info **ppsinfo;
struct x509_certificate *certs;
struct x509_certificate **ppcerts;
long unsigned int data;
enum OID last_oid;
unsigned int x509_index;
unsigned int sinfo_index;
const void *raw_serial;
unsigned int raw_serial_size;
unsigned int raw_issuer_size;
const void *raw_issuer;
const void *raw_skid;
unsigned int raw_skid_size;
bool expect_skid;
};
struct io_uring_probe_op {
__u8 op;
__u8 resv;
__u16 flags;
__u32 resv2;
};
struct io_uring_probe {
__u8 last_op;
__u8 ops_len;
__u16 resv;
__u32 resv2[3];
struct io_uring_probe_op ops[0];
};
struct io_uring_restriction {
__u16 opcode;
union {
__u8 register_op;
__u8 sqe_op;
__u8 sqe_flags;
};
__u8 resv;
__u32 resv2[3];
};
enum {
IORING_RESTRICTION_REGISTER_OP = 0,
IORING_RESTRICTION_SQE_OP = 1,
IORING_RESTRICTION_SQE_FLAGS_ALLOWED = 2,
IORING_RESTRICTION_SQE_FLAGS_REQUIRED = 3,
IORING_RESTRICTION_LAST = 4,
};
struct io_uring_getevents_arg {
__u64 sigmask;
__u32 sigmask_sz;
__u32 pad;
__u64 ts;
};
struct trace_event_raw_io_uring_create {
struct trace_entry ent;
int fd;
void *ctx;
u32 sq_entries;
u32 cq_entries;
u32 flags;
char __data[0];
};
struct trace_event_raw_io_uring_register {
struct trace_entry ent;
void *ctx;
unsigned int opcode;
unsigned int nr_files;
unsigned int nr_bufs;
long int ret;
char __data[0];
};
struct trace_event_raw_io_uring_file_get {
struct trace_entry ent;
void *ctx;
void *req;
u64 user_data;
int fd;
char __data[0];
long: 32;
};
struct trace_event_raw_io_uring_queue_async_work {
struct trace_entry ent;
void *ctx;
void *req;
u64 user_data;
u8 opcode;
unsigned int flags;
struct io_wq_work *work;
int rw;
u32 __data_loc_op_str;
char __data[0];
long: 32;
};
struct trace_event_raw_io_uring_defer {
struct trace_entry ent;
void *ctx;
void *req;
long long unsigned int data;
u8 opcode;
u32 __data_loc_op_str;
char __data[0];
};
struct trace_event_raw_io_uring_link {
struct trace_entry ent;
void *ctx;
void *req;
void *target_req;
char __data[0];
};
struct trace_event_raw_io_uring_cqring_wait {
struct trace_entry ent;
void *ctx;
int min_events;
char __data[0];
};
struct trace_event_raw_io_uring_fail_link {
struct trace_entry ent;
void *ctx;
void *req;
long long unsigned int user_data;
u8 opcode;
void *link;
u32 __data_loc_op_str;
char __data[0];
long: 32;
};
struct trace_event_raw_io_uring_complete {
struct trace_entry ent;
void *ctx;
void *req;
u64 user_data;
int res;
unsigned int cflags;
u64 extra1;
u64 extra2;
char __data[0];
};
struct trace_event_raw_io_uring_submit_sqe {
struct trace_entry ent;
void *ctx;
void *req;
long long unsigned int user_data;
u8 opcode;
u32 flags;
bool force_nonblock;
bool sq_thread;
u32 __data_loc_op_str;
char __data[0];
};
struct trace_event_raw_io_uring_poll_arm {
struct trace_entry ent;
void *ctx;
void *req;
long long unsigned int user_data;
u8 opcode;
int mask;
int events;
u32 __data_loc_op_str;
char __data[0];
};
struct trace_event_raw_io_uring_task_add {
struct trace_entry ent;
void *ctx;
void *req;
long long unsigned int user_data;
u8 opcode;
int mask;
u32 __data_loc_op_str;
char __data[0];
long: 32;
};
struct trace_event_raw_io_uring_req_failed {
struct trace_entry ent;
void *ctx;
void *req;
long long unsigned int user_data;
u8 opcode;
u8 flags;
u8 ioprio;
long: 32;
u64 off;
u64 addr;
u32 len;
u32 op_flags;
u16 buf_index;
u16 personality;
u32 file_index;
u64 pad1;
u64 addr3;
int error;
u32 __data_loc_op_str;
char __data[0];
};
struct trace_event_raw_io_uring_cqe_overflow {
struct trace_entry ent;
void *ctx;
long: 32;
long long unsigned int user_data;
s32 res;
u32 cflags;
void *ocqe;
char __data[0];
long: 32;
};
struct trace_event_raw_io_uring_task_work_run {
struct trace_entry ent;
void *tctx;
unsigned int count;
unsigned int loops;
char __data[0];
};
struct trace_event_raw_io_uring_short_write {
struct trace_entry ent;
void *ctx;
long: 32;
u64 fpos;
u64 wanted;
u64 got;
char __data[0];
};
struct trace_event_raw_io_uring_local_work_run {
struct trace_entry ent;
void *ctx;
int count;
unsigned int loops;
char __data[0];
};
struct trace_event_data_offsets_io_uring_create {};
struct trace_event_data_offsets_io_uring_register {};
struct trace_event_data_offsets_io_uring_file_get {};
struct trace_event_data_offsets_io_uring_queue_async_work {
u32 op_str;
};
struct trace_event_data_offsets_io_uring_defer {
u32 op_str;
};
struct trace_event_data_offsets_io_uring_link {};
struct trace_event_data_offsets_io_uring_cqring_wait {};
struct trace_event_data_offsets_io_uring_fail_link {
u32 op_str;
};
struct trace_event_data_offsets_io_uring_complete {};
struct trace_event_data_offsets_io_uring_submit_sqe {
u32 op_str;
};
struct trace_event_data_offsets_io_uring_poll_arm {
u32 op_str;
};
struct trace_event_data_offsets_io_uring_task_add {
u32 op_str;
};
struct trace_event_data_offsets_io_uring_req_failed {
u32 op_str;
};
struct trace_event_data_offsets_io_uring_cqe_overflow {};
struct trace_event_data_offsets_io_uring_task_work_run {};
struct trace_event_data_offsets_io_uring_short_write {};
struct trace_event_data_offsets_io_uring_local_work_run {};
typedef void (*btf_trace_io_uring_create)(void *, int, void *, u32, u32, u32);
typedef void (*btf_trace_io_uring_register)(void *, void *, unsigned int, unsigned int, unsigned int, long int);
typedef void (*btf_trace_io_uring_file_get)(void *, struct io_kiocb *, int);
typedef void (*btf_trace_io_uring_queue_async_work)(void *, struct io_kiocb *, int);
typedef void (*btf_trace_io_uring_defer)(void *, struct io_kiocb *);
typedef void (*btf_trace_io_uring_link)(void *, struct io_kiocb *, struct io_kiocb *);
typedef void (*btf_trace_io_uring_cqring_wait)(void *, void *, int);
typedef void (*btf_trace_io_uring_fail_link)(void *, struct io_kiocb *, struct io_kiocb *);
typedef void (*btf_trace_io_uring_complete)(void *, void *, void *, u64, int, unsigned int, u64, u64);
typedef void (*btf_trace_io_uring_submit_sqe)(void *, struct io_kiocb *, bool);
typedef void (*btf_trace_io_uring_poll_arm)(void *, struct io_kiocb *, int, int);
typedef void (*btf_trace_io_uring_task_add)(void *, struct io_kiocb *, int);
typedef void (*btf_trace_io_uring_req_failed)(void *, const struct io_uring_sqe *, struct io_kiocb *, int);
typedef void (*btf_trace_io_uring_cqe_overflow)(void *, void *, long long unsigned int, s32, u32, void *);
typedef void (*btf_trace_io_uring_task_work_run)(void *, void *, unsigned int, unsigned int);
typedef void (*btf_trace_io_uring_short_write)(void *, void *, u64, u64, u64);
typedef void (*btf_trace_io_uring_local_work_run)(void *, void *, int, unsigned int);
enum {
IO_CHECK_CQ_OVERFLOW_BIT = 0,
IO_CHECK_CQ_DROPPED_BIT = 1,
};
enum {
IO_EVENTFD_OP_SIGNAL_BIT = 0,
IO_EVENTFD_OP_FREE_BIT = 1,
};
struct io_defer_entry {
struct list_head list;
struct io_kiocb *req;
u32 seq;
};
struct io_wait_queue {
struct wait_queue_entry wq;
struct io_ring_ctx *ctx;
unsigned int cq_tail;
unsigned int nr_timeouts;
};
struct io_tctx_exit {
struct callback_head task_work;
struct completion completion;
struct io_ring_ctx *ctx;
};
struct io_task_cancel {
struct task_struct *task;
bool all;
};
struct creds;
struct value_name_pair;
struct sa_name_list {
int opcode;
const struct value_name_pair *arr;
int arr_sz;
};
struct value_name_pair {
int value;
const char *name;
};
struct error_info {
short unsigned int code12;
short unsigned int size;
};
struct error_info2 {
unsigned char code1;
unsigned char code2_min;
unsigned char code2_max;
const char *str;
const char *fmt;
};
enum ata_lpm_hints {
ATA_LPM_EMPTY = 1,
ATA_LPM_HIPM = 2,
ATA_LPM_WAKE_ONLY = 4,
};
enum {
ATA_EH_SPDN_NCQ_OFF = 1,
ATA_EH_SPDN_SPEED_DOWN = 2,
ATA_EH_SPDN_FALLBACK_TO_PIO = 4,
ATA_EH_SPDN_KEEP_ERRORS = 8,
ATA_EFLAG_IS_IO = 1,
ATA_EFLAG_DUBIOUS_XFER = 2,
ATA_EFLAG_OLD_ER = -2147483648,
ATA_ECAT_NONE = 0,
ATA_ECAT_ATA_BUS = 1,
ATA_ECAT_TOUT_HSM = 2,
ATA_ECAT_UNK_DEV = 3,
ATA_ECAT_DUBIOUS_NONE = 4,
ATA_ECAT_DUBIOUS_ATA_BUS = 5,
ATA_ECAT_DUBIOUS_TOUT_HSM = 6,
ATA_ECAT_DUBIOUS_UNK_DEV = 7,
ATA_ECAT_NR = 8,
ATA_EH_CMD_DFL_TIMEOUT = 5000,
ATA_EH_RESET_COOL_DOWN = 5000,
ATA_EH_PRERESET_TIMEOUT = 10000,
ATA_EH_FASTDRAIN_INTERVAL = 3000,
ATA_EH_UA_TRIES = 5,
ATA_EH_PROBE_TRIAL_INTERVAL = 60000,
ATA_EH_PROBE_TRIALS = 2,
};
struct ata_eh_cmd_timeout_ent {
const u8 *commands;
const unsigned int *timeouts;
};
struct speed_down_verdict_arg {
u64 since;
int xfer_ok;
int nr_errors[8];
long: 32;
};
struct serport {
struct tty_struct *tty;
wait_queue_head_t wait;
struct serio *serio;
struct serio_device_id id;
spinlock_t lock;
long unsigned int flags;
};
enum synaptics_pkt_type {
SYN_NEWABS = 0,
SYN_NEWABS_STRICT = 1,
SYN_NEWABS_RELAXED = 2,
SYN_OLDABS = 3,
};
struct synaptics_hw_state {
int x;
int y;
int z;
int w;
unsigned int left: 1;
unsigned int right: 1;
unsigned int middle: 1;
unsigned int up: 1;
unsigned int down: 1;
u8 ext_buttons;
s8 scroll;
};
struct synaptics_device_info {
u32 model_id;
u32 firmware_id;
u32 board_id;
u32 capabilities;
u32 ext_cap;
u32 ext_cap_0c;
u32 ext_cap_10;
u32 identity;
u32 x_res;
u32 y_res;
u32 x_max;
u32 y_max;
u32 x_min;
u32 y_min;
};
struct synaptics_data {
struct synaptics_device_info info;
enum synaptics_pkt_type pkt_type;
u8 mode;
int scroll;
bool absolute_mode;
bool disable_gesture;
struct serio *pt_port;
struct synaptics_hw_state agm;
unsigned int agm_count;
long unsigned int press_start;
bool press;
bool report_press;
bool is_forcepad;
};
struct min_max_quirk {
const char * const *pnp_ids;
struct {
u32 min;
u32 max;
} board_id;
u32 x_min;
u32 x_max;
u32 y_min;
u32 y_max;
};
struct syscon_reboot_context {
struct regmap *map;
u32 offset;
u32 value;
u32 mask;
struct notifier_block restart_handler;
};
enum {
TCA_STATS_UNSPEC = 0,
TCA_STATS_BASIC = 1,
TCA_STATS_RATE_EST = 2,
TCA_STATS_QUEUE = 3,
TCA_STATS_APP = 4,
TCA_STATS_RATE_EST64 = 5,
TCA_STATS_PAD = 6,
TCA_STATS_BASIC_HW = 7,
TCA_STATS_PKT64 = 8,
__TCA_STATS_MAX = 9,
};
struct gnet_stats_basic {
__u64 bytes;
__u32 packets;
long: 32;
};
struct gnet_stats_rate_est {
__u32 bps;
__u32 pps;
};
struct sch_frag_data {
long unsigned int dst;
struct qdisc_skb_cb cb;
__be16 inner_protocol;
u16 vlan_tci;
__be16 vlan_proto;
unsigned int l2_len;
u8 l2_data[18];
int (*xmit)(struct sk_buff *);
};
enum {
CTRL_CMD_UNSPEC = 0,
CTRL_CMD_NEWFAMILY = 1,
CTRL_CMD_DELFAMILY = 2,
CTRL_CMD_GETFAMILY = 3,
CTRL_CMD_NEWOPS = 4,
CTRL_CMD_DELOPS = 5,
CTRL_CMD_GETOPS = 6,
CTRL_CMD_NEWMCAST_GRP = 7,
CTRL_CMD_DELMCAST_GRP = 8,
CTRL_CMD_GETMCAST_GRP = 9,
CTRL_CMD_GETPOLICY = 10,
__CTRL_CMD_MAX = 11,
};
enum {
CTRL_ATTR_UNSPEC = 0,
CTRL_ATTR_FAMILY_ID = 1,
CTRL_ATTR_FAMILY_NAME = 2,
CTRL_ATTR_VERSION = 3,
CTRL_ATTR_HDRSIZE = 4,
CTRL_ATTR_MAXATTR = 5,
CTRL_ATTR_OPS = 6,
CTRL_ATTR_MCAST_GROUPS = 7,
CTRL_ATTR_POLICY = 8,
CTRL_ATTR_OP_POLICY = 9,
CTRL_ATTR_OP = 10,
__CTRL_ATTR_MAX = 11,
};
enum {
CTRL_ATTR_OP_UNSPEC = 0,
CTRL_ATTR_OP_ID = 1,
CTRL_ATTR_OP_FLAGS = 2,
__CTRL_ATTR_OP_MAX = 3,
};
enum {
CTRL_ATTR_MCAST_GRP_UNSPEC = 0,
CTRL_ATTR_MCAST_GRP_NAME = 1,
CTRL_ATTR_MCAST_GRP_ID = 2,
__CTRL_ATTR_MCAST_GRP_MAX = 3,
};
enum {
CTRL_ATTR_POLICY_UNSPEC = 0,
CTRL_ATTR_POLICY_DO = 1,
CTRL_ATTR_POLICY_DUMP = 2,
__CTRL_ATTR_POLICY_DUMP_MAX = 3,
CTRL_ATTR_POLICY_DUMP_MAX = 2,
};
struct genl_start_context {
const struct genl_family *family;
struct nlmsghdr *nlh;
struct netlink_ext_ack *extack;
const struct genl_ops *ops;
int hdrlen;
};
struct ctrl_dump_policy_ctx {
struct netlink_policy_dump_state *state;
const struct genl_family *rt;
unsigned int opidx;
u32 op;
u16 fam_id;
u8 policies: 1;
u8 single_op: 1;
};
enum {
ETHTOOL_A_FEC_STAT_UNSPEC = 0,
ETHTOOL_A_FEC_STAT_PAD = 1,
ETHTOOL_A_FEC_STAT_CORRECTED = 2,
ETHTOOL_A_FEC_STAT_UNCORR = 3,
ETHTOOL_A_FEC_STAT_CORR_BITS = 4,
__ETHTOOL_A_FEC_STAT_CNT = 5,
ETHTOOL_A_FEC_STAT_MAX = 4,
};
struct fec_stat_grp {
u64 stats[9];
u8 cnt;
long: 32;
};
struct fec_reply_data {
struct ethnl_reply_data base;
long unsigned int fec_link_modes[3];
u32 active_fec;
u8 fec_auto;
struct fec_stat_grp corr;
struct fec_stat_grp uncorr;
struct fec_stat_grp corr_bits;
};
struct inet_diag_req {
__u8 idiag_family;
__u8 idiag_src_len;
__u8 idiag_dst_len;
__u8 idiag_ext;
struct inet_diag_sockid id;
__u32 idiag_states;
__u32 idiag_dbs;
};
struct inet_diag_bc_op {
unsigned char code;
unsigned char yes;
short unsigned int no;
};
enum {
INET_DIAG_BC_NOP = 0,
INET_DIAG_BC_JMP = 1,
INET_DIAG_BC_S_GE = 2,
INET_DIAG_BC_S_LE = 3,
INET_DIAG_BC_D_GE = 4,
INET_DIAG_BC_D_LE = 5,
INET_DIAG_BC_AUTO = 6,
INET_DIAG_BC_S_COND = 7,
INET_DIAG_BC_D_COND = 8,
INET_DIAG_BC_DEV_COND = 9,
INET_DIAG_BC_MARK_COND = 10,
INET_DIAG_BC_S_EQ = 11,
INET_DIAG_BC_D_EQ = 12,
INET_DIAG_BC_CGROUP_COND = 13,
};
struct inet_diag_hostcond {
__u8 family;
__u8 prefix_len;
int port;
__be32 addr[0];
};
struct inet_diag_markcond {
__u32 mark;
__u32 mask;
};
struct inet_diag_meminfo {
__u32 idiag_rmem;
__u32 idiag_wmem;
__u32 idiag_fmem;
__u32 idiag_tmem;
};
struct inet_diag_sockopt {
__u8 recverr: 1;
__u8 is_icsk: 1;
__u8 freebind: 1;
__u8 hdrincl: 1;
__u8 mc_loop: 1;
__u8 transparent: 1;
__u8 mc_all: 1;
__u8 nodefrag: 1;
__u8 bind_address_no_port: 1;
__u8 recverr_rfc4884: 1;
__u8 defer_connect: 1;
__u8 unused: 5;
};
struct inet_diag_dump_data {
struct nlattr *req_nlas[4];
struct bpf_sk_storage_diag *bpf_stg_diag;
};
struct inet_diag_entry {
const __be32 *saddr;
const __be32 *daddr;
u16 sport;
u16 dport;
u16 family;
u16 userlocks;
u32 ifindex;
u32 mark;
};
struct mld2_grec {
__u8 grec_type;
__u8 grec_auxwords;
__be16 grec_nsrcs;
struct in6_addr grec_mca;
struct in6_addr grec_src[0];
};
struct mld2_report {
struct icmp6hdr mld2r_hdr;
struct mld2_grec mld2r_grec[0];
};
struct mld2_query {
struct icmp6hdr mld2q_hdr;
struct in6_addr mld2q_mca;
__u8 mld2q_qrv: 3;
__u8 mld2q_suppress: 1;
__u8 mld2q_resv2: 4;
__u8 mld2q_qqic;
__be16 mld2q_nsrcs;
struct in6_addr mld2q_srcs[0];
};
struct igmp6_mc_iter_state {
struct seq_net_private p;
struct net_device *dev;
struct inet6_dev *idev;
};
struct igmp6_mcf_iter_state {
struct seq_net_private p;
struct net_device *dev;
struct inet6_dev *idev;
struct ifmcaddr6 *im;
};
struct ip_tunnel_prl {
__be32 addr;
__u16 flags;
__u16 __reserved;
__u32 datalen;
__u32 __reserved2;
};
struct sit_net {
struct ip_tunnel *tunnels_r_l[16];
struct ip_tunnel *tunnels_r[16];
struct ip_tunnel *tunnels_l[16];
struct ip_tunnel *tunnels_wc[1];
struct ip_tunnel **tunnels[4];
struct net_device *fb_tunnel_dev;
};
enum l3mdev_type {
L3MDEV_TYPE_UNSPEC = 0,
L3MDEV_TYPE_VRF = 1,
__L3MDEV_TYPE_MAX = 2,
};
typedef int (*lookup_by_table_id_t)(struct net *, u32);
struct l3mdev_handler {
lookup_by_table_id_t dev_lookup;
};
struct word_at_a_time {
const long unsigned int one_bits;
const long unsigned int high_bits;
};
#ifndef BPF_NO_PRESERVE_ACCESS_INDEX
#pragma clang attribute pop
#endif
#endif /* __VMLINUX_H__ */