wlan_hw_sim/
test_utils.rs

1// Copyright 2018 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.
4use crate::event::{self, Handler};
5use crate::netdevice_helper;
6use crate::wlancfg_helper::{start_ap_and_wait_for_confirmation, NetworkConfigBuilder};
7use fidl::endpoints::{create_endpoints, create_proxy, Proxy};
8use fuchsia_async::{DurationExt, MonotonicInstant, TimeoutExt, Timer};
9use fuchsia_component::client::{connect_to_protocol, connect_to_protocol_at};
10use zx::prelude::*;
11
12use futures::channel::oneshot;
13use futures::{FutureExt, StreamExt};
14use ieee80211::{MacAddr, MacAddrBytes};
15use log::{debug, info, warn};
16use realm_client::{extend_namespace, InstalledNamespace};
17use std::fmt::Display;
18use std::future::Future;
19use std::pin::Pin;
20use std::sync::Arc;
21use std::task::{Context, Poll};
22use test_realm_helpers::tracing::Tracing;
23use wlan_common::test_utils::ExpectWithin;
24use wlantap_client::Wlantap;
25use {
26    fidl_fuchsia_driver_test as fidl_driver_test, fidl_fuchsia_wlan_policy as fidl_policy,
27    fidl_fuchsia_wlan_tap as wlantap, fidl_test_wlan_realm as fidl_realm,
28};
29
30/// Percent of a timeout duration past which we log a warning.
31const TIMEOUT_WARN_THRESHOLD: f64 = 0.8;
32
33// Struct that allows a test suite to interact with the test realm.
34//
35// If the test suite needs to connect to a protocol exposed by the test realm, it MUST use the
36// context's realm_proxy and cannot use fuchsia_component::client::connect_to_protocol.
37//
38// Similarly, if the test suite needs to connect to /dev hosted by the test realm, it must use the
39// context's devfs. There is currently no way to access any other directories in the test realm. If
40// the test suite needs to access any other directories, the test realm factory implementation and
41// FIDL API will need to be changed.
42//
43// Example:
44//
45// // Create a new test realm context
46// let ctx = ctx::new(fidl_realm::WlanConfig{ ..Default::default() };
47//
48// // Connect to a protocol
49// let protocol_proxy = ctx.test_realm_proxy()
50//   .connect_to_protocol::<fidl_fuchsia_protocol::Protocol>()
51//   .await?;
52//
53// // Connect to dev/class/network in the test realm
54// let (directory, directory_server) =
55//      create_proxy::<fidl_fuchsia_io::DirectoryMarker>();
56//  fdio::service_connect_at(
57//     ctx.devfs().as_channel().as_ref(),
58//     "class/network",
59//     directory_server.into_channel(),
60//  )?;
61pub struct TestRealmContext {
62    // The test namespace, which allows the test suite to connect to protocols exposed by
63    // the test realm.
64    test_ns: InstalledNamespace,
65
66    // A directory proxy connected to "/dev" in the test realm.
67    devfs: fidl_fuchsia_io::DirectoryProxy,
68}
69
70impl TestRealmContext {
71    // Connect to the test realm factory to create and start a new test realm and return the test
72    // realm context. This will also start the driver test realm.
73    //
74    // Panics if any errors occur when the realm factory is being created.
75    pub async fn new(config: fidl_realm::WlanConfig) -> Arc<Self> {
76        let realm_factory = connect_to_protocol::<fidl_realm::RealmFactoryMarker>()
77            .expect("Could not connect to realm factory protocol");
78
79        let (dict_client, dict_server) = create_endpoints();
80        let (devfs_proxy, devfs_server) = create_proxy();
81
82        // Create the test realm for this test. This returns a
83        // `fuchsia.component.sandbox/Dictionary`, which is then consumed by `extend_namespace`
84        // to turn it into a directory installed in this component's namespace at
85        // `test_ns.prefix()`.
86        let options = fidl_realm::RealmOptions {
87            devfs_server_end: Some(devfs_server),
88            wlan_config: Some(config),
89            ..Default::default()
90        };
91        let _ = realm_factory
92            .create_realm2(options, dict_server)
93            .await
94            .expect("Could not create realm");
95        let test_ns =
96            extend_namespace(realm_factory, dict_client).await.expect("failed to extend ns");
97
98        // Start the driver test realm
99        let driver_test_realm_proxy =
100            connect_to_protocol_at::<fidl_driver_test::RealmMarker>(&test_ns)
101                .expect("Failed to connect to driver test realm");
102
103        let (pkg_client, pkg_server) = create_endpoints();
104        fuchsia_fs::directory::open_channel_in_namespace(
105            "/pkg",
106            fidl_fuchsia_io::PERM_READABLE | fidl_fuchsia_io::PERM_EXECUTABLE,
107            pkg_server,
108        )
109        .expect("Could not open /pkg");
110
111        let test_component = fidl_fuchsia_component_resolution::Component {
112            package: Some(fidl_fuchsia_component_resolution::Package {
113                directory: Some(pkg_client),
114                ..Default::default()
115            }),
116            ..Default::default()
117        };
118
119        driver_test_realm_proxy
120            .start(fidl_driver_test::RealmArgs {
121                test_component: Some(test_component),
122                ..Default::default()
123            })
124            .await
125            .expect("FIDL error when starting driver test realm")
126            .expect("Driver test realm server returned an error");
127
128        Arc::new(Self { test_ns, devfs: devfs_proxy })
129    }
130
131    pub fn test_ns_prefix(&self) -> &str {
132        self.test_ns.prefix()
133    }
134
135    pub fn devfs(&self) -> &fidl_fuchsia_io::DirectoryProxy {
136        &self.devfs
137    }
138}
139
140type EventStream = wlantap::WlantapPhyEventStream;
141pub struct TestHelper {
142    ctx: Arc<TestRealmContext>,
143    _tracing: Option<Tracing>,
144    netdevice_task_handles: Vec<fuchsia_async::Task<()>>,
145    _wlantap: Wlantap,
146    proxy: Arc<wlantap::WlantapPhyProxy>,
147    event_stream: Option<EventStream>,
148}
149struct TestHelperFuture<H, F>
150where
151    H: Handler<(), wlantap::WlantapPhyEvent>,
152    F: Future + Unpin,
153{
154    event_stream: Option<EventStream>,
155    handler: H,
156    future: F,
157}
158impl<H, F> Unpin for TestHelperFuture<H, F>
159where
160    H: Handler<(), wlantap::WlantapPhyEvent>,
161    F: Future + Unpin,
162{
163}
164impl<H, F> Future for TestHelperFuture<H, F>
165where
166    H: Handler<(), wlantap::WlantapPhyEvent>,
167    F: Future + Unpin,
168{
169    type Output = (F::Output, EventStream);
170    /// Any events that accumulated in the |event_stream| since last poll will be passed to
171    /// |event_handler| before the |main_future| is polled
172    fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
173        let helper = &mut *self;
174        let stream = helper.event_stream.as_mut().unwrap();
175        while let Poll::Ready(optional_result) = stream.poll_next_unpin(cx) {
176            let event = optional_result
177                .expect("Unexpected end of the WlantapPhy event stream")
178                .expect("WlantapPhy event stream returned an error");
179            helper.handler.call(&mut (), &event);
180        }
181        match helper.future.poll_unpin(cx) {
182            Poll::Pending => {
183                debug!("Main future poll response is pending. Waiting for completion.");
184                Poll::Pending
185            }
186            Poll::Ready(x) => Poll::Ready((x, helper.event_stream.take().unwrap())),
187        }
188    }
189}
190impl TestHelper {
191    // Create a client TestHelper with a new TestRealmContext.
192    // NOTE: if a test case creates multiple TestHelpers that should all share the same test realm,
193    // it should use TestHelper::begin_test_with_context.
194    pub async fn begin_test(
195        phy_config: wlantap::WlantapPhyConfig,
196        realm_config: fidl_realm::WlanConfig,
197    ) -> Self {
198        let ctx = TestRealmContext::new(realm_config).await;
199        Self::begin_test_with_context(ctx, phy_config).await
200    }
201
202    // Create client TestHelper with a given TestRealmContext.
203    // If a test case creates multiple TestHelpers that must refer to the same instance of WLAN
204    // components, then all TestHelpers must use a copy of the same TestRealmContext.
205    //
206    // Example:
207    //
208    // // Create a new test realm context
209    // let ctx = TestRealmContext::new(fidl_realm::WlanConfig{ ..Default::default() };
210    //
211    // // Create both helpers with copies of the same context
212    // let helper1 = TestHelper::begin_test_with_context(
213    //    ctx.clone(),
214    //    default_wlantap_client_config(),
215    // ).await;
216    //
217    // let helper2 = TestHelper::begin_test_with_context(
218    //    ctx.clone(),
219    //    default_wlantap_client_config()).await;
220    pub async fn begin_test_with_context(
221        ctx: Arc<TestRealmContext>,
222        config: wlantap::WlantapPhyConfig,
223    ) -> Self {
224        let mut helper = TestHelper::create_phy_and_helper(config, ctx).await;
225        helper.wait_for_wlan_softmac_start().await;
226        helper
227    }
228
229    // Create an AP TestHelper with a new TestRealmContext.
230    // NOTE: if a test case creates multiple TestHelpers that should all share the same test realm,
231    // it should use TestHelper::begin_ap_test_with_context.
232    pub async fn begin_ap_test(
233        phy_config: wlantap::WlantapPhyConfig,
234        network_config: NetworkConfigBuilder,
235        realm_config: fidl_realm::WlanConfig,
236    ) -> Self {
237        let ctx = TestRealmContext::new(realm_config).await;
238        Self::begin_ap_test_with_context(ctx, phy_config, network_config).await
239    }
240
241    // Create AP TestHelper with a given TestRealmContext.
242    // If a test case creates multiple TestHelpers that must refer to the same instance of WLAN
243    // components, then all TestHelpers must use a copy of the same TestRealmContext.
244    //
245    // Example:
246    //
247    // // Create a new test realm context
248    // let ctx = TestRealmContext::new(fidl_realm::WlanConfig{ ..Default::default() };
249    //
250    // // Create both helpers with copies of the same context
251    // let helper1 = TestHelper::begin_ap_test_with_context(
252    //    ctx.clone(),
253    //    default_wlantap_client_config(),
254    //    network_config1,
255    // ).await;
256    //
257    // let helper2 = TestHelper::begin_ap_test_with_context(
258    //    ctx.clone(),
259    //    default_wlantap_client_config(),
260    //    network_config2
261    // ).await;
262    pub async fn begin_ap_test_with_context(
263        ctx: Arc<TestRealmContext>,
264        config: wlantap::WlantapPhyConfig,
265        network_config: NetworkConfigBuilder,
266    ) -> Self {
267        let mut helper = TestHelper::create_phy_and_helper(config, ctx).await;
268        start_ap_and_wait_for_confirmation(helper.ctx.test_ns_prefix(), network_config).await;
269        helper.wait_for_wlan_softmac_start().await;
270        helper
271    }
272
273    async fn create_phy_and_helper(
274        config: wlantap::WlantapPhyConfig,
275        ctx: Arc<TestRealmContext>,
276    ) -> Self {
277        let tracing = Tracing::create_and_initialize_tracing(ctx.test_ns_prefix())
278            .await
279            .map_err(|e| warn!("{e:?}"))
280            .ok();
281
282        // Trigger creation of wlantap serviced phy and iface for testing.
283        let wlantap =
284            Wlantap::open_from_devfs(&ctx.devfs).await.expect("Failed to open wlantapctl");
285        let proxy = wlantap.create_phy(config).await.expect("Failed to create wlantap PHY");
286        let event_stream = Some(proxy.take_event_stream());
287        TestHelper {
288            ctx,
289            _tracing: tracing,
290            netdevice_task_handles: vec![],
291            _wlantap: wlantap,
292            proxy: Arc::new(proxy),
293            event_stream,
294        }
295    }
296
297    async fn wait_for_wlan_softmac_start(&mut self) {
298        let (sender, receiver) = oneshot::channel::<()>();
299        self.run_until_complete_or_timeout(
300            zx::MonotonicDuration::from_seconds(120),
301            "receive a WlanSoftmacStart event",
302            event::on_start_mac(event::once(|_, _| sender.send(()))),
303            receiver,
304        )
305        .await
306        .unwrap_or_else(|oneshot::Canceled| panic!());
307    }
308
309    /// Returns a clone of the `Arc<wlantap::WlantapPhyProxy>` as a convenience for passing
310    /// the proxy to futures. Tests must drop every `Arc<wlantap::WlantapPhyProxy>` returned from this
311    /// method before dropping the TestHelper. Otherwise, TestHelper::drop() cannot synchronously
312    /// block on WlantapPhy.Shutdown().
313    pub fn proxy(&self) -> Arc<wlantap::WlantapPhyProxy> {
314        Arc::clone(&self.proxy)
315    }
316
317    pub fn test_ns_prefix(&self) -> &str {
318        self.ctx.test_ns_prefix()
319    }
320
321    pub fn devfs(&self) -> &fidl_fuchsia_io::DirectoryProxy {
322        self.ctx.devfs()
323    }
324
325    pub async fn start_netdevice_session(
326        &mut self,
327        mac: MacAddr,
328    ) -> (netdevice_client::Session, netdevice_client::Port) {
329        let mac = fidl_fuchsia_net::MacAddress { octets: mac.to_array() };
330        let (client, port) = netdevice_helper::create_client(self.devfs(), mac)
331            .await
332            .expect("failed to create netdevice client");
333        let (session, task_handle) = netdevice_helper::start_session(client, port).await;
334        self.netdevice_task_handles.push(task_handle);
335        (session, port)
336    }
337
338    /// Will run the main future until it completes or when it has run past the specified duration.
339    /// Note that any events that are observed on the event stream will be passed to the
340    /// |event_handler| closure first before making progress on the main future.
341    /// So if a test generates many events each of which requires significant computational time in
342    /// the event handler, the main future may not be able to complete in time.
343    pub async fn run_until_complete_or_timeout<H, F>(
344        &mut self,
345        timeout: zx::MonotonicDuration,
346        context: impl Display,
347        handler: H,
348        future: F,
349    ) -> F::Output
350    where
351        H: Handler<(), wlantap::WlantapPhyEvent>,
352        F: Future + Unpin,
353    {
354        info!("Running main future until completion or timeout with event handler: {}", context);
355        let start_time = zx::MonotonicInstant::get();
356        let (item, stream) = TestHelperFuture {
357            event_stream: Some(self.event_stream.take().unwrap()),
358            handler,
359            future,
360        }
361        .expect_within(timeout, format!("Main future timed out: {}", context))
362        .await;
363        let end_time = zx::MonotonicInstant::get();
364        let elapsed = end_time - start_time;
365        let elapsed_seconds = elapsed.into_seconds_f64();
366        let elapsed_ratio = elapsed_seconds / timeout.into_seconds_f64();
367        if elapsed_ratio < TIMEOUT_WARN_THRESHOLD {
368            info!("Main future completed in {:.2} seconds: {}", elapsed_seconds, context);
369        } else {
370            warn!(
371                "Main future completed in {:.2} seconds ({:.1}% of timeout): {}",
372                elapsed_seconds,
373                elapsed_ratio * 100.,
374                context,
375            );
376        }
377        self.event_stream = Some(stream);
378        item
379    }
380}
381impl Drop for TestHelper {
382    fn drop(&mut self) {
383        // Drop each fuchsia_async::Task driving each
384        // netdevice_client::Session in the reverse order the test
385        // created them.
386        while let Some(task_handle) = self.netdevice_task_handles.pop() {
387            drop(task_handle);
388        }
389
390        // Create a placeholder proxy to swap into place of self.proxy. This allows this
391        // function to create a synchronous proxy from the real proxy.
392        let (placeholder_proxy, _server_end) =
393            fidl::endpoints::create_proxy::<wlantap::WlantapPhyMarker>();
394        let mut proxy = Arc::new(placeholder_proxy);
395        std::mem::swap(&mut self.proxy, &mut proxy);
396
397        // Drop the event stream so the WlantapPhyProxy can be converted
398        // back into a channel. Conversion from a proxy into a channel fails
399        // otherwise.
400        let event_stream = self.event_stream.take();
401        drop(event_stream);
402
403        let sync_proxy = wlantap::WlantapPhySynchronousProxy::new(fidl::Channel::from_handle(
404            // Arc::into_inner() should succeed in a properly constructed test. Using a WlantapPhyProxy
405            // returned from TestHelper beyond the lifetime of TestHelper is not supported.
406            Arc::<wlantap::WlantapPhyProxy>::into_inner(proxy)
407                .expect("Outstanding references to WlantapPhyProxy! Failed to drop TestHelper.")
408                .into_channel()
409                .expect("failed to get fidl::AsyncChannel from proxy")
410                .into_zx_channel()
411                .into_handle(),
412        ));
413
414        // TODO(b/307808624): At this point in the shutdown, we should
415        // stop wlancfg first and destroy all ifaces through
416        // fuchsia.wlan.device.service/DeviceMonitor.DestroyIface().
417        // This test framework does not currently support stopping
418        // individual components. If instead we drop the
419        // TestRealmProxy, and thus stop both wlancfg and
420        // wlandevicemonitor, wlandevicemonitor which will drop the
421        // GenericSme channel before graceful destruction of the
422        // iface. Dropping the GenericSme channel for an existing
423        // iface is considered an error because doing so prevents
424        // future communication with the iface.
425        //
426        // In lieu of stopping wlancfg first, we instead shutdown the
427        // phy device via WlantapPhy.Shutdown() which will block until
428        // both the phy and any remaining ifaces are shutdown. We
429        // first shutdown the phy to prevent any automated CreateIface
430        // calls from wlancfg after removing the iface.
431        sync_proxy
432            .shutdown(zx::MonotonicInstant::INFINITE)
433            .expect("Failed to shutdown WlantapPhy gracefully.");
434    }
435}
436
437pub struct RetryWithBackoff {
438    deadline: MonotonicInstant,
439    prev_delay: zx::MonotonicDuration,
440    next_delay: zx::MonotonicDuration,
441    max_delay: zx::MonotonicDuration,
442}
443impl RetryWithBackoff {
444    pub fn new(timeout: zx::MonotonicDuration) -> Self {
445        RetryWithBackoff {
446            deadline: MonotonicInstant::after(timeout),
447            prev_delay: zx::MonotonicDuration::from_millis(0),
448            next_delay: zx::MonotonicDuration::from_millis(1),
449            max_delay: zx::MonotonicDuration::INFINITE,
450        }
451    }
452    pub fn infinite_with_max_interval(max_delay: zx::MonotonicDuration) -> Self {
453        Self {
454            deadline: MonotonicInstant::INFINITE,
455            max_delay,
456            ..Self::new(zx::MonotonicDuration::from_nanos(0))
457        }
458    }
459
460    /// Return Err if the deadline was exceeded when this function was called.
461    /// Otherwise, sleep for a little longer (following Fibonacci series) or up
462    /// to the deadline, whichever is soonest. If a sleep occurred, this function
463    /// returns Ok. The value contained in both Ok and Err is the zx::MonotonicDuration
464    /// until or after the deadline when the function returns.
465    async fn sleep_unless_after_deadline_(
466        &mut self,
467        verbose: bool,
468    ) -> Result<zx::MonotonicDuration, zx::MonotonicDuration> {
469        // Add an inner scope up to just after Timer::new to ensure all
470        // time assignments are dropped after the sleep occurs. This
471        // prevents misusing them after the sleep since they are all
472        // no longer correct after the clock moves.
473        {
474            if MonotonicInstant::after(zx::MonotonicDuration::from_millis(0)) > self.deadline {
475                if verbose {
476                    info!("Skipping sleep. Deadline exceeded.");
477                }
478                return Err(self.deadline - MonotonicInstant::now());
479            }
480
481            let sleep_deadline =
482                std::cmp::min(MonotonicInstant::after(self.next_delay), self.deadline);
483            if verbose {
484                let micros = sleep_deadline.into_nanos() / 1_000;
485                info!("Sleeping until {}.{} 😴", micros / 1_000_000, micros % 1_000_000);
486            }
487
488            Timer::new(sleep_deadline).await;
489        }
490
491        // If the next delay interval exceeds max_delay (even if by overflow),
492        // then saturate at max_delay.
493        if self.next_delay < self.max_delay {
494            let next_delay = std::cmp::min(
495                self.max_delay,
496                zx::MonotonicDuration::from_nanos(
497                    self.prev_delay.into_nanos().saturating_add(self.next_delay.into_nanos()),
498                ),
499            );
500            self.prev_delay = self.next_delay;
501            self.next_delay = next_delay;
502        }
503
504        Ok(self.deadline - MonotonicInstant::now())
505    }
506
507    pub async fn sleep_unless_after_deadline(
508        &mut self,
509    ) -> Result<zx::MonotonicDuration, zx::MonotonicDuration> {
510        self.sleep_unless_after_deadline_(false).await
511    }
512
513    pub async fn sleep_unless_after_deadline_verbose(
514        &mut self,
515    ) -> Result<zx::MonotonicDuration, zx::MonotonicDuration> {
516        self.sleep_unless_after_deadline_(true).await
517    }
518}
519
520/// TODO(https://fxbug.dev/42164608): This function strips the `timestamp_nanos` field
521/// from each `fidl_fuchsia_wlan_policy::ScanResult` entry since the `timestamp_nanos`
522/// field is undefined.
523pub fn strip_timestamp_nanos_from_scan_results(
524    mut scan_result_list: Vec<fidl_fuchsia_wlan_policy::ScanResult>,
525) -> Vec<fidl_fuchsia_wlan_policy::ScanResult> {
526    for scan_result in &mut scan_result_list {
527        scan_result
528            .entries
529            .as_mut()
530            .unwrap()
531            .sort_by(|a, b| a.bssid.as_ref().unwrap().cmp(&b.bssid.as_ref().unwrap()));
532        for entry in scan_result.entries.as_mut().unwrap() {
533            // TODO(https://fxbug.dev/42164608): Strip timestamp_nanos since it's not implemented.
534            entry.timestamp_nanos.take();
535        }
536    }
537    scan_result_list
538}
539
540/// Sort a list of scan results by the `id` and `bssid` fields.
541///
542/// This function will panic if either of the `id` or `entries` fields
543/// are `None`.
544pub fn sort_policy_scan_result_list(
545    mut scan_result_list: Vec<fidl_fuchsia_wlan_policy::ScanResult>,
546) -> Vec<fidl_fuchsia_wlan_policy::ScanResult> {
547    scan_result_list
548        .sort_by(|a, b| a.id.as_ref().expect("empty id").cmp(&b.id.as_ref().expect("empty id")));
549    scan_result_list
550}
551
552/// Returns a map with the scan results returned by the policy layer. The map is
553/// keyed by the `id` field of each `fidl_fuchsia_policy::ScanResult`.
554///
555/// This function will panic if the `id` field is ever `None` or if policy returns
556/// the same `id` twice. Both of these are invariants we expect the policy layer
557/// to uphold.
558pub async fn policy_scan_for_networks<'a>(
559    client_controller: fidl_policy::ClientControllerProxy,
560) -> Vec<fidl_policy::ScanResult> {
561    // Request a scan from the policy layer.
562    let (scan_proxy, server_end) = create_proxy();
563    client_controller.scan_for_networks(server_end).expect("requesting scan");
564    let mut scan_result_list = Vec::new();
565    loop {
566        let proxy_result = scan_proxy.get_next().await.expect("getting scan results");
567        let next_scan_result_list = proxy_result.expect("scanning failed");
568        if next_scan_result_list.is_empty() {
569            break;
570        }
571        scan_result_list.extend(next_scan_result_list);
572    }
573    sort_policy_scan_result_list(strip_timestamp_nanos_from_scan_results(scan_result_list))
574}
575
576/// This function returns `Ok(r)`, where `r` is the return value from `main_future`,
577/// if `main_future` completes before the `timeout` duration. Otherwise, `Err(())` is returned.
578pub async fn timeout_after<R, F: Future<Output = R> + Unpin>(
579    timeout: zx::MonotonicDuration,
580    main_future: &mut F,
581) -> Result<R, ()> {
582    async { Ok(main_future.await) }.on_timeout(timeout.after_now(), || Err(())).await
583}