Function report |
Source Code:mm\kasan\common.c |
Create Date:2022-07-28 15:50:36 |
Last Modify:2020-03-12 14:18:49 | Copyright©Brick |
home page | Tree |
Annotation kernel can get tool activity | Download SCCT | Chinese |
Name:memset
Proto:void *memset(void *addr, int c, size_t len)
Type:void
Parameter:
Type | Parameter | Name |
---|---|---|
void * | addr | |
int | c | |
size_t | len |
108 | check_memory_region((unsignedlong)addr, len, true, _RET_IP_) |
Name | Describe |
---|---|
move_right | |
ip6_compressed_string | |
radix_tree_node_rcu_free | |
radix_tree_node_ctor | |
start_bunzip | Allocate the structure, read file header. If in_fd ==-1, inbuf must containa complete bunzip file (len bytes long). If in_fd!=-1, inbuf and len areignored, and data is read from file handle into temporary buffer. |
__bitmap_shift_right | __bitmap_shift_right - logical right shift of the bits in a bitmap*@dst : destination bitmap*@src : source bitmap*@shift : shift by this many bits*@nbits : bitmap size, in bits* Shifting right (dividing) means moving bits in the MS -> LS bit* direction |
__bitmap_shift_left | __bitmap_shift_left - logical left shift of the bits in a bitmap*@dst : destination bitmap*@src : source bitmap*@shift : shift by this many bits*@nbits : bitmap size, in bits* Shifting left (multiplying) means moving bits in the LS -> MS* direction |
sg_init_table | sg_init_table - Initialize SG table*@sgl: The SG table*@nents: Number of entries in table* Notes:* If this is part of a chained sg table, sg_mark_end() should be* used only on the last table part. |
__sg_alloc_table | __sg_alloc_table - Allocate and initialize an sg table with given allocator*@table: The sg table header to use*@nents: Number of entries in sg list*@max_ents: The maximum number of entries the allocator returns per call*@nents_first_chunk: Number of |
sg_miter_start | sg_miter_start - start mapping iteration over a sg list*@miter: sg mapping iter to be started*@sgl: sg list to iterate over*@nents: number of sg entries* Description:* Starts mapping iterator @miter.* Context:* Don't care. |
sg_zero_buffer | sg_zero_buffer - Zero-out a part of a SG list*@sgl: The SG list*@nents: Number of SG entries*@buflen: The number of bytes to zero out*@skip: Number of bytes to skip before zeroing* Returns the number of bytes zeroed. |
memzero_page | |
iov_iter_zero | |
initregs | SPDX-License-Identifier: GPL-2.0-or-later |
write_ldt | |
extend_brk | |
e820__range_remove | Remove a range of memory from the E820 table: |
copy_thread_tls | |
flush_thread | |
fpstate_init | |
fpu__copy | |
fpstate_sanitize_xstate | When executing XSAVEOPT (or other optimized XSAVE instructions), if* a processor implementation detects that an FPU state component is still* (or is again) in its initialized state, it may clear the corresponding* bit in the header |
copy_xstate_to_kernel | Convert from kernel XSAVES compacted format to standard format and copy* to a kernel-space ptrace buffer.* It supports partial copy but pos always starts from zero. This is called* from xstateregs_get() and there we check the CPU has XSAVES. |
copy_xstate_to_user | Convert from kernel XSAVES compacted format to standard format and copy* to a user-space buffer. It supports partial copy but pos always starts from* zero. This is called from xstateregs_get() and there we check the CPU* has XSAVES. |
set_tls_desc | |
fill_user_desc | Get the current Thread-Local Storage area: |
early_identify_cpu | Do minimum CPU detection early.* Fields really needed: vendor, cpuid_level, family, model, mask,* cache alignment.* The others are not touched to avoid unwanted side effects.* WARNING: this function is only called on the boot CPU. Don't add code |
identify_cpu | This does the hard work of actually picking apart the CPU stuff... |
cpu_init | pu_init() initializes state that is per-CPU. Some data is already* initialized (naturally) in the bootstrap process, such as the GDT* and IDT. We reload them nevertheless, this function acts as a* 'CPU state barrier', nothing should get across. |
do_clear_cpu_cap | |
mce_setup | Do initial initialization of a struct mce |
mce_reign | The Monarch's reign |
do_machine_check | The actual machine check handler. This only handles real* exceptions when something got corrupted coming in through int 18.* This is executed in NMI context not subject to normal locking rules. This* implies that most kernel services cannot be safely used |
prepare_threshold_block | |
log_and_reset_block | |
store_interrupt_enable | |
store_threshold_limit | |
apei_write_mce | |
mtrr_write | seq_file can seek but we ignore it.* Format of control line:* "base=%Lx size=%Lx type=%s" or "disable=%d" |
mtrr_ioctl | |
generic_set_mtrr | generic_set_mtrr - set variable MTRR register on the local CPU.*@reg: The register to set.*@base: The base address of the region.*@size: The size of the region. If this is 0 the region is disabled.*@type: The type of the region.* Returns nothing. |
mtrr_trim_uncached_memory | mtrr_trim_uncached_memory - trim RAM not covered by MTRRs*@end_pfn: ending page frame number* Some buggy BIOSes don't setup the MTRRs properly for systems with certain* memory configurations |
collect_cpu_info | |
collect_cpu_info_early | |
collect_cpu_info | |
free_equiv_cpu_table | |
load_microcode_amd | |
__mon_event_count | |
pseudo_lock_dev_mmap | |
init_irq_alloc_info | |
copy_irq_alloc_info | |
native_restore_boot_irq_mode | |
unlock_ExtINT_logic | This looks a bit hackish but it's about the only one way of sending* a few INTA cycles to 8259As and any associated glue logic |
mp_unregister_ioapic | |
mp_setup_entry | |
get_mn | |
crash_setup_memmap_entries | Prepare memory map for crash dump kernel |
setup_boot_parameters | |
do_sys_vm86 | |
kvmclock_init_mem | |
jailhouse_get_wallclock | |
setup_bios_corruption_check | |
branch_clear_offset | |
create_simplefb | |
__unwind_start | |
__unwind_start | |
__unwind_start | |
mm_alloc | Allocate and initialize an mm_struct. |
copy_process | Create a new process |
alloc_resource | |
copy_siginfo_to_user32 | |
do_sigaltstack | |
do_compat_sigaltstack | |
SYSCALL_DEFINE1 | |
SYSCALL_DEFINE2 | |
SYSCALL_DEFINE2 | Only setdomainname; getdomainname can be implemented by calling* uname() |
getrusage | |
do_sysinfo | do_sysinfo - fill in sysinfo struct*@info: pointer to buffer to fill |
init_pwq | alize newly alloced @pwq which is associated with @wq and @pool |
__kthread_init_worker | |
sched_copy_attr | Mimics kernel/events/core.c perf_copy_attr(). |
__visit_domain_allocation_hell | |
cpuacct_stats_show | |
sugov_start | |
group_init | |
debug_mutex_lock_common | Must be called with lock->wait_lock held. |
debug_mutex_free_waiter | |
lockdep_reset | |
reinit_class | |
debug_rt_mutex_init_waiter | |
debug_rt_mutex_free_waiter | |
pm_qos_remove_request | pm_qos_remove_request - modifies an existing qos request*@req: handle to request list element* Will remove pm qos request from the list of constraints and* recompute the current target value for the pm_qos_class. Call this* on slow code paths. |
test_wakealarm | To test system suspend, we need a hands-off mechanism to resume the* system. RTCs wake alarms are a common self-contained mechanism. |
__get_safe_page | |
init_header | |
save_image_lzo | save_image_lzo - Save the suspend image data compressed with LZO.*@handle: Swap map handle to use for saving the image.*@snapshot: Image to read data from.*@nr_to_write: Number of pages to save. |
swsusp_write | swsusp_write - Write entire image and metadata.*@flags: flags to pass to the "boot" kernel in the image header* It is important _NOT_ to umount filesystems at this point. We want* them synced (in case something goes wrong) but we DO not want to mark |
load_image_lzo | load_image_lzo - Load compressed image data and decompress them with LZO.*@handle: Swap map handle to use for loading data.*@snapshot: Image to copy uncompressed data into.*@nr_to_read: Number of pages to load. |
swsusp_read | swsusp_read - read the hibernation image.*@flags_p: flags passed by the "frozen" kernel in the image header should* be written into this memory location |
snapshot_open | |
snapshot_ioctl | |
log_store | sert record into the buffer, discard old ones, update heads |
rcu_sync_init | _sync_init() - Initialize an rcu_sync structure*@rsp: Pointer to rcu_sync structure to be initialized |
dma_direct_alloc_pages | |
__dma_alloc_from_coherent | |
__dma_entry_alloc | |
swiotlb_update_mem_attributes | Early SWIOTLB allocation may be too early to allow an architecture to* perform the desired operations. This function allows the architecture to* call SWIOTLB when the operations are possible. It needs to be called* before the SWIOTLB memory is used. |
swiotlb_late_init_with_tbl | |
write_profile | Writing to /proc/profile resets the counters* Writing a 'profiling multiplier' value into it also re-sets the profiling* interrupt frequency, on architectures that support this. |
__hrtimer_init | |
do_timer_create | Create a POSIX.1b interval timer. |
do_timer_gettime | Get the time remaining on a POSIX.1b interval timer. |
do_timer_settime | |
do_cpu_nanosleep | |
SYSCALL_DEFINE3 | |
COMPAT_SYSCALL_DEFINE3 | |
move_module | |
kdb_walk_kallsyms | |
fill_ac | Write an accounting entry for an exiting process* The acct_process() call is the workhorse of the process* accounting system. The struct acct is built here and then written* into the accounting file. This function should only be called from |
final_note | |
kimage_load_crash_segment | |
crash_save_cpu | |
crash_prepare_elf64_headers | |
elf_read_ehdr | |
kexec_free_elf_info | kexec_free_elf_info - free memory allocated by elf_read_from_buffer |
put_compat_rusage | |
compat_get_user_cpu_mask | |
get_compat_sigevent | We currently only need the following fields from the sigevent* structure: sigev_value, sigev_signo, sig_notify and (sometimes* sigev_notify_thread_id). The others are handled in user mode.* We also assume that copying sigev_value.sival_int is sufficient |
css_task_iter_start | ss_task_iter_start - initiate task iteration*@css: the css to walk tasks of*@flags: CSS_TASK_ITER_* flags*@it: the task iterator to use* Initiate iteration through the tasks of @css |
init_and_link_css | |
map_write | |
cpu_stop_init_done | |
audit_receive_msg | |
audit_krule_to_data | Translate kernel rule representation to struct audit_rule_data. |
audit_alloc_name | |
__audit_mq_open | __audit_mq_open - record audit data for a POSIX MQ open*@oflag: open flag*@mode: mode bits*@attr: queue attributes |
__audit_mq_sendrecv | __audit_mq_sendrecv - record audit data for a POSIX MQ timed send/receive*@mqdes: MQ descriptor*@msg_len: Message length*@msg_prio: Message priority*@abs_timeout: Message timeout in absolute time |
gcov_info_reset | gcov_info_reset - reset profiling data to zero*@info: profiling data set |
gcov_info_reset | gcov_info_reset - reset profiling data to zero*@info: profiling data set |
gcov_info_reset | gcov_info_reset - reset profiling data to zero*@info: profiling data set |
__get_insn_slot | __get_insn_slot() - Find a slot on an executable page for an instruction.* We allocate an executable page if there's no room on existing ones. |
kgdb_handle_exception | kgdb_handle_exception() - main entry point from a kernel exception* Locking hierarchy:* interface locks, if any (begin_session)* kgdb lock (kgdb_active) |
gdb_serial_stub | This function performs all gdbserial command procesing |
kdb_read | kdb_read* This function reads a string of characters, terminated by* a newline, or by reaching the end of the supplied buffer,* from the current kernel debugger console device.* Parameters:* Returns:* Returns a pointer to the buffer containing the received |
kdb_defcmd | |
kdb_md_line | kdb_md - This function implements the 'md', 'md1', 'md2', 'md4',* 'md8' 'mdr' and 'mds' commands.* md|mds [ |
kdb_sysinfo | Most of this code has been lifted from kernel/timer.c::sys_sysinfo().* I cannot call that code directly from kdb, it has an unconditional* cli()/sti() and calls routines that take locks which can stop the debugger. |
kdb_register_flags | |
kdbgetsymval | kdbgetsymval - Return the address of the given symbol |
kdbnearsym | kdbnearsym - Return the name of the symbol with the nearest address* less than 'addr' |
debug_kmalloc | |
debug_kfree | |
kdb_initbptab | Initialize the breakpoint table and register breakpoint commands. |
read_actions_logged | |
write_actions_logged | |
audit_actions_logged | |
relay_alloc_buf | lay_alloc_buf - allocate a channel buffer*@buf: the buffer struct*@size: total size of the buffer* Returns a pointer to the resulting buffer, %NULL if unsuccessful. The* passed in size will get page aligned, if it isn't already. |
fill_stats | |
fill_stats_for_tgid | |
cgroupstats_user_cmd | |
clear_tsk_latency_tracing | |
clear_global_latency_tracing | |
__account_scheduler_latency | __account_scheduler_latency - record an occurred latency*@tsk - the task struct of the task hitting the latency*@usecs - the duration of the latency in microseconds*@inter - 1 if the sleep was interruptible, 0 if uninterruptible* This function is the main |
ring_buffer_read_page | g_buffer_read_page - extract a page from the ring buffer*@buffer: buffer to extract from*@data_page: the page to use allocated from ring_buffer_alloc_read_page*@len: amount to extract*@cpu: the cpu of the buffer to extract |
trace_parser_get_init | race_parser_get_init - gets the buffer for trace parser |
allocate_cmdlines_buffer | |
trace_buffered_event_enable | race_buffered_event_enable - enable buffering events* When events are being filtered, it is quicker to use a temporary* buffer to write the event data into if there's a likely chance* that it will not be committed |
tracing_read_pipe | Consumer reader. |
tracing_map_array_clear | |
perf_trace_buf_alloc | |
perf_ftrace_function_call | |
event_hist_trigger | |
____bpf_probe_read_user | |
____bpf_probe_read_user_str | |
bpf_probe_read_kernel_common | |
bpf_probe_read_kernel_str_common | |
____bpf_perf_event_read_value | |
____bpf_perf_prog_read_value | |
trace_probe_log_clear | |
bpf_prog_calc_tag | |
bpf_probe_read_kernel | |
bpf_map_charge_move | |
bpf_obj_name_cpy | dst and src must have at least BPF_OBJ_NAME_LEN number of bytes.* Return 0 on success and < 0 on error. |
identify_ramdisk_image | This routine tries to find a RAM disk image to load, and returns the* number of blocks to read for a non-compressed image, 0 if the image* is a compressed image, and -1 if an image with the right magic* numbers could not be found |
shrink_page_list | shrink_page_list() returns the number of reclaimed pages |
shrink_node | |
lruvec_init | |
wb_init | |
pcpu_alloc | pcpu_alloc - the percpu allocator*@size: size of area to allocate in bytes*@align: alignment of area (max PAGE_SIZE)*@reserved: allocate from the reserved chunk if available*@gfp: allocation flags* Allocate percpu area of @size bytes aligned at @align |
memcg_accumulate_slabinfo | |
cache_show | |
kzfree | kzfree - like kfree but zero memory*@p: object to free memory of* The memory of the object @p points to is zeroed before freed.* If @p is %NULL, kzfree() does nothing.* Note: this function zeroes the whole allocated buffer which can be a good |
do_mmap_private | set up a private mapping or an anonymous shared mapping |
do_mmap | handle mapping creation for uClinux |
init_rss_vec | |
mincore_pte_range | |
do_mincore | Do a chunk of "sys_mincore()". We've already checked* all the arguments, we hold the mmap semaphore: we should* just return the amount of info we're asked for. |
aligned_vread | small helper routine , copy contents to buf from addr.* If the page is not present, fill zero. |
vread | vread() - read vmalloc area in a safe way.*@buf: buffer for reading data*@addr: vm address.*@count: number of bytes to be read.* This function checks that addr is a valid vmalloc'ed area, and* copy data from that area to a given buffer |
show_numa_info | |
build_zonelists | Build zonelists ordered by zone and nodes within zones.* This results in conserving DMA zone[s] until all Normal memory is* exhausted, but results in overflowing to remote node while memory* may still exist in local DMA zone. |
__build_all_zonelists | |
pageset_init | |
free_reserved_area | |
memblock_double_array | |
memblock_alloc_try_nid | memblock_alloc_try_nid - allocate boot memory block*@size: size of memory block to be allocated in bytes*@align: alignment of the region and block's size*@min_addr: the lower bound of the memory region from where the allocation* is preferred (phys |
swap_cluster_schedule_discard | Add a cluster to discard list and schedule it to do discard |
swap_do_scheduled_discard | Doing discard actually. After a cluster discard is finished, the cluster* will be added to free cluster list. caller should hold si->lock. |
swap_free_cluster | |
dma_pool_alloc | dma_pool_alloc - get a block of consistent memory*@pool: dma pool that will produce the block*@mem_flags: GFP_* bitmask*@handle: pointer to dma address of block* Return: the kernel virtual address of a currently unused block, |
dma_pool_free | dma_pool_free - put block back into dma pool*@pool: the dma pool holding the block*@vaddr: virtual address of block*@dma: dma address of block* Caller promises neither device nor driver will again touch this block* unless it is first re-allocated. |
vmemmap_alloc_block_zero | |
slob_alloc | slob_alloc: entry point into the slob allocator. |
poison_page | |
slab_alloc_node | |
slab_alloc | |
___cache_free | |
kmem_cache_alloc_bulk | |
slab_free_freelist_hook | |
maybe_wipe_obj_freeptr | If the object has been wiped upon free, make sure it's fully initialized by* zeroing out freelist pointer. |
slab_alloc_node | Inlined fastpath so that allocation functions (kmalloc, kmem_cache_alloc)* have the fastpath folded into their functions. So no function call* overhead for requests that can be satisfied on the fastpath. |
kmem_cache_alloc_bulk | Note that interrupts must be enabled when calling this function. |
msgctl_info | |
msgctl_stat | |
copy_compat_msqid_from_user | |
copy_compat_msqid_to_user | |
copy_semid_to_user | |
semctl_stat | |
semctl_info | |
copy_compat_semid_from_user | |
copy_compat_semid_to_user | |
copy_shmid_to_user | |
shmctl_ipc_info | |
shmctl_shm_info | |
shmctl_stat | |
copy_compat_shminfo_to_user | |
put_compat_shm_info | |
copy_compat_shmid_to_user | |
copy_compat_shmid_from_user | |
mqueue_get_inode | |
get_compat_mq_attr | |
put_compat_mq_attr | |
bio_reset | _reset - reinitialize a bio*@bio: bio to reset* Description:* After calling bio_reset(), @bio will be in the same state as a freshly* allocated bio returned bio bio_alloc_bioset() - the only fields that are |
zero_fill_bio_iter | |
blk_rq_init | |
blk_insert_flush | lk_insert_flush - insert a new PREFLUSH/FUA request*@rq: request to insert* To be called from __elv_add_request() for %ELEVATOR_INSERT_FLUSH insertions.* or __blk_mq_run_hw_queue() to dispatch request.*@rq is being submitted |
blk_rq_map_sg | map a request to scatterlist, return number of sg entries setup. Caller* must make sure sg can hold rq->nr_phys_segments entries |
blk_mq_init_sq_queue | Helper for setting up a queue with mq ops, given queue depth, and* the passed in mq ops flags. |
blkdev_getgeo | |
check_partition | |
find_label | |
scsi_cmd_ioctl | |
scsi_req_init | scsi_req_init - initialize certain fields of a scsi_request structure*@req: Pointer to a scsi_request structure.* Initializes .__cmd[], .cmd, .cmd_len and .sense_len but no other members* of struct scsi_request. |
bsg_register_queue | |
bsg_initialize_rq | alled right before the request is given to the request_queue user |
blkcg_reset_stats | |
calculate_percentile | Calculate the histogram bucket with the given percentile rank, or -1 if there* aren't enough samples yet. |
compat_hdio_getgeo | |
bio_integrity_alloc | _integrity_alloc - Allocate integrity payload and attach it to bio*@bio: bio to attach integrity metadata to*@gfp_mask: Memory allocation mask*@nr_vecs: Number of integrity metadata scatter-gather elements* Description: This function prepares a bio for |
blk_integrity_unregister | lk_integrity_unregister - Unregister block integrity profile*@disk: disk whose integrity profile to unregister* Description: This function unregisters the integrity capability from* a block device. |
opal_recv_check | |
opal_discovery0 | |
clear_opal_cmd | |
key_instantiate_and_link | key_instantiate_and_link - Instantiate a key and link it into the keyring.*@key: The key to instantiate.*@data: The data to use to instantiate the keyring.*@datalen: The length of @data.*@keyring: Keyring to create a link in on success (or NULL). |
key_create_or_update | key_create_or_update - Update or create and instantiate a key.*@keyring_ref: A pointer to the destination keyring with possession flag.*@type: The type of key.*@description: The searchable description for the key. |
key_update | key_update - Update a key's contents.*@key_ref: The pointer (plus possession flag) to the key.*@payload: The data to be used to update the key.*@plen: The length of @payload.* Attempt to update the contents of a key with the given payload data. The |
register_key_type | gister_key_type - Register a type of key.*@ktype: The new key type.* Register a new key type.* Returns 0 on success or -EEXIST if a type of this name already exists. |
key_get_persistent | Get the persistent keyring for a specific UID and link it to the nominated* keyring. |
kdf_ctr | Implementation of the KDF in counter mode according to SP800-108 section 5 |
__keyctl_dh_compute | |
keyctl_pkey_params_get | Interpret parameters. Callers must always call the free function* on params, even if an error is returned. |
keyctl_pkey_params_get_2 | Get parameters from userspace. Callers must always call the free function* on params, even if an error is returned. |
keyctl_pkey_query | Query information about an asymmetric key. |
big_key_crypt | Encrypt/decrypt big_key data |
big_key_free_buffer | Free up the buffer. |
get_vfs_caps_from_disk | Extract the on-exec-apply capability sets for an executable file. |
security_inode_init_security | |
selinux_init | |
selnl_add_payload | |
smk_set_cipso | smk_set_cipso - do the work for write() for cipso and cipso2*@file: file pointer, not actually used*@buf: where to get the data from*@count: bytes sent*@ppos: where to start*@format: /smack/cipso or /smack/cipso2 |
dump_common_audit_data | dump_common_audit_data - helper to dump common audit data*@a : common audit data |
tomoyo_assign_profile | moyo_assign_profile - Create a new profile.*@ns: Pointer to "struct tomoyo_policy_namespace".*@profile: Profile number to create.* Returns pointer to "struct tomoyo_profile" on success, NULL otherwise. |
tomoyo_select_domain | moyo_select_domain - Parse select command.*@head: Pointer to "struct tomoyo_io_buffer".*@data: String to parse.* Returns true on success, false otherwise.* Caller holds tomoyo_read_lock(). |
tomoyo_set_namespace_cursor | moyo_set_namespace_cursor - Set namespace to read.*@head: Pointer to "struct tomoyo_io_buffer".* Returns nothing. |
tomoyo_write_control | moyo_write_control - write() for /sys/kernel/security/tomoyo/ interface.*@head: Pointer to "struct tomoyo_io_buffer".*@buffer: Pointer to buffer to read from.*@buffer_len: Size of @buffer.* Returns @buffer_len on success, negative value otherwise. |
tomoyo_scan_bprm | moyo_scan_bprm - Scan "struct linux_binprm".*@ee: Pointer to "struct tomoyo_execve".*@argc: Length of @argc.*@argv: Pointer to "struct tomoyo_argv".*@envc: Length of @envp.*@envp: Poiner to "struct tomoyo_envp".* Returns true on success, false otherwise. |
tomoyo_commit_ok | moyo_commit_ok - Check memory quota.*@data: Data to copy from.*@size: Size in byte.* Returns pointer to allocated memory on success, NULL otherwise.*@data is zero-cleared on success.* Caller holds tomoyo_policy_lock mutex. |
tomoyo_parse_number_union | moyo_parse_number_union - Parse a tomoyo_number_union.*@param: Pointer to "struct tomoyo_acl_param".*@ptr: Pointer to "struct tomoyo_number_union".* Returns true on success, false otherwise. |
tomoyo_init_request_info | moyo_init_request_info - Initialize "struct tomoyo_request_info" members.*@r: Pointer to "struct tomoyo_request_info" to initialize.*@domain: Pointer to "struct tomoyo_domain_info". NULL for tomoyo_domain().*@index: Index number of functionality. |
query_data | query_data - queries a policy and writes its data to buf*@buf: the resulting data is stored here (NOT NULL)*@buf_len: size of buf*@query: query string used to retrieve data*@query_len: size of query including second NUL byte |
deflate_decompress | |
deflate_compress | |
free_proxy | |
set_access | |
devcgroup_update_access | Modify the exception list using allow/deny rules |
init_once | |
asymmetric_verify | |
ima_add_template_entry | Add template entry to the measurement list and hash table, and* extend the pcr.* On systems which support carrying the IMA measurement list across* kexec, maintain the total memory size required for serializing the* binary_runtime_measurements. |
ima_add_boot_aggregate | Add the boot aggregate to the IMA measurement list and extend* the PCR register.* Calculate the boot aggregate, a SHA1 over tpm registers 0-7,* assuming a TPM chip exists, and zeroes if the TPM chip does not* exist |
ima_collect_measurement | ma_collect_measurement - collect file measurement* Calculate the file hash, if it doesn't already exist,* storing the measurement and i_version in the iint.* Must be called with iint->mutex held.* Return 0 on success, error code otherwise |
ima_lsm_copy_rule | |
ima_init_arch_policy | |
ima_eventdigest_init | This function writes the digest of an event (with size limit). |
hmac_add_misc | Protect against 'cutting & pasting' security.evm xattr, include inode* specific info.* (Additional directory/file metadata needs to be added for more complete* protection.) |
evm_init_key | Get the key from the TPM for the SHA1-HMAC |
vfs_getattr_nosec | vfs_getattr_nosec - getattr without security checks*@path: file to get attributes from*@stat: structure to return attributes in*@request_mask: STATX_xxx flags indicating what the caller wants*@query_flags: Query mode (KSTAT_QUERY_FLAGS) |
cp_old_stat | For backward compatibility? Maybe this should be moved* into arch/i386 instead? |
cp_statx | |
cp_compat_stat | |
prepare_binprm | Fill the binprm structure from the inode.* Check permissions, then read the first BINPRM_BUF_SIZE bytes* This may be called multiple times for binary chains (scripts for example). |
put_compat_flock | |
put_compat_flock64 | |
fiemap_fill_next_extent | |
__generic_block_fiemap | __generic_block_fiemap - FIEMAP for block based inodes (no locking)*@inode: the inode to map*@fieinfo: the fiemap info struct that will be passed back to userspace*@start: where to start mapping in the inode*@len: how much space to map*@get_block: the |
poll_select_finish | |
get_fd_set | Use "unsigned long" accesses to let user-mode fd_set's be long-aligned. |
zero_fd_set | |
address_space_init_once | |
inode_init_once | These are initializations that only need to be done* once, because the fields are idempotent across use* of the inode, so let the slab aware of that. |
copy_fd_bitmaps | Copy 'count' fd bits from the old table to the new table and clear the extra* space if any. This does not copy the file pointers. Called with the files* spinlock held for write. |
copy_fdtable | Copy all file descriptors from the old table to the new, expanded table and* clear the extra space. Called with the files spinlock held for write. |
dup_fd | Allocate a new files structure and copy contents from the* passed in files structure.* errorp will be valid only when the returned files_struct is NULL. |
exact_copy_from_user | Some copy_from_user() implementations do not return the exact number of* bytes remaining to copy on a fault. But copy_mount_options() requires that.* Note that this function differs from copy_from_user() in that it will oops |
copy_mount_options | |
seq_pad | seq_pad - write padding spaces to buffer*@m: seq_file identifying the buffer to which data should be written*@c: the byte to append after padding if non-zero |
vfs_getxattr_alloc | vfs_getxattr_alloc - allocate memory, if necessary, before calling getxattr* Allocate memory, if not already allocated, or re-allocate correct size,* before retrieving the extended attribute. |
statfs_by_dentry | |
do_statfs_native | |
do_statfs64 | |
SYSCALL_DEFINE2 | |
put_compat_statfs | |
put_compat_statfs64 | |
COMPAT_SYSCALL_DEFINE2 | This is a copy of sys_ustat, just dealing with a structure layout.* Given how simple this syscall is that apporach is more maintainable* than the various conversion hacks. |
init_once | |
do_blockdev_direct_IO | This is a library function for use by filesystem drivers |
fsnotify_init_mark | Nothing fancy, just initialize lists and locks and counters. |
signalfd_copyinfo | Copied from copy_siginfo_to_user() in kernel/signal.c |
msg_init | |
userfaultfd_api | serland asks for a certain API version and we return which bits* and ioctl commands are implemented in this kernel for such API* version or -EINVAL if unknown. |
io_uring_create | |
__dax_zero_page_range | |
fscrypt_generate_iv | |
fname_encrypt | ame_encrypt() - encrypt a filename* The output buffer must be at least as large as the input buffer.* Any extra space is filled with NUL padding before encryption.* Return: 0 on success, -errno on failure |
fscrypt_setup_filename | scrypt_setup_filename() - prepare to search a possibly encrypted directory*@dir: the directory that will be searched*@iname: the user-provided filename being searched for*@lookup: 1 if we're allowed to proceed without the key because it's* ->lookup() or |
fscrypt_ioctl_add_key | Add a master encryption key to the filesystem, causing all files which were* encrypted with it to appear "unlocked" (decrypted) when accessed.* When adding a key for use by v1 encryption policies, this ioctl is |
fscrypt_ioctl_get_key_status | Retrieve the status of an fscrypt master encryption key |
fscrypt_get_encryption_info | |
fscrypt_new_context_from_policy | |
fscrypt_policy_from_context | |
build_merkle_tree_level | |
build_merkle_tree | Build the Merkle tree for the given inode using the given parameters, and* return the root hash in @root_hash.* The tree is written to a filesystem-specific location as determined by the* ->write_merkle_tree_block() method |
fsverity_ioctl_measure | sverity_ioctl_measure() - get a verity file's measurement* Retrieve the file measurement that the kernel is enforcing for reads from a* verity file |
fsverity_init_merkle_tree_params | sverity_init_merkle_tree_params() - initialize Merkle tree parameters*@params: the parameters struct to initialize*@inode: the inode for which the Merkle tree is being built*@hash_algorithm: number of hash algorithm to use*@log_blocksize: log base 2 of |
locks_init_lock | |
load_misc_binary | he loader itself |
create_entry | This registers a new binary format, it recognises the syntax* ':name:type:offset:magic:mask:interpreter:flags'* where the ':' is the IFS, that can be chosen with the first char |
create_elf_tables | |
load_elf_fdpic_binary | load an fdpic binary into various bits of memory |
load_flat_binary | These are the functions used to load flat style executables and shared* libraries. There is no binary dependent code anywhere else. |
iomap_read_inline_data | |
iomap_dio_inline_actor | |
iomap_fiemap | |
do_get_dqblk | Generic routine for getting common part of quota structure |
dquot_get_state | Generic routine for getting common part of quota file information |
v1_read_dqblk | |
v2r0_disk2memdqb | |
v2r1_disk2memdqb | |
read_blk | |
get_free_dqblk | Remove empty block from list and return it |
find_free_dqentry | Find space for dquot |
do_insert_tree | Insert reference to structure into the trie |
free_dqentry | Free dquot entry in data block |
qtree_read_dquot | |
quota_getinfo | |
quota_setinfo | |
copy_to_if_dqblk | |
quota_getstate | |
quota_getstatev | |
quota_getxstatev | |
copy_qcinfo_from_xfs_dqblk | |
copy_to_xfs_dqblk | |
ramfs_nommu_expand_for_mapping | add a contiguous set of pages into a ramfs inode when it's truncated from* size 0 on the assumption that it's going to be used for an mmap of shared* memory |
Source code conversion tool public plug-in interface | X |
---|---|
Support c/c++/esqlc/java Oracle/Informix/Mysql Plug-in can realize: logical Report Code generation and batch code conversion |