machina_virtio_device/
lib.rs

1// Copyright 2021 The Fuchsia Authors. All rights reserved.
2// Use of this source code is governed by a BSD-style license that can be
3// found in the LICENSE file.
4
5//! Write Machina virtio devices in Rust.
6//!
7//! This crate aims to simplify the writing of virtio devices as out of process FIDL services by
8//! automating boiler plate and providing common wrappers for Machina/Fuchsia specifics.
9//!
10//! The primary helper is the [`Device`] object that wraps most of the common other helpers, and
11//! this must be constructed via the [`DeviceBuilder`], although any of the individual helpers can
12//! be used independently without [`Device`] if desired.
13
14mod bell;
15mod mem;
16mod notify;
17
18pub use bell::{BellError, GuestBellTrap};
19pub use mem::{guest_mem_from_vmo, translate_queue, GuestMem};
20pub use notify::NotifyEvent;
21
22use fidl_fuchsia_virtualization_hardware::{
23    StartInfo, VirtioDeviceReadyResponder, VirtioDeviceRequest, VirtioDeviceRequestStream,
24};
25use fuchsia_sync::Mutex;
26
27use futures::task::AtomicWaker;
28use futures::{Stream, TryFutureExt, TryStreamExt};
29use std::collections::{hash_map, HashMap};
30use std::pin::Pin;
31use std::task::{Context, Poll};
32use thiserror::Error;
33use virtio_device::mem::DriverMem;
34use virtio_device::queue::{DescChain, DriverNotify, Queue};
35use virtio_device::util::DescChainStream;
36
37#[derive(Error, Debug)]
38pub enum DeviceError {
39    #[error("Error with status {0}")]
40    Status(#[from] zx::Status),
41    #[error("FIDL error {0}")]
42    Fidl(#[from] fidl::Error),
43    #[error("Queue {0} was invalid for the requested operation")]
44    InvalidQueue(u16),
45    #[error("Provided configuration for queue {0} was invalid")]
46    BadQueueConfig(u16),
47    #[error("Received message {0:?} that was unexpected for the current operation")]
48    UnexpectedMessage(VirtioDeviceRequest),
49    #[error("Stream ended with messages required to complete current operation")]
50    UnexpectedEndOfStream,
51    #[error(transparent)]
52    Bell(#[from] BellError),
53    #[error(transparent)]
54    Other(#[from] anyhow::Error),
55}
56
57/// Helper to process device messages and build a [`Device`]
58///
59/// The [`DeviceBuilder`] provides a stateful interface and can assist with process the startup
60/// messages for queue configuration that virtio devices need to undertake.
61///
62/// If a device needs full control of how messages are handled it can use the raw [`add_queue`] and
63/// [`build`] methods to build a [`Device`], otherwise it is expected that
64/// [`config_builder_from_stream`] will typically be sufficient and automates the message loop.
65#[derive(Debug)]
66pub struct DeviceBuilder<N> {
67    notify: N,
68    trap: Option<GuestBellTrap>,
69    queues: HashMap<u16, QueueConfig>,
70    vmo: Option<zx::Vmo>,
71}
72
73impl DeviceBuilder<()> {
74    /// Construct a new [`DeviceBuilder`]
75    ///
76    /// This provides complete flexibility on processing the [`StartInfo`], but typically it is
77    /// expected that [`from_start_info`] is the more useful way to get a partially initialized
78    /// [`DeviceBuilder`].
79    ///
80    /// If a [`GuestBellTrap`] exists it can optionally be provided here. If not provided then the
81    /// final [`Device`] will not have the trap, although users can always process the stream of
82    /// trap notifications themselves.
83    pub fn new(trap: Option<GuestBellTrap>, vmo: Option<zx::Vmo>) -> DeviceBuilder<()> {
84        DeviceBuilder { notify: (), trap, queues: HashMap::new(), vmo }
85    }
86}
87
88impl<N> DeviceBuilder<N> {
89    /// Check if a trap has been configured.
90    ///
91    /// Since it is an error to [`set_trap`] if one already exists
92
93    /// Change the notify to a different type.
94    ///
95    /// Passes the current notification object to the provided function, and stores any success
96    /// result as the new notify.
97    ///
98    /// When building the final [`Device`] the internal notify will be given to each [`Queue`] that
99    /// is constructed. Initially the notify type `N` will always be [`NotifyEvent`] and is created
100    /// from the [zx::Event`] provided in the [`StartInfo`].
101    ///
102    /// The normal reason to want to change the notify type is to interpose a [`BufferedNotify`]
103    /// (virtio_device::util::BufferedNotify).
104    ///
105    /// ```
106    /// builder.map_notify(
107    ///     |e| Result::<_, zx::Status>::Ok(virtio_device::util::BufferedNotify::new(e))
108    /// )
109    /// ```
110    pub fn map_notify<N2>(
111        self,
112        map: impl FnOnce(N) -> Result<N2, DeviceError>,
113    ) -> Result<DeviceBuilder<N2>, DeviceError> {
114        let DeviceBuilder { notify, trap, queues, vmo } = self;
115        let notify = map(notify)?;
116        Ok(DeviceBuilder { notify, trap, queues, vmo })
117    }
118
119    /// Add the specified [`QueueConfig`] to the list of queues.
120    ///
121    /// This just records the [`QueueConfig`] and aside from ensuring `config.queue` is not a
122    /// duplicate, no further validation is done. The [`Queue`] itself will get build in the
123    /// [`build`] step after all queues have been specified.
124    pub fn add_queue(mut self, config: QueueConfig) -> Result<Self, DeviceError> {
125        let queue = config.queue;
126        if self.queues.insert(queue, config).is_some() {
127            return Err(DeviceError::InvalidQueue(queue));
128        }
129        Ok(self)
130    }
131
132    /// Query the queues configured so far.
133    ///
134    /// Returns an iterator of the queue numbers that have been configured so far in the builder.
135    pub fn configured_queues(&self) -> impl Iterator<Item = u16> + '_ {
136        self.queues.keys().cloned()
137    }
138
139    /// Allow virtio devices to take the guest [`zx::Vmo`]. If the [`zx::Vmo`] is not taken it will
140    ///  be dropped as part of the DeviceBuilder::build call
141    ///
142    /// Returns an option to guest vmo
143    pub fn take_vmo(&mut self) -> Option<zx::Vmo> {
144        self.vmo.take()
145    }
146}
147
148impl<N: Clone> DeviceBuilder<N> {
149    /// Build a [`Device`] from the current builder state.
150    ///
151    /// This builds all of the queues the were configured and constructs the final [`Device`]. The
152    /// negotiated features and a [`DriverMem`] need to given here for queue building.
153    pub fn build<'a, M: DriverMem>(
154        self,
155        negotiated_features: u32,
156        mem: &'a M,
157    ) -> Result<Device<'a, N>, DeviceError> {
158        let DeviceBuilder { notify, trap, queues, vmo } = self;
159        // Dropping of the VMO handle here is an explicit design decision and devices that need to
160        // retain it must call take_vmo before building the device.
161        drop(vmo);
162        // Note: Queue does not currently support any features so they're not passed in, but
163        // eventually it will.
164        let queues = queues
165            .into_iter()
166            .map(|(queue_num, config)| {
167                Queue::new(
168                    translate_queue(
169                        mem,
170                        config.size,
171                        config.desc as usize,
172                        config.avail as usize,
173                        config.used as usize,
174                    )
175                    .ok_or(DeviceError::BadQueueConfig(queue_num))?,
176                    notify.clone(),
177                )
178                .map(|q| (queue_num, q))
179                .ok_or(DeviceError::BadQueueConfig(queue_num))
180            })
181            .collect::<Result<_, DeviceError>>()?;
182        let device = Device {
183            notify,
184            inner: Mutex::new(Inner { trap, wakers: HashMap::new() }),
185            queues,
186            features: negotiated_features,
187        };
188        return Ok(device);
189    }
190}
191
192/// Construct a [`DeviceBuilder`] from the provided [`StartInfo`]
193///
194/// Consumes all the handles out of the [`StartInfo`] and will initialize the provided
195/// [`GuestMem`] using [`GuestMem::provide_vmo`].
196///
197/// [`from_start_info`] is the preferred way to construct a [`DeviceBuilder`], this variant exists
198/// should your device have unusual requirements on the lifetime of [`GuestMem`].
199///
200/// The state of [`mem`] is undefined if an `Error` is returned.
201pub fn builder_from_start_info(
202    info: StartInfo,
203    mem: &mut GuestMem,
204) -> Result<DeviceBuilder<NotifyEvent>, DeviceError> {
205    let StartInfo { trap, guest, event, vmo } = info;
206    mem.set_vmo(&vmo)?;
207    DeviceBuilder::new(
208        guest
209            .map(|guest| {
210                GuestBellTrap::new(&guest, zx::GPAddr(trap.addr as usize), trap.size as usize)
211            })
212            .transpose()?,
213        Some(vmo),
214    )
215    .map_notify(|_| Ok(NotifyEvent::new(event)))
216}
217
218/// Construct a [`DeviceBuilder`] and [`GuestMem`] from the provided [`StartInfo`]
219///
220/// Consumes all the handles out of the [`StartInfo`] and will return a [`GuestMem`] as well as a
221/// [`DeviceBuilder`] that has already been initialized with any traps and notifications sources
222/// provided in the [`StartInfo`].
223pub fn from_start_info(
224    info: StartInfo,
225) -> Result<(DeviceBuilder<NotifyEvent>, GuestMem), DeviceError> {
226    let mut mem = GuestMem::new();
227    let builder = builder_from_start_info(info, &mut mem)?;
228    Ok((builder, mem))
229}
230
231/// Process a [`VirtioDeviceRequestStream`] to configure all the queues.
232///
233/// Runs a simple message loop to process all [`VirtioDeviceRequest::ConfigureQueue`] until a
234/// [`VirtioDeviceRequest::Ready`] is received. If a device expects no other messages during
235/// this configuration then this automates the building. Otherwise if other messages are
236/// expected clients will need to run their own message loop and use [`add_queue`].
237///
238/// On success a [`Device`] and a [`VirtioDeviceReadyResponder`] will be returned. The
239/// negotiated features can be [queried](Device::get_features) and then the [responder]
240/// (VirtioDeviceReadyResponder) can be signaled once the device is satisfied and able to start.
241///
242/// A reference to a [`QueueCheck`] must be provided for the builder to know whether to accept
243/// or reject any particular queue configuration request.
244pub async fn config_builder_from_stream<'a, N: Clone, M: DriverMem, Q: QueueCheck + ?Sized>(
245    mut builder: DeviceBuilder<N>,
246    stream: &mut VirtioDeviceRequestStream,
247    queues: &Q,
248    mem: &'a M,
249) -> Result<(Device<'a, N>, VirtioDeviceReadyResponder), DeviceError> {
250    while let Some(msg) = stream.try_next().await? {
251        match msg {
252            VirtioDeviceRequest::ConfigureQueue { queue, size, desc, avail, used, responder } => {
253                queues.check_queue(queue, builder.configured_queues()).map_err(Into::into)?;
254                builder = builder.add_queue(QueueConfig { queue, size, desc, avail, used })?;
255                responder.send()?;
256            }
257            VirtioDeviceRequest::Ready { negotiated_features, responder } => {
258                return builder.build(negotiated_features, mem).map(|device| (device, responder));
259            }
260            x => {
261                return Err(DeviceError::UnexpectedMessage(x));
262            }
263        };
264    }
265    Err(DeviceError::UnexpectedEndOfStream)
266}
267
268struct Inner {
269    trap: Option<GuestBellTrap>,
270    wakers: HashMap<u16, std::sync::Arc<AtomicWaker>>,
271}
272
273/// State for managing a virtio device and its queues using futures.
274///
275/// Provides a wrapper around one or more [`Queue`]s along with helpers to send and receive queue
276/// notifications to the guest driver. These wrappers focus on presenting a asynchronous futures
277/// interface on top of the underlying objects.
278///
279/// Primary this [provides](take_stream) a wrapper around a [`DescChainStream`] for processing
280/// descriptor chains. The guest signals that there are descriptors available either using a
281/// [`GuestBellTrap`] or via a [`VirtioDeviceRequest::NotifyQueue`] message. Connecting these two
282/// sources of notifications to the underlying waker from the [`DescChainStream`] can be done in a
283/// most easily using [`run_device_notify`]. It will run forever processing messages from a
284/// [`VirtioDeviceRequestStream`], and from any [`GuestBellTrap`], performing [`notify_queue`] as
285/// needed.
286///
287/// If the the device needs to run its own message loop on the stream, and therefore cannot give it
288/// to [`run_device_notify`], it can also just [`take_bell_traps`] and use
289/// [`GuestBellTrap::complete`] or [`GuestBellTrap::complete_or_pending`] to process them. In this
290/// case the device message loop should use [`notify_queue`] for any
291/// [`VirtioDeviceRequest::NotifyQueue`] it receives.
292///
293/// The [`DriverNotify`] object that was configured in the [`DeviceBuilder]` can be retrieved using
294/// [`get_notify`]. The notify object might be needed by a device to:
295/// - Signal a configuration change
296/// - Flush pending queue notifications if something like  [`virtio_device::util::BufferedNotify`]
297///   is being used.
298pub struct Device<'a, N> {
299    notify: N,
300    queues: HashMap<u16, Queue<'a, N>>,
301    inner: Mutex<Inner>,
302    features: u32,
303}
304
305impl<'a, N> Device<'a, N> {
306    /// Take a [`Stream`] that yields [`DescChain`] for the requested queue
307    ///
308    /// This returns an error if the specified queue either was not configured in the
309    /// [`DeviceBuilder`], or has already been taken and not returned. The
310    /// [`WrappedDescChainStream`] that this returns will automatically return itself when dropped.
311    ///
312    /// Note that the [`Stream`] needs to have its waker signalled to work correctly, see [struct]
313    /// (Device) level comment for details.
314    pub fn take_stream<'b>(
315        &'b self,
316        idx: u16,
317    ) -> Result<WrappedDescChainStream<'a, 'b, N>, DeviceError> {
318        let mut inner = self.inner.lock();
319        let entry = if let hash_map::Entry::Vacant(entry) = inner.wakers.entry(idx) {
320            entry
321        } else {
322            return Err(DeviceError::InvalidQueue(idx));
323        };
324        let queue = self.queues.get(&idx).ok_or(DeviceError::InvalidQueue(idx))?;
325        let desc_stream = DescChainStream::new(queue);
326        entry.insert(desc_stream.waker());
327        Ok(WrappedDescChainStream(idx, desc_stream, self))
328    }
329
330    /// Retrieve underlying driver notification object
331    pub fn get_notify(&self) -> &N {
332        &self.notify
333    }
334
335    /// Query the configured queues.
336    ///
337    /// Returns an iterator of the queue numbers that were configured.
338    pub fn configured_queues<'b>(&'b self) -> impl Iterator<Item = u16> + 'b
339    where
340        'b: 'a,
341    {
342        self.queues.keys().cloned()
343    }
344
345    /// Notify a queue in response to a notification from the driver.
346    ///
347    /// This signals the waker for the given queue and is required to have the streams returned from
348    /// [`take_stream`] yield items.
349    ///
350    /// See [struct](Device) level documentation for more details.
351    pub fn notify_queue(&self, idx: u16) -> Result<(), DeviceError> {
352        self.inner.lock().wakers.get(&idx).ok_or(DeviceError::InvalidQueue(idx))?.wake();
353        Ok(())
354    }
355
356    /// Take any [`GuestBellTraps`] that might have been configured.
357    ///
358    /// If bell traps were provided in the [`DeviceBuilder`] this returns them. This completely
359    /// removes them from the [`Device`] and the caller is now responsible for them and forwarding
360    /// any notifications from the driver to [`notify_queue`].
361    ///
362    /// Internally [`run_device_notify`] uses this to get the bell traps and so once you call it
363    /// this will always return a `None`. Similarly if you call this [`run_device_notify`] will
364    /// not be able to process bell traps, since you are responsible for them.
365    ///
366    /// The normal reason to use this is if you need to run your own message loop and cannot use
367    /// [`run_device_notify`], in which case you almost always want to
368    /// ```
369    /// GuestBellTrap::complete_or_pending(device.take_bell_traps(), &device)
370    /// ```
371    pub fn take_bell_traps(&self) -> Option<GuestBellTrap> {
372        self.inner.lock().trap.take()
373    }
374
375    /// Return the negotiated features from [`DeviceBuilder::give_ready`]
376    pub fn get_features(&self) -> u32 {
377        self.features
378    }
379
380    /// Run any notifications from the driver till completion.
381    ///
382    /// Consumes both a [`VirtioDeviceStream`] as well as any [bell traps](take_bell_traps) to
383    /// receive any notifications from the driver, for the device, and calls [`notify_queue`] with
384    /// them. Will never yield a success and only ever yields an error should either source of
385    /// notifications close unexpectedly, or indicate an invalidate queue.
386    ///
387    /// This method is ideal if you do not need to process device specific messages from the FIDL
388    /// channel.
389    pub async fn run_device_notify(
390        &self,
391        stream: VirtioDeviceRequestStream,
392    ) -> Result<(), DeviceError> {
393        // Each of our notification sources, stream and bell, should not end, as this indicates some
394        // underlying connection issue. As such we transform each future to become an error should
395        // it ever yield a success value.
396        let notify = self.run_device_notify_stream(stream).and_then(|()| {
397            futures::future::ready(Result::<(), _>::Err(DeviceError::UnexpectedEndOfStream))
398        });
399        let bell =
400            GuestBellTrap::complete_or_pending(self.take_bell_traps(), self).and_then(|()| {
401                futures::future::ready(Result::<(), _>::Err(DeviceError::UnexpectedEndOfStream))
402            });
403        // Although join tries to run both futures to completion, since we already wrapped each
404        // future to yield an error when it completes, this will effectively run both futures till
405        // either completes or yields an error, which is the behavior we want.
406        futures::future::try_join(notify, bell).await.map(|((), ())| ())
407    }
408
409    /// Process all queue notifications on a [`VirtioDeviceRequestStream`]
410    ///
411    /// Unlike [`run_device_notify`] this does not [`take_bell_trap`] and process those messages.
412    /// This will also yield an `Ok(())` should the stream end, leaving the caller to determine if
413    /// that is an error condition or not.
414    pub async fn run_device_notify_stream(
415        &self,
416        stream: VirtioDeviceRequestStream,
417    ) -> Result<(), DeviceError> {
418        stream
419            .err_into()
420            .try_for_each(|msg| {
421                futures::future::ready(match msg {
422                    VirtioDeviceRequest::NotifyQueue { queue, .. } => self.notify_queue(queue),
423                    msg => Err(DeviceError::UnexpectedMessage(msg)),
424                })
425            })
426            .await
427    }
428}
429
430/// Raw queue configuration from a [`VirtioDeviceRequest::ConfigureQueue`]
431///
432/// This is just a [`VirtioDeviceRequest::ConfigureQueue`] without the responder to allow for
433/// more easily passing around queue configuration.
434#[derive(Debug, Clone, Eq, PartialEq)]
435pub struct QueueConfig {
436    pub queue: u16,
437    pub size: u16,
438    pub desc: u64,
439    pub avail: u64,
440    pub used: u64,
441}
442
443/// Wrapper around a [`DescChainStream`]
444///
445/// Yields [`DescChain`] from a [`Stream`] much like [`DescChainStream`], but will de-register
446/// itself from its associated [`Device`] on drop.
447pub struct WrappedDescChainStream<'a, 'b, N>(u16, DescChainStream<'a, 'b, N>, &'b Device<'a, N>);
448
449impl<'a, 'b, N: DriverNotify> Stream for WrappedDescChainStream<'a, 'b, N> {
450    type Item = DescChain<'a, 'b, N>;
451    fn poll_next(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Option<Self::Item>> {
452        Pin::new(&mut self.1).poll_next(cx)
453    }
454}
455
456impl<'a, 'b, N> Drop for WrappedDescChainStream<'a, 'b, N> {
457    fn drop(&mut self) {
458        self.2.inner.lock().wakers.remove(&self.0).unwrap();
459    }
460}
461
462/// Describes the queues that are expected and valid for a device
463///
464/// Provides a way for the automated device building in [`config_builder_from_stream`] to check
465/// if a provided queue is valid prior to acknowledging the message and continuing. A device
466/// can always opt out of using the [`QueueCheck`] if it does not easily map to their initialization
467/// process, however they must then run their own message loop and use [`DeviceBuilder::add_queue`]
468/// directly.
469///
470/// Some devices may only support a fixed set of queues, or they may support a variable number that
471/// the guest can configure. This provides flexibility on supporting both. For convenience of the
472/// common case of a fixed set of queues, [`QueueCheck`] is implemented for `[u16]` where
473/// elements in the slice represent valid queues. This allows for doing:
474/// ```
475/// config_builder_from_stream(device_builder, stream, &[0,1,2][..], guest_mem).await?;
476/// ```
477/// This will cause the [`DeviceBuilder`] to allow only those queues to be configured.
478/// After `config_builder_from_stream` returns, either the [`Device::configured_queues`], or using
479/// [`Device::take_stream`] can be used to validate that all the expected queues were configured,
480/// prior to sending on the [`VirtioDeviceReadyResponder`].
481/// Note that building the [`Device`] itself does not communicate back to the VMM, and so there is
482/// no information leakage by building the [`Device`] prior to being given the opportunity to
483/// checking the queues, provided this is done before sending on the ready responder.
484pub trait QueueCheck {
485    type Error: Into<DeviceError>;
486    /// Check a queue that is being added.
487    ///
488    /// If this returns `Ok(())` then the device acknowledges this is a valid queue, otherwise it
489    /// can return an `Err`. An iterator over any queues that have already been added is also
490    /// provided, although a guest can configure queues in any order.
491    fn check_queue(
492        &self,
493        queue: u16,
494        existing: impl Iterator<Item = u16>,
495    ) -> Result<(), Self::Error>;
496}
497
498impl QueueCheck for [u16] {
499    type Error = DeviceError;
500    fn check_queue(
501        &self,
502        queue: u16,
503        _existing: impl Iterator<Item = u16>,
504    ) -> Result<(), Self::Error> {
505        // Search the slice and ensure this is a queue that was requested.
506        self.iter().find(|&&x| x == queue).map(|_| ()).ok_or(DeviceError::InvalidQueue(queue))
507    }
508}
509
510impl<T: std::ops::RangeBounds<u16>> QueueCheck for T {
511    type Error = DeviceError;
512    fn check_queue(
513        &self,
514        queue: u16,
515        _existing: impl Iterator<Item = u16>,
516    ) -> Result<(), Self::Error> {
517        match self.contains(&queue) {
518            true => Ok(()),
519            false => Err(DeviceError::InvalidQueue(queue)),
520        }
521    }
522}
523
524#[cfg(test)]
525mod tests {
526    use super::*;
527    use assert_matches::assert_matches;
528    use fidl_fuchsia_virtualization_hardware::VirtioDeviceMarker;
529    use fuchsia_async::{self as fasync};
530    use virtio_device::util::NotificationCounter;
531
532    // Make a QueueConfig for a given queue size offset in guest memory. Also returns the offset at
533    // which the queue ends.
534    fn make_queue_config(queue: u16, size: u16, offset: u64) -> (QueueConfig, u64) {
535        let round_up = |val| (val + (16 - (val % 16)));
536        let desc = round_up(offset);
537        let desc_len = std::mem::size_of::<u16>() as u64 * size as u64;
538        let avail = round_up(desc + desc_len);
539        let avail_len = virtio_device::ring::Driver::avail_len_for_queue_size(size) as u64;
540        let used = round_up(avail + avail_len);
541        let used_len = virtio_device::ring::Device::used_len_for_queue_size(size) as u64;
542        let end = round_up(used + used_len);
543        (QueueConfig { queue, size, desc, avail, used }, end)
544    }
545
546    fn guest_mem(size: u64) -> GuestMem {
547        let vmo = zx::Vmo::create(size).unwrap();
548        guest_mem_from_vmo(&vmo).unwrap()
549    }
550
551    #[test]
552    fn queue_check() {
553        let queues = &[1, 3][..];
554        assert_matches!(queues.check_queue(1, [].iter().cloned()), Ok(()));
555        assert_matches!(queues.check_queue(3, [].iter().cloned()), Ok(()));
556        assert_matches!(
557            queues.check_queue(0, [].iter().cloned()),
558            Err(DeviceError::InvalidQueue(0))
559        );
560
561        let queues = 1..=2;
562        assert_matches!(queues.check_queue(1, [].iter().cloned()), Ok(()));
563        assert_matches!(queues.check_queue(2, [].iter().cloned()), Ok(()));
564        assert_matches!(
565            queues.check_queue(3, [].iter().cloned()),
566            Err(DeviceError::InvalidQueue(3))
567        );
568    }
569
570    #[test]
571    fn invalid_queue() {
572        // try and add two different queues with the same number
573        let (queue1, queue2_offset) = make_queue_config(0, 4, 64);
574        let (queue2, _) = make_queue_config(0, 8, queue2_offset);
575        assert_matches!(
576            DeviceBuilder::new(None, None).add_queue(queue1).unwrap().add_queue(queue2),
577            Err(DeviceError::InvalidQueue(0))
578        );
579    }
580
581    #[test]
582    fn invalid_queue_config() {
583        let (queue1, queue1_end) = make_queue_config(0, 4, 64);
584        let mem_size = queue1_end
585            + (zx::system_get_page_size() as u64
586                - (queue1_end % zx::system_get_page_size() as u64));
587        let (queue2, _) = make_queue_config(1, 6, mem_size);
588        let builder = DeviceBuilder::new(None, None)
589            .add_queue(queue1)
590            .unwrap()
591            .add_queue(queue2)
592            .unwrap()
593            .map_notify(|_| Ok(NotificationCounter::new()))
594            .unwrap();
595
596        let mem = guest_mem(mem_size);
597
598        assert_matches!(builder.build(0, &mem).err(), Some(DeviceError::BadQueueConfig(1)));
599    }
600
601    #[fasync::run_until_stalled(test)]
602    async fn builder_from_stream() -> Result<(), anyhow::Error> {
603        let (queue1, queue1_end) = make_queue_config(0, 4, 64);
604        let (queue2, queue2_end) = make_queue_config(1, 8, queue1_end);
605        let mem = guest_mem(queue2_end);
606
607        let builder =
608            DeviceBuilder::new(None, None).map_notify(|_| Ok(NotificationCounter::new())).unwrap();
609
610        assert_eq!(builder.vmo, None);
611
612        let (vmm_side, device_side) = fidl::endpoints::create_endpoints::<VirtioDeviceMarker>();
613        let vmm_side = vmm_side.into_proxy();
614        let mut device_side = device_side.into_stream();
615
616        let device_fut = config_builder_from_stream(builder, &mut device_side, &(0..=1), &mem);
617
618        let config_fut = async {
619            vmm_side
620                .configure_queue(queue1.queue, queue1.size, queue1.desc, queue1.avail, queue1.used)
621                .await
622                .unwrap();
623            // send a notify instead of a ready to cause an error.
624            vmm_side.notify_queue(0).unwrap();
625        };
626
627        assert_matches!(
628            futures::join!(device_fut, config_fut).0.err(),
629            Some(DeviceError::UnexpectedMessage(_))
630        );
631
632        // Now build again with a ready that should succeed.
633
634        let builder =
635            DeviceBuilder::new(None, None).map_notify(|_| Ok(NotificationCounter::new())).unwrap();
636
637        let (vmm_side, device_side) = fidl::endpoints::create_endpoints::<VirtioDeviceMarker>();
638        let vmm_side = vmm_side.into_proxy();
639        let mut device_side = device_side.into_stream();
640
641        let device_fut = config_builder_from_stream(builder, &mut device_side, &(0..=1), &mem)
642            .map_ok(|(device, responder)| {
643                responder.send().unwrap();
644                device
645            });
646
647        let config_fut = async {
648            vmm_side
649                .configure_queue(queue1.queue, queue1.size, queue1.desc, queue1.avail, queue1.used)
650                .await
651                .unwrap();
652            vmm_side
653                .configure_queue(queue2.queue, queue2.size, queue2.desc, queue2.avail, queue2.used)
654                .await
655                .unwrap();
656            vmm_side.ready(3).await.unwrap();
657        };
658
659        let device = futures::join!(device_fut, config_fut).0.unwrap();
660
661        // Check the features and queues are in the device
662        assert_eq!(device.get_features(), 3);
663        assert!(device.take_stream(0).is_ok());
664        assert!(device.take_stream(1).is_ok());
665
666        Ok(())
667    }
668
669    #[test]
670    fn builder_take_vmo() {
671        let vmo = zx::Vmo::create(4096).unwrap();
672
673        let mut builder = DeviceBuilder::new(None, Some(vmo))
674            .map_notify(|_| Ok(NotificationCounter::new()))
675            .unwrap();
676        assert_eq!(builder.take_vmo().unwrap().get_size().unwrap(), 4096);
677    }
678}