cregit-Linux how code gets into the kernel

Release 4.7 virt/kvm/kvm_main.c

Directory: virt/kvm
/*
 * Kernel-based Virtual Machine driver for Linux
 *
 * This module enables machines with Intel VT-x extensions to run virtual
 * machines without emulation or binary translation.
 *
 * Copyright (C) 2006 Qumranet, Inc.
 * Copyright 2010 Red Hat, Inc. and/or its affiliates.
 *
 * Authors:
 *   Avi Kivity   <avi@qumranet.com>
 *   Yaniv Kamay  <yaniv@qumranet.com>
 *
 * This work is licensed under the terms of the GNU GPL, version 2.  See
 * the COPYING file in the top-level directory.
 *
 */

#include <kvm/iodev.h>

#include <linux/kvm_host.h>
#include <linux/kvm.h>
#include <linux/module.h>
#include <linux/errno.h>
#include <linux/percpu.h>
#include <linux/mm.h>
#include <linux/miscdevice.h>
#include <linux/vmalloc.h>
#include <linux/reboot.h>
#include <linux/debugfs.h>
#include <linux/highmem.h>
#include <linux/file.h>
#include <linux/syscore_ops.h>
#include <linux/cpu.h>
#include <linux/sched.h>
#include <linux/cpumask.h>
#include <linux/smp.h>
#include <linux/anon_inodes.h>
#include <linux/profile.h>
#include <linux/kvm_para.h>
#include <linux/pagemap.h>
#include <linux/mman.h>
#include <linux/swap.h>
#include <linux/bitops.h>
#include <linux/spinlock.h>
#include <linux/compat.h>
#include <linux/srcu.h>
#include <linux/hugetlb.h>
#include <linux/slab.h>
#include <linux/sort.h>
#include <linux/bsearch.h>

#include <asm/processor.h>
#include <asm/io.h>
#include <asm/ioctl.h>
#include <asm/uaccess.h>
#include <asm/pgtable.h>

#include "coalesced_mmio.h"
#include "async_pf.h"
#include "vfio.h"


#define CREATE_TRACE_POINTS
#include <trace/events/kvm.h>

/* Worst case buffer size needed for holding an integer. */

#define ITOA_MAX_LEN 12

MODULE_AUTHOR("Qumranet");
MODULE_LICENSE("GPL");

/* Architectures should define their poll value according to the halt latency */

static unsigned int halt_poll_ns = KVM_HALT_POLL_NS_DEFAULT;
module_param(halt_poll_ns, uint, S_IRUGO | S_IWUSR);

/* Default doubles per-vcpu halt_poll_ns. */

static unsigned int halt_poll_ns_grow = 2;
module_param(halt_poll_ns_grow, uint, S_IRUGO | S_IWUSR);

/* Default resets per-vcpu halt_poll_ns . */

static unsigned int halt_poll_ns_shrink;
module_param(halt_poll_ns_shrink, uint, S_IRUGO | S_IWUSR);

/*
 * Ordering of locks:
 *
 *      kvm->lock --> kvm->slots_lock --> kvm->irq_lock
 */


DEFINE_SPINLOCK(kvm_lock);
static DEFINE_RAW_SPINLOCK(kvm_count_lock);

LIST_HEAD(vm_list);


static cpumask_var_t cpus_hardware_enabled;

static int kvm_usage_count;

static atomic_t hardware_enable_failed;


struct kmem_cache *kvm_vcpu_cache;

EXPORT_SYMBOL_GPL(kvm_vcpu_cache);


static __read_mostly struct preempt_ops kvm_preempt_ops;


struct dentry *kvm_debugfs_dir;

EXPORT_SYMBOL_GPL(kvm_debugfs_dir);


static int kvm_debugfs_num_entries;

static const struct file_operations *stat_fops_per_vm[];

static long kvm_vcpu_ioctl(struct file *file, unsigned int ioctl,
			   unsigned long arg);
#ifdef CONFIG_KVM_COMPAT
static long kvm_vcpu_compat_ioctl(struct file *file, unsigned int ioctl,
				  unsigned long arg);
#endif
static int hardware_enable_all(void);
static void hardware_disable_all(void);

static void kvm_io_bus_destroy(struct kvm_io_bus *bus);

static void kvm_release_pfn_dirty(kvm_pfn_t pfn);
static void mark_page_dirty_in_slot(struct kvm_memory_slot *memslot, gfn_t gfn);


__visible bool kvm_rebooting;

EXPORT_SYMBOL_GPL(kvm_rebooting);


static bool largepages_enabled = true;


