2020-03-04 02:12:22 +00:00
|
|
|
// Copyright (c) 2020 Ant Financial
|
|
|
|
//
|
|
|
|
// Licensed under the Apache License, Version 2.0 (the "License");
|
|
|
|
// you may not use this file except in compliance with the License.
|
|
|
|
// You may obtain a copy of the License at
|
|
|
|
//
|
|
|
|
// http://www.apache.org/licenses/LICENSE-2.0
|
|
|
|
//
|
|
|
|
// Unless required by applicable law or agreed to in writing, software
|
|
|
|
// distributed under the License is distributed on an "AS IS" BASIS,
|
|
|
|
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
|
|
|
// See the License for the specific language governing permissions and
|
|
|
|
// limitations under the License.
|
|
|
|
|
|
|
|
use super::Error as DeviceError;
|
|
|
|
use super::{
|
2020-08-04 11:16:44 +00:00
|
|
|
ActivateError, ActivateResult, DescriptorChain, EpollHelper, EpollHelperError,
|
2020-09-03 09:37:36 +00:00
|
|
|
EpollHelperHandler, Queue, VirtioCommon, VirtioDevice, VirtioDeviceType,
|
|
|
|
EPOLL_HELPER_EVENT_LAST, VIRTIO_F_VERSION_1,
|
2020-03-04 02:12:22 +00:00
|
|
|
};
|
2020-08-04 11:16:44 +00:00
|
|
|
|
2020-08-18 01:48:52 +00:00
|
|
|
use crate::seccomp_filters::{get_seccomp_filter, Thread};
|
2020-03-04 02:12:22 +00:00
|
|
|
use crate::{VirtioInterrupt, VirtioInterruptType};
|
2021-02-02 10:35:38 +00:00
|
|
|
use anyhow::anyhow;
|
2020-03-04 02:12:22 +00:00
|
|
|
use libc::EFD_NONBLOCK;
|
2020-08-18 01:48:52 +00:00
|
|
|
use seccomp::{SeccompAction, SeccompFilter};
|
2020-07-16 09:34:51 +00:00
|
|
|
use std::io;
|
2020-03-04 02:12:22 +00:00
|
|
|
use std::mem::size_of;
|
2020-08-04 11:16:44 +00:00
|
|
|
use std::os::unix::io::{AsRawFd, RawFd};
|
2020-03-04 02:12:22 +00:00
|
|
|
use std::result;
|
|
|
|
use std::sync::atomic::{AtomicBool, AtomicU64, Ordering};
|
|
|
|
use std::sync::mpsc;
|
2020-08-11 14:05:06 +00:00
|
|
|
use std::sync::{Arc, Barrier, Mutex};
|
2020-03-04 02:12:22 +00:00
|
|
|
use std::thread;
|
|
|
|
use vm_memory::{
|
|
|
|
Address, ByteValued, Bytes, GuestAddress, GuestAddressSpace, GuestMemoryAtomic,
|
|
|
|
GuestMemoryError, GuestMemoryMmap, GuestMemoryRegion, GuestRegionMmap,
|
|
|
|
};
|
2019-05-01 16:59:51 +00:00
|
|
|
use vm_migration::{Migratable, MigratableError, Pausable, Snapshottable, Transportable};
|
2020-03-04 02:12:22 +00:00
|
|
|
use vmm_sys_util::eventfd::EventFd;
|
|
|
|
|
|
|
|
const QUEUE_SIZE: u16 = 128;
|
|
|
|
const QUEUE_SIZES: &[u16] = &[QUEUE_SIZE];
|
|
|
|
|
2020-09-14 09:36:31 +00:00
|
|
|
// 128MiB is the standard memory block size in Linux. A virtio-mem region must
|
|
|
|
// be aligned on this size, and the region size must be a multiple of it.
|
2021-02-02 10:35:38 +00:00
|
|
|
pub const VIRTIO_MEM_ALIGN_SIZE: u64 = 128 << 20;
|
2020-03-04 02:12:22 +00:00
|
|
|
// Use 2 MiB alignment so transparent hugepages can be used by KVM.
|
2021-02-02 10:35:38 +00:00
|
|
|
const VIRTIO_MEM_DEFAULT_BLOCK_SIZE: u64 = 2 << 20;
|
2020-03-04 02:12:22 +00:00
|
|
|
|
|
|
|
// Request processed successfully, applicable for
|
|
|
|
// - VIRTIO_MEM_REQ_PLUG
|
|
|
|
// - VIRTIO_MEM_REQ_UNPLUG
|
|
|
|
// - VIRTIO_MEM_REQ_UNPLUG_ALL
|
|
|
|
// - VIRTIO_MEM_REQ_STATE
|
|
|
|
const VIRTIO_MEM_RESP_ACK: u16 = 0;
|
|
|
|
|
|
|
|
// Request denied - e.g. trying to plug more than requested, applicable for
|
|
|
|
// - VIRTIO_MEM_REQ_PLUG
|
|
|
|
const VIRTIO_MEM_RESP_NACK: u16 = 1;
|
|
|
|
|
|
|
|
// Request cannot be processed right now, try again later, applicable for
|
|
|
|
// - VIRTIO_MEM_REQ_PLUG
|
|
|
|
// - VIRTIO_MEM_REQ_UNPLUG
|
|
|
|
// - VIRTIO_MEM_REQ_UNPLUG_ALL
|
2021-02-02 10:35:38 +00:00
|
|
|
#[allow(unused)]
|
|
|
|
const VIRTIO_MEM_RESP_BUSY: u16 = 2;
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2020-09-22 11:31:42 +00:00
|
|
|
// Error in request (e.g. addresses/alignment), applicable for
|
2020-03-04 02:12:22 +00:00
|
|
|
// - VIRTIO_MEM_REQ_PLUG
|
|
|
|
// - VIRTIO_MEM_REQ_UNPLUG
|
|
|
|
// - VIRTIO_MEM_REQ_STATE
|
|
|
|
const VIRTIO_MEM_RESP_ERROR: u16 = 3;
|
|
|
|
|
|
|
|
// State of memory blocks is "plugged"
|
|
|
|
const VIRTIO_MEM_STATE_PLUGGED: u16 = 0;
|
|
|
|
// State of memory blocks is "unplugged"
|
|
|
|
const VIRTIO_MEM_STATE_UNPLUGGED: u16 = 1;
|
|
|
|
// State of memory blocks is "mixed"
|
|
|
|
const VIRTIO_MEM_STATE_MIXED: u16 = 2;
|
|
|
|
|
|
|
|
// request to plug memory blocks
|
|
|
|
const VIRTIO_MEM_REQ_PLUG: u16 = 0;
|
|
|
|
// request to unplug memory blocks
|
|
|
|
const VIRTIO_MEM_REQ_UNPLUG: u16 = 1;
|
|
|
|
// request to unplug all blocks and shrink the usable size
|
|
|
|
const VIRTIO_MEM_REQ_UNPLUG_ALL: u16 = 2;
|
|
|
|
// request information about the plugged state of memory blocks
|
|
|
|
const VIRTIO_MEM_REQ_STATE: u16 = 3;
|
|
|
|
|
|
|
|
// Get resize event.
|
2020-08-04 11:16:44 +00:00
|
|
|
const RESIZE_EVENT: u16 = EPOLL_HELPER_EVENT_LAST + 1;
|
2020-03-04 02:12:22 +00:00
|
|
|
// New descriptors are pending on the virtio queue.
|
2020-08-04 11:16:44 +00:00
|
|
|
const QUEUE_AVAIL_EVENT: u16 = EPOLL_HELPER_EVENT_LAST + 2;
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2020-09-11 13:09:06 +00:00
|
|
|
// Virtio features
|
|
|
|
const VIRTIO_MEM_F_ACPI_PXM: u8 = 0;
|
|
|
|
|
2020-03-04 02:12:22 +00:00
|
|
|
#[derive(Debug)]
|
|
|
|
pub enum Error {
|
|
|
|
// Guest gave us bad memory addresses.
|
|
|
|
GuestMemory(GuestMemoryError),
|
|
|
|
// Guest gave us a write only descriptor that protocol says to read from.
|
|
|
|
UnexpectedWriteOnlyDescriptor,
|
|
|
|
// Guest gave us a read only descriptor that protocol says to write to.
|
|
|
|
UnexpectedReadOnlyDescriptor,
|
|
|
|
// Guest gave us too few descriptors in a descriptor chain.
|
|
|
|
DescriptorChainTooShort,
|
|
|
|
// Guest gave us a buffer that was too short to use.
|
|
|
|
BufferLengthTooSmall,
|
|
|
|
// Guest sent us invalid request.
|
|
|
|
InvalidRequest,
|
|
|
|
// Failed to EventFd write.
|
|
|
|
EventFdWriteFail(std::io::Error),
|
|
|
|
// Failed to EventFd try_clone.
|
|
|
|
EventFdTryCloneFail(std::io::Error),
|
|
|
|
// Failed to MpscRecv.
|
|
|
|
MpscRecvFail(mpsc::RecvError),
|
|
|
|
// Resize invalid argument
|
2021-02-02 10:35:38 +00:00
|
|
|
ResizeError(anyhow::Error),
|
2020-03-04 02:12:22 +00:00
|
|
|
// Fail to resize trigger
|
|
|
|
ResizeTriggerFail(DeviceError),
|
2021-02-02 10:35:38 +00:00
|
|
|
// Invalid configuration
|
|
|
|
ValidateError(anyhow::Error),
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
#[repr(C)]
|
|
|
|
#[derive(Copy, Clone, Debug, Default)]
|
|
|
|
struct VirtioMemReq {
|
|
|
|
req_type: u16,
|
|
|
|
padding: [u16; 3],
|
|
|
|
addr: u64,
|
|
|
|
nb_blocks: u16,
|
2021-02-02 10:35:38 +00:00
|
|
|
padding_1: [u16; 3],
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Safe because it only has data and has no implicit padding.
|
|
|
|
unsafe impl ByteValued for VirtioMemReq {}
|
|
|
|
|
|
|
|
#[repr(C)]
|
|
|
|
#[derive(Copy, Clone, Debug, Default)]
|
|
|
|
struct VirtioMemResp {
|
|
|
|
resp_type: u16,
|
|
|
|
padding: [u16; 3],
|
2021-02-02 10:35:38 +00:00
|
|
|
state: u16,
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Safe because it only has data and has no implicit padding.
|
|
|
|
unsafe impl ByteValued for VirtioMemResp {}
|
|
|
|
|
2020-10-07 10:20:30 +00:00
|
|
|
#[repr(C)]
|
2020-03-04 02:12:22 +00:00
|
|
|
#[derive(Copy, Clone, Debug, Default)]
|
|
|
|
struct VirtioMemConfig {
|
|
|
|
// Block size and alignment. Cannot change.
|
2020-06-12 07:19:34 +00:00
|
|
|
block_size: u64,
|
2020-03-04 02:12:22 +00:00
|
|
|
// Valid with VIRTIO_MEM_F_ACPI_PXM. Cannot change.
|
|
|
|
node_id: u16,
|
2020-06-12 07:19:34 +00:00
|
|
|
padding: [u8; 6],
|
2020-03-04 02:12:22 +00:00
|
|
|
// Start address of the memory region. Cannot change.
|
|
|
|
addr: u64,
|
|
|
|
// Region size (maximum). Cannot change.
|
|
|
|
region_size: u64,
|
|
|
|
// Currently usable region size. Can grow up to region_size. Can
|
|
|
|
// shrink due to VIRTIO_MEM_REQ_UNPLUG_ALL (in which case no config
|
|
|
|
// update will be sent).
|
|
|
|
usable_region_size: u64,
|
|
|
|
// Currently used size. Changes due to plug/unplug requests, but no
|
|
|
|
// config updates will be sent.
|
|
|
|
plugged_size: u64,
|
|
|
|
// Requested size. New plug requests cannot exceed it. Can change.
|
|
|
|
requested_size: u64,
|
|
|
|
}
|
|
|
|
|
|
|
|
// Safe because it only has data and has no implicit padding.
|
|
|
|
unsafe impl ByteValued for VirtioMemConfig {}
|
|
|
|
|
2021-02-02 10:35:38 +00:00
|
|
|
impl VirtioMemConfig {
|
|
|
|
fn validate(&self) -> result::Result<(), Error> {
|
|
|
|
if self.addr % self.block_size != 0 {
|
|
|
|
return Err(Error::ValidateError(anyhow!(
|
|
|
|
"addr 0x{:x} is not aligned on block_size 0x{:x}",
|
|
|
|
self.addr,
|
|
|
|
self.block_size
|
|
|
|
)));
|
|
|
|
}
|
|
|
|
if self.region_size % self.block_size != 0 {
|
|
|
|
return Err(Error::ValidateError(anyhow!(
|
|
|
|
"region_size 0x{:x} is not aligned on block_size 0x{:x}",
|
|
|
|
self.region_size,
|
|
|
|
self.block_size
|
|
|
|
)));
|
|
|
|
}
|
|
|
|
if self.usable_region_size % self.block_size != 0 {
|
|
|
|
return Err(Error::ValidateError(anyhow!(
|
|
|
|
"usable_region_size 0x{:x} is not aligned on block_size 0x{:x}",
|
|
|
|
self.usable_region_size,
|
|
|
|
self.block_size
|
|
|
|
)));
|
|
|
|
}
|
|
|
|
if self.plugged_size % self.block_size != 0 {
|
|
|
|
return Err(Error::ValidateError(anyhow!(
|
|
|
|
"plugged_size 0x{:x} is not aligned on block_size 0x{:x}",
|
|
|
|
self.plugged_size,
|
|
|
|
self.block_size
|
|
|
|
)));
|
|
|
|
}
|
|
|
|
if self.requested_size % self.block_size != 0 {
|
|
|
|
return Err(Error::ValidateError(anyhow!(
|
|
|
|
"requested_size 0x{:x} is not aligned on block_size 0x{:x}",
|
|
|
|
self.requested_size,
|
|
|
|
self.block_size
|
|
|
|
)));
|
|
|
|
}
|
|
|
|
|
|
|
|
Ok(())
|
2020-08-10 10:22:55 +00:00
|
|
|
}
|
|
|
|
|
2021-02-02 10:35:38 +00:00
|
|
|
fn resize(&mut self, size: u64) -> result::Result<(), Error> {
|
|
|
|
if self.requested_size == size {
|
|
|
|
return Err(Error::ResizeError(anyhow!(
|
|
|
|
"new size 0x{:x} and requested_size are identical",
|
|
|
|
size
|
|
|
|
)));
|
|
|
|
} else if size > self.region_size {
|
|
|
|
return Err(Error::ResizeError(anyhow!(
|
|
|
|
"new size 0x{:x} is bigger than region_size 0x{:x}",
|
|
|
|
size,
|
|
|
|
self.region_size
|
|
|
|
)));
|
|
|
|
} else if size % (self.block_size as u64) != 0 {
|
|
|
|
return Err(Error::ResizeError(anyhow!(
|
|
|
|
"new size 0x{:x} is not aligned on block_size 0x{:x}",
|
|
|
|
size,
|
|
|
|
self.block_size
|
|
|
|
)));
|
|
|
|
}
|
|
|
|
|
|
|
|
self.requested_size = size;
|
2020-08-10 10:22:55 +00:00
|
|
|
|
2021-02-02 10:35:38 +00:00
|
|
|
Ok(())
|
|
|
|
}
|
2020-08-10 10:22:55 +00:00
|
|
|
}
|
|
|
|
|
2020-03-04 02:12:22 +00:00
|
|
|
struct Request {
|
|
|
|
req: VirtioMemReq,
|
|
|
|
status_addr: GuestAddress,
|
|
|
|
}
|
|
|
|
|
|
|
|
impl Request {
|
|
|
|
fn parse(
|
|
|
|
avail_desc: &DescriptorChain,
|
|
|
|
mem: &GuestMemoryMmap,
|
|
|
|
) -> result::Result<Request, Error> {
|
|
|
|
// The head contains the request type which MUST be readable.
|
|
|
|
if avail_desc.is_write_only() {
|
|
|
|
return Err(Error::UnexpectedWriteOnlyDescriptor);
|
|
|
|
}
|
|
|
|
if avail_desc.len as usize != size_of::<VirtioMemReq>() {
|
|
|
|
return Err(Error::InvalidRequest);
|
|
|
|
}
|
|
|
|
let req: VirtioMemReq = mem.read_obj(avail_desc.addr).map_err(Error::GuestMemory)?;
|
|
|
|
|
|
|
|
let status_desc = avail_desc
|
|
|
|
.next_descriptor()
|
|
|
|
.ok_or(Error::DescriptorChainTooShort)?;
|
|
|
|
|
|
|
|
// The status MUST always be writable
|
|
|
|
if !status_desc.is_write_only() {
|
|
|
|
return Err(Error::UnexpectedReadOnlyDescriptor);
|
|
|
|
}
|
|
|
|
|
|
|
|
if (status_desc.len as usize) < size_of::<VirtioMemResp>() {
|
|
|
|
return Err(Error::BufferLengthTooSmall);
|
|
|
|
}
|
|
|
|
|
|
|
|
Ok(Request {
|
|
|
|
req,
|
|
|
|
status_addr: status_desc.addr,
|
|
|
|
})
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2021-02-02 15:17:35 +00:00
|
|
|
pub struct ResizeSender {
|
|
|
|
size: Arc<AtomicU64>,
|
|
|
|
tx: mpsc::Sender<Result<(), Error>>,
|
|
|
|
evt: EventFd,
|
|
|
|
}
|
|
|
|
|
|
|
|
impl ResizeSender {
|
|
|
|
fn size(&self) -> u64 {
|
|
|
|
self.size.load(Ordering::Acquire)
|
|
|
|
}
|
|
|
|
|
|
|
|
fn send(&self, r: Result<(), Error>) -> Result<(), mpsc::SendError<Result<(), Error>>> {
|
|
|
|
self.tx.send(r)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
impl Clone for ResizeSender {
|
|
|
|
fn clone(&self) -> Self {
|
|
|
|
ResizeSender {
|
|
|
|
size: self.size.clone(),
|
|
|
|
tx: self.tx.clone(),
|
|
|
|
evt: self
|
|
|
|
.evt
|
|
|
|
.try_clone()
|
|
|
|
.expect("Failed cloning EventFd from ResizeSender"),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2020-03-04 02:12:22 +00:00
|
|
|
pub struct Resize {
|
|
|
|
size: Arc<AtomicU64>,
|
|
|
|
tx: mpsc::Sender<Result<(), Error>>,
|
2021-02-02 15:17:35 +00:00
|
|
|
rx: mpsc::Receiver<Result<(), Error>>,
|
2020-03-04 02:12:22 +00:00
|
|
|
evt: EventFd,
|
|
|
|
}
|
|
|
|
|
|
|
|
impl Resize {
|
|
|
|
pub fn new() -> io::Result<Self> {
|
|
|
|
let (tx, rx) = mpsc::channel();
|
|
|
|
|
|
|
|
Ok(Resize {
|
|
|
|
size: Arc::new(AtomicU64::new(0)),
|
|
|
|
tx,
|
2021-02-02 15:17:35 +00:00
|
|
|
rx,
|
2020-03-04 02:12:22 +00:00
|
|
|
evt: EventFd::new(EFD_NONBLOCK)?,
|
|
|
|
})
|
|
|
|
}
|
|
|
|
|
2021-02-02 15:17:35 +00:00
|
|
|
pub fn new_resize_sender(&self) -> Result<ResizeSender, Error> {
|
|
|
|
Ok(ResizeSender {
|
2020-03-04 02:12:22 +00:00
|
|
|
size: self.size.clone(),
|
|
|
|
tx: self.tx.clone(),
|
|
|
|
evt: self.evt.try_clone().map_err(Error::EventFdTryCloneFail)?,
|
|
|
|
})
|
|
|
|
}
|
|
|
|
|
|
|
|
pub fn work(&self, size: u64) -> Result<(), Error> {
|
2021-02-02 15:17:35 +00:00
|
|
|
self.size.store(size, Ordering::Release);
|
|
|
|
self.evt.write(1).map_err(Error::EventFdWriteFail)?;
|
|
|
|
self.rx.recv().map_err(Error::MpscRecvFail)?
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
struct MemEpollHandler {
|
|
|
|
host_addr: u64,
|
|
|
|
host_fd: Option<RawFd>,
|
|
|
|
mem_state: Vec<bool>,
|
|
|
|
config: Arc<Mutex<VirtioMemConfig>>,
|
2021-02-02 15:17:35 +00:00
|
|
|
resize: ResizeSender,
|
2020-03-04 02:12:22 +00:00
|
|
|
queue: Queue,
|
|
|
|
mem: GuestMemoryAtomic<GuestMemoryMmap>,
|
|
|
|
interrupt_cb: Arc<dyn VirtioInterrupt>,
|
|
|
|
queue_evt: EventFd,
|
|
|
|
kill_evt: EventFd,
|
|
|
|
pause_evt: EventFd,
|
|
|
|
}
|
|
|
|
|
|
|
|
struct StateChangeRequest<'a> {
|
|
|
|
config: VirtioMemConfig,
|
|
|
|
addr: u64,
|
|
|
|
size: u64,
|
|
|
|
nb_blocks: u16,
|
|
|
|
mem_state: &'a mut Vec<bool>,
|
|
|
|
host_addr: u64,
|
|
|
|
host_fd: Option<RawFd>,
|
|
|
|
plug: bool,
|
|
|
|
}
|
|
|
|
|
|
|
|
impl MemEpollHandler {
|
|
|
|
fn virtio_mem_valid_range(config: &VirtioMemConfig, addr: u64, size: u64) -> bool {
|
|
|
|
// address properly aligned?
|
|
|
|
if addr % config.block_size as u64 != 0 {
|
|
|
|
return false;
|
|
|
|
}
|
|
|
|
|
|
|
|
// reasonable size
|
|
|
|
if addr + size <= addr || size == 0 {
|
|
|
|
return false;
|
|
|
|
}
|
|
|
|
|
|
|
|
// start address in usable range?
|
|
|
|
if addr < config.addr || addr >= config.addr + config.usable_region_size {
|
|
|
|
return false;
|
|
|
|
}
|
|
|
|
|
|
|
|
// end address in usable range?
|
|
|
|
if addr + size > config.addr + config.usable_region_size {
|
|
|
|
return false;
|
|
|
|
}
|
|
|
|
|
|
|
|
true
|
|
|
|
}
|
|
|
|
|
|
|
|
fn virtio_mem_check_bitmap(
|
|
|
|
bit_index: usize,
|
|
|
|
nb_blocks: u16,
|
|
|
|
mem_state: &[bool],
|
|
|
|
plug: bool,
|
|
|
|
) -> bool {
|
|
|
|
for state in mem_state.iter().skip(bit_index).take(nb_blocks as usize) {
|
|
|
|
if *state != plug {
|
|
|
|
return false;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
true
|
|
|
|
}
|
|
|
|
|
|
|
|
fn virtio_mem_set_bitmap(
|
|
|
|
bit_index: usize,
|
|
|
|
nb_blocks: u16,
|
|
|
|
mem_state: &mut Vec<bool>,
|
|
|
|
plug: bool,
|
|
|
|
) {
|
|
|
|
for state in mem_state
|
|
|
|
.iter_mut()
|
|
|
|
.skip(bit_index)
|
|
|
|
.take(nb_blocks as usize)
|
|
|
|
{
|
|
|
|
*state = plug;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
fn virtio_mem_state_change_request(r: StateChangeRequest) -> u16 {
|
|
|
|
if r.plug && (r.config.plugged_size + r.size > r.config.requested_size) {
|
|
|
|
return VIRTIO_MEM_RESP_NACK;
|
|
|
|
}
|
|
|
|
if !MemEpollHandler::virtio_mem_valid_range(&r.config, r.addr, r.size) {
|
|
|
|
return VIRTIO_MEM_RESP_ERROR;
|
|
|
|
}
|
|
|
|
|
|
|
|
let offset = r.addr - r.config.addr;
|
|
|
|
|
|
|
|
let bit_index = (offset / r.config.block_size as u64) as usize;
|
|
|
|
if !MemEpollHandler::virtio_mem_check_bitmap(bit_index, r.nb_blocks, r.mem_state, !r.plug) {
|
|
|
|
return VIRTIO_MEM_RESP_ERROR;
|
|
|
|
}
|
|
|
|
|
|
|
|
if !r.plug {
|
|
|
|
if let Some(fd) = r.host_fd {
|
|
|
|
let res = unsafe {
|
|
|
|
libc::fallocate64(
|
|
|
|
fd,
|
|
|
|
libc::FALLOC_FL_PUNCH_HOLE | libc::FALLOC_FL_KEEP_SIZE,
|
|
|
|
offset as libc::off64_t,
|
|
|
|
r.size as libc::off64_t,
|
|
|
|
)
|
|
|
|
};
|
|
|
|
if res != 0 {
|
|
|
|
error!("fallocate64 get error {}", io::Error::last_os_error());
|
|
|
|
return VIRTIO_MEM_RESP_ERROR;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
let res = unsafe {
|
|
|
|
libc::madvise(
|
|
|
|
(r.host_addr + offset) as *mut libc::c_void,
|
|
|
|
r.size as libc::size_t,
|
|
|
|
libc::MADV_DONTNEED,
|
|
|
|
)
|
|
|
|
};
|
|
|
|
if res != 0 {
|
|
|
|
error!("madvise get error {}", io::Error::last_os_error());
|
|
|
|
return VIRTIO_MEM_RESP_ERROR;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
MemEpollHandler::virtio_mem_set_bitmap(bit_index, r.nb_blocks, r.mem_state, r.plug);
|
|
|
|
|
|
|
|
VIRTIO_MEM_RESP_ACK
|
|
|
|
}
|
|
|
|
|
|
|
|
fn virtio_mem_unplug_all(
|
|
|
|
config: VirtioMemConfig,
|
|
|
|
mem_state: &mut Vec<bool>,
|
|
|
|
host_addr: u64,
|
|
|
|
host_fd: Option<RawFd>,
|
|
|
|
) -> u16 {
|
|
|
|
for x in 0..(config.region_size / config.block_size as u64) as usize {
|
|
|
|
if mem_state[x] {
|
|
|
|
let resp_type =
|
|
|
|
MemEpollHandler::virtio_mem_state_change_request(StateChangeRequest {
|
|
|
|
config,
|
|
|
|
addr: config.addr + x as u64 * config.block_size as u64,
|
|
|
|
size: config.block_size as u64,
|
|
|
|
nb_blocks: 1,
|
|
|
|
mem_state,
|
|
|
|
host_addr,
|
|
|
|
host_fd,
|
|
|
|
plug: false,
|
|
|
|
});
|
|
|
|
if resp_type != VIRTIO_MEM_RESP_ACK {
|
|
|
|
return resp_type;
|
|
|
|
}
|
|
|
|
mem_state[x] = false;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
VIRTIO_MEM_RESP_ACK
|
|
|
|
}
|
|
|
|
|
|
|
|
fn virtio_mem_state_request(
|
|
|
|
config: VirtioMemConfig,
|
|
|
|
addr: u64,
|
|
|
|
nb_blocks: u16,
|
|
|
|
mem_state: &mut Vec<bool>,
|
|
|
|
) -> (u16, u16) {
|
|
|
|
let size: u64 = nb_blocks as u64 * config.block_size as u64;
|
|
|
|
let resp_type = if MemEpollHandler::virtio_mem_valid_range(&config, addr, size) {
|
|
|
|
VIRTIO_MEM_RESP_ACK
|
|
|
|
} else {
|
|
|
|
VIRTIO_MEM_RESP_ERROR
|
|
|
|
};
|
|
|
|
|
|
|
|
let offset = addr - config.addr;
|
|
|
|
let bit_index = (offset / config.block_size as u64) as usize;
|
|
|
|
let resp_state =
|
|
|
|
if MemEpollHandler::virtio_mem_check_bitmap(bit_index, nb_blocks, mem_state, true) {
|
|
|
|
VIRTIO_MEM_STATE_PLUGGED
|
|
|
|
} else if MemEpollHandler::virtio_mem_check_bitmap(
|
|
|
|
bit_index, nb_blocks, mem_state, false,
|
|
|
|
) {
|
|
|
|
VIRTIO_MEM_STATE_UNPLUGGED
|
|
|
|
} else {
|
|
|
|
VIRTIO_MEM_STATE_MIXED
|
|
|
|
};
|
|
|
|
|
|
|
|
(resp_type, resp_state)
|
|
|
|
}
|
|
|
|
|
|
|
|
fn virtio_mem_send_response(
|
|
|
|
mem: &GuestMemoryMmap,
|
|
|
|
resp_type: u16,
|
2021-01-02 20:37:05 +00:00
|
|
|
state: u16,
|
2020-03-04 02:12:22 +00:00
|
|
|
status_addr: GuestAddress,
|
|
|
|
) -> u32 {
|
2021-01-02 20:37:05 +00:00
|
|
|
let resp = VirtioMemResp {
|
|
|
|
resp_type,
|
2021-02-02 10:35:38 +00:00
|
|
|
state,
|
2021-01-02 20:37:05 +00:00
|
|
|
..Default::default()
|
|
|
|
};
|
2020-03-04 02:12:22 +00:00
|
|
|
match mem.write_obj(resp, status_addr) {
|
|
|
|
Ok(_) => size_of::<VirtioMemResp>() as u32,
|
|
|
|
Err(e) => {
|
|
|
|
error!("bad guest memory address: {}", e);
|
|
|
|
0
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
fn signal(&self, int_type: &VirtioInterruptType) -> result::Result<(), DeviceError> {
|
|
|
|
self.interrupt_cb
|
|
|
|
.trigger(int_type, Some(&self.queue))
|
|
|
|
.map_err(|e| {
|
|
|
|
error!("Failed to signal used queue: {:?}", e);
|
|
|
|
DeviceError::FailedSignalingUsedQueue(e)
|
|
|
|
})
|
|
|
|
}
|
|
|
|
|
|
|
|
fn process_queue(&mut self) -> bool {
|
|
|
|
let mut used_desc_heads = [(0, 0); QUEUE_SIZE as usize];
|
|
|
|
let mut used_count = 0;
|
|
|
|
let mem = self.mem.memory();
|
|
|
|
for avail_desc in self.queue.iter(&mem) {
|
|
|
|
let len = match Request::parse(&avail_desc, &mem) {
|
|
|
|
Err(e) => {
|
|
|
|
error!("failed parse VirtioMemReq: {:?}", e);
|
|
|
|
0
|
|
|
|
}
|
|
|
|
Ok(r) => {
|
|
|
|
let mut config = self.config.lock().unwrap();
|
|
|
|
match r.req.req_type {
|
|
|
|
VIRTIO_MEM_REQ_PLUG => {
|
|
|
|
let size: u64 = r.req.nb_blocks as u64 * config.block_size as u64;
|
|
|
|
let resp_type = MemEpollHandler::virtio_mem_state_change_request(
|
|
|
|
StateChangeRequest {
|
|
|
|
config: *config,
|
|
|
|
addr: r.req.addr,
|
|
|
|
size,
|
|
|
|
nb_blocks: r.req.nb_blocks,
|
|
|
|
mem_state: &mut self.mem_state,
|
|
|
|
host_addr: self.host_addr,
|
|
|
|
host_fd: self.host_fd,
|
|
|
|
plug: true,
|
|
|
|
},
|
|
|
|
);
|
|
|
|
if resp_type == VIRTIO_MEM_RESP_ACK {
|
|
|
|
config.plugged_size += size;
|
|
|
|
}
|
|
|
|
MemEpollHandler::virtio_mem_send_response(
|
|
|
|
&mem,
|
|
|
|
resp_type,
|
|
|
|
0u16,
|
|
|
|
r.status_addr,
|
|
|
|
)
|
|
|
|
}
|
|
|
|
VIRTIO_MEM_REQ_UNPLUG => {
|
|
|
|
let size: u64 = r.req.nb_blocks as u64 * config.block_size as u64;
|
|
|
|
let resp_type = MemEpollHandler::virtio_mem_state_change_request(
|
|
|
|
StateChangeRequest {
|
|
|
|
config: *config,
|
|
|
|
addr: r.req.addr,
|
|
|
|
size,
|
|
|
|
nb_blocks: r.req.nb_blocks,
|
|
|
|
mem_state: &mut self.mem_state,
|
|
|
|
host_addr: self.host_addr,
|
|
|
|
host_fd: self.host_fd,
|
|
|
|
plug: false,
|
|
|
|
},
|
|
|
|
);
|
|
|
|
if resp_type == VIRTIO_MEM_RESP_ACK {
|
|
|
|
config.plugged_size -= size;
|
|
|
|
}
|
|
|
|
MemEpollHandler::virtio_mem_send_response(
|
|
|
|
&mem,
|
|
|
|
resp_type,
|
|
|
|
0u16,
|
|
|
|
r.status_addr,
|
|
|
|
)
|
|
|
|
}
|
|
|
|
VIRTIO_MEM_REQ_UNPLUG_ALL => {
|
|
|
|
let resp_type = MemEpollHandler::virtio_mem_unplug_all(
|
|
|
|
*config,
|
|
|
|
&mut self.mem_state,
|
|
|
|
self.host_addr,
|
|
|
|
self.host_fd,
|
|
|
|
);
|
|
|
|
if resp_type == VIRTIO_MEM_RESP_ACK {
|
|
|
|
config.plugged_size = 0;
|
|
|
|
}
|
|
|
|
MemEpollHandler::virtio_mem_send_response(
|
|
|
|
&mem,
|
|
|
|
resp_type,
|
|
|
|
0u16,
|
|
|
|
r.status_addr,
|
|
|
|
)
|
|
|
|
}
|
|
|
|
VIRTIO_MEM_REQ_STATE => {
|
|
|
|
let (resp_type, resp_state) = MemEpollHandler::virtio_mem_state_request(
|
|
|
|
*config,
|
|
|
|
r.req.addr,
|
|
|
|
r.req.nb_blocks,
|
|
|
|
&mut self.mem_state,
|
|
|
|
);
|
|
|
|
MemEpollHandler::virtio_mem_send_response(
|
|
|
|
&mem,
|
|
|
|
resp_type,
|
|
|
|
resp_state,
|
|
|
|
r.status_addr,
|
|
|
|
)
|
|
|
|
}
|
|
|
|
_ => {
|
|
|
|
error!("VirtioMemReq unknown request type {:?}", r.req.req_type);
|
|
|
|
0
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
};
|
|
|
|
used_desc_heads[used_count] = (avail_desc.index, len);
|
|
|
|
used_count += 1;
|
|
|
|
}
|
|
|
|
|
|
|
|
for &(desc_index, len) in &used_desc_heads[..used_count] {
|
|
|
|
self.queue.add_used(&mem, desc_index, len);
|
|
|
|
}
|
|
|
|
used_count > 0
|
|
|
|
}
|
|
|
|
|
2020-08-11 14:05:06 +00:00
|
|
|
fn run(
|
|
|
|
&mut self,
|
|
|
|
paused: Arc<AtomicBool>,
|
|
|
|
paused_sync: Arc<Barrier>,
|
|
|
|
) -> result::Result<(), EpollHelperError> {
|
2020-08-04 11:16:44 +00:00
|
|
|
let mut helper = EpollHelper::new(&self.kill_evt, &self.pause_evt)?;
|
|
|
|
helper.add_event(self.resize.evt.as_raw_fd(), RESIZE_EVENT)?;
|
|
|
|
helper.add_event(self.queue_evt.as_raw_fd(), QUEUE_AVAIL_EVENT)?;
|
2020-08-11 14:05:06 +00:00
|
|
|
helper.run(paused, paused_sync, self)?;
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2020-08-04 11:16:44 +00:00
|
|
|
Ok(())
|
|
|
|
}
|
|
|
|
}
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2020-08-04 11:16:44 +00:00
|
|
|
impl EpollHelperHandler for MemEpollHandler {
|
2020-08-11 17:12:02 +00:00
|
|
|
fn handle_event(&mut self, _helper: &mut EpollHelper, event: &epoll::Event) -> bool {
|
|
|
|
let ev_type = event.data as u16;
|
|
|
|
match ev_type {
|
2020-08-04 11:16:44 +00:00
|
|
|
RESIZE_EVENT => {
|
|
|
|
if let Err(e) = self.resize.evt.read() {
|
|
|
|
error!("Failed to get resize event: {:?}", e);
|
|
|
|
return true;
|
|
|
|
} else {
|
2021-02-02 15:17:35 +00:00
|
|
|
let size = self.resize.size();
|
2020-08-04 11:16:44 +00:00
|
|
|
let mut config = self.config.lock().unwrap();
|
|
|
|
let mut signal_error = false;
|
2021-02-02 10:35:38 +00:00
|
|
|
let mut r = config.resize(size);
|
2020-08-10 10:22:55 +00:00
|
|
|
r = match r {
|
|
|
|
Err(e) => Err(e),
|
|
|
|
_ => match self.signal(&VirtioInterruptType::Config) {
|
|
|
|
Err(e) => {
|
|
|
|
signal_error = true;
|
|
|
|
Err(Error::ResizeTriggerFail(e))
|
|
|
|
}
|
|
|
|
_ => Ok(()),
|
|
|
|
},
|
2020-08-04 11:16:44 +00:00
|
|
|
};
|
|
|
|
if let Err(e) = self.resize.send(r) {
|
2020-09-22 11:31:42 +00:00
|
|
|
error!("Sending \"resize\" response: {:?}", e);
|
2020-08-04 11:16:44 +00:00
|
|
|
return true;
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
2020-08-04 11:16:44 +00:00
|
|
|
if signal_error {
|
|
|
|
return true;
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
2020-08-04 11:16:44 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
QUEUE_AVAIL_EVENT => {
|
|
|
|
if let Err(e) = self.queue_evt.read() {
|
|
|
|
error!("Failed to get queue event: {:?}", e);
|
|
|
|
return true;
|
|
|
|
} else if self.process_queue() {
|
|
|
|
if let Err(e) = self.signal(&VirtioInterruptType::Queue) {
|
|
|
|
error!("Failed to signal used queue: {:?}", e);
|
|
|
|
return true;
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2020-08-04 11:16:44 +00:00
|
|
|
_ => {
|
2020-08-11 17:12:02 +00:00
|
|
|
error!("Unexpected event: {}", ev_type);
|
2020-08-04 11:16:44 +00:00
|
|
|
return true;
|
|
|
|
}
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
2020-08-04 11:16:44 +00:00
|
|
|
false
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Virtio device for exposing entropy to the guest OS through virtio.
|
|
|
|
pub struct Mem {
|
2020-09-03 09:37:36 +00:00
|
|
|
common: VirtioCommon,
|
2020-04-27 11:44:43 +00:00
|
|
|
id: String,
|
2021-02-02 15:17:35 +00:00
|
|
|
resize: ResizeSender,
|
2020-03-04 02:12:22 +00:00
|
|
|
host_addr: u64,
|
|
|
|
host_fd: Option<RawFd>,
|
|
|
|
config: Arc<Mutex<VirtioMemConfig>>,
|
2020-08-18 01:48:52 +00:00
|
|
|
seccomp_action: SeccompAction,
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
impl Mem {
|
|
|
|
// Create a new virtio-mem device.
|
2020-08-18 01:48:52 +00:00
|
|
|
pub fn new(
|
|
|
|
id: String,
|
|
|
|
region: &Arc<GuestRegionMmap>,
|
2021-02-02 15:17:35 +00:00
|
|
|
resize: ResizeSender,
|
2020-08-18 01:48:52 +00:00
|
|
|
seccomp_action: SeccompAction,
|
2020-09-11 13:09:06 +00:00
|
|
|
numa_node_id: Option<u16>,
|
2020-08-10 10:22:55 +00:00
|
|
|
initial_size: u64,
|
2020-08-18 01:48:52 +00:00
|
|
|
) -> io::Result<Mem> {
|
2020-03-04 02:12:22 +00:00
|
|
|
let region_len = region.len();
|
|
|
|
|
2020-09-14 09:36:31 +00:00
|
|
|
if region_len != region_len / VIRTIO_MEM_ALIGN_SIZE * VIRTIO_MEM_ALIGN_SIZE {
|
2020-03-04 02:12:22 +00:00
|
|
|
return Err(io::Error::new(
|
|
|
|
io::ErrorKind::Other,
|
|
|
|
format!(
|
|
|
|
"Virtio-mem size is not aligned with {}",
|
2020-09-14 09:36:31 +00:00
|
|
|
VIRTIO_MEM_ALIGN_SIZE
|
2020-03-04 02:12:22 +00:00
|
|
|
),
|
|
|
|
));
|
|
|
|
}
|
|
|
|
|
2020-09-11 13:09:06 +00:00
|
|
|
let mut avail_features = 1u64 << VIRTIO_F_VERSION_1;
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2021-02-02 10:35:38 +00:00
|
|
|
let mut config = VirtioMemConfig {
|
|
|
|
block_size: VIRTIO_MEM_DEFAULT_BLOCK_SIZE,
|
|
|
|
addr: region.start_addr().raw_value(),
|
|
|
|
region_size: region.len(),
|
|
|
|
usable_region_size: region.len(),
|
|
|
|
plugged_size: 0,
|
|
|
|
requested_size: 0,
|
|
|
|
..Default::default()
|
|
|
|
};
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2020-08-10 10:22:55 +00:00
|
|
|
if initial_size != 0 {
|
2021-02-02 10:35:38 +00:00
|
|
|
config.resize(initial_size).map_err(|e| {
|
2020-08-10 10:22:55 +00:00
|
|
|
io::Error::new(
|
|
|
|
io::ErrorKind::Other,
|
2021-02-02 10:35:38 +00:00
|
|
|
format!(
|
|
|
|
"Failed to resize virtio-mem configuration to {}: {:?}",
|
|
|
|
initial_size, e
|
|
|
|
),
|
2020-08-10 10:22:55 +00:00
|
|
|
)
|
|
|
|
})?;
|
|
|
|
}
|
|
|
|
|
2020-09-11 13:09:06 +00:00
|
|
|
if let Some(node_id) = numa_node_id {
|
|
|
|
avail_features |= 1u64 << VIRTIO_MEM_F_ACPI_PXM;
|
|
|
|
config.node_id = node_id;
|
|
|
|
}
|
|
|
|
|
2021-02-02 10:35:38 +00:00
|
|
|
// Make sure the virtio-mem configuration complies with the
|
|
|
|
// specification.
|
|
|
|
config.validate().map_err(|e| {
|
|
|
|
io::Error::new(
|
|
|
|
io::ErrorKind::Other,
|
|
|
|
format!("Invalid virtio-mem configuration: {:?}", e),
|
|
|
|
)
|
|
|
|
})?;
|
|
|
|
|
|
|
|
let host_fd = region
|
|
|
|
.file_offset()
|
|
|
|
.map(|f_offset| f_offset.file().as_raw_fd());
|
2020-03-04 02:12:22 +00:00
|
|
|
|
|
|
|
Ok(Mem {
|
2020-09-03 09:37:36 +00:00
|
|
|
common: VirtioCommon {
|
2020-09-04 08:37:37 +00:00
|
|
|
device_type: VirtioDeviceType::TYPE_MEM as u32,
|
2020-09-03 09:37:36 +00:00
|
|
|
avail_features,
|
2020-09-04 08:37:37 +00:00
|
|
|
paused_sync: Some(Arc::new(Barrier::new(2))),
|
|
|
|
queue_sizes: QUEUE_SIZES.to_vec(),
|
2021-01-19 06:11:07 +00:00
|
|
|
min_queues: 1,
|
2020-09-03 15:56:32 +00:00
|
|
|
..Default::default()
|
2020-09-03 09:37:36 +00:00
|
|
|
},
|
2020-04-27 11:44:43 +00:00
|
|
|
id,
|
2020-03-04 02:12:22 +00:00
|
|
|
resize,
|
|
|
|
host_addr: region.as_ptr() as u64,
|
|
|
|
host_fd,
|
|
|
|
config: Arc::new(Mutex::new(config)),
|
2020-08-18 01:48:52 +00:00
|
|
|
seccomp_action,
|
2020-03-04 02:12:22 +00:00
|
|
|
})
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
impl Drop for Mem {
|
|
|
|
fn drop(&mut self) {
|
2020-09-04 08:37:37 +00:00
|
|
|
if let Some(kill_evt) = self.common.kill_evt.take() {
|
2020-03-04 02:12:22 +00:00
|
|
|
// Ignore the result because there is nothing we can do about it.
|
|
|
|
let _ = kill_evt.write(1);
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
impl VirtioDevice for Mem {
|
|
|
|
fn device_type(&self) -> u32 {
|
2020-09-04 08:37:37 +00:00
|
|
|
self.common.device_type
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
fn queue_max_sizes(&self) -> &[u16] {
|
2020-09-04 08:37:37 +00:00
|
|
|
&self.common.queue_sizes
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
fn features(&self) -> u64 {
|
2020-09-03 09:37:36 +00:00
|
|
|
self.common.avail_features
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
fn ack_features(&mut self, value: u64) {
|
2020-09-03 09:37:36 +00:00
|
|
|
self.common.ack_features(value)
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
2020-07-16 09:34:51 +00:00
|
|
|
fn read_config(&self, offset: u64, data: &mut [u8]) {
|
|
|
|
self.read_config_from_slice(self.config.lock().unwrap().as_slice(), offset, data);
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
fn activate(
|
|
|
|
&mut self,
|
|
|
|
mem: GuestMemoryAtomic<GuestMemoryMmap>,
|
|
|
|
interrupt_cb: Arc<dyn VirtioInterrupt>,
|
|
|
|
mut queues: Vec<Queue>,
|
|
|
|
mut queue_evts: Vec<EventFd>,
|
|
|
|
) -> ActivateResult {
|
2020-09-04 08:37:37 +00:00
|
|
|
self.common.activate(&queues, &queue_evts, &interrupt_cb)?;
|
|
|
|
let kill_evt = self
|
|
|
|
.common
|
|
|
|
.kill_evt
|
|
|
|
.as_ref()
|
|
|
|
.unwrap()
|
|
|
|
.try_clone()
|
2020-03-04 02:12:22 +00:00
|
|
|
.map_err(|e| {
|
2020-09-04 08:37:37 +00:00
|
|
|
error!("failed to clone kill_evt eventfd: {}", e);
|
2020-03-04 02:12:22 +00:00
|
|
|
ActivateError::BadActivate
|
|
|
|
})?;
|
2020-09-04 08:37:37 +00:00
|
|
|
let pause_evt = self
|
|
|
|
.common
|
|
|
|
.pause_evt
|
|
|
|
.as_ref()
|
|
|
|
.unwrap()
|
|
|
|
.try_clone()
|
2020-03-04 02:12:22 +00:00
|
|
|
.map_err(|e| {
|
2020-09-04 08:37:37 +00:00
|
|
|
error!("failed to clone pause_evt eventfd: {}", e);
|
2020-03-04 02:12:22 +00:00
|
|
|
ActivateError::BadActivate
|
|
|
|
})?;
|
|
|
|
|
|
|
|
let config = self.config.lock().unwrap();
|
|
|
|
let mut handler = MemEpollHandler {
|
|
|
|
host_addr: self.host_addr,
|
|
|
|
host_fd: self.host_fd,
|
|
|
|
mem_state: vec![false; config.region_size as usize / config.block_size as usize],
|
|
|
|
config: self.config.clone(),
|
2021-02-02 15:17:35 +00:00
|
|
|
resize: self.resize.clone(),
|
2020-03-04 02:12:22 +00:00
|
|
|
queue: queues.remove(0),
|
|
|
|
mem,
|
|
|
|
interrupt_cb,
|
|
|
|
queue_evt: queue_evts.remove(0),
|
|
|
|
kill_evt,
|
|
|
|
pause_evt,
|
|
|
|
};
|
|
|
|
|
2020-09-04 08:37:37 +00:00
|
|
|
let paused = self.common.paused.clone();
|
|
|
|
let paused_sync = self.common.paused_sync.clone();
|
2020-03-04 02:12:22 +00:00
|
|
|
let mut epoll_threads = Vec::new();
|
2020-08-18 01:48:52 +00:00
|
|
|
// Retrieve seccomp filter for virtio_mem thread
|
|
|
|
let virtio_mem_seccomp_filter = get_seccomp_filter(&self.seccomp_action, Thread::VirtioMem)
|
|
|
|
.map_err(ActivateError::CreateSeccompFilter)?;
|
2020-03-04 02:12:22 +00:00
|
|
|
thread::Builder::new()
|
2021-01-13 13:10:36 +00:00
|
|
|
.name(self.id.clone())
|
2020-08-17 19:45:17 +00:00
|
|
|
.spawn(move || {
|
2020-08-18 01:48:52 +00:00
|
|
|
if let Err(e) = SeccompFilter::apply(virtio_mem_seccomp_filter) {
|
|
|
|
error!("Error applying seccomp filter: {:?}", e);
|
2020-09-04 08:37:37 +00:00
|
|
|
} else if let Err(e) = handler.run(paused, paused_sync.unwrap()) {
|
2020-08-17 19:45:17 +00:00
|
|
|
error!("Error running worker: {:?}", e);
|
|
|
|
}
|
|
|
|
})
|
2020-03-04 02:12:22 +00:00
|
|
|
.map(|thread| epoll_threads.push(thread))
|
|
|
|
.map_err(|e| {
|
|
|
|
error!("failed to clone virtio-mem epoll thread: {}", e);
|
|
|
|
ActivateError::BadActivate
|
|
|
|
})?;
|
2020-09-04 08:37:37 +00:00
|
|
|
self.common.epoll_threads = Some(epoll_threads);
|
2020-03-04 02:12:22 +00:00
|
|
|
|
|
|
|
Ok(())
|
|
|
|
}
|
|
|
|
|
2021-01-18 12:38:08 +00:00
|
|
|
fn reset(&mut self) -> Option<Arc<dyn VirtioInterrupt>> {
|
2020-09-04 08:37:37 +00:00
|
|
|
self.common.reset()
|
|
|
|
}
|
|
|
|
}
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2020-09-04 08:37:37 +00:00
|
|
|
impl Pausable for Mem {
|
|
|
|
fn pause(&mut self) -> result::Result<(), MigratableError> {
|
|
|
|
self.common.pause()
|
|
|
|
}
|
2020-03-04 02:12:22 +00:00
|
|
|
|
2020-09-04 08:37:37 +00:00
|
|
|
fn resume(&mut self) -> result::Result<(), MigratableError> {
|
|
|
|
self.common.resume()
|
2020-03-04 02:12:22 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2020-04-27 11:44:43 +00:00
|
|
|
impl Snapshottable for Mem {
|
|
|
|
fn id(&self) -> String {
|
|
|
|
self.id.clone()
|
|
|
|
}
|
|
|
|
}
|
2019-05-01 16:59:51 +00:00
|
|
|
impl Transportable for Mem {}
|
2020-03-04 02:12:22 +00:00
|
|
|
impl Migratable for Mem {}
|