bool kvm_is_reserved_pfn(kvm_pfn_t pfn) { if (pfn_valid(pfn)) return PageReserved(pfn_to_page(pfn)); return true; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity933.33%112.50%
xiantao zhangxiantao zhang829.63%112.50%
andrea arcangeliandrea arcangeli725.93%337.50%
xiao guangrongxiao guangrong13.70%112.50%
ard biesheuvelard biesheuvel13.70%112.50%
dan williamsdan williams13.70%112.50%
Total27100.00%8100.00%

/* * Switches to specified vcpu, until a matching vcpu_put() */
int vcpu_load(struct kvm_vcpu *vcpu) { int cpu; if (mutex_lock_killable(&vcpu->mutex)) return -EINTR; cpu = get_cpu(); preempt_notifier_register(&vcpu->preempt_notifier); kvm_arch_vcpu_load(vcpu, cpu); put_cpu(); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity2547.17%133.33%
sheng yangsheng yang1630.19%133.33%
michael s. tsirkinmichael s. tsirkin1222.64%133.33%
Total53100.00%3100.00%


void vcpu_put(struct kvm_vcpu *vcpu) { preempt_disable(); kvm_arch_vcpu_put(vcpu); preempt_notifier_unregister(&vcpu->preempt_notifier); preempt_enable(); mutex_unlock(&vcpu->mutex); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity1848.65%125.00%
xiantao zhangxiantao zhang1129.73%125.00%
marcelo tosattimarcelo tosatti513.51%125.00%
sheng yangsheng yang38.11%125.00%
Total37100.00%4100.00%


static void ack_flush(void *_completed) { }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity888.89%150.00%
sheng yangsheng yang111.11%150.00%
Total9100.00%2100.00%


bool kvm_make_all_cpus_request(struct kvm *kvm, unsigned int req) { int i, cpu, me; cpumask_var_t cpus; bool called = true; struct kvm_vcpu *vcpu; zalloc_cpumask_var(&cpus, GFP_ATOMIC); me = get_cpu(); kvm_for_each_vcpu(i, vcpu, kvm) { kvm_make_request(req, vcpu); cpu = vcpu->cpu; /* Set ->requests bit before we read ->mode. */ smp_mb__after_atomic(); if (cpus != NULL && cpu != -1 && cpu != me && kvm_vcpu_exiting_guest_mode(vcpu) != OUTSIDE_GUEST_MODE) cpumask_set_cpu(cpu, cpus); } if (unlikely(cpus == NULL)) smp_call_function_many(cpu_online_mask, ack_flush, NULL, 1); else if (!cpumask_empty(cpus)) smp_call_function_many(cpus, ack_flush, NULL, 1); else called = false; put_cpu(); free_cpumask_var(cpus); return called; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity8654.09%19.09%
sheng yangsheng yang3220.13%327.27%
xiantao zhangxiantao zhang1610.06%19.09%
xiao guangrongxiao guangrong148.81%218.18%
marcelo tosattimarcelo tosatti63.77%19.09%
mark mcloughlinmark mcloughlin21.26%19.09%
lan tianyulan tianyu21.26%19.09%
tang chentang chen10.63%19.09%
Total159100.00%11100.00%

#ifndef CONFIG_HAVE_KVM_ARCH_TLB_FLUSH_ALL
void kvm_flush_remote_tlbs(struct kvm *kvm) { /* * Read tlbs_dirty before setting KVM_REQ_TLB_FLUSH in * kvm_make_all_cpus_request. */ long dirty_count = smp_load_acquire(&kvm->tlbs_dirty); /* * We want to publish modifications to the page tables before reading * mode. Pairs with a memory barrier in arch-specific code. * - x86: smp_mb__after_srcu_read_unlock in vcpu_enter_guest * and smp_mb in walk_shadow_page_lockless_begin/end. * - powerpc: smp_mb in kvmppc_prepare_to_enter. * * There is already an smp_mb__after_atomic() before * kvm_make_all_cpus_request() reads vcpu->mode. We reuse that * barrier here. */ if (kvm_make_all_cpus_request(kvm, KVM_REQ_TLB_FLUSH)) ++kvm->stat.remote_tlb_flush; cmpxchg(&kvm->tlbs_dirty, dirty_count, 0); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong1937.25%222.22%
xiantao zhangxiantao zhang1223.53%111.11%
avi kivityavi kivity815.69%111.11%
lan tianyulan tianyu611.76%111.11%
marcelo tosattimarcelo tosatti35.88%111.11%
mark mcloughlinmark mcloughlin11.96%111.11%
sheng yangsheng yang11.96%111.11%
tang chentang chen11.96%111.11%
Total51100.00%9100.00%

EXPORT_SYMBOL_GPL(kvm_flush_remote_tlbs); #endif
void kvm_reload_remote_mmus(struct kvm *kvm) { kvm_make_all_cpus_request(kvm, KVM_REQ_MMU_RELOAD); }

Contributors

PersonTokensPropCommitsCommitProp
xiantao zhangxiantao zhang847.06%120.00%
sheng yangsheng yang635.29%240.00%
avi kivityavi kivity211.76%120.00%
tang chentang chen15.88%120.00%
Total17100.00%5100.00%


int kvm_vcpu_init(struct kvm_vcpu *vcpu, struct kvm *kvm, unsigned id) { struct page *page; int r; mutex_init(&vcpu->mutex); vcpu->cpu = -1; vcpu->kvm = kvm; vcpu->vcpu_id = id; vcpu->pid = NULL; init_swait_queue_head(&vcpu->wq); kvm_async_pf_vcpu_init(vcpu); vcpu->pre_pcpu = -1; INIT_LIST_HEAD(&vcpu->blocked_vcpu_list); page = alloc_page(GFP_KERNEL | __GFP_ZERO); if (!page) { r = -ENOMEM; goto fail; } vcpu->run = page_address(page); kvm_vcpu_set_in_spin_loop(vcpu, false); kvm_vcpu_set_dy_eligible(vcpu, false); vcpu->preempted = false; r = kvm_arch_vcpu_init(vcpu); if (r < 0) goto fail_free_run; return 0; fail_free_run: free_page((unsigned long)vcpu->run); fail: return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity7542.37%17.14%
sheng yangsheng yang3519.77%321.43%
raghavendra k t* (same as raghavendra koushik)raghavendra k t* (same as raghavendra koushik)2011.30%214.29%
feng wufeng wu158.47%17.14%
mark mcloughlinmark mcloughlin105.65%214.29%
xiantao zhangxiantao zhang63.39%17.14%
rik van rielrik van riel63.39%17.14%
gleb natapovgleb natapov52.82%17.14%
marcelo tosattimarcelo tosatti52.82%214.29%
Total177100.00%14100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_init);
void kvm_vcpu_uninit(struct kvm_vcpu *vcpu) { put_pid(vcpu->pid); kvm_arch_vcpu_uninit(vcpu); free_page((unsigned long)vcpu->run); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity1339.39%125.00%
sheng yangsheng yang1236.36%125.00%
rik van rielrik van riel721.21%125.00%
xiantao zhangxiantao zhang13.03%125.00%
Total33100.00%4100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_uninit); #if defined(CONFIG_MMU_NOTIFIER) && defined(KVM_ARCH_WANT_MMU_NOTIFIER)
static inline struct kvm *mmu_notifier_to_kvm(struct mmu_notifier *mn) { return container_of(mn, struct kvm, mmu_notifier); }

Contributors

PersonTokensPropCommitsCommitProp
sheng yangsheng yang1352.00%250.00%
avi kivityavi kivity1144.00%125.00%
mark mcloughlinmark mcloughlin14.00%125.00%
Total25100.00%4100.00%


static void kvm_mmu_notifier_invalidate_page(struct mmu_notifier *mn, struct mm_struct *mm, unsigned long address) { struct kvm *kvm = mmu_notifier_to_kvm(mn); int need_tlb_flush, idx; /* * When ->invalidate_page runs, the linux pte has been zapped * already but the page is still allocated until * ->invalidate_page returns. So if we increase the sequence * here the kvm page fault will notice if the spte can't be * established because the page is going to be freed. If * instead the kvm page fault establishes the spte before * ->invalidate_page runs, kvm_unmap_hva will release it * before returning. * * The sequence increase only need to be seen at spin_unlock * time, and not at spin_lock time. * * Increasing the sequence after the spin_unlock would be * unsafe because the kvm page fault could then establish the * pte after kvm_unmap_hva returned, without noticing the page * is going to be freed. */ idx = srcu_read_lock(&kvm->srcu); spin_lock(&kvm->mmu_lock); kvm->mmu_notifier_seq++; need_tlb_flush = kvm_unmap_hva(kvm, address) | kvm->tlbs_dirty; /* we've to flush the tlb before the pages can be freed */ if (need_tlb_flush) kvm_flush_remote_tlbs(kvm); spin_unlock(&kvm->mmu_lock); kvm_arch_mmu_notifier_invalidate_page(kvm, address); srcu_read_unlock(&kvm->srcu, idx); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3229.91%111.11%
marcelo tosattimarcelo tosatti2220.56%111.11%
xiantao zhangxiantao zhang1514.02%111.11%
mark mcloughlinmark mcloughlin1110.28%111.11%
takuya yoshikawatakuya yoshikawa109.35%111.11%
tang chentang chen76.54%111.11%
sheng yangsheng yang65.61%222.22%
xiao guangrongxiao guangrong43.74%111.11%
Total107100.00%9100.00%


static void kvm_mmu_notifier_change_pte(struct mmu_notifier *mn, struct mm_struct *mm, unsigned long address, pte_t pte) { struct kvm *kvm = mmu_notifier_to_kvm(mn); int idx; idx = srcu_read_lock(&kvm->srcu); spin_lock(&kvm->mmu_lock); kvm->mmu_notifier_seq++; kvm_set_spte_hva(kvm, address, pte); spin_unlock(&kvm->mmu_lock); srcu_read_unlock(&kvm->srcu, idx); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3034.88%125.00%
marcelo tosattimarcelo tosatti2326.74%125.00%
xiantao zhangxiantao zhang2124.42%125.00%
sheng yangsheng yang1213.95%125.00%
Total86100.00%4100.00%


static void kvm_mmu_notifier_invalidate_range_start(struct mmu_notifier *mn, struct mm_struct *mm, unsigned long start, unsigned long end) { struct kvm *kvm = mmu_notifier_to_kvm(mn); int need_tlb_flush = 0, idx; idx = srcu_read_lock(&kvm->srcu); spin_lock(&kvm->mmu_lock); /* * The count increase must become visible at unlock time as no * spte can be established without taking the mmu_lock and * count is also read inside the mmu_lock critical section. */ kvm->mmu_notifier_count++; need_tlb_flush = kvm_unmap_hva_range(kvm, start, end); need_tlb_flush |= kvm->tlbs_dirty; /* we've to flush the tlb before the pages can be freed */ if (need_tlb_flush) kvm_flush_remote_tlbs(kvm); spin_unlock(&kvm->mmu_lock); srcu_read_unlock(&kvm->srcu, idx); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3733.64%110.00%
marcelo tosattimarcelo tosatti2220.00%110.00%
sheng yangsheng yang1715.45%330.00%
takuya yoshikawatakuya yoshikawa1412.73%220.00%
xiantao zhangxiantao zhang109.09%110.00%
xiao guangrongxiao guangrong65.45%110.00%
mark mcloughlinmark mcloughlin43.64%110.00%
Total110100.00%10100.00%


static void kvm_mmu_notifier_invalidate_range_end(struct mmu_notifier *mn, struct mm_struct *mm, unsigned long start, unsigned long end) { struct kvm *kvm = mmu_notifier_to_kvm(mn); spin_lock(&kvm->mmu_lock); /* * This sequence increase will notify the kvm page fault that * the page that is going to be mapped in the spte could have * been freed. */ kvm->mmu_notifier_seq++; smp_wmb(); /* * The above sequence increase must be visible before the * below count decrease, which is ensured by the smp_wmb above * in conjunction with the smp_rmb in mmu_notifier_retry(). */ kvm->mmu_notifier_count--; spin_unlock(&kvm->mmu_lock); BUG_ON(kvm->mmu_notifier_count < 0); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3750.00%116.67%
sheng yangsheng yang2837.84%350.00%
xiantao zhangxiantao zhang56.76%116.67%
paul mackerraspaul mackerras45.41%116.67%
Total74100.00%6100.00%


static int kvm_mmu_notifier_clear_flush_young(struct mmu_notifier *mn, struct mm_struct *mm, unsigned long start, unsigned long end) { struct kvm *kvm = mmu_notifier_to_kvm(mn); int young, idx; idx = srcu_read_lock(&kvm->srcu); spin_lock(&kvm->mmu_lock); young = kvm_age_hva(kvm, start, end); if (young) kvm_flush_remote_tlbs(kvm); spin_unlock(&kvm->mmu_lock); srcu_read_unlock(&kvm->srcu, idx); return young; }

Contributors

PersonTokensPropCommitsCommitProp
sheng yangsheng yang3030.61%342.86%
avi kivityavi kivity2929.59%114.29%
marcelo tosattimarcelo tosatti2222.45%114.29%
takuya yoshikawatakuya yoshikawa99.18%114.29%
andres lagar-cavillaandres lagar-cavilla88.16%114.29%
Total98100.00%7100.00%


static int kvm_mmu_notifier_clear_young(struct mmu_notifier *mn, struct mm_struct *mm, unsigned long start, unsigned long end) { struct kvm *kvm = mmu_notifier_to_kvm(mn); int young, idx; idx = srcu_read_lock(&kvm->srcu); spin_lock(&kvm->mmu_lock); /* * Even though we do not flush TLB, this will still adversely * affect performance on pre-Haswell Intel EPT, where there is * no EPT Access Bit to clear so that we have to tear down EPT * tables instead. If we find this unacceptable, we can always * add a parameter to kvm_age_hva so that it effectively doesn't * do anything on clear_young. * * Also note that currently we never issue secondary TLB flushes * from clear_young, leaving this job up to the regular system * cadence. If we find this inaccurate, we might come up with a * more sophisticated heuristic later. */ young = kvm_age_hva(kvm, start, end); spin_unlock(&kvm->mmu_lock); srcu_read_unlock(&kvm->srcu, idx); return young; }

Contributors

PersonTokensPropCommitsCommitProp
vladimir davydovvladimir davydov90100.00%1100.00%
Total90100.00%1100.00%


static int kvm_mmu_notifier_test_young(struct mmu_notifier *mn, struct mm_struct *mm, unsigned long address) { struct kvm *kvm = mmu_notifier_to_kvm(mn); int young, idx; idx = srcu_read_lock(&kvm->srcu); spin_lock(&kvm->mmu_lock); young = kvm_test_age_hva(kvm, address); spin_unlock(&kvm->mmu_lock); srcu_read_unlock(&kvm->srcu, idx); return young; }

Contributors

PersonTokensPropCommitsCommitProp
andrea arcangeliandrea arcangeli83100.00%1100.00%
Total83100.00%1100.00%


static void kvm_mmu_notifier_release(struct mmu_notifier *mn, struct mm_struct *mm) { struct kvm *kvm = mmu_notifier_to_kvm(mn); int idx; idx = srcu_read_lock(&kvm->srcu); kvm_arch_flush_shadow_all(kvm); srcu_read_unlock(&kvm->srcu, idx); }

Contributors

PersonTokensPropCommitsCommitProp
lai jiangshanlai jiangshan2342.59%114.29%
sheng yangsheng yang1324.07%342.86%
avi kivityavi kivity1120.37%114.29%
xiantao zhangxiantao zhang611.11%114.29%
marcelo tosattimarcelo tosatti11.85%114.29%
Total54100.00%7100.00%

static const struct mmu_notifier_ops kvm_mmu_notifier_ops = { .invalidate_page = kvm_mmu_notifier_invalidate_page, .invalidate_range_start = kvm_mmu_notifier_invalidate_range_start, .invalidate_range_end = kvm_mmu_notifier_invalidate_range_end, .clear_flush_young = kvm_mmu_notifier_clear_flush_young, .clear_young = kvm_mmu_notifier_clear_young, .test_young = kvm_mmu_notifier_test_young, .change_pte = kvm_mmu_notifier_change_pte, .release = kvm_mmu_notifier_release, };
static int kvm_init_mmu_notifier(struct kvm *kvm) { kvm->mmu_notifier.ops = &kvm_mmu_notifier_ops; return mmu_notifier_register(&kvm->mmu_notifier, current->mm); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity33100.00%1100.00%
Total33100.00%1100.00%

#else /* !(CONFIG_MMU_NOTIFIER && KVM_ARCH_WANT_MMU_NOTIFIER) */
static int kvm_init_mmu_notifier(struct kvm *kvm) { return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity14100.00%1100.00%
Total14100.00%1100.00%

#endif /* CONFIG_MMU_NOTIFIER && KVM_ARCH_WANT_MMU_NOTIFIER */
static struct kvm_memslots *kvm_alloc_memslots(void) { int i; struct kvm_memslots *slots; slots = kvm_kvzalloc(sizeof(struct kvm_memslots)); if (!slots) return NULL; /* * Init kvm generation close to the maximum to easily test the * code of handling generation number wrap-around. */ slots->generation = -150; for (i = 0; i < KVM_MEM_SLOTS_NUM; i++) slots->id_to_index[i] = slots->memslots[i].id = i; return slots; }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong4455.70%266.67%
paolo bonzinipaolo bonzini3544.30%133.33%
Total79100.00%3100.00%


static void kvm_destroy_dirty_bitmap(struct kvm_memory_slot *memslot) { if (!memslot->dirty_bitmap) return; kvfree(memslot->dirty_bitmap); memslot->dirty_bitmap = NULL; }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini32100.00%1100.00%
Total32100.00%1100.00%

/* * Free any memory in @free but not in @dont. */
static void kvm_free_memslot(struct kvm *kvm, struct kvm_memory_slot *free, struct kvm_memory_slot *dont) { if (!dont || free->dirty_bitmap != dont->dirty_bitmap) kvm_destroy_dirty_bitmap(free); kvm_arch_free_memslot(kvm, free, dont); free->npages = 0; }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini54100.00%1100.00%
Total54100.00%1100.00%


static void kvm_free_memslots(struct kvm *kvm, struct kvm_memslots *slots) { struct kvm_memory_slot *memslot; if (!slots) return; kvm_for_each_memslot(memslot, slots) kvm_free_memslot(kvm, memslot, NULL); kvfree(slots); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini4697.87%150.00%
xiao guangrongxiao guangrong12.13%150.00%
Total47100.00%2100.00%


static void kvm_destroy_vm_debugfs(struct kvm *kvm) { int i; if (!kvm->debugfs_dentry) return; debugfs_remove_recursive(kvm->debugfs_dentry); for (i = 0; i < kvm_debugfs_num_entries; i++) kfree(kvm->debugfs_stat_data[i]); kfree(kvm->debugfs_stat_data); }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank59100.00%1100.00%
Total59100.00%1100.00%


static int kvm_create_vm_debugfs(struct kvm *kvm, int fd) { char dir_name[ITOA_MAX_LEN * 2]; struct kvm_stat_data *stat_data; struct kvm_stats_debugfs_item *p; if (!debugfs_initialized()) return 0; snprintf(dir_name, sizeof(dir_name), "%d-%d", task_pid_nr(current), fd); kvm->debugfs_dentry = debugfs_create_dir(dir_name, kvm_debugfs_dir); if (!kvm->debugfs_dentry) return -ENOMEM; kvm->debugfs_stat_data = kcalloc(kvm_debugfs_num_entries, sizeof(*kvm->debugfs_stat_data), GFP_KERNEL); if (!kvm->debugfs_stat_data) return -ENOMEM; for (p = debugfs_entries; p->name; p++) { stat_data = kzalloc(sizeof(*stat_data), GFP_KERNEL); if (!stat_data) return -ENOMEM; stat_data->kvm = kvm; stat_data->offset = p->offset; kvm->debugfs_stat_data[p - debugfs_entries] = stat_data; if (!debugfs_create_file(p->name, 0444, kvm->debugfs_dentry, stat_data, stat_fops_per_vm[p->kind])) return -ENOMEM; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank206100.00%1100.00%
Total206100.00%1100.00%


static struct kvm *kvm_create_vm(unsigned long type) { int r, i; struct kvm *kvm = kvm_arch_alloc_vm(); if (!kvm) return ERR_PTR(-ENOMEM); spin_lock_init(&kvm->mmu_lock); atomic_inc(&current->mm->mm_count); kvm->mm = current->mm; kvm_eventfd_init(kvm); mutex_init(&kvm->lock); mutex_init(&kvm->irq_lock); mutex_init(&kvm->slots_lock); atomic_set(&kvm->users_count, 1); INIT_LIST_HEAD(&kvm->devices); r = kvm_arch_init_vm(kvm, type); if (r) goto out_err_no_disable; r = hardware_enable_all(); if (r) goto out_err_no_disable; #ifdef CONFIG_HAVE_KVM_IRQFD INIT_HLIST_HEAD(&kvm->irq_ack_notifier_list); #endif BUILD_BUG_ON(KVM_MEM_SLOTS_NUM > SHRT_MAX); r = -ENOMEM; for (i = 0; i < KVM_ADDRESS_SPACE_NUM; i++) { kvm->memslots[i] = kvm_alloc_memslots(); if (!kvm->memslots[i]) goto out_err_no_srcu; } if (init_srcu_struct(&kvm->srcu)) goto out_err_no_srcu; if (init_srcu_struct(&kvm->irq_srcu)) goto out_err_no_irq_srcu; for (i = 0; i < KVM_NR_BUSES; i++) { kvm->buses[i] = kzalloc(sizeof(struct kvm_io_bus), GFP_KERNEL); if (!kvm->buses[i]) goto out_err; } r = kvm_init_mmu_notifier(kvm); if (r) goto out_err; spin_lock(&kvm_lock); list_add(&kvm->vm_list, &vm_list); spin_unlock(&kvm_lock); preempt_notifier_inc(); return kvm; out_err: cleanup_srcu_struct(&kvm->irq_srcu); out_err_no_irq_srcu: cleanup_srcu_struct(&kvm->srcu); out_err_no_srcu: hardware_disable_all(); out_err_no_disable: for (i = 0; i < KVM_NR_BUSES; i++) kfree(kvm->buses[i]); for (i = 0; i < KVM_ADDRESS_SPACE_NUM; i++) kvm_free_memslots(kvm, kvm->memslots[i]); kvm_arch_free_vm(kvm); mmdrop(current->mm); return ERR_PTR(r); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini12530.56%523.81%
marcelo tosattimarcelo tosatti10826.41%314.29%
sheng yangsheng yang4210.27%314.29%
christian borntraegerchristian borntraeger297.09%14.76%
jan kiszkajan kiszka286.85%29.52%
avi kivityavi kivity184.40%14.76%
alexander grafalexander graf184.40%14.76%
mike waychisonmike waychison143.42%14.76%
xiantao zhangxiantao zhang122.93%14.76%
alex williamsonalex williamson71.71%14.76%
carsten ottecarsten otte51.22%14.76%
peter zijlstrapeter zijlstra30.73%14.76%
Total409100.00%21100.00%

/* * Avoid using vmalloc for a small buffer. * Should not be used when the size is statically known. */
void *kvm_kvzalloc(unsigned long size) { if (size > PAGE_SIZE) return vzalloc(size); else return kzalloc(size, GFP_KERNEL); }

Contributors

PersonTokensPropCommitsCommitProp
takuya yoshikawatakuya yoshikawa31100.00%2100.00%
Total31100.00%2100.00%


static void kvm_destroy_devices(struct kvm *kvm) { struct kvm_device *dev, *tmp; list_for_each_entry_safe(dev, tmp, &kvm->devices, vm_node) { list_del(&dev->vm_node); dev->ops->destroy(dev); } }

Contributors

PersonTokensPropCommitsCommitProp
scott woodscott wood3879.17%150.00%
geliang tanggeliang tang1020.83%150.00%
Total48100.00%2100.00%


static void kvm_destroy_vm(struct kvm *kvm) { int i; struct mm_struct *mm = kvm->mm; kvm_destroy_vm_debugfs(kvm); kvm_arch_sync_events(kvm); spin_lock(&kvm_lock); list_del(&kvm->vm_list); spin_unlock(&kvm_lock); kvm_free_irq_routing(kvm); for (i = 0; i < KVM_NR_BUSES; i++) kvm_io_bus_destroy(kvm->buses[i]); kvm_coalesced_mmio_free(kvm); #if defined(CONFIG_MMU_NOTIFIER) && defined(KVM_ARCH_WANT_MMU_NOTIFIER) mmu_notifier_unregister(&kvm->mmu_notifier, kvm->mm); #else kvm_arch_flush_shadow_all(kvm); #endif kvm_arch_destroy_vm(kvm); kvm_destroy_devices(kvm); for (i = 0; i < KVM_ADDRESS_SPACE_NUM; i++) kvm_free_memslots(kvm, kvm->memslots[i]); cleanup_srcu_struct(&kvm->irq_srcu); cleanup_srcu_struct(&kvm->srcu); kvm_arch_free_vm(kvm); preempt_notifier_dec(); hardware_disable_all(); mmdrop(mm); }

Contributors

PersonTokensPropCommitsCommitProp
xiantao zhangxiantao zhang5127.57%15.26%
avi kivityavi kivity3720.00%315.79%
paolo bonzinipaolo bonzini3016.22%421.05%
marcelo tosattimarcelo tosatti2412.97%315.79%
jan kiszkajan kiszka179.19%15.26%
janosch frankjanosch frank73.78%15.26%
scott woodscott wood52.70%15.26%
mark mcloughlinmark mcloughlin52.70%15.26%
sheng yangsheng yang42.16%210.53%
peter zijlstrapeter zijlstra31.62%15.26%
alexander grafalexander graf21.08%15.26%
Total185100.00%19100.00%


void kvm_get_kvm(struct kvm *kvm) { atomic_inc(&kvm->users_count); }

Contributors

PersonTokensPropCommitsCommitProp
weidong hanweidong han633.33%125.00%
avi kivityavi kivity527.78%125.00%
sheng yangsheng yang527.78%125.00%
xiantao zhangxiantao zhang211.11%125.00%
Total18100.00%4100.00%

EXPORT_SYMBOL_GPL(kvm_get_kvm);
void kvm_put_kvm(struct kvm *kvm) { if (atomic_dec_and_test(&kvm->users_count)) kvm_destroy_vm(kvm); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity1352.00%240.00%
weidong hanweidong han1040.00%240.00%
xiantao zhangxiantao zhang28.00%120.00%
Total25100.00%5100.00%

EXPORT_SYMBOL_GPL(kvm_put_kvm);
static int kvm_vm_release(struct inode *inode, struct file *filp) { struct kvm *kvm = filp->private_data; kvm_irqfd_release(kvm); kvm_put_kvm(kvm); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity2155.26%233.33%
ben-ami yassourben-ami yassour513.16%116.67%
xiantao zhangxiantao zhang513.16%116.67%
mark mcloughlinmark mcloughlin410.53%116.67%
joerg roedeljoerg roedel37.89%116.67%
Total38100.00%6100.00%

/* * Allocation size is twice as large as the actual dirty bitmap size. * See x86's kvm_vm_ioctl_get_dirty_log() why this is needed. */
static int kvm_create_dirty_bitmap(struct kvm_memory_slot *memslot) { unsigned long dirty_bytes = 2 * kvm_dirty_bitmap_bytes(memslot); memslot->dirty_bitmap = kvm_kvzalloc(dirty_bytes); if (!memslot->dirty_bitmap) return -ENOMEM; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
takuya yoshikawatakuya yoshikawa45100.00%4100.00%
Total45100.00%4100.00%

/* * Insert memslot and re-sort memslots based on their GFN, * so binary search could be used to lookup GFN. * Sorting algorithm takes advantage of having initially * sorted array and known changed memslot position. */
static void update_memslots(struct kvm_memslots *slots, struct kvm_memory_slot *new) { int id = new->id; int i = slots->id_to_index[id]; struct kvm_memory_slot *mslots = slots->memslots; WARN_ON(mslots[i].id != id); if (!new->npages) { WARN_ON(!mslots[i].npages); if (mslots[i].npages) slots->used_slots--; } else { if (!mslots[i].npages) slots->used_slots++; } while (i < KVM_MEM_SLOTS_NUM - 1 && new->base_gfn <= mslots[i + 1].base_gfn) { if (!mslots[i + 1].npages) break; mslots[i] = mslots[i + 1]; slots->id_to_index[mslots[i].id] = i; i++; } /* * The ">=" is needed when creating a slot with base_gfn == 0, * so that it moves before all those with base_gfn == npages == 0. * * On the other hand, if new->npages is zero, the above loop has * already left i pointing to the beginning of the empty part of * mslots, and the ">=" would move the hole backwards in this * case---which is wrong. So skip the loop when deleting a slot. */ if (new->npages) { while (i > 0 && new->base_gfn >= mslots[i - 1].base_gfn) { mslots[i] = mslots[i - 1]; slots->id_to_index[mslots[i].id] = i; i--; } } else WARN_ON_ONCE(i != slots->used_slots); mslots[i] = *new; slots->id_to_index[mslots[i].id] = i; }

Contributors

PersonTokensPropCommitsCommitProp
igor mammedovigor mammedov14655.73%333.33%
paolo bonzinipaolo bonzini8130.92%444.44%
xiao guangrongxiao guangrong3513.36%222.22%
Total262100.00%9100.00%


static int check_memory_region_flags(const struct kvm_userspace_memory_region *mem) { u32 valid_flags = KVM_MEM_LOG_DIRTY_PAGES; #ifdef __KVM_HAVE_READONLY_MEM valid_flags |= KVM_MEM_READONLY; #endif if (mem->flags & ~valid_flags) return -EINVAL; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong4095.24%250.00%
christoffer dallchristoffer dall12.38%125.00%
paolo bonzinipaolo bonzini12.38%125.00%
Total42100.00%4100.00%


static struct kvm_memslots *install_new_memslots(struct kvm *kvm, int as_id, struct kvm_memslots *slots) { struct kvm_memslots *old_memslots = __kvm_memslots(kvm, as_id); /* * Set the low bit in the generation, which disables SPTE caching * until the end of synchronize_srcu_expedited. */ WARN_ON(old_memslots->generation & 1); slots->generation = old_memslots->generation + 1; rcu_assign_pointer(kvm->memslots[as_id], slots); synchronize_srcu_expedited(&kvm->srcu); /* * Increment the new memslot generation a second time. This prevents * vm exits that race with memslot updates from caching a memslot * generation that will (potentially) be valid forever. */ slots->generation++; kvm_arch_memslots_updated(kvm, slots); return old_memslots; }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov5056.18%116.67%
david matlackdavid matlack2123.60%116.67%
paolo bonzinipaolo bonzini1314.61%350.00%
takuya yoshikawatakuya yoshikawa55.62%116.67%
Total89100.00%6100.00%

/* * Allocate some memory and give it an address in the guest physical address * space. * * Discontiguous memory is allowed, mostly for framebuffers. * * Must be called holding kvm->slots_lock for write. */
int __kvm_set_memory_region(struct kvm *kvm, const struct kvm_userspace_memory_region *mem) { int r; gfn_t base_gfn; unsigned long npages; struct kvm_memory_slot *slot; struct kvm_memory_slot old, new; struct kvm_memslots *slots = NULL, *old_memslots; int as_id, id; enum kvm_mr_change change; r = check_memory_region_flags(mem); if (r) goto out; r = -EINVAL; as_id = mem->slot >> 16; id = (u16)mem->slot; /* General sanity checks */ if (mem->memory_size & (PAGE_SIZE - 1)) goto out; if (mem->guest_phys_addr & (PAGE_SIZE - 1)) goto out; /* We can read the guest memory with __xxx_user() later on. */ if ((id < KVM_USER_MEM_SLOTS) && ((mem->userspace_addr & (PAGE_SIZE - 1)) || !access_ok(VERIFY_WRITE, (void __user *)(unsigned long)mem->userspace_addr, mem->memory_size))) goto out; if (as_id >= KVM_ADDRESS_SPACE_NUM || id >= KVM_MEM_SLOTS_NUM) goto out; if (mem->guest_phys_addr + mem->memory_size < mem->guest_phys_addr) goto out; slot = id_to_memslot(__kvm_memslots(kvm, as_id), id); base_gfn = mem->guest_phys_addr >> PAGE_SHIFT; npages = mem->memory_size >> PAGE_SHIFT; if (npages > KVM_MEM_MAX_NR_PAGES) goto out; new = old = *slot; new.id = id; new.base_gfn = base_gfn; new.npages = npages; new.flags = mem->flags; if (npages) { if (!old.npages) change = KVM_MR_CREATE; else { /* Modify an existing slot. */ if ((mem->userspace_addr != old.userspace_addr) || (npages != old.npages) || ((new.flags ^ old.flags) & KVM_MEM_READONLY)) goto out; if (base_gfn != old.base_gfn) change = KVM_MR_MOVE; else if (new.flags != old.flags) change = KVM_MR_FLAGS_ONLY; else { /* Nothing to change. */ r = 0; goto out; } } } else { if (!old.npages) goto out; change = KVM_MR_DELETE; new.base_gfn = 0; new.flags = 0; } if ((change == KVM_MR_CREATE) || (change == KVM_MR_MOVE)) { /* Check for overlaps */ r = -EEXIST; kvm_for_each_memslot(slot, __kvm_memslots(kvm, as_id)) { if ((slot->id >= KVM_USER_MEM_SLOTS) || (slot->id == id)) continue; if (!((base_gfn + npages <= slot->base_gfn) || (base_gfn >= slot->base_gfn + slot->npages))) goto out; } } /* Free page dirty bitmap if unneeded */ if (!(new.flags & KVM_MEM_LOG_DIRTY_PAGES)) new.dirty_bitmap = NULL; r = -ENOMEM; if (change == KVM_MR_CREATE) { new.userspace_addr = mem->userspace_addr; if (kvm_arch_create_memslot(kvm, &new, npages)) goto out_free; } /* Allocate page dirty bitmap if needed */ if ((new.flags & KVM_MEM_LOG_DIRTY_PAGES) && !new.dirty_bitmap) { if (kvm_create_dirty_bitmap(&new) < 0) goto out_free; } slots = kvm_kvzalloc(sizeof(struct kvm_memslots)); if (!slots) goto out_free; memcpy(slots, __kvm_memslots(kvm, as_id), sizeof(struct kvm_memslots)); if ((change == KVM_MR_DELETE) || (change == KVM_MR_MOVE)) { slot = id_to_memslot(slots, id); slot->flags |= KVM_MEMSLOT_INVALID; old_memslots = install_new_memslots(kvm, as_id, slots); /* slot was deleted or moved, clear iommu mapping */ kvm_iommu_unmap_pages(kvm, &old); /* From this point no new shadow pages pointing to a deleted, * or moved, memslot will be created. * * validation of sp->gfn happens in: * - gfn_to_hva (kvm_read_guest, gfn_to_pfn) * - kvm_is_visible_gfn (mmu_check_roots) */ kvm_arch_flush_shadow_memslot(kvm, slot); /* * We can re-use the old_memslots from above, the only difference * from the currently installed memslots is the invalid flag. This * will get overwritten by update_memslots anyway. */ slots = old_memslots; } r = kvm_arch_prepare_memory_region(kvm, &new, mem, change); if (r) goto out_slots; /* actual memory is freed via old in kvm_free_memslot below */ if (change == KVM_MR_DELETE) { new.dirty_bitmap = NULL; memset(&new.arch, 0, sizeof(new.arch)); } update_memslots(slots, &new); old_memslots = install_new_memslots(kvm, as_id, slots); kvm_arch_commit_memory_region(kvm, mem, &old, &new, change); kvm_free_memslot(kvm, &old, &new); kvfree(old_memslots); /* * IOMMU mapping: New slots need to be mapped. Old slots need to be * un-mapped and re-mapped if their base changes. Since base change * unmapping is handled above with slot deletion, mapping alone is * needed here. Anything else the iommu might care about for existing * slots (size changes, userspace addr changes and read-only flag * changes) is disallowed above, so any other attribute changes getting * here can be skipped. */ if ((change == KVM_MR_CREATE) || (change == KVM_MR_MOVE)) { r = kvm_iommu_map_pages(kvm, &new); return r; } return 0; out_slots: kvfree(slots); out_free: kvm_free_memslot(kvm, &new, &old); out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity20624.97%23.17%
takuya yoshikawatakuya yoshikawa18622.55%1625.40%
marcelo tosattimarcelo tosatti10012.12%711.11%
paolo bonzinipaolo bonzini9611.64%711.11%
alex williamsonalex williamson435.21%57.94%
weidong hanweidong han334.00%11.59%
yang zhangyang zhang303.64%11.59%
xiao guangrongxiao guangrong283.39%34.76%
sheng yangsheng yang172.06%23.17%
igor mammedovigor mammedov161.94%11.59%
ben-ami yassourben-ami yassour131.58%11.59%
hollis blanchardhollis blanchard101.21%11.59%
anthony liguorianthony liguori101.21%23.17%
heiko carstensheiko carstens91.09%11.59%
carsten ottecarsten otte70.85%11.59%
aneesh kumaraneesh kumar60.73%11.59%
izik eidusizik eidus30.36%34.76%
rusty russellrusty russell30.36%11.59%
gleb natapovgleb natapov30.36%23.17%
glauber costaglauber costa20.24%11.59%
al viroal viro10.12%11.59%
xiubo lixiubo li10.12%11.59%
joerg roedeljoerg roedel10.12%11.59%
xiantao zhangxiantao zhang10.12%11.59%
Total825100.00%63100.00%

EXPORT_SYMBOL_GPL(__kvm_set_memory_region);
int kvm_set_memory_region(struct kvm *kvm, const struct kvm_userspace_memory_region *mem) { int r; mutex_lock(&kvm->slots_lock); r = __kvm_set_memory_region(kvm, mem); mutex_unlock(&kvm->slots_lock); return r; }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori2042.55%222.22%
sheng yangsheng yang1327.66%111.11%
avi kivityavi kivity612.77%222.22%
marcelo tosattimarcelo tosatti48.51%222.22%
izik eidusizik eidus36.38%111.11%
paolo bonzinipaolo bonzini12.13%111.11%
Total47100.00%9100.00%

EXPORT_SYMBOL_GPL(kvm_set_memory_region);
static int kvm_vm_ioctl_set_memory_region(struct kvm *kvm, struct kvm_userspace_memory_region *mem) { if ((u16)mem->slot >= KVM_USER_MEM_SLOTS) return -EINVAL; return kvm_set_memory_region(kvm, mem); }

Contributors

PersonTokensPropCommitsCommitProp
izik eidusizik eidus3384.62%342.86%
paolo bonzinipaolo bonzini37.69%114.29%
alex williamsonalex williamson12.56%114.29%
anthony liguorianthony liguori12.56%114.29%
stephen hemmingerstephen hemminger12.56%114.29%
Total39100.00%7100.00%


int kvm_get_dirty_log(struct kvm *kvm, struct kvm_dirty_log *log, int *is_dirty) { struct kvm_memslots *slots; struct kvm_memory_slot *memslot; int r, i, as_id, id; unsigned long n; unsigned long any = 0; r = -EINVAL; as_id = log->slot >> 16; id = (u16)log->slot; if (as_id >= KVM_ADDRESS_SPACE_NUM || id >= KVM_USER_MEM_SLOTS) goto out; slots = __kvm_memslots(kvm, as_id); memslot = id_to_memslot(slots, id); r = -ENOENT; if (!memslot->dirty_bitmap) goto out; n = kvm_dirty_bitmap_bytes(memslot); for (i = 0; !any && i < n/sizeof(long); ++i) any = memslot->dirty_bitmap[i]; r = -EFAULT; if (copy_to_user(log->dirty_bitmap, memslot->dirty_bitmap, n)) goto out; if (any) *is_dirty = 1; r = 0; out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity11157.22%17.69%
paolo bonzinipaolo bonzini4121.13%215.38%
anthony liguorianthony liguori157.73%215.38%
xiantao zhangxiantao zhang94.64%17.69%
xiao guangrongxiao guangrong42.06%17.69%
rusty russellrusty russell42.06%17.69%
takuya yoshikawatakuya yoshikawa31.55%17.69%
uri lublinuri lublin31.55%17.69%
izik eidusizik eidus21.03%17.69%
ben-ami yassourben-ami yassour10.52%17.69%
alex williamsonalex williamson10.52%17.69%
Total194100.00%13100.00%

EXPORT_SYMBOL_GPL(kvm_get_dirty_log); #ifdef CONFIG_KVM_GENERIC_DIRTYLOG_READ_PROTECT /** * kvm_get_dirty_log_protect - get a snapshot of dirty pages, and if any pages * are dirty write protect them for next write. * @kvm: pointer to kvm instance * @log: slot id and address to which we copy the log * @is_dirty: flag set if any page is dirty * * We need to keep it in mind that VCPU threads can write to the bitmap * concurrently. So, to avoid losing track of dirty pages we keep the * following order: * * 1. Take a snapshot of the bit and clear it if needed. * 2. Write protect the corresponding page. * 3. Copy the snapshot to the userspace. * 4. Upon return caller flushes TLB's if needed. * * Between 2 and 4, the guest may write to the page using the remaining TLB * entry. This is not a problem because the page is reported dirty using * the snapshot taken before and step 4 ensures that writes done after * exiting to userspace will be logged for the next call. * */
int kvm_get_dirty_log_protect(struct kvm *kvm, struct kvm_dirty_log *log, bool *is_dirty) { struct kvm_memslots *slots; struct kvm_memory_slot *memslot; int r, i, as_id, id; unsigned long n; unsigned long *dirty_bitmap; unsigned long *dirty_bitmap_buffer; r = -EINVAL; as_id = log->slot >> 16; id = (u16)log->slot; if (as_id >= KVM_ADDRESS_SPACE_NUM || id >= KVM_USER_MEM_SLOTS) goto out; slots = __kvm_memslots(kvm, as_id); memslot = id_to_memslot(slots, id); dirty_bitmap = memslot->dirty_bitmap; r = -ENOENT; if (!dirty_bitmap) goto out; n = kvm_dirty_bitmap_bytes(memslot); dirty_bitmap_buffer = dirty_bitmap + n / sizeof(long); memset(dirty_bitmap_buffer, 0, n); spin_lock(&kvm->mmu_lock); *is_dirty = false; for (i = 0; i < n / sizeof(long); i++) { unsigned long mask; gfn_t offset; if (!dirty_bitmap[i]) continue; *is_dirty = true; mask = xchg(&dirty_bitmap[i], 0); dirty_bitmap_buffer[i] = mask; if (mask) { offset = i * BITS_PER_LONG; kvm_arch_mmu_enable_log_dirty_pt_masked(kvm, memslot, offset, mask); } } spin_unlock(&kvm->mmu_lock); r = -EFAULT; if (copy_to_user(log->dirty_bitmap, dirty_bitmap_buffer, n)) goto out; r = 0; out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
mario smarduchmario smarduch23883.22%120.00%
paolo bonzinipaolo bonzini4114.34%240.00%
takuya yoshikawatakuya yoshikawa62.10%120.00%
kai huangkai huang10.35%120.00%
Total286100.00%5100.00%

EXPORT_SYMBOL_GPL(kvm_get_dirty_log_protect); #endif
bool kvm_largepages_enabled(void) { return largepages_enabled; }

Contributors

PersonTokensPropCommitsCommitProp
takuya yoshikawatakuya yoshikawa10100.00%1100.00%
Total10100.00%1100.00%


void kvm_disable_largepages(void) { largepages_enabled = false; }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori654.55%150.00%
marcelo tosattimarcelo tosatti545.45%150.00%
Total11100.00%2100.00%

EXPORT_SYMBOL_GPL(kvm_disable_largepages);
struct kvm_memory_slot *gfn_to_memslot(struct kvm *kvm, gfn_t gfn) { return __gfn_to_memslot(kvm_memslots(kvm), gfn); }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov1869.23%125.00%
anthony liguorianthony liguori415.38%250.00%
carsten ottecarsten otte415.38%125.00%
Total26100.00%4100.00%

EXPORT_SYMBOL_GPL(gfn_to_memslot);
struct kvm_memory_slot *kvm_vcpu_gfn_to_memslot(struct kvm_vcpu *vcpu, gfn_t gfn) { return __gfn_to_memslot(kvm_vcpu_memslots(vcpu), gfn); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini26100.00%1100.00%
Total26100.00%1100.00%


bool kvm_is_visible_gfn(struct kvm *kvm, gfn_t gfn) { struct kvm_memory_slot *memslot = gfn_to_memslot(kvm, gfn); if (!memslot || memslot->id >= KVM_USER_MEM_SLOTS || memslot->flags & KVM_MEMSLOT_INVALID) return false; return true; }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong1327.08%110.00%
izik eidusizik eidus1225.00%110.00%
marcelo tosattimarcelo tosatti918.75%220.00%
qing heqing he510.42%220.00%
carsten ottecarsten otte48.33%110.00%
yaowei baiyaowei bai36.25%110.00%
alex williamsonalex williamson12.08%110.00%
anthony liguorianthony liguori12.08%110.00%
Total48100.00%10100.00%

EXPORT_SYMBOL_GPL(kvm_is_visible_gfn);
unsigned long kvm_host_page_size(struct kvm *kvm, gfn_t gfn) { struct vm_area_struct *vma; unsigned long addr, size; size = PAGE_SIZE; addr = gfn_to_hva(kvm, gfn); if (kvm_is_error_hva(addr)) return PAGE_SIZE; down_read(&current->mm->mmap_sem); vma = find_vma(current->mm, addr); if (!vma) goto out; size = vma_kernel_pagesize(vma); out: up_read(&current->mm->mmap_sem); return size; }

Contributors

PersonTokensPropCommitsCommitProp
joerg roedeljoerg roedel99100.00%1100.00%
Total99100.00%1100.00%


static bool memslot_is_readonly(struct kvm_memory_slot *slot) { return slot->flags & KVM_MEM_READONLY; }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong18100.00%1100.00%
Total18100.00%1100.00%


static unsigned long __gfn_to_hva_many(struct kvm_memory_slot *slot, gfn_t gfn, gfn_t *nr_pages, bool write) { if (!slot || slot->flags & KVM_MEMSLOT_INVALID) return KVM_HVA_ERR_BAD; if (memslot_is_readonly(slot) && write) return KVM_HVA_ERR_RO_BAD; if (nr_pages) *nr_pages = slot->npages - (gfn - slot->base_gfn); return __gfn_to_hva_memslot(slot, gfn); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong4053.33%337.50%
marcelo tosattimarcelo tosatti2128.00%225.00%
takuya yoshikawatakuya yoshikawa68.00%112.50%
izik eidusizik eidus68.00%112.50%
gleb natapovgleb natapov22.67%112.50%
Total75100.00%8100.00%


static unsigned long gfn_to_hva_many(struct kvm_memory_slot *slot, gfn_t gfn, gfn_t *nr_pages) { return __gfn_to_hva_many(slot, gfn, nr_pages, true); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong2993.55%266.67%
gleb natapovgleb natapov26.45%133.33%
Total31100.00%3100.00%


unsigned long gfn_to_hva_memslot(struct kvm_memory_slot *slot, gfn_t gfn) { return gfn_to_hva_many(slot, gfn, NULL); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong1979.17%240.00%
gleb natapovgleb natapov28.33%120.00%
takuya yoshikawatakuya yoshikawa28.33%120.00%
izik eidusizik eidus14.17%120.00%
Total24100.00%5100.00%

EXPORT_SYMBOL_GPL(gfn_to_hva_memslot);
unsigned long gfn_to_hva(struct kvm *kvm, gfn_t gfn) { return gfn_to_hva_many(gfn_to_memslot(kvm, gfn), gfn, NULL); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong2172.41%133.33%
gleb natapovgleb natapov827.59%266.67%
Total29100.00%3100.00%

EXPORT_SYMBOL_GPL(gfn_to_hva);
unsigned long kvm_vcpu_gfn_to_hva(struct kvm_vcpu *vcpu, gfn_t gfn) { return gfn_to_hva_many(kvm_vcpu_gfn_to_memslot(vcpu, gfn), gfn, NULL); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini29100.00%1100.00%
Total29100.00%1100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_gfn_to_hva); /* * If writable is set to false, the hva returned by this function is only * allowed to be read. */
unsigned long gfn_to_hva_memslot_prot(struct kvm_memory_slot *slot, gfn_t gfn, bool *writable) { unsigned long hva = __gfn_to_hva_many(slot, gfn, NULL, false); if (!kvm_is_error_hva(hva) && writable) *writable = !memslot_is_readonly(slot); return hva; }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov2240.00%125.00%
paolo bonzinipaolo bonzini1730.91%125.00%
xiao guangrongxiao guangrong1323.64%125.00%
christoffer dallchristoffer dall35.45%125.00%
Total55100.00%4100.00%


unsigned long gfn_to_hva_prot(struct kvm *kvm, gfn_t gfn, bool *writable) { struct kvm_memory_slot *slot = gfn_to_memslot(kvm, gfn); return gfn_to_hva_memslot_prot(slot, gfn, writable); }

Contributors

PersonTokensPropCommitsCommitProp
christoffer dallchristoffer dall40100.00%1100.00%
Total40100.00%1100.00%


unsigned long kvm_vcpu_gfn_to_hva_prot(struct kvm_vcpu *vcpu, gfn_t gfn, bool *writable) { struct kvm_memory_slot *slot = kvm_vcpu_gfn_to_memslot(vcpu, gfn); return gfn_to_hva_memslot_prot(slot, gfn, writable); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini40100.00%1100.00%
Total40100.00%1100.00%


static int get_user_page_nowait(unsigned long start, int write, struct page **page) { int flags = FOLL_TOUCH | FOLL_NOWAIT | FOLL_HWPOISON | FOLL_GET; if (write) flags |= FOLL_WRITE; return __get_user_pages(current, current->mm, start, 1, flags, page, NULL, NULL); }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov5693.33%133.33%
dave hansendave hansen35.00%133.33%
geoff levandgeoff levand11.67%133.33%
Total60100.00%3100.00%


static inline int check_user_page_hwpoison(unsigned long addr) { int rc, flags = FOLL_TOUCH | FOLL_HWPOISON | FOLL_WRITE; rc = __get_user_pages(current, current->mm, addr, 1, flags, NULL, NULL, NULL); return rc == -EHWPOISON; }

Contributors

PersonTokensPropCommitsCommitProp
huang yinghuang ying51100.00%1100.00%
Total51100.00%1100.00%

/* * The atomic path to get the writable pfn which will be stored in @pfn, * true indicates success, otherwise false is returned. */
static bool hva_to_pfn_fast(unsigned long addr, bool atomic, bool *async, bool write_fault, bool *writable, kvm_pfn_t *pfn) { struct page *page[1]; int npages; if (!(async || atomic)) return false; /* * Fast pin a writable pfn only if it is a write fault request * or the caller allows to map a writable pfn for a read fault * request. */ if (!(write_fault || writable)) return false; npages = __get_user_pages_fast(addr, 1, 1, page); if (npages == 1) { *pfn = page_to_pfn(page[0]); if (writable) *writable = true; return true; } return false; }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong6962.16%330.00%
marcelo tosattimarcelo tosatti1412.61%220.00%
gleb natapovgleb natapov1311.71%110.00%
carsten ottecarsten otte98.11%110.00%
izik eidusizik eidus43.60%110.00%
avi kivityavi kivity10.90%110.00%
dan williamsdan williams10.90%110.00%
Total111100.00%10100.00%

/* * The slow path to get the pfn of the specified host virtual address, * 1 indicates success, -errno is returned if error is detected. */
static int hva_to_pfn_slow(unsigned long addr, bool *async, bool write_fault, bool *writable, kvm_pfn_t *pfn) { struct page *page[1]; int npages = 0; might_sleep(); if (writable) *writable = write_fault; if (async) { down_read(&current->mm->mmap_sem); npages = get_user_page_nowait(addr, write_fault, page); up_read(&current->mm->mmap_sem); } else npages = __get_user_pages_unlocked(current, current->mm, addr, 1, write_fault, 0, page, FOLL_TOUCH|FOLL_HWPOISON); if (npages != 1) return npages; /* map read fault as writable if possible */ if (unlikely(!write_fault) && writable) { struct page *wpage[1]; npages = __get_user_pages_fast(addr, 1, 1, wpage); if (npages == 1) { *writable = true; put_page(page[0]); page[0] = wpage[0]; } npages = 1; } *pfn = page_to_pfn(page[0]); return npages; }

Contributors

PersonTokensPropCommitsCommitProp
marcelo tosattimarcelo tosatti7737.56%19.09%
xiao guangrongxiao guangrong5928.78%327.27%
gleb natapovgleb natapov3818.54%19.09%
andrea arcangeliandrea arcangeli94.39%19.09%
izik eidusizik eidus83.90%19.09%
carsten ottecarsten otte62.93%19.09%
andres lagar-cavillaandres lagar-cavilla62.93%19.09%
dan williamsdan williams10.49%19.09%
avi kivityavi kivity10.49%19.09%
Total205100.00%11100.00%


static bool vma_is_valid(struct vm_area_struct *vma, bool write_fault) { if (unlikely(!(vma->vm_flags & VM_READ))) return false; if (write_fault && (unlikely(!(vma->vm_flags & VM_WRITE)))) return false; return true; }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong4989.09%125.00%
izik eidusizik eidus47.27%250.00%
anthony liguorianthony liguori23.64%125.00%
Total55100.00%4100.00%

/* * Pin guest page in memory and return its pfn. * @addr: host virtual address which maps memory to the guest * @atomic: whether this function can sleep * @async: whether this function need to wait IO complete if the * host page is not in the memory * @write_fault: whether we should get a writable host page * @writable: whether it allows to map a writable host page for !@write_fault * * The function will map a writable host page for these two cases: * 1): @write_fault = true * 2): @write_fault = false && @writable, @writable will tell the caller * whether the mapping is writable. */
static kvm_pfn_t hva_to_pfn(unsigned long addr, bool atomic, bool *async, bool write_fault, bool *writable) { struct vm_area_struct *vma; kvm_pfn_t pfn = 0; int npages; /* we can do it either atomically or asynchronously, not both */ BUG_ON(atomic && async); if (hva_to_pfn_fast(addr, atomic, async, write_fault, writable, &pfn)) return pfn; if (atomic) return KVM_PFN_ERR_FAULT; npages = hva_to_pfn_slow(addr, async, write_fault, writable, &pfn); if (npages == 1) return pfn; down_read(&current->mm->mmap_sem); if (npages == -EHWPOISON || (!async && check_user_page_hwpoison(addr))) { pfn = KVM_PFN_ERR_HWPOISON; goto exit; } vma = find_vma_intersection(current->mm, addr, addr + 1); if (vma == NULL) pfn = KVM_PFN_ERR_FAULT; else if ((vma->vm_flags & VM_PFNMAP)) { pfn = ((addr - vma->vm_start) >> PAGE_SHIFT) + vma->vm_pgoff; BUG_ON(!kvm_is_reserved_pfn(pfn)); } else { if (async && vma_is_valid(vma, write_fault)) *async = true; pfn = KVM_PFN_ERR_FAULT; } exit: up_read(&current->mm->mmap_sem); return pfn; }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong10142.62%531.25%
gleb natapovgleb natapov6627.85%318.75%
anthony liguorianthony liguori239.70%16.25%
huang yinghuang ying208.44%318.75%
izik eidusizik eidus156.33%16.25%
marcelo tosattimarcelo tosatti93.80%16.25%
dan williamsdan williams20.84%16.25%
ard biesheuvelard biesheuvel10.42%16.25%
Total237100.00%16100.00%


kvm_pfn_t __gfn_to_pfn_memslot(struct kvm_memory_slot *slot, gfn_t gfn, bool atomic, bool *async, bool write_fault, bool *writable) { unsigned long addr = __gfn_to_hva_many(slot, gfn, NULL, write_fault); if (addr == KVM_HVA_ERR_RO_BAD) { if (writable) *writable = false; return KVM_PFN_ERR_RO_FAULT; } if (kvm_is_error_hva(addr)) { if (writable) *writable = false; return KVM_PFN_NOSLOT; } /* Do not map writable pfn in the readonly memslot. */ if (writable && memslot_is_readonly(slot)) { *writable = false; writable = NULL; } return hva_to_pfn(addr, atomic, async, write_fault, writable); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong9277.97%342.86%
paolo bonzinipaolo bonzini2218.64%114.29%
marcelo tosattimarcelo tosatti21.69%114.29%
gleb natapovgleb natapov10.85%114.29%
dan williamsdan williams10.85%114.29%
Total118100.00%7100.00%

EXPORT_SYMBOL_GPL(__gfn_to_pfn_memslot);
kvm_pfn_t gfn_to_pfn_prot(struct kvm *kvm, gfn_t gfn, bool write_fault, bool *writable) { return __gfn_to_pfn_memslot(gfn_to_memslot(kvm, gfn), gfn, false, NULL, write_fault, writable); }

Contributors

PersonTokensPropCommitsCommitProp
marcelo tosattimarcelo tosatti2560.98%222.22%
xiao guangrongxiao guangrong819.51%333.33%
paolo bonzinipaolo bonzini614.63%222.22%
gleb natapovgleb natapov12.44%111.11%
dan williamsdan williams12.44%111.11%
Total41100.00%9100.00%

EXPORT_SYMBOL_GPL(gfn_to_pfn_prot);
kvm_pfn_t gfn_to_pfn_memslot(struct kvm_memory_slot *slot, gfn_t gfn) { return __gfn_to_pfn_memslot(slot, gfn, false, NULL, true, NULL); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong1655.17%120.00%
paolo bonzinipaolo bonzini827.59%120.00%
marcelo tosattimarcelo tosatti310.34%120.00%
gleb natapovgleb natapov13.45%120.00%
dan williamsdan williams13.45%120.00%
Total29100.00%5100.00%

EXPORT_SYMBOL_GPL(gfn_to_pfn_memslot);
kvm_pfn_t gfn_to_pfn_memslot_atomic(struct kvm_memory_slot *slot, gfn_t gfn) { return __gfn_to_pfn_memslot(slot, gfn, true, NULL, true, NULL); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong1344.83%116.67%
paolo bonzinipaolo bonzini827.59%116.67%
marcelo tosattimarcelo tosatti620.69%233.33%
dan williamsdan williams13.45%116.67%
gleb natapovgleb natapov13.45%116.67%
Total29100.00%6100.00%

EXPORT_SYMBOL_GPL(gfn_to_pfn_memslot_atomic);
kvm_pfn_t gfn_to_pfn_atomic(struct kvm *kvm, gfn_t gfn) { return gfn_to_pfn_memslot_atomic(gfn_to_memslot(kvm, gfn), gfn); }

Contributors

PersonTokensPropCommitsCommitProp
marcelo tosattimarcelo tosatti1973.08%133.33%
paolo bonzinipaolo bonzini623.08%133.33%
dan williamsdan williams13.85%133.33%
Total26100.00%3100.00%

EXPORT_SYMBOL_GPL(gfn_to_pfn_atomic);
kvm_pfn_t kvm_vcpu_gfn_to_pfn_atomic(struct kvm_vcpu *vcpu, gfn_t gfn) { return gfn_to_pfn_memslot_atomic(kvm_vcpu_gfn_to_memslot(vcpu, gfn), gfn); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini2596.15%150.00%
dan williamsdan williams13.85%150.00%
Total26100.00%2100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_gfn_to_pfn_atomic);
kvm_pfn_t gfn_to_pfn(struct kvm *kvm, gfn_t gfn) { return gfn_to_pfn_memslot(gfn_to_memslot(kvm, gfn), gfn); }

Contributors

PersonTokensPropCommitsCommitProp
marcelo tosattimarcelo tosatti1661.54%120.00%
paolo bonzinipaolo bonzini726.92%120.00%
xiao guangrongxiao guangrong27.69%240.00%
dan williamsdan williams13.85%120.00%
Total26100.00%5100.00%

EXPORT_SYMBOL_GPL(gfn_to_pfn);
kvm_pfn_t kvm_vcpu_gfn_to_pfn(struct kvm_vcpu *vcpu, gfn_t gfn) { return gfn_to_pfn_memslot(kvm_vcpu_gfn_to_memslot(vcpu, gfn), gfn); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini2596.15%150.00%
dan williamsdan williams13.85%150.00%
Total26100.00%2100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_gfn_to_pfn);
int gfn_to_page_many_atomic(struct kvm_memory_slot *slot, gfn_t gfn, struct page **pages, int nr_pages) { unsigned long addr; gfn_t entry; addr = gfn_to_hva_many(slot, gfn, &entry); if (kvm_is_error_hva(addr)) return -1; if (entry < nr_pages) return 0; return __get_user_pages_fast(addr, nr_pages, 1, pages); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong6589.04%125.00%
paolo bonzinipaolo bonzini34.11%125.00%
marcelo tosattimarcelo tosatti34.11%125.00%
gleb natapovgleb natapov22.74%125.00%
Total73100.00%4100.00%

EXPORT_SYMBOL_GPL(gfn_to_page_many_atomic);
static struct page *kvm_pfn_to_page(kvm_pfn_t pfn) { if (is_error_noslot_pfn(pfn)) return KVM_ERR_PTR_BAD_PAGE; if (kvm_is_reserved_pfn(pfn)) { WARN_ON(1); return KVM_ERR_PTR_BAD_PAGE; } return pfn_to_page(pfn); }

Contributors

PersonTokensPropCommitsCommitProp
xiao guangrongxiao guangrong4295.45%466.67%
ard biesheuvelard biesheuvel12.27%116.67%
dan williamsdan williams12.27%116.67%
Total44100.00%6100.00%


struct page *gfn_to_page(struct kvm *kvm, gfn_t gfn) { kvm_pfn_t pfn; pfn = gfn_to_pfn(kvm, gfn); return kvm_pfn_to_page(pfn); }

Contributors

PersonTokensPropCommitsCommitProp
izik eidusizik eidus1957.58%120.00%
anthony liguorianthony liguori1236.36%240.00%
xiao guangrongxiao guangrong13.03%120.00%
dan williamsdan williams13.03%120.00%
Total33100.00%5100.00%

EXPORT_SYMBOL_GPL(gfn_to_page);
struct page *kvm_vcpu_gfn_to_page(struct kvm_vcpu *vcpu, gfn_t gfn) { kvm_pfn_t pfn; pfn = kvm_vcpu_gfn_to_pfn(vcpu, gfn); return kvm_pfn_to_page(pfn); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini3296.97%150.00%
dan williamsdan williams13.03%150.00%
Total33100.00%2100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_gfn_to_page);
void kvm_release_page_clean(struct page *page) { WARN_ON(is_error_page(page)); kvm_release_pfn_clean(page_to_pfn(page)); }

Contributors

PersonTokensPropCommitsCommitProp
izik eidusizik eidus1350.00%233.33%
xiao guangrongxiao guangrong830.77%233.33%
uri lublinuri lublin311.54%116.67%
anthony liguorianthony liguori27.69%116.67%
Total26100.00%6100.00%

EXPORT_SYMBOL_GPL(kvm_release_page_clean);
void kvm_release_pfn_clean(kvm_pfn_t pfn) { if (!is_error_noslot_pfn(pfn) && !kvm_is_reserved_pfn(pfn)) put_page(pfn_to_page(pfn)); }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori1860.00%225.00%
xiao guangrongxiao guangrong826.67%337.50%
izik eidusizik eidus26.67%112.50%
ard biesheuvelard biesheuvel13.33%112.50%
dan williamsdan williams13.33%112.50%
Total30100.00%8100.00%

EXPORT_SYMBOL_GPL(kvm_release_pfn_clean);
void kvm_release_page_dirty(struct page *page) { WARN_ON(is_error_page(page)); kvm_release_pfn_dirty(page_to_pfn(page)); }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori934.62%120.00%
xiao guangrongxiao guangrong830.77%120.00%
avi kivityavi kivity519.23%120.00%
carsten ottecarsten otte27.69%120.00%
izik eidusizik eidus27.69%120.00%
Total26100.00%5100.00%

EXPORT_SYMBOL_GPL(kvm_release_page_dirty);
static void kvm_release_pfn_dirty(kvm_pfn_t pfn) { kvm_set_pfn_dirty(pfn); kvm_release_pfn_clean(pfn); }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori1157.89%125.00%
izik eidusizik eidus631.58%125.00%
stephen hemmingerstephen hemminger15.26%125.00%
dan williamsdan williams15.26%125.00%
Total19100.00%4100.00%


void kvm_set_pfn_dirty(kvm_pfn_t pfn) { if (!kvm_is_reserved_pfn(pfn)) { struct page *page = pfn_to_page(pfn); if (!PageReserved(page)) SetPageDirty(page); } }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori1639.02%216.67%
eddie dongeddie dong717.07%18.33%
carsten ottecarsten otte512.20%18.33%
gleb natapovgleb natapov49.76%18.33%
marcelo tosattimarcelo tosatti37.32%216.67%
hollis blanchardhollis blanchard24.88%18.33%
ard biesheuvelard biesheuvel12.44%18.33%
avi kivityavi kivity12.44%18.33%
dan williamsdan williams12.44%18.33%
ben-ami yassourben-ami yassour12.44%18.33%
Total41100.00%12100.00%

EXPORT_SYMBOL_GPL(kvm_set_pfn_dirty);
void kvm_set_pfn_accessed(kvm_pfn_t pfn) { if (!kvm_is_reserved_pfn(pfn)) mark_page_accessed(pfn_to_page(pfn)); }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori1562.50%333.33%
avi kivityavi kivity625.00%333.33%
hollis blanchardhollis blanchard14.17%111.11%
ard biesheuvelard biesheuvel14.17%111.11%
dan williamsdan williams14.17%111.11%
Total24100.00%9100.00%

EXPORT_SYMBOL_GPL(kvm_set_pfn_accessed);
void kvm_get_pfn(kvm_pfn_t pfn) { if (!kvm_is_reserved_pfn(pfn)) get_page(pfn_to_page(pfn)); }

Contributors

PersonTokensPropCommitsCommitProp
anthony liguorianthony liguori1041.67%225.00%
avi kivityavi kivity729.17%225.00%
laurent vivierlaurent vivier416.67%112.50%
ard biesheuvelard biesheuvel14.17%112.50%
dan williamsdan williams14.17%112.50%
ben-ami yassourben-ami yassour14.17%112.50%
Total24100.00%8100.00%

EXPORT_SYMBOL_GPL(kvm_get_pfn);
static int next_segment(unsigned long len, int offset) { if (len > PAGE_SIZE - offset) return PAGE_SIZE - offset; else return len; }

Contributors

PersonTokensPropCommitsCommitProp
carsten ottecarsten otte1550.00%133.33%
avi kivityavi kivity930.00%133.33%
izik eidusizik eidus620.00%133.33%
Total30100.00%3100.00%


static int __kvm_read_guest_page(struct kvm_memory_slot *slot, gfn_t gfn, void *data, int offset, int len) { int r; unsigned long addr; addr = gfn_to_hva_memslot_prot(slot, gfn, NULL); if (kvm_is_error_hva(addr)) return -EFAULT; r = __copy_from_user(data, (void __user *)addr + offset, len); if (r) return -EFAULT; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3643.90%436.36%
izik eidusizik eidus2732.93%218.18%
paolo bonzinipaolo bonzini910.98%327.27%
carsten ottecarsten otte910.98%19.09%
anthony liguorianthony liguori11.22%19.09%
Total82100.00%11100.00%


int kvm_read_guest_page(struct kvm *kvm, gfn_t gfn, void *data, int offset, int len) { struct kvm_memory_slot *slot = gfn_to_memslot(kvm, gfn); return __kvm_read_guest_page(slot, gfn, data, offset, len); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini3265.31%133.33%
izik eidusizik eidus1530.61%133.33%
avi kivityavi kivity24.08%133.33%
Total49100.00%3100.00%

EXPORT_SYMBOL_GPL(kvm_read_guest_page);
int kvm_vcpu_read_guest_page(struct kvm_vcpu *vcpu, gfn_t gfn, void *data, int offset, int len) { struct kvm_memory_slot *slot = kvm_vcpu_gfn_to_memslot(vcpu, gfn); return __kvm_read_guest_page(slot, gfn, data, offset, len); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini49100.00%1100.00%
Total49100.00%1100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_read_guest_page);
int kvm_read_guest(struct kvm *kvm, gpa_t gpa, void *data, unsigned long len) { gfn_t gfn = gpa >> PAGE_SHIFT; int seg; int offset = offset_in_page(gpa); int ret; while ((seg = next_segment(len, offset)) != 0) { ret = kvm_read_guest_page(kvm, gfn, data, offset, seg); if (ret < 0) return ret; offset = 0; len -= seg; data += seg; ++gfn; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
izik eidusizik eidus5554.46%112.50%
paolo bonzinipaolo bonzini3635.64%112.50%
avi kivityavi kivity76.93%450.00%
rusty russellrusty russell21.98%112.50%
ulrich drepperulrich drepper10.99%112.50%
Total101100.00%8100.00%

EXPORT_SYMBOL_GPL(kvm_read_guest);
int kvm_vcpu_read_guest(struct kvm_vcpu *vcpu, gpa_t gpa, void *data, unsigned long len) { gfn_t gfn = gpa >> PAGE_SHIFT; int seg; int offset = offset_in_page(gpa); int ret; while ((seg = next_segment(len, offset)) != 0) { ret = kvm_vcpu_read_guest_page(vcpu, gfn, data, offset, seg); if (ret < 0) return ret; offset = 0; len -= seg; data += seg; ++gfn; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini8988.12%133.33%
marcelo tosattimarcelo tosatti76.93%133.33%
izik eidusizik eidus54.95%133.33%
Total101100.00%3100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_read_guest);
static int __kvm_read_guest_atomic(struct kvm_memory_slot *slot, gfn_t gfn, void *data, int offset, unsigned long len) { int r; unsigned long addr; addr = gfn_to_hva_memslot_prot(slot, gfn, NULL); if (kvm_is_error_hva(addr)) return -EFAULT; pagefault_disable(); r = __copy_from_user_inatomic(data, (void __user *)addr + offset, len); pagefault_enable(); if (r) return -EFAULT; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini89100.00%1100.00%
Total89100.00%1100.00%


int kvm_read_guest_atomic(struct kvm *kvm, gpa_t gpa, void *data, unsigned long len) { gfn_t gfn = gpa >> PAGE_SHIFT; struct kvm_memory_slot *slot = gfn_to_memslot(kvm, gfn); int offset = offset_in_page(gpa); return __kvm_read_guest_atomic(slot, gfn, data, offset, len); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini62100.00%1100.00%
Total62100.00%1100.00%

EXPORT_SYMBOL_GPL(kvm_read_guest_atomic);
int kvm_vcpu_read_guest_atomic(struct kvm_vcpu *vcpu, gpa_t gpa, void *data, unsigned long len) { gfn_t gfn = gpa >> PAGE_SHIFT; struct kvm_memory_slot *slot = kvm_vcpu_gfn_to_memslot(vcpu, gfn); int offset = offset_in_page(gpa); return __kvm_read_guest_atomic(slot, gfn, data, offset, len); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini62100.00%1100.00%
Total62100.00%1100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_read_guest_atomic);
static int __kvm_write_guest_page(struct kvm_memory_slot *memslot, gfn_t gfn, const void *data, int offset, int len) { int r; unsigned long addr; addr = gfn_to_hva_memslot(memslot, gfn); if (kvm_is_error_hva(addr)) return -EFAULT; r = __copy_to_user((void __user *)addr + offset, data, len); if (r) return -EFAULT; mark_page_dirty_in_slot(memslot, gfn); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini88100.00%1100.00%
Total88100.00%1100.00%


int kvm_write_guest_page(struct kvm *kvm, gfn_t gfn, const void *data, int offset, int len) { struct kvm_memory_slot *slot = gfn_to_memslot(kvm, gfn); return __kvm_write_guest_page(slot, gfn, data, offset, len); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini50100.00%1100.00%
Total50100.00%1100.00%

EXPORT_SYMBOL_GPL(kvm_write_guest_page);
int kvm_vcpu_write_guest_page(struct kvm_vcpu *vcpu, gfn_t gfn, const void *data, int offset, int len) { struct kvm_memory_slot *slot = kvm_vcpu_gfn_to_memslot(vcpu, gfn); return __kvm_write_guest_page(slot, gfn, data, offset, len); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini3264.00%240.00%
marcelo tosattimarcelo tosatti1326.00%120.00%
izik eidusizik eidus48.00%120.00%
avi kivityavi kivity12.00%120.00%
Total50100.00%5100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_write_guest_page);
int kvm_write_guest(struct kvm *kvm, gpa_t gpa, const void *data, unsigned long len) { gfn_t gfn = gpa >> PAGE_SHIFT; int seg; int offset = offset_in_page(gpa); int ret; while ((seg = next_segment(len, offset)) != 0) { ret = kvm_write_guest_page(kvm, gfn, data, offset, seg); if (ret < 0) return ret; offset = 0; len -= seg; data += seg; ++gfn; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini5856.86%110.00%
izik eidusizik eidus2423.53%330.00%
gleb natapovgleb natapov76.86%330.00%
avi kivityavi kivity65.88%110.00%
radim krcmarradim krcmar54.90%110.00%
rusty russellrusty russell21.96%110.00%
Total102100.00%10100.00%

EXPORT_SYMBOL_GPL(kvm_write_guest);
int kvm_vcpu_write_guest(struct kvm_vcpu *vcpu, gpa_t gpa, const void *data, unsigned long len) { gfn_t gfn = gpa >> PAGE_SHIFT; int seg; int offset = offset_in_page(gpa); int ret; while ((seg = next_segment(len, offset)) != 0) { ret = kvm_vcpu_write_guest_page(vcpu, gfn, data, offset, seg); if (ret < 0) return ret; offset = 0; len -= seg; data += seg; ++gfn; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
izik eidusizik eidus5351.96%114.29%
avi kivityavi kivity3534.31%228.57%
paolo bonzinipaolo bonzini54.90%114.29%
carsten ottecarsten otte54.90%114.29%
eddie dongeddie dong21.96%114.29%
al viroal viro21.96%114.29%
Total102100.00%7100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_write_guest);
int kvm_gfn_to_hva_cache_init(struct kvm *kvm, struct gfn_to_hva_cache *ghc, gpa_t gpa, unsigned long len) { struct kvm_memslots *slots = kvm_memslots(kvm); int offset = offset_in_page(gpa); gfn_t start_gfn = gpa >> PAGE_SHIFT; gfn_t end_gfn = (gpa + len - 1) >> PAGE_SHIFT; gfn_t nr_pages_needed = end_gfn - start_gfn + 1; gfn_t nr_pages_avail; ghc->gpa = gpa; ghc->generation = slots->generation; ghc->len = len; ghc->memslot = gfn_to_memslot(kvm, start_gfn); ghc->hva = gfn_to_hva_many(ghc->memslot, start_gfn, NULL); if (!kvm_is_error_hva(ghc->hva) && nr_pages_needed <= 1) { ghc->hva += offset; } else { /* * If the requested region crosses two memslots, we still * verify that the entire region is valid here. */ while (start_gfn <= end_gfn) { ghc->memslot = gfn_to_memslot(kvm, start_gfn); ghc->hva = gfn_to_hva_many(ghc->memslot, start_gfn, &nr_pages_avail); if (kvm_is_error_hva(ghc->hva)) return -EFAULT; start_gfn += nr_pages_avail; } /* Use the slow path for cross page reads and writes. */ ghc->memslot = NULL; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov10149.03%125.00%
andy honigandy honig10048.54%125.00%
radim krcmarradim krcmar31.46%125.00%
paul mackerraspaul mackerras20.97%125.00%
Total206100.00%4100.00%

EXPORT_SYMBOL_GPL(kvm_gfn_to_hva_cache_init);
int kvm_write_guest_cached(struct kvm *kvm, struct gfn_to_hva_cache *ghc, void *data, unsigned long len) { struct kvm_memslots *slots = kvm_memslots(kvm); int r; BUG_ON(len > ghc->len); if (slots->generation != ghc->generation) kvm_gfn_to_hva_cache_init(kvm, ghc, ghc->gpa, ghc->len); if (unlikely(!ghc->memslot)) return kvm_write_guest(kvm, ghc->gpa, data, len); if (kvm_is_error_hva(ghc->hva)) return -EFAULT; r = __copy_to_user((void __user *)ghc->hva, data, len); if (r) return -EFAULT; mark_page_dirty_in_slot(ghc->memslot, ghc->gpa >> PAGE_SHIFT); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov11174.50%133.33%
andy honigandy honig3724.83%133.33%
xiao guangrongxiao guangrong10.67%133.33%
Total149100.00%3100.00%

EXPORT_SYMBOL_GPL(kvm_write_guest_cached);
int kvm_read_guest_cached(struct kvm *kvm, struct gfn_to_hva_cache *ghc, void *data, unsigned long len) { struct kvm_memslots *slots = kvm_memslots(kvm); int r; BUG_ON(len > ghc->len); if (slots->generation != ghc->generation) kvm_gfn_to_hva_cache_init(kvm, ghc, ghc->gpa, ghc->len); if (unlikely(!ghc->memslot)) return kvm_read_guest(kvm, ghc->gpa, data, len); if (kvm_is_error_hva(ghc->hva)) return -EFAULT; r = __copy_from_user(data, (void __user *)ghc->hva, len); if (r) return -EFAULT; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov9972.79%150.00%
andy honigandy honig3727.21%150.00%
Total136100.00%2100.00%

EXPORT_SYMBOL_GPL(kvm_read_guest_cached);
int kvm_clear_guest_page(struct kvm *kvm, gfn_t gfn, int offset, int len) { const void *zero_page = (const void *) __va(page_to_phys(ZERO_PAGE(0))); return kvm_write_guest_page(kvm, gfn, zero_page, offset, len); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity2750.00%250.00%
heiko carstensheiko carstens2240.74%125.00%
gleb natapovgleb natapov59.26%125.00%
Total54100.00%4100.00%

EXPORT_SYMBOL_GPL(kvm_clear_guest_page);
int kvm_clear_guest(struct kvm *kvm, gpa_t gpa, unsigned long len) { gfn_t gfn = gpa >> PAGE_SHIFT; int seg; int offset = offset_in_page(gpa); int ret; while ((seg = next_segment(len, offset)) != 0) { ret = kvm_clear_guest_page(kvm, gfn, offset, seg); if (ret < 0) return ret; offset = 0; len -= seg; ++gfn; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity7582.42%562.50%
gleb natapovgleb natapov99.89%112.50%
carsten ottecarsten otte66.59%112.50%
nick pigginnick piggin11.10%112.50%
Total91100.00%8100.00%

EXPORT_SYMBOL_GPL(kvm_clear_guest);
static void mark_page_dirty_in_slot(struct kvm_memory_slot *memslot, gfn_t gfn) { if (memslot && memslot->dirty_bitmap) { unsigned long rel_gfn = gfn - memslot->base_gfn; set_bit_le(rel_gfn, memslot->dirty_bitmap); } }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3274.42%450.00%
gleb natapovgleb natapov511.63%112.50%
takuya yoshikawatakuya yoshikawa511.63%225.00%
stephen hemmingerstephen hemminger12.33%112.50%
Total43100.00%8100.00%


void mark_page_dirty(struct kvm *kvm, gfn_t gfn) { struct kvm_memory_slot *memslot; memslot = gfn_to_memslot(kvm, gfn); mark_page_dirty_in_slot(memslot, gfn); }

Contributors

PersonTokensPropCommitsCommitProp
gleb natapovgleb natapov34100.00%1100.00%
Total34100.00%1100.00%

EXPORT_SYMBOL_GPL(mark_page_dirty);
void kvm_vcpu_mark_page_dirty(struct kvm_vcpu *vcpu, gfn_t gfn) { struct kvm_memory_slot *memslot; memslot = kvm_vcpu_gfn_to_memslot(vcpu, gfn); mark_page_dirty_in_slot(memslot, gfn); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini34100.00%1100.00%
Total34100.00%1100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_mark_page_dirty);
static void grow_halt_poll_ns(struct kvm_vcpu *vcpu) { unsigned int old, val, grow; old = val = vcpu->halt_poll_ns; grow = READ_ONCE(halt_poll_ns_grow); /* 10us base */ if (val == 0 && grow) val = 10000; else val *= grow; if (val > halt_poll_ns) val = halt_poll_ns; vcpu->halt_poll_ns = val; trace_kvm_halt_poll_ns_grow(vcpu->vcpu_id, val, old); }

Contributors

PersonTokensPropCommitsCommitProp
wanpeng liwanpeng li5772.15%250.00%
christian borntraegerchristian borntraeger1215.19%125.00%
david matlackdavid matlack1012.66%125.00%
Total79100.00%4100.00%


static void shrink_halt_poll_ns(struct kvm_vcpu *vcpu) { unsigned int old, val, shrink; old = val = vcpu->halt_poll_ns; shrink = READ_ONCE(halt_poll_ns_shrink); if (shrink == 0) val = 0; else val /= shrink; vcpu->halt_poll_ns = val; trace_kvm_halt_poll_ns_shrink(vcpu->vcpu_id, val, old); }

Contributors

PersonTokensPropCommitsCommitProp
wanpeng liwanpeng li5481.82%266.67%
christian borntraegerchristian borntraeger1218.18%133.33%
Total66100.00%3100.00%


static int kvm_vcpu_check_block(struct kvm_vcpu *vcpu) { if (kvm_arch_vcpu_runnable(vcpu)) { kvm_make_request(KVM_REQ_UNHALT, vcpu); return -EINTR; } if (kvm_cpu_has_pending_timer(vcpu)) return -EINTR; if (signal_pending(current)) return -EINTR; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini56100.00%1100.00%
Total56100.00%1100.00%

/* * The vCPU has executed a HLT instruction with in-kernel mode enabled. */
void kvm_vcpu_block(struct kvm_vcpu *vcpu) { ktime_t start, cur; DECLARE_SWAITQUEUE(wait); bool waited = false; u64 block_ns; start = cur = ktime_get(); if (vcpu->halt_poll_ns) { ktime_t stop = ktime_add_ns(ktime_get(), vcpu->halt_poll_ns); ++vcpu->stat.halt_attempted_poll; do { /* * This sets KVM_REQ_UNHALT if an interrupt * arrives. */ if (kvm_vcpu_check_block(vcpu) < 0) { ++vcpu->stat.halt_successful_poll; if (!vcpu_valid_wakeup(vcpu)) ++vcpu->stat.halt_poll_invalid; goto out; } cur = ktime_get(); } while (single_task_running() && ktime_before(cur, stop)); } kvm_arch_vcpu_blocking(vcpu); for (;;) { prepare_to_swait(&vcpu->wq, &wait, TASK_INTERRUPTIBLE); if (kvm_vcpu_check_block(vcpu) < 0) break; waited = true; schedule(); } finish_swait(&vcpu->wq, &wait); cur = ktime_get(); kvm_arch_vcpu_unblocking(vcpu); out: block_ns = ktime_to_ns(cur) - ktime_to_ns(start); if (!vcpu_valid_wakeup(vcpu)) shrink_halt_poll_ns(vcpu); else if (halt_poll_ns) { if (block_ns <= vcpu->halt_poll_ns) ; /* we had a long block, shrink polling */ else if (vcpu->halt_poll_ns && block_ns > halt_poll_ns) shrink_halt_poll_ns(vcpu); /* we had a short halt and our poll time is too small */ else if (vcpu->halt_poll_ns < halt_poll_ns && block_ns < halt_poll_ns) grow_halt_poll_ns(vcpu); } else vcpu->halt_poll_ns = 0; trace_kvm_vcpu_wakeup(block_ns, waited, vcpu_valid_wakeup(vcpu)); kvm_arch_vcpu_block_finish(vcpu); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini11138.68%213.33%
wanpeng liwanpeng li7124.74%320.00%
christian borntraegerchristian borntraeger3913.59%213.33%
avi kivityavi kivity289.76%426.67%
sheng yangsheng yang248.36%16.67%
christoffer dallchristoffer dall103.48%16.67%
marcelo tosattimarcelo tosatti31.05%16.67%
rusty russellrusty russell10.35%16.67%
Total287100.00%15100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_block); #ifndef CONFIG_S390
void kvm_vcpu_wake_up(struct kvm_vcpu *vcpu) { struct swait_queue_head *wqp; wqp = kvm_arch_vcpu_wq(vcpu); if (swait_active(wqp)) { swake_up(wqp); ++vcpu->stat.halt_wakeup; } }

Contributors

PersonTokensPropCommitsCommitProp
christoffer dallchristoffer dall3786.05%133.33%
marcelo tosattimarcelo tosatti49.30%133.33%
radim krcmarradim krcmar24.65%133.33%
Total43100.00%3100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_wake_up); /* * Kick a sleeping VCPU, or a guest VCPU in guest mode, into host kernel mode. */
void kvm_vcpu_kick(struct kvm_vcpu *vcpu) { int me; int cpu = vcpu->cpu; kvm_vcpu_wake_up(vcpu); me = get_cpu(); if (cpu != me && (unsigned)cpu < nr_cpu_ids && cpu_online(cpu)) if (kvm_arch_vcpu_should_kick(vcpu)) smp_send_reschedule(cpu); put_cpu(); }

Contributors

PersonTokensPropCommitsCommitProp
christoffer dallchristoffer dall3961.90%150.00%
radim krcmarradim krcmar2438.10%150.00%
Total63100.00%2100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_kick); #endif /* !CONFIG_S390 */
int kvm_vcpu_yield_to(struct kvm_vcpu *target) { struct pid *pid; struct task_struct *task = NULL; int ret = 0; rcu_read_lock(); pid = rcu_dereference(target->pid); if (pid) task = get_pid_task(pid, PIDTYPE_PID); rcu_read_unlock(); if (!task) return ret; ret = yield_to(task, 1); put_task_struct(task); return ret; }

Contributors

PersonTokensPropCommitsCommitProp
konstantin weitzkonstantin weitz7087.50%133.33%
raghavendra k t* (same as raghavendra koushik)raghavendra k t* (same as raghavendra koushik)78.75%133.33%
dan carpenterdan carpenter33.75%133.33%
Total80100.00%3100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_yield_to); /* * Helper that checks whether a VCPU is eligible for directed yield. * Most eligible candidate to yield is decided by following heuristics: * * (a) VCPU which has not done pl-exit or cpu relax intercepted recently * (preempted lock holder), indicated by @in_spin_loop. * Set at the beiginning and cleared at the end of interception/PLE handler. * * (b) VCPU which has done pl-exit/ cpu relax intercepted but did not get * chance last time (mostly it has become eligible now since we have probably * yielded to lockholder in last iteration. This is done by toggling * @dy_eligible each time a VCPU checked for eligibility.) * * Yielding to a recently pl-exited/cpu relax intercepted VCPU before yielding * to preempted lock-holder could result in wrong VCPU selection and CPU * burning. Giving priority for a potential lock-holder increases lock * progress. * * Since algorithm is based on heuristics, accessing another VCPU data without * locking does not harm. It may result in trying to yield to same VCPU, fail * and continue with next VCPU and so on. */
static bool kvm_vcpu_eligible_for_directed_yield(struct kvm_vcpu *vcpu) { #ifdef CONFIG_HAVE_KVM_CPU_RELAX_INTERCEPT bool eligible; eligible = !vcpu->spin_loop.in_spin_loop || vcpu->spin_loop.dy_eligible; if (vcpu->spin_loop.in_spin_loop) kvm_vcpu_set_dy_eligible(vcpu, !vcpu->spin_loop.dy_eligible); return eligible; #else return true; #endif }

Contributors

PersonTokensPropCommitsCommitProp
raghavendra k t* (same as raghavendra koushik)raghavendra k t* (same as raghavendra koushik)4877.42%125.00%
scott woodscott wood914.52%125.00%
konstantin weitzkonstantin weitz46.45%125.00%
stephen hemmingerstephen hemminger11.61%125.00%
Total62100.00%4100.00%


void kvm_vcpu_on_spin(struct kvm_vcpu *me) { struct kvm *kvm = me->kvm; struct kvm_vcpu *vcpu; int last_boosted_vcpu = me->kvm->last_boosted_vcpu; int yielded = 0; int try = 3; int pass; int i; kvm_vcpu_set_in_spin_loop(me, true); /* * We boost the priority of a VCPU that is runnable but not * currently running, because it got preempted by something * else and called schedule in __vcpu_run. Hopefully that * VCPU is holding the lock that we need and will release it. * We approximate round-robin by starting at the last boosted VCPU. */ for (pass = 0; pass < 2 && !yielded && try; pass++) { kvm_for_each_vcpu(i, vcpu, kvm) { if (!pass && i <= last_boosted_vcpu) { i = last_boosted_vcpu; continue; } else if (pass && i > last_boosted_vcpu) break; if (!ACCESS_ONCE(vcpu->preempted)) continue; if (vcpu == me) continue; if (swait_active(&vcpu->wq) && !kvm_arch_vcpu_runnable(vcpu)) continue; if (!kvm_vcpu_eligible_for_directed_yield(vcpu)) continue; yielded = kvm_vcpu_yield_to(vcpu); if (yielded > 0) { kvm->last_boosted_vcpu = i; break; } else if (yielded < 0) { try--; if (!try) break; } } } kvm_vcpu_set_in_spin_loop(me, false); /* Ensure vcpu is not eligible during next spinloop */ kvm_vcpu_set_dy_eligible(me, false); }

Contributors

PersonTokensPropCommitsCommitProp
rik van rielrik van riel11353.30%218.18%
raghavendra k t* (same as raghavendra koushik)raghavendra k t* (same as raghavendra koushik)7133.49%436.36%
edwin zhaiedwin zhai157.08%19.09%
michael muellermichael mueller62.83%19.09%
sheng yangsheng yang52.36%19.09%
marcelo tosattimarcelo tosatti10.47%19.09%
konstantin weitzkonstantin weitz10.47%19.09%
Total212100.00%11100.00%

EXPORT_SYMBOL_GPL(kvm_vcpu_on_spin);
static int kvm_vcpu_fault(struct vm_area_struct *vma, struct vm_fault *vmf) { struct kvm_vcpu *vcpu = vma->vm_file->private_data; struct page *page; if (vmf->pgoff == 0) page = virt_to_page(vcpu->run); #ifdef CONFIG_X86 else if (vmf->pgoff == KVM_PIO_PAGE_OFFSET) page = virt_to_page(vcpu->arch.pio_data); #endif #ifdef KVM_COALESCED_MMIO_PAGE_OFFSET else if (vmf->pgoff == KVM_COALESCED_MMIO_PAGE_OFFSET) page = virt_to_page(vcpu->kvm->coalesced_mmio_ring); #endif else return kvm_arch_vcpu_fault(vcpu, vmf); get_page(page); vmf->page = page; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity6150.00%327.27%
sheng yangsheng yang3831.15%19.09%
carsten ottecarsten otte119.02%327.27%
gleb natapovgleb natapov54.10%218.18%
rusty russellrusty russell43.28%19.09%
al viroal viro32.46%19.09%
Total122100.00%11100.00%

static const struct vm_operations_struct kvm_vcpu_vm_ops = { .fault = kvm_vcpu_fault, };
static int kvm_vcpu_mmap(struct file *file, struct vm_area_struct *vma) { vma->vm_ops = &kvm_vcpu_vm_ops; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity2076.92%250.00%
gleb natapovgleb natapov415.38%125.00%
carsten ottecarsten otte27.69%125.00%
Total26100.00%4100.00%


static int kvm_vcpu_release(struct inode *inode, struct file *filp) { struct kvm_vcpu *vcpu = filp->private_data; kvm_put_kvm(vcpu->kvm); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3291.43%583.33%
carsten ottecarsten otte38.57%116.67%
Total35100.00%6100.00%

static struct file_operations kvm_vcpu_fops = { .release = kvm_vcpu_release, .unlocked_ioctl = kvm_vcpu_ioctl, #ifdef CONFIG_KVM_COMPAT .compat_ioctl = kvm_vcpu_compat_ioctl, #endif .mmap = kvm_vcpu_mmap, .llseek = noop_llseek, }; /* * Allocates an inode for the vcpu. */
static int create_vcpu_fd(struct kvm_vcpu *vcpu) { return anon_inode_getfd("kvm-vcpu", &kvm_vcpu_fops, vcpu, O_RDWR | O_CLOEXEC); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity2388.46%571.43%
yann droneaudyann droneaud27.69%114.29%
roland dreierroland dreier13.85%114.29%
Total26100.00%7100.00%

/* * Creates some virtual cpus. Good luck creating more than one. */
static int kvm_vm_ioctl_create_vcpu(struct kvm *kvm, u32 id) { int r; struct kvm_vcpu *vcpu; if (id >= KVM_MAX_VCPU_ID) return -EINVAL; vcpu = kvm_arch_vcpu_create(kvm, id); if (IS_ERR(vcpu)) return PTR_ERR(vcpu); preempt_notifier_init(&vcpu->preempt_notifier, &kvm_preempt_ops); r = kvm_arch_vcpu_setup(vcpu); if (r) goto vcpu_destroy; mutex_lock(&kvm->lock); if (!kvm_vcpu_compatible(vcpu)) { r = -EINVAL; goto unlock_vcpu_destroy; } if (atomic_read(&kvm->online_vcpus) == KVM_MAX_VCPUS) { r = -EINVAL; goto unlock_vcpu_destroy; } if (kvm_get_vcpu_by_id(kvm, id)) { r = -EEXIST; goto unlock_vcpu_destroy; } BUG_ON(kvm->vcpus[atomic_read(&kvm->online_vcpus)]); /* Now it's all set up, let userspace reach it */ kvm_get_kvm(kvm); r = create_vcpu_fd(vcpu); if (r < 0) { kvm_put_kvm(kvm); goto unlock_vcpu_destroy; } kvm->vcpus[atomic_read(&kvm->online_vcpus)] = vcpu; /* * Pairs with smp_rmb() in kvm_get_vcpu. Write kvm->vcpus * before kvm->online_vcpu's incremented value. */ smp_wmb(); atomic_inc(&kvm->online_vcpus); mutex_unlock(&kvm->lock); kvm_arch_vcpu_postcreate(vcpu); return r; unlock_vcpu_destroy: mutex_unlock(&kvm->lock); vcpu_destroy: kvm_arch_vcpu_destroy(vcpu); return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity13452.76%637.50%
sheng yangsheng yang5521.65%16.25%
xiantao zhangxiantao zhang218.27%16.25%
dave hansendave hansen135.12%16.25%
andy honigandy honig93.54%16.25%
jan kiszkajan kiszka93.54%16.25%
marcelo tosattimarcelo tosatti51.97%16.25%
david hildenbranddavid hildenbrand51.97%16.25%
paolo bonzinipaolo bonzini10.39%16.25%
carsten ottecarsten otte10.39%16.25%
greg kurzgreg kurz10.39%16.25%
Total254100.00%16100.00%


static int kvm_vcpu_ioctl_set_sigmask(struct kvm_vcpu *vcpu, sigset_t *sigset) { if (sigset) { sigdelsetmask(sigset, sigmask(SIGKILL)|sigmask(SIGSTOP)); vcpu->sigset_active = 1; vcpu->sigset = *sigset; } else vcpu->sigset_active = 0; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3152.54%240.00%
sheng yangsheng yang1932.20%120.00%
dave hansendave hansen58.47%120.00%
marcelo tosattimarcelo tosatti46.78%120.00%
Total59100.00%5100.00%


static long kvm_vcpu_ioctl(struct file *filp, unsigned int ioctl, unsigned long arg) { struct kvm_vcpu *vcpu = filp->private_data; void __user *argp = (void __user *)arg; int r; struct kvm_fpu *fpu = NULL; struct kvm_sregs *kvm_sregs = NULL; if (vcpu->kvm->mm != current->mm) return -EIO; if (unlikely(_IOC_TYPE(ioctl) != KVMIO)) return -EINVAL; #if defined(CONFIG_S390) || defined(CONFIG_PPC) || defined(CONFIG_MIPS) /* * Special cases: vcpu ioctls that are asynchronous to vcpu execution, * so vcpu_load() would break it. */ if (ioctl == KVM_S390_INTERRUPT || ioctl == KVM_S390_IRQ || ioctl == KVM_INTERRUPT) return kvm_arch_vcpu_ioctl(filp, ioctl, arg); #endif r = vcpu_load(vcpu); if (r) return r; switch (ioctl) { case KVM_RUN: r = -EINVAL; if (arg) goto out; if (unlikely(vcpu->pid != current->pids[PIDTYPE_PID].pid)) { /* The thread running this VCPU changed. */ struct pid *oldpid = vcpu->pid; struct pid *newpid = get_task_pid(current, PIDTYPE_PID); rcu_assign_pointer(vcpu->pid, newpid); if (oldpid) synchronize_rcu(); put_pid(oldpid); } r = kvm_arch_vcpu_ioctl_run(vcpu, vcpu->run); trace_kvm_userspace_exit(vcpu->run->exit_reason, r); break; case KVM_GET_REGS: { struct kvm_regs *kvm_regs; r = -ENOMEM; kvm_regs = kzalloc(sizeof(struct kvm_regs), GFP_KERNEL); if (!kvm_regs) goto out; r = kvm_arch_vcpu_ioctl_get_regs(vcpu, kvm_regs); if (r) goto out_free1; r = -EFAULT; if (copy_to_user(argp, kvm_regs, sizeof(struct kvm_regs))) goto out_free1; r = 0; out_free1: kfree(kvm_regs); break; } case KVM_SET_REGS: { struct kvm_regs *kvm_regs; r = -ENOMEM; kvm_regs = memdup_user(argp, sizeof(*kvm_regs)); if (IS_ERR(kvm_regs)) { r = PTR_ERR(kvm_regs); goto out; } r = kvm_arch_vcpu_ioctl_set_regs(vcpu, kvm_regs); kfree(kvm_regs); break; } case KVM_GET_SREGS: { kvm_sregs = kzalloc(sizeof(struct kvm_sregs), GFP_KERNEL); r = -ENOMEM; if (!kvm_sregs) goto out; r = kvm_arch_vcpu_ioctl_get_sregs(vcpu, kvm_sregs); if (r) goto out; r = -EFAULT; if (copy_to_user(argp, kvm_sregs, sizeof(struct kvm_sregs))) goto out; r = 0; break; } case KVM_SET_SREGS: { kvm_sregs = memdup_user(argp, sizeof(*kvm_sregs)); if (IS_ERR(kvm_sregs)) { r = PTR_ERR(kvm_sregs); kvm_sregs = NULL; goto out; } r = kvm_arch_vcpu_ioctl_set_sregs(vcpu, kvm_sregs); break; } case KVM_GET_MP_STATE: { struct kvm_mp_state mp_state; r = kvm_arch_vcpu_ioctl_get_mpstate(vcpu, &mp_state); if (r) goto out; r = -EFAULT; if (copy_to_user(argp, &mp_state, sizeof(mp_state))) goto out; r = 0; break; } case KVM_SET_MP_STATE: { struct kvm_mp_state mp_state; r = -EFAULT; if (copy_from_user(&mp_state, argp, sizeof(mp_state))) goto out; r = kvm_arch_vcpu_ioctl_set_mpstate(vcpu, &mp_state); break; } case KVM_TRANSLATE: { struct kvm_translation tr; r = -EFAULT; if (copy_from_user(&tr, argp, sizeof(tr))) goto out; r = kvm_arch_vcpu_ioctl_translate(vcpu, &tr); if (r) goto out; r = -EFAULT; if (copy_to_user(argp, &tr, sizeof(tr))) goto out; r = 0; break; } case KVM_SET_GUEST_DEBUG: { struct kvm_guest_debug dbg; r = -EFAULT; if (copy_from_user(&dbg, argp, sizeof(dbg))) goto out; r = kvm_arch_vcpu_ioctl_set_guest_debug(vcpu, &dbg); break; } case KVM_SET_SIGNAL_MASK: { struct kvm_signal_mask __user *sigmask_arg = argp; struct kvm_signal_mask kvm_sigmask; sigset_t sigset, *p; p = NULL; if (argp) { r = -EFAULT; if (copy_from_user(&kvm_sigmask, argp, sizeof(kvm_sigmask))) goto out; r = -EINVAL; if (kvm_sigmask.len != sizeof(sigset)) goto out; r = -EFAULT; if (copy_from_user(&sigset, sigmask_arg->sigset, sizeof(sigset))) goto out; p = &sigset; } r = kvm_vcpu_ioctl_set_sigmask(vcpu, p); break; } case KVM_GET_FPU: { fpu = kzalloc(sizeof(struct kvm_fpu), GFP_KERNEL); r = -ENOMEM; if (!fpu) goto out; r = kvm_arch_vcpu_ioctl_get_fpu(vcpu, fpu); if (r) goto out; r = -EFAULT; if (copy_to_user(argp, fpu, sizeof(struct kvm_fpu))) goto out; r = 0; break; } case KVM_SET_FPU: { fpu = memdup_user(argp, sizeof(*fpu)); if (IS_ERR(fpu)) { r = PTR_ERR(fpu); fpu = NULL; goto out; } r = kvm_arch_vcpu_ioctl_set_fpu(vcpu, fpu); break; } default: r = kvm_arch_vcpu_ioctl(filp, ioctl, arg); } out: vcpu_put(vcpu); kfree(fpu); kfree(kvm_sregs); return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity28728.19%1028.57%
carsten ottecarsten otte1009.82%12.86%
laurent vivierlaurent vivier979.53%12.86%
qing heqing he929.04%12.86%
xiantao zhangxiantao zhang767.47%25.71%
christian borntraegerchristian borntraeger636.19%12.86%
marcelo tosattimarcelo tosatti555.40%12.86%
dave hansendave hansen525.11%12.86%
eddie dongeddie dong474.62%38.57%
sasha levinsasha levin353.44%12.86%
sheng yangsheng yang181.77%12.86%
david matlackdavid matlack161.57%12.86%
xiubo lixiubo li161.57%12.86%
al viroal viro121.18%12.86%
gleb natapovgleb natapov111.08%12.86%
michael s. tsirkinmichael s. tsirkin90.88%12.86%
izik eidusizik eidus90.88%25.71%
guo chaoguo chao80.79%12.86%
sanjay lalsanjay lal50.49%12.86%
hollis blanchardhollis blanchard50.49%12.86%
jens freimannjens freimann40.39%12.86%
andi kleenandi kleen10.10%12.86%
Total1018100.00%35100.00%

#ifdef CONFIG_KVM_COMPAT
static long kvm_vcpu_compat_ioctl(struct file *filp, unsigned int ioctl, unsigned long arg) { struct kvm_vcpu *vcpu = filp->private_data; void __user *argp = compat_ptr(arg); int r; if (vcpu->kvm->mm != current->mm) return -EIO; switch (ioctl) { case KVM_SET_SIGNAL_MASK: { struct kvm_signal_mask __user *sigmask_arg = argp; struct kvm_signal_mask kvm_sigmask; compat_sigset_t csigset; sigset_t sigset; if (argp) { r = -EFAULT; if (copy_from_user(&kvm_sigmask, argp, sizeof(kvm_sigmask))) goto out; r = -EINVAL; if (kvm_sigmask.len != sizeof(csigset)) goto out; r = -EFAULT; if (copy_from_user(&csigset, sigmask_arg->sigset, sizeof(csigset))) goto out; sigset_from_compat(&sigset, &csigset); r = kvm_vcpu_ioctl_set_sigmask(vcpu, &sigset); } else r = kvm_vcpu_ioctl_set_sigmask(vcpu, NULL); break; } default: r = kvm_vcpu_ioctl(filp, ioctl, arg); } out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
alexander grafalexander graf18991.75%133.33%
alan coxalan cox115.34%133.33%
xiubo lixiubo li62.91%133.33%
Total206100.00%3100.00%

#endif
static int kvm_device_ioctl_attr(struct kvm_device *dev, int (*accessor)(struct kvm_device *dev, struct kvm_device_attr *attr), unsigned long arg) { struct kvm_device_attr attr; if (!accessor) return -EPERM; if (copy_from_user(&attr, (void __user *)arg, sizeof(attr))) return -EFAULT; return accessor(dev, &attr); }

Contributors

PersonTokensPropCommitsCommitProp
scott woodscott wood5469.23%125.00%
avi kivityavi kivity2126.92%125.00%
xiantao zhangxiantao zhang22.56%125.00%
sheng yangsheng yang11.28%125.00%
Total78100.00%4100.00%


static long kvm_device_ioctl(struct file *filp, unsigned int ioctl, unsigned long arg) { struct kvm_device *dev = filp->private_data; switch (ioctl) { case KVM_SET_DEVICE_ATTR: return kvm_device_ioctl_attr(dev, dev->ops->set_attr, arg); case KVM_GET_DEVICE_ATTR: return kvm_device_ioctl_attr(dev, dev->ops->get_attr, arg); case KVM_HAS_DEVICE_ATTR: return kvm_device_ioctl_attr(dev, dev->ops->has_attr, arg); default: if (dev->ops->ioctl) return dev->ops->ioctl(dev, ioctl, arg); return -ENOTTY; } }

Contributors

PersonTokensPropCommitsCommitProp
scott woodscott wood9584.82%125.00%
avi kivityavi kivity87.14%125.00%
weidong hanweidong han65.36%125.00%
sheng yangsheng yang32.68%125.00%
Total112100.00%4100.00%


static int kvm_device_release(struct inode *inode, struct file *filp) { struct kvm_device *dev = filp->private_data; struct kvm *kvm = dev->kvm; kvm_put_kvm(kvm); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
scott woodscott wood42100.00%1100.00%
Total42100.00%1100.00%

static const struct file_operations kvm_device_fops = { .unlocked_ioctl = kvm_device_ioctl, #ifdef CONFIG_KVM_COMPAT .compat_ioctl = kvm_device_ioctl, #endif .release = kvm_device_release, };
struct kvm_device *kvm_device_from_filp(struct file *filp) { if (filp->f_op != &kvm_device_fops) return NULL; return filp->private_data; }

Contributors

PersonTokensPropCommitsCommitProp
scott woodscott wood29100.00%1100.00%
Total29100.00%1100.00%

static struct kvm_device_ops *kvm_device_ops_table[KVM_DEV_TYPE_MAX] = { #ifdef CONFIG_KVM_MPIC [KVM_DEV_TYPE_FSL_MPIC_20] = &kvm_mpic_ops, [KVM_DEV_TYPE_FSL_MPIC_42] = &kvm_mpic_ops, #endif #ifdef CONFIG_KVM_XICS [KVM_DEV_TYPE_XICS] = &kvm_xics_ops, #endif };
int kvm_register_device_ops(struct kvm_device_ops *ops, u32 type) { if (type >= ARRAY_SIZE(kvm_device_ops_table)) return -ENOSPC; if (kvm_device_ops_table[type] != NULL) return -EEXIST; kvm_device_ops_table[type] = ops; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
will deaconwill deacon4591.84%150.00%
scott woodscott wood48.16%150.00%
Total49100.00%2100.00%


void kvm_unregister_device_ops(u32 type) { if (kvm_device_ops_table[type] != NULL) kvm_device_ops_table[type] = NULL; }

Contributors

PersonTokensPropCommitsCommitProp
wanpeng liwanpeng li24100.00%1100.00%
Total24100.00%1100.00%


static int kvm_ioctl_create_device(struct kvm *kvm, struct kvm_create_device *cd) { struct kvm_device_ops *ops = NULL; struct kvm_device *dev; bool test = cd->flags & KVM_CREATE_DEVICE_TEST; int ret; if (cd->type >= ARRAY_SIZE(kvm_device_ops_table)) return -ENODEV; ops = kvm_device_ops_table[cd->type]; if (ops == NULL) return -ENODEV; if (test) return 0; dev = kzalloc(sizeof(*dev), GFP_KERNEL); if (!dev) return -ENOMEM; dev->ops = ops; dev->kvm = kvm; ret = ops->create(dev, cd->type); if (ret < 0) { kfree(dev); return ret; } ret = anon_inode_getfd(ops->name, &kvm_device_fops, dev, O_RDWR | O_CLOEXEC); if (ret < 0) { ops->destroy(dev); return ret; } list_add(&dev->vm_node, &kvm->devices); kvm_get_kvm(kvm); cd->fd = ret; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
scott woodscott wood18086.96%233.33%
will deaconwill deacon2110.14%116.67%
christoffer dallchristoffer dall31.45%116.67%
yann droneaudyann droneaud20.97%116.67%
jens freimannjens freimann10.48%116.67%
Total207100.00%6100.00%


static long kvm_vm_ioctl_check_extension_generic(struct kvm *kvm, long arg) { switch (arg) { case KVM_CAP_USER_MEMORY: case KVM_CAP_DESTROY_MEMORY_REGION_WORKS: case KVM_CAP_JOIN_MEMORY_REGIONS_WORKS: case KVM_CAP_INTERNAL_ERROR_DATA: #ifdef CONFIG_HAVE_KVM_MSI case KVM_CAP_SIGNAL_MSI: #endif #ifdef CONFIG_HAVE_KVM_IRQFD case KVM_CAP_IRQFD: case KVM_CAP_IRQFD_RESAMPLE: #endif case KVM_CAP_IOEVENTFD_ANY_LENGTH: case KVM_CAP_CHECK_EXTENSION_VM: return 1; #ifdef CONFIG_HAVE_KVM_IRQ_ROUTING case KVM_CAP_IRQ_ROUTING: return KVM_MAX_IRQ_ROUTES; #endif #if KVM_ADDRESS_SPACE_NUM > 1 case KVM_CAP_MULTI_ADDRESS_SPACE: return KVM_ADDRESS_SPACE_NUM; #endif case KVM_CAP_MAX_VCPU_ID: return KVM_MAX_VCPU_ID; default: break; } return kvm_vm_ioctl_check_extension(kvm, arg); }

Contributors

PersonTokensPropCommitsCommitProp
alexander grafalexander graf7474.00%116.67%
paolo bonzinipaolo bonzini1616.00%233.33%
greg kurzgreg kurz66.00%116.67%
jason wangjason wang33.00%116.67%
paul mackerraspaul mackerras11.00%116.67%
Total100100.00%6100.00%


static long kvm_vm_ioctl(struct file *filp, unsigned int ioctl, unsigned long arg) { struct kvm *kvm = filp->private_data; void __user *argp = (void __user *)arg; int r; if (kvm->mm != current->mm) return -EIO; switch (ioctl) { case KVM_CREATE_VCPU: r = kvm_vm_ioctl_create_vcpu(kvm, arg); break; case KVM_SET_USER_MEMORY_REGION: { struct kvm_userspace_memory_region kvm_userspace_mem; r = -EFAULT; if (copy_from_user(&kvm_userspace_mem, argp, sizeof(kvm_userspace_mem))) goto out; r = kvm_vm_ioctl_set_memory_region(kvm, &kvm_userspace_mem); break; } case KVM_GET_DIRTY_LOG: { struct kvm_dirty_log log; r = -EFAULT; if (copy_from_user(&log, argp, sizeof(log))) goto out; r = kvm_vm_ioctl_get_dirty_log(kvm, &log); break; } #ifdef KVM_COALESCED_MMIO_PAGE_OFFSET case KVM_REGISTER_COALESCED_MMIO: { struct kvm_coalesced_mmio_zone zone; r = -EFAULT; if (copy_from_user(&zone, argp, sizeof(zone))) goto out; r = kvm_vm_ioctl_register_coalesced_mmio(kvm, &zone); break; } case KVM_UNREGISTER_COALESCED_MMIO: { struct kvm_coalesced_mmio_zone zone; r = -EFAULT; if (copy_from_user(&zone, argp, sizeof(zone))) goto out; r = kvm_vm_ioctl_unregister_coalesced_mmio(kvm, &zone); break; } #endif case KVM_IRQFD: { struct kvm_irqfd data; r = -EFAULT; if (copy_from_user(&data, argp, sizeof(data))) goto out; r = kvm_irqfd(kvm, &data); break; } case KVM_IOEVENTFD: { struct kvm_ioeventfd data; r = -EFAULT; if (copy_from_user(&data, argp, sizeof(data))) goto out; r = kvm_ioeventfd(kvm, &data); break; } #ifdef CONFIG_HAVE_KVM_MSI case KVM_SIGNAL_MSI: { struct kvm_msi msi; r = -EFAULT; if (copy_from_user(&msi, argp, sizeof(msi))) goto out; r = kvm_send_userspace_msi(kvm, &msi); break; } #endif #ifdef __KVM_HAVE_IRQ_LINE case KVM_IRQ_LINE_STATUS: case KVM_IRQ_LINE: { struct kvm_irq_level irq_event; r = -EFAULT; if (copy_from_user(&irq_event, argp, sizeof(irq_event))) goto out; r = kvm_vm_ioctl_irq_line(kvm, &irq_event, ioctl == KVM_IRQ_LINE_STATUS); if (r) goto out; r = -EFAULT; if (ioctl == KVM_IRQ_LINE_STATUS) { if (copy_to_user(argp, &irq_event, sizeof(irq_event))) goto out; } r = 0; break; } #endif #ifdef CONFIG_HAVE_KVM_IRQ_ROUTING case KVM_SET_GSI_ROUTING: { struct kvm_irq_routing routing; struct kvm_irq_routing __user *urouting; struct kvm_irq_routing_entry *entries = NULL; r = -EFAULT; if (copy_from_user(&routing, argp, sizeof(routing))) goto out; r = -EINVAL; if (routing.nr > KVM_MAX_IRQ_ROUTES) goto out; if (routing.flags) goto out; if (routing.nr) { r = -ENOMEM; entries = vmalloc(routing.nr * sizeof(*entries)); if (!entries) goto out; r = -EFAULT; urouting = argp; if (copy_from_user(entries, urouting->entries, routing.nr * sizeof(*entries))) goto out_free_irq_routing; } r = kvm_set_irq_routing(kvm, entries, routing.nr, routing.flags); out_free_irq_routing: vfree(entries); break; } #endif /* CONFIG_HAVE_KVM_IRQ_ROUTING */ case KVM_CREATE_DEVICE: { struct kvm_create_device cd; r = -EFAULT; if (copy_from_user(&cd, argp, sizeof(cd))) goto out; r = kvm_ioctl_create_device(kvm, &cd); if (r) goto out; r = -EFAULT; if (copy_to_user(argp, &cd, sizeof(cd))) goto out; r = 0; break; } case KVM_CHECK_EXTENSION: r = kvm_vm_ioctl_check_extension_generic(kvm, arg); break; default: r = kvm_arch_vm_ioctl(filp, ioctl, arg); } out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
christoffer dallchristoffer dall13918.27%14.55%
avi kivityavi kivity12716.69%313.64%
gregory haskinsgregory haskins12115.90%29.09%
alexander grafalexander graf10714.06%29.09%
sheng yangsheng yang8110.64%29.09%
jan kiszkajan kiszka719.33%14.55%
weidong hanweidong han374.86%14.55%
xiubo lixiubo li192.50%29.09%
scott woodscott wood131.71%14.55%
carsten ottecarsten otte111.45%14.55%
paolo bonzinipaolo bonzini101.31%14.55%
gleb natapovgleb natapov101.31%14.55%
xiantao zhangxiantao zhang60.79%14.55%
marcelo tosattimarcelo tosatti40.53%14.55%
yang zhangyang zhang40.53%14.55%
alex williamsonalex williamson10.13%14.55%
Total761100.00%22100.00%

#ifdef CONFIG_KVM_COMPAT struct compat_kvm_dirty_log { __u32 slot; __u32 padding1; union { compat_uptr_t dirty_bitmap; /* one bit per page */ __u64 padding2; }; };
static long kvm_vm_compat_ioctl(struct file *filp, unsigned int ioctl, unsigned long arg) { struct kvm *kvm = filp->private_data; int r; if (kvm->mm != current->mm) return -EIO; switch (ioctl) { case KVM_GET_DIRTY_LOG: { struct compat_kvm_dirty_log compat_log; struct kvm_dirty_log log; r = -EFAULT; if (copy_from_user(&compat_log, (void __user *)arg, sizeof(compat_log))) goto out; log.slot = compat_log.slot; log.padding1 = compat_log.padding1; log.padding2 = compat_log.padding2; log.dirty_bitmap = compat_ptr(compat_log.dirty_bitmap); r = kvm_vm_ioctl_get_dirty_log(kvm, &log); break; } default: r = kvm_vm_ioctl(filp, ioctl, arg); } out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
arnd bergmannarnd bergmann12882.58%116.67%
carsten ottecarsten otte106.45%116.67%
avi kivityavi kivity85.16%116.67%
marcelo tosattimarcelo tosatti42.58%116.67%
gleb natapovgleb natapov31.94%116.67%
gregory haskinsgregory haskins21.29%116.67%
Total155100.00%6100.00%

#endif static struct file_operations kvm_vm_fops = { .release = kvm_vm_release, .unlocked_ioctl = kvm_vm_ioctl, #ifdef CONFIG_KVM_COMPAT .compat_ioctl = kvm_vm_compat_ioctl, #endif .llseek = noop_llseek, };
static int kvm_dev_ioctl_create_vm(unsigned long type) { int r; struct kvm *kvm; kvm = kvm_create_vm(type); if (IS_ERR(kvm)) return PTR_ERR(kvm); #ifdef KVM_COALESCED_MMIO_PAGE_OFFSET r = kvm_coalesced_mmio_init(kvm); if (r < 0) { kvm_put_kvm(kvm); return r; } #endif r = anon_inode_getfd("kvm-vm", &kvm_vm_fops, kvm, O_RDWR | O_CLOEXEC); if (r < 0) { kvm_put_kvm(kvm); return r; } if (kvm_create_vm_debugfs(kvm, r) < 0) { kvm_put_kvm(kvm); return -ENOMEM; } return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity5141.46%218.18%
takuya yoshikawatakuya yoshikawa2923.58%19.09%
janosch frankjanosch frank2721.95%19.09%
carsten ottecarsten otte64.88%19.09%
al viroal viro32.44%218.18%
heiko carstensheiko carstens32.44%19.09%
yann droneaudyann droneaud21.63%19.09%
roland dreierroland dreier10.81%19.09%
ulrich drepperulrich drepper10.81%19.09%
Total123100.00%11100.00%


static long kvm_dev_ioctl(struct file *filp, unsigned int ioctl, unsigned long arg) { long r = -EINVAL; switch (ioctl) { case KVM_GET_API_VERSION: if (arg) goto out; r = KVM_API_VERSION; break; case KVM_CREATE_VM: r = kvm_dev_ioctl_create_vm(arg); break; case KVM_CHECK_EXTENSION: r = kvm_vm_ioctl_check_extension_generic(NULL, arg); break; case KVM_GET_VCPU_MMAP_SIZE: if (arg) goto out; r = PAGE_SIZE; /* struct kvm_run */ #ifdef CONFIG_X86 r += PAGE_SIZE; /* pio data page */ #endif #ifdef KVM_COALESCED_MMIO_PAGE_OFFSET r += PAGE_SIZE; /* coalesced mmio ring page */ #endif break; case KVM_TRACE_ENABLE: case KVM_TRACE_PAUSE: case KVM_TRACE_DISABLE: r = -EOPNOTSUPP; break; default: return kvm_arch_dev_ioctl(filp, ioctl, arg); } out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity9166.42%538.46%
feng (eric) liufeng (eric) liu139.49%17.69%
carsten ottecarsten otte139.49%215.38%
laurent vivierlaurent vivier107.30%17.69%
xiantao zhangxiantao zhang42.92%17.69%
alexander grafalexander graf32.19%17.69%
marcelo tosattimarcelo tosatti21.46%17.69%
christian borntraegerchristian borntraeger10.73%17.69%
Total137100.00%13100.00%

static struct file_operations kvm_chardev_ops = { .unlocked_ioctl = kvm_dev_ioctl, .compat_ioctl = kvm_dev_ioctl, .llseek = noop_llseek, }; static struct miscdevice kvm_dev = { KVM_MINOR, "kvm", &kvm_chardev_ops, };
static void hardware_enable_nolock(void *junk) { int cpu = raw_smp_processor_id(); int r; if (cpumask_test_cpu(cpu, cpus_hardware_enabled)) return; cpumask_set_cpu(cpu, cpus_hardware_enabled); r = kvm_arch_hardware_enable(); if (r) { cpumask_clear_cpu(cpu, cpus_hardware_enabled); atomic_inc(&hardware_enable_failed); pr_info("kvm: enabling virtualization on CPU%d failed\n", cpu); } }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3146.27%114.29%
alexander grafalexander graf2943.28%114.29%
xiubo lixiubo li22.99%114.29%
rusty russellrusty russell22.99%114.29%
takuya yoshikawatakuya yoshikawa11.49%114.29%
xiantao zhangxiantao zhang11.49%114.29%
radim krcmarradim krcmar11.49%114.29%
Total67100.00%7100.00%


static void hardware_enable(void) { raw_spin_lock(&kvm_count_lock); if (kvm_usage_count) hardware_enable_nolock(NULL); raw_spin_unlock(&kvm_count_lock); }

Contributors

PersonTokensPropCommitsCommitProp
takuya yoshikawatakuya yoshikawa1862.07%120.00%
paolo bonzinipaolo bonzini724.14%240.00%
avi kivityavi kivity26.90%120.00%
jan kiszkajan kiszka26.90%120.00%
Total29100.00%5100.00%


static void hardware_disable_nolock(void *junk) { int cpu = raw_smp_processor_id(); if (!cpumask_test_cpu(cpu, cpus_hardware_enabled)) return; cpumask_clear_cpu(cpu, cpus_hardware_enabled); kvm_arch_hardware_disable(); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3081.08%120.00%
takuya yoshikawatakuya yoshikawa38.11%120.00%
rusty russellrusty russell25.41%120.00%
xiantao zhangxiantao zhang12.70%120.00%
radim krcmarradim krcmar12.70%120.00%
Total37100.00%5100.00%


static void hardware_disable(void) { raw_spin_lock(&kvm_count_lock); if (kvm_usage_count) hardware_disable_nolock(NULL); raw_spin_unlock(&kvm_count_lock); }

Contributors

PersonTokensPropCommitsCommitProp
takuya yoshikawatakuya yoshikawa2068.97%125.00%
paolo bonzinipaolo bonzini724.14%250.00%
jan kiszkajan kiszka26.90%125.00%
Total29100.00%4100.00%


static void hardware_disable_all_nolock(void) { BUG_ON(!kvm_usage_count); kvm_usage_count--; if (!kvm_usage_count) on_each_cpu(hardware_disable_nolock, NULL, 1); }

Contributors

PersonTokensPropCommitsCommitProp
alexander grafalexander graf3096.77%150.00%
takuya yoshikawatakuya yoshikawa13.23%150.00%
Total31100.00%2100.00%


static void hardware_disable_all(void) { raw_spin_lock(&kvm_count_lock); hardware_disable_all_nolock(); raw_spin_unlock(&kvm_count_lock); }

Contributors

PersonTokensPropCommitsCommitProp
alexander grafalexander graf1982.61%133.33%
paolo bonzinipaolo bonzini28.70%133.33%
jan kiszkajan kiszka28.70%133.33%
Total23100.00%3100.00%


static int hardware_enable_all(void) { int r = 0; raw_spin_lock(&kvm_count_lock); kvm_usage_count++; if (kvm_usage_count == 1) { atomic_set(&hardware_enable_failed, 0); on_each_cpu(hardware_enable_nolock, NULL, 1); if (atomic_read(&hardware_enable_failed)) { hardware_disable_all_nolock(); r = -EBUSY; } } raw_spin_unlock(&kvm_count_lock); return r; }

Contributors

PersonTokensPropCommitsCommitProp
alexander grafalexander graf6993.24%125.00%
jan kiszkajan kiszka22.70%125.00%
paolo bonzinipaolo bonzini22.70%125.00%
takuya yoshikawatakuya yoshikawa11.35%125.00%
Total74100.00%4100.00%


static int kvm_cpu_hotplug(struct notifier_block *notifier, unsigned long val, void *v) { val &= ~CPU_TASKS_FROZEN; switch (val) { case CPU_DYING: hardware_disable(); break; case CPU_STARTING: hardware_enable(); break; } return NOTIFY_OK; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity4391.49%457.14%
paolo bonzinipaolo bonzini24.26%114.29%
rafael j. wysockirafael j. wysocki12.13%114.29%
zachary amsdenzachary amsden12.13%114.29%
Total47100.00%7100.00%


static int kvm_reboot(struct notifier_block *notifier, unsigned long val, void *v) { /* * Some (well, at least mine) BIOSes hang on reboot if * in vmx root mode. * * And Intel TXT required VMX off for all cpu when system shutdown. */ pr_info("kvm: exiting hardware virtualization\n"); kvm_rebooting = true; on_each_cpu(hardware_disable_nolock, NULL, 1); return NOTIFY_OK; }

Contributors

PersonTokensPropCommitsCommitProp
rusty russellrusty russell3482.93%120.00%
avi kivityavi kivity49.76%120.00%
xiubo lixiubo li12.44%120.00%
sheng yangsheng yang12.44%120.00%
takuya yoshikawatakuya yoshikawa12.44%120.00%
Total41100.00%5100.00%

static struct notifier_block kvm_reboot_notifier = { .notifier_call = kvm_reboot, .priority = 0, };
static void kvm_io_bus_destroy(struct kvm_io_bus *bus) { int i; for (i = 0; i < bus->dev_count; i++) { struct kvm_io_device *pos = bus->range[i].dev; kvm_iodevice_destructor(pos); } kfree(bus); }

Contributors

PersonTokensPropCommitsCommitProp
gregory haskinsgregory haskins4683.64%133.33%
marcelo tosattimarcelo tosatti610.91%133.33%
sasha levinsasha levin35.45%133.33%
Total55100.00%3100.00%


static inline int kvm_io_bus_cmp(const struct kvm_io_range *r1, const struct kvm_io_range *r2) { gpa_t addr1 = r1->addr; gpa_t addr2 = r2->addr; if (addr1 < addr2) return -1; /* If r2->len == 0, match the exact address. If r2->len != 0, * accept any overlapping write. Any order is acceptable for * overlapping ranges, because kvm_io_bus_get_first_dev ensures * we process all of them. */ if (r2->len) { addr1 += r1->len; addr2 += r2->len; } if (addr1 > addr2) return 1; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
sasha levinsasha levin4052.63%120.00%
jason wangjason wang3039.47%120.00%
paolo bonzinipaolo bonzini56.58%240.00%
geoff levandgeoff levand11.32%120.00%
Total76100.00%5100.00%


static int kvm_io_bus_sort_cmp(const void *p1, const void *p2) { return kvm_io_bus_cmp(p1, p2); }

Contributors

PersonTokensPropCommitsCommitProp
paolo bonzinipaolo bonzini24100.00%2100.00%
Total24100.00%2100.00%


static int kvm_io_bus_insert_dev(struct kvm_io_bus *bus, struct kvm_io_device *dev, gpa_t addr, int len) { bus->range[bus->dev_count++] = (struct kvm_io_range) { .addr = addr, .len = len, .dev = dev, }; sort(bus->range, bus->dev_count, sizeof(struct kvm_io_range), kvm_io_bus_sort_cmp, NULL); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
sasha levinsasha levin7698.70%150.00%
geoff levandgeoff levand11.30%150.00%
Total77100.00%2100.00%


static int kvm_io_bus_get_first_dev(struct kvm_io_bus *bus, gpa_t addr, int len) { struct kvm_io_range *range, key; int off; key = (struct kvm_io_range) { .addr = addr, .len = len, }; range = bsearch(&key, bus->range, bus->dev_count, sizeof(struct kvm_io_range), kvm_io_bus_sort_cmp); if (range == NULL) return -ENOENT; off = range - bus->range; while (off > 0 && kvm_io_bus_cmp(&key, &bus->range[off-1]) == 0) off--; return off; }

Contributors

PersonTokensPropCommitsCommitProp
sasha levinsasha levin11598.29%133.33%
paolo bonzinipaolo bonzini10.85%133.33%
geoff levandgeoff levand10.85%133.33%
Total117100.00%3100.00%


static int __kvm_io_bus_write(struct kvm_vcpu *vcpu, struct kvm_io_bus *bus, struct kvm_io_range *range, const void *val) { int idx; idx = kvm_io_bus_get_first_dev(bus, range->addr, range->len); if (idx < 0) return -EOPNOTSUPP; while (idx < bus->dev_count && kvm_io_bus_cmp(range, &bus->range[idx]) == 0) { if (!kvm_iodevice_write(vcpu, bus->range[idx].dev, range->addr, range->len, val)) return idx; idx++; } return -EOPNOTSUPP; }

Contributors

PersonTokensPropCommitsCommitProp
cornelia huckcornelia huck10893.10%133.33%
nikolay nikolaevnikolay nikolaev76.03%133.33%
paolo bonzinipaolo bonzini10.86%133.33%
Total116100.00%3100.00%

/* kvm_io_bus_write - called under kvm->slots_lock */
int kvm_io_bus_write(struct kvm_vcpu *vcpu, enum kvm_bus bus_idx, gpa_t addr, int len, const void *val) { struct kvm_io_bus *bus; struct kvm_io_range range; int r; range = (struct kvm_io_range) { .addr = addr, .len = len, }; bus = srcu_dereference(vcpu->kvm->buses[bus_idx], &vcpu->kvm->srcu); r = __kvm_io_bus_write(vcpu, bus, &range, val); return r < 0 ? r : 0; }

Contributors

PersonTokensPropCommitsCommitProp
cornelia huckcornelia huck6767.68%116.67%
gregory haskinsgregory haskins1010.10%116.67%
nikolay nikolaevnikolay nikolaev88.08%116.67%
michael s. tsirkinmichael s. tsirkin66.06%116.67%
laurent vivierlaurent vivier44.04%116.67%
marcelo tosattimarcelo tosatti44.04%116.67%
Total99100.00%6100.00%

/* kvm_io_bus_write_cookie - called under kvm->slots_lock */
int kvm_io_bus_write_cookie(struct kvm_vcpu *vcpu, enum kvm_bus bus_idx, gpa_t addr, int len, const void *val, long cookie) { struct kvm_io_bus *bus; struct kvm_io_range range; range = (struct kvm_io_range) { .addr = addr, .len = len, }; bus = srcu_dereference(vcpu->kvm->buses[bus_idx], &vcpu->kvm->srcu); /* First try the device referenced by cookie. */ if ((cookie >= 0) && (cookie < bus->dev_count) && (kvm_io_bus_cmp(&range, &bus->range[cookie]) == 0)) if (!kvm_iodevice_write(vcpu, bus->range[cookie].dev, addr, len, val)) return cookie; /* * cookie contained garbage; fall back to search and return the * correct cookie value. */ return __kvm_io_bus_write(vcpu, bus, &range, val); }

Contributors

PersonTokensPropCommitsCommitProp
cornelia huckcornelia huck9663.58%116.67%
sasha levinsasha levin2214.57%116.67%
marcelo tosattimarcelo tosatti127.95%116.67%
lai jiangshanlai jiangshan106.62%116.67%
nikolay nikolaevnikolay nikolaev106.62%116.67%
paolo bonzinipaolo bonzini10.66%116.67%
Total151100.00%6100.00%


static int __kvm_io_bus_read(struct kvm_vcpu *vcpu, struct kvm_io_bus *bus, struct kvm_io_range *range, void *val) { int idx; idx = kvm_io_bus_get_first_dev(bus, range->addr, range->len); if (idx < 0) return -EOPNOTSUPP; while (idx < bus->dev_count && kvm_io_bus_cmp(range, &bus->range[idx]) == 0) { if (!kvm_iodevice_read(vcpu, bus->range[idx].dev, range->addr, range->len, val)) return idx; idx++; } return -EOPNOTSUPP; }

Contributors

PersonTokensPropCommitsCommitProp
sasha levinsasha levin4640.00%116.67%
cornelia huckcornelia huck3227.83%116.67%
michael s. tsirkinmichael s. tsirkin1916.52%116.67%
gregory haskinsgregory haskins108.70%116.67%
nikolay nikolaevnikolay nikolaev76.09%116.67%
paolo bonzinipaolo bonzini10.87%116.67%
Total115100.00%6100.00%

EXPORT_SYMBOL_GPL(kvm_io_bus_write); /* kvm_io_bus_read - called under kvm->slots_lock */
int kvm_io_bus_read(struct kvm_vcpu *vcpu, enum kvm_bus bus_idx, gpa_t addr, int len, void *val) { struct kvm_io_bus *bus; struct kvm_io_range range; int r; range = (struct kvm_io_range) { .addr = addr, .len = len, }; bus = srcu_dereference(vcpu->kvm->buses[bus_idx], &vcpu->kvm->srcu); r = __kvm_io_bus_read(vcpu, bus, &range, val); return r < 0 ? r : 0; }

Contributors

PersonTokensPropCommitsCommitProp
sasha levinsasha levin3030.61%116.67%
michael s. tsirkinmichael s. tsirkin1919.39%116.67%
marcelo tosattimarcelo tosatti1616.33%116.67%
cornelia huckcornelia huck1515.31%116.67%
lai jiangshanlai jiangshan1010.20%116.67%
nikolay nikolaevnikolay nikolaev88.16%116.67%
Total98100.00%6100.00%

/* Caller must hold slots_lock. */
int kvm_io_bus_register_dev(struct kvm *kvm, enum kvm_bus bus_idx, gpa_t addr, int len, struct kvm_io_device *dev) { struct kvm_io_bus *new_bus, *bus; bus = kvm->buses[bus_idx]; /* exclude ioeventfd which is limited by maximum fd */ if (bus->dev_count - bus->ioeventfd_count > NR_IOBUS_DEVS - 1) return -ENOSPC; new_bus = kmalloc(sizeof(*bus) + ((bus->dev_count + 1) * sizeof(struct kvm_io_range)), GFP_KERNEL); if (!new_bus) return -ENOMEM; memcpy(new_bus, bus, sizeof(*bus) + (bus->dev_count * sizeof(struct kvm_io_range))); kvm_io_bus_insert_dev(new_bus, dev, addr, len); rcu_assign_pointer(kvm->buses[bus_idx], new_bus); synchronize_srcu_expedited(&kvm->srcu); kfree(bus); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
marcelo tosattimarcelo tosatti6137.42%111.11%
amos kongamos kong4628.22%222.22%
gregory haskinsgregory haskins2515.34%222.22%
michael s. tsirkinmichael s. tsirkin159.20%111.11%
sasha levinsasha levin148.59%111.11%
thomas meyerthomas meyer10.61%111.11%
jason wangjason wang10.61%111.11%
Total163100.00%9100.00%

/* Caller must hold slots_lock. */
int kvm_io_bus_unregister_dev(struct kvm *kvm, enum kvm_bus bus_idx, struct kvm_io_device *dev) { int i, r; struct kvm_io_bus *new_bus, *bus; bus = kvm->buses[bus_idx]; r = -ENOENT; for (i = 0; i < bus->dev_count; i++) if (bus->range[i].dev == dev) { r = 0; break; } if (r) return r; new_bus = kmalloc(sizeof(*bus) + ((bus->dev_count - 1) * sizeof(struct kvm_io_range)), GFP_KERNEL); if (!new_bus) return -ENOMEM; memcpy(new_bus, bus, sizeof(*bus) + i * sizeof(struct kvm_io_range)); new_bus->dev_count--; memcpy(new_bus->range + i, bus->range + i + 1, (new_bus->dev_count - i) * sizeof(struct kvm_io_range)); rcu_assign_pointer(kvm->buses[bus_idx], new_bus); synchronize_srcu_expedited(&kvm->srcu); kfree(bus); return r; }

Contributors

PersonTokensPropCommitsCommitProp
amos kongamos kong8037.91%114.29%
marcelo tosattimarcelo tosatti5927.96%114.29%
gregory haskinsgregory haskins4320.38%228.57%
sasha levinsasha levin2813.27%228.57%
jason wangjason wang10.47%114.29%
Total211100.00%7100.00%

static struct notifier_block kvm_cpu_notifier = { .notifier_call = kvm_cpu_hotplug, };
static int kvm_debugfs_open(struct inode *inode, struct file *file, int (*get)(void *, u64 *), int (*set)(void *, u64), const char *fmt) { struct kvm_stat_data *stat_data = (struct kvm_stat_data *) inode->i_private; /* The debugfs files are a reference to the kvm struct which * is still valid when kvm_destroy_vm is called. * To avoid the race between open and the removal of the debugfs * directory we test against the users count. */ if (!atomic_add_unless(&stat_data->kvm->users_count, 1, 0)) return -ENOENT; if (simple_attr_open(inode, file, get, set, fmt)) { kvm_put_kvm(stat_data->kvm); return -ENOMEM; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank8575.22%125.00%
avi kivityavi kivity2320.35%250.00%
christoph hellwigchristoph hellwig54.42%125.00%
Total113100.00%4100.00%


static int kvm_debugfs_release(struct inode *inode, struct file *file) { struct kvm_stat_data *stat_data = (struct kvm_stat_data *) inode->i_private; simple_attr_release(inode, file); kvm_put_kvm(stat_data->kvm); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank4391.49%150.00%
avi kivityavi kivity48.51%150.00%
Total47100.00%2100.00%


static int vm_stat_get_per_vm(void *data, u64 *val) { struct kvm_stat_data *stat_data = (struct kvm_stat_data *)data; *val = *(u32 *)((void *)stat_data->kvm + stat_data->offset); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity2447.06%250.00%
janosch frankjanosch frank1937.25%125.00%
christoph hellwigchristoph hellwig815.69%125.00%
Total51100.00%4100.00%


static int vm_stat_get_per_vm_open(struct inode *inode, struct file *file) { __simple_attr_check_format("%llu\n", 0ull); return kvm_debugfs_open(inode, file, vm_stat_get_per_vm, NULL, "%llu\n"); }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank37100.00%1100.00%
Total37100.00%1100.00%

static const struct file_operations vm_stat_get_per_vm_fops = { .owner = THIS_MODULE, .open = vm_stat_get_per_vm_open, .release = kvm_debugfs_release, .read = simple_attr_read, .write = simple_attr_write, .llseek = generic_file_llseek, };
static int vcpu_stat_get_per_vm(void *data, u64 *val) { int i; struct kvm_stat_data *stat_data = (struct kvm_stat_data *)data; struct kvm_vcpu *vcpu; *val = 0; kvm_for_each_vcpu(i, vcpu, stat_data->kvm) *val += *(u32 *)((void *)vcpu + stat_data->offset); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank72100.00%1100.00%
Total72100.00%1100.00%


static int vcpu_stat_get_per_vm_open(struct inode *inode, struct file *file) { __simple_attr_check_format("%llu\n", 0ull); return kvm_debugfs_open(inode, file, vcpu_stat_get_per_vm, NULL, "%llu\n"); }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank37100.00%1100.00%
Total37100.00%1100.00%

static const struct file_operations vcpu_stat_get_per_vm_fops = { .owner = THIS_MODULE, .open = vcpu_stat_get_per_vm_open, .release = kvm_debugfs_release, .read = simple_attr_read, .write = simple_attr_write, .llseek = generic_file_llseek, }; static const struct file_operations *stat_fops_per_vm[] = { [KVM_STAT_VCPU] = &vcpu_stat_get_per_vm_fops, [KVM_STAT_VM] = &vm_stat_get_per_vm_fops, };
static int vm_stat_get(void *_offset, u64 *val) { unsigned offset = (long)_offset; struct kvm *kvm; struct kvm_stat_data stat_tmp = {.offset = offset}; u64 tmp_val; *val = 0; spin_lock(&kvm_lock); list_for_each_entry(kvm, &vm_list, vm_list) { stat_tmp.kvm = kvm; vm_stat_get_per_vm((void *)&stat_tmp, &tmp_val); *val += tmp_val; } spin_unlock(&kvm_lock); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank95100.00%1100.00%
Total95100.00%1100.00%

DEFINE_SIMPLE_ATTRIBUTE(vm_stat_fops, vm_stat_get, NULL, "%llu\n");
static int vcpu_stat_get(void *_offset, u64 *val) { unsigned offset = (long)_offset; struct kvm *kvm; struct kvm_stat_data stat_tmp = {.offset = offset}; u64 tmp_val; *val = 0; spin_lock(&kvm_lock); list_for_each_entry(kvm, &vm_list, vm_list) { stat_tmp.kvm = kvm; vcpu_stat_get_per_vm((void *)&stat_tmp, &tmp_val); *val += tmp_val; } spin_unlock(&kvm_lock); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
janosch frankjanosch frank9195.79%133.33%
avi kivityavi kivity33.16%133.33%
christoph hellwigchristoph hellwig11.05%133.33%
Total95100.00%3100.00%

DEFINE_SIMPLE_ATTRIBUTE(vcpu_stat_fops, vcpu_stat_get, NULL, "%llu\n"); static const struct file_operations *stat_fops[] = { [KVM_STAT_VCPU] = &vcpu_stat_fops, [KVM_STAT_VM] = &vm_stat_fops, };
static int kvm_init_debug(void) { int r = -EEXIST; struct kvm_stats_debugfs_item *p; kvm_debugfs_dir = debugfs_create_dir("kvm", NULL); if (kvm_debugfs_dir == NULL) goto out; kvm_debugfs_num_entries = 0; for (p = debugfs_entries; p->name; ++p, kvm_debugfs_num_entries++) { if (!debugfs_create_file(p->name, 0444, kvm_debugfs_dir, (void *)(long)p->offset, stat_fops[p->kind])) goto out_dir; } return 0; out_dir: debugfs_remove_recursive(kvm_debugfs_dir); out: return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity5954.13%333.33%
yang baiyang bai3633.03%111.11%
janosch frankjanosch frank109.17%222.22%
hollis blanchardhollis blanchard21.83%111.11%
paolo bonzinipaolo bonzini10.92%111.11%
al viroal viro10.92%111.11%
Total109100.00%9100.00%


static int kvm_suspend(void) { if (kvm_usage_count) hardware_disable_nolock(NULL); return 0; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity1470.00%350.00%
alexander grafalexander graf420.00%116.67%
takuya yoshikawatakuya yoshikawa15.00%116.67%
rafael j. wysockirafael j. wysocki15.00%116.67%
Total20100.00%6100.00%


static void kvm_resume(void) { if (kvm_usage_count) { WARN_ON(raw_spin_is_locked(&kvm_count_lock)); hardware_enable_nolock(NULL); } }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity1035.71%225.00%
zachary amsdenzachary amsden932.14%112.50%
alexander grafalexander graf414.29%112.50%
rafael j. wysockirafael j. wysocki27.14%112.50%
jan kiszkajan kiszka13.57%112.50%
takuya yoshikawatakuya yoshikawa13.57%112.50%
paolo bonzinipaolo bonzini13.57%112.50%
Total28100.00%8100.00%

static struct syscore_ops kvm_syscore_ops = { .suspend = kvm_suspend, .resume = kvm_resume, };
static inline struct kvm_vcpu *preempt_notifier_to_vcpu(struct preempt_notifier *pn) { return container_of(pn, struct kvm_vcpu, preempt_notifier); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity25100.00%1100.00%
Total25100.00%1100.00%


static void kvm_sched_in(struct preempt_notifier *pn, int cpu) { struct kvm_vcpu *vcpu = preempt_notifier_to_vcpu(pn); if (vcpu->preempted) vcpu->preempted = false; kvm_arch_sched_in(vcpu, cpu); kvm_arch_vcpu_load(vcpu, cpu); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3060.00%125.00%
raghavendra k t* (same as raghavendra koushik)raghavendra k t* (same as raghavendra koushik)1224.00%125.00%
radim krcmarradim krcmar714.00%125.00%
xiantao zhangxiantao zhang12.00%125.00%
Total50100.00%4100.00%


static void kvm_sched_out(struct preempt_notifier *pn, struct task_struct *next) { struct kvm_vcpu *vcpu = preempt_notifier_to_vcpu(pn); if (current->state == TASK_RUNNING) vcpu->preempted = true; kvm_arch_vcpu_put(vcpu); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3066.67%133.33%
raghavendra k t* (same as raghavendra koushik)raghavendra k t* (same as raghavendra koushik)1431.11%133.33%
xiantao zhangxiantao zhang12.22%133.33%
Total45100.00%3100.00%


int kvm_init(void *opaque, unsigned vcpu_size, unsigned vcpu_align, struct module *module) { int r; int cpu; r = kvm_arch_init(opaque); if (r) goto out_fail; /* * kvm_arch_init makes sure there's at most one caller * for architectures that support multiple implementations, * like intel and amd on x86. * kvm_arch_init must be called before kvm_irqfd_init to avoid creating * conflicts in case kvm is already setup for another implementation. */ r = kvm_irqfd_init(); if (r) goto out_irqfd; if (!zalloc_cpumask_var(&cpus_hardware_enabled, GFP_KERNEL)) { r = -ENOMEM; goto out_free_0; } r = kvm_arch_hardware_setup(); if (r < 0) goto out_free_0a; for_each_online_cpu(cpu) { smp_call_function_single(cpu, kvm_arch_check_processor_compat, &r, 1); if (r < 0) goto out_free_1; } r = register_cpu_notifier(&kvm_cpu_notifier); if (r) goto out_free_2; register_reboot_notifier(&kvm_reboot_notifier); /* A kmem cache lets us meet the alignment requirements of fx_save. */ if (!vcpu_align) vcpu_align = __alignof__(struct kvm_vcpu); kvm_vcpu_cache = kmem_cache_create("kvm_vcpu", vcpu_size, vcpu_align, 0, NULL); if (!kvm_vcpu_cache) { r = -ENOMEM; goto out_free_3; } r = kvm_async_pf_init(); if (r) goto out_free; kvm_chardev_ops.owner = module; kvm_vm_fops.owner = module; kvm_vcpu_fops.owner = module; r = misc_register(&kvm_dev); if (r) { pr_err("kvm: misc device register failed\n"); goto out_unreg; } register_syscore_ops(&kvm_syscore_ops); kvm_preempt_ops.sched_in = kvm_sched_in; kvm_preempt_ops.sched_out = kvm_sched_out; r = kvm_init_debug(); if (r) { pr_err("kvm: create debugfs files failed\n"); goto out_undebugfs; } r = kvm_vfio_ops_init(); WARN_ON(r); return 0; out_undebugfs: unregister_syscore_ops(&kvm_syscore_ops); misc_deregister(&kvm_dev); out_unreg: kvm_async_pf_deinit(); out_free: kmem_cache_destroy(kvm_vcpu_cache); out_free_3: unregister_reboot_notifier(&kvm_reboot_notifier); unregister_cpu_notifier(&kvm_cpu_notifier); out_free_2: out_free_1: kvm_arch_hardware_unsetup(); out_free_0a: free_cpumask_var(cpus_hardware_enabled); out_free_0: kvm_irqfd_exit(); out_irqfd: kvm_arch_exit(); out_fail: return r; }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity12736.18%829.63%
rusty russellrusty russell6418.23%27.41%
sheng yangsheng yang298.26%13.70%
xiantao zhangxiantao zhang236.55%414.81%
yang baiyang bai236.55%13.70%
gleb natapovgleb natapov185.13%13.70%
asias heasias he133.70%13.70%
christian borntraegerchristian borntraeger123.42%13.70%
cornelia huckcornelia huck123.42%13.70%
paolo bonzinipaolo bonzini102.85%13.70%
rafael j. wysockirafael j. wysocki71.99%13.70%
wei yongjunwei yongjun61.71%13.70%
darrick j. wongdarrick j. wong30.85%13.70%
xiubo lixiubo li20.57%13.70%
xiao guangrongxiao guangrong10.28%13.70%
joe perchesjoe perches10.28%13.70%
Total351100.00%27100.00%

EXPORT_SYMBOL_GPL(kvm_init);
void kvm_exit(void) { debugfs_remove_recursive(kvm_debugfs_dir); misc_deregister(&kvm_dev); kmem_cache_destroy(kvm_vcpu_cache); kvm_async_pf_deinit(); unregister_syscore_ops(&kvm_syscore_ops); unregister_reboot_notifier(&kvm_reboot_notifier); unregister_cpu_notifier(&kvm_cpu_notifier); on_each_cpu(hardware_disable_nolock, NULL, 1); kvm_arch_hardware_unsetup(); kvm_arch_exit(); kvm_irqfd_exit(); free_cpumask_var(cpus_hardware_enabled); kvm_vfio_ops_exit(); }

Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity3752.86%212.50%
rusty russellrusty russell1014.29%212.50%
janosch frankjanosch frank45.71%16.25%
xiantao zhangxiantao zhang45.71%318.75%
cornelia huckcornelia huck34.29%16.25%
gleb natapovgleb natapov34.29%16.25%
wanpeng liwanpeng li34.29%16.25%
rafael j. wysockirafael j. wysocki22.86%16.25%
yoshimi ichiyanagiyoshimi ichiyanagi11.43%16.25%
takuya yoshikawatakuya yoshikawa11.43%16.25%
darrick j. wongdarrick j. wong11.43%16.25%
al viroal viro11.43%16.25%
Total70100.00%16100.00%

EXPORT_SYMBOL_GPL(kvm_exit);

Overall Contributors

PersonTokensPropCommitsCommitProp
avi kivityavi kivity286317.11%5312.07%
paolo bonzinipaolo bonzini190711.39%337.52%
janosch frankjanosch frank9205.50%20.46%
xiao guangrongxiao guangrong9095.43%286.38%
marcelo tosattimarcelo tosatti8635.16%245.47%
gleb natapovgleb natapov7434.44%122.73%
alexander grafalexander graf6033.60%61.37%
sheng yangsheng yang6023.60%173.87%
scott woodscott wood5123.06%51.14%
sasha levinsasha levin4152.48%30.68%
takuya yoshikawatakuya yoshikawa4112.46%286.38%
xiantao zhangxiantao zhang4082.44%92.05%
izik eidusizik eidus3612.16%112.51%
cornelia huckcornelia huck3342.00%20.46%
christoffer dallchristoffer dall2721.63%61.37%
gregory haskinsgregory haskins2571.54%40.91%
mario smarduchmario smarduch2541.52%20.46%
carsten ottecarsten otte2431.45%51.14%
wanpeng liwanpeng li2401.43%51.14%
anthony liguorianthony liguori2121.27%40.91%
andy honigandy honig1831.09%20.46%
christian borntraegerchristian borntraeger1811.08%92.05%
arnd bergmannarnd bergmann1751.05%20.46%
raghavendra k t* (same as raghavendra koushik)raghavendra k t* (same as raghavendra koushik)1731.03%51.14%
igor mammedovigor mammedov1630.97%40.91%
rusty russellrusty russell1480.88%61.37%
jan kiszkajan kiszka1340.80%51.14%
amos kongamos kong1260.75%20.46%
rik van rielrik van riel1260.75%30.68%
laurent vivierlaurent vivier1160.69%20.46%
joerg roedeljoerg roedel1060.63%30.68%
andrea arcangeliandrea arcangeli1040.62%51.14%
qing heqing he970.58%20.46%
vladimir davydovvladimir davydov950.57%10.23%
weidong hanweidong han930.56%20.46%
michael s. tsirkinmichael s. tsirkin870.52%40.91%
will deaconwill deacon840.50%10.23%
konstantin weitzkonstantin weitz800.48%10.23%
dave hansendave hansen730.44%20.46%
huang yinghuang ying710.42%30.68%
yang baiyang bai590.35%10.23%
eddie dongeddie dong590.35%40.91%
alex williamsonalex williamson540.32%71.59%
david matlackdavid matlack500.30%30.68%
radim krcmarradim krcmar490.29%51.14%
xiubo lixiubo li480.29%40.91%
lai jiangshanlai jiangshan430.26%20.46%
nikolay nikolaevnikolay nikolaev400.24%10.23%
yang zhangyang zhang390.23%30.68%
mark mcloughlinmark mcloughlin380.23%30.68%
jason wangjason wang350.21%30.68%
heiko carstensheiko carstens340.20%30.68%
aneesh kumaraneesh kumar260.16%20.46%
stephen hemmingerstephen hemminger240.14%10.23%
al viroal viro230.14%40.91%
hollis blanchardhollis blanchard220.13%61.37%
dan williamsdan williams220.13%10.23%
paul mackerraspaul mackerras210.13%51.14%
ben-ami yassourben-ami yassour210.13%20.46%
edwin zhaiedwin zhai200.12%10.23%
rafael j. wysockirafael j. wysocki160.10%20.46%
feng wufeng wu150.09%10.23%
christoph hellwigchristoph hellwig140.08%10.23%
andres lagar-cavillaandres lagar-cavilla140.08%20.46%
mike waychisonmike waychison140.08%10.23%
feng (eric) liufeng (eric) liu130.08%10.23%
asias heasias he130.08%10.23%
alan coxalan cox110.07%10.23%
zachary amsdenzachary amsden110.07%20.46%
tang chentang chen100.06%20.46%
geliang tanggeliang tang100.06%10.23%
lan tianyulan tianyu80.05%20.46%
guo chaoguo chao80.05%10.23%
greg kurzgreg kurz70.04%10.23%
ard biesheuvelard biesheuvel70.04%10.23%
david hildenbranddavid hildenbrand70.04%20.46%
wei yongjunwei yongjun60.04%10.23%
uri lublinuri lublin60.04%20.46%
yann droneaudyann droneaud60.04%10.23%
michael muellermichael mueller60.04%10.23%
peter zijlstrapeter zijlstra60.04%10.23%
sanjay lalsanjay lal50.03%10.23%
jens freimannjens freimann50.03%20.46%
geoff levandgeoff levand40.02%10.23%
mike daymike day40.02%10.23%
darrick j. wongdarrick j. wong40.02%10.23%
wincy vanwincy van40.02%10.23%
dan carpenterdan carpenter30.02%10.23%
yaowei baiyaowei bai30.02%10.23%
tejun heotejun heo30.02%10.23%
alexey dobriyanalexey dobriyan30.02%20.46%
andrew mortonandrew morton20.01%10.23%
roland dreierroland dreier20.01%10.23%
andi kleenandi kleen20.01%20.46%
glauber costaglauber costa20.01%10.23%
ulrich drepperulrich drepper20.01%10.23%
joe perchesjoe perches10.01%10.23%
kai huangkai huang10.01%10.23%
kay sieverskay sievers10.01%10.23%
nick pigginnick piggin10.01%10.23%
nicolas kaisernicolas kaiser10.01%10.23%
dominik dingeldominik dingel10.01%10.23%
yoshimi ichiyanagiyoshimi ichiyanagi10.01%10.23%
andre przywaraandre przywara10.01%10.23%
thomas meyerthomas meyer10.01%10.23%
Total16736100.00%439100.00%
Directory: virt/kvm
Information contained on this website is for historical information purposes only and does not indicate or represent copyright ownership.
{% endraw %}