1use 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
30const TIMEOUT_WARN_THRESHOLD: f64 = 0.8;
32
33pub struct TestRealmContext {
62 test_ns: InstalledNamespace,
65
66 devfs: fidl_fuchsia_io::DirectoryProxy,
68}
69
70impl TestRealmContext {
71 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 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 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 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 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 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 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 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 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 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 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 while let Some(task_handle) = self.netdevice_task_handles.pop() {
387 drop(task_handle);
388 }
389
390 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 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::<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 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 async fn sleep_unless_after_deadline_(
466 &mut self,
467 verbose: bool,
468 ) -> Result<zx::MonotonicDuration, zx::MonotonicDuration> {
469 {
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 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
520pub 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 entry.timestamp_nanos.take();
535 }
536 }
537 scan_result_list
538}
539
540pub 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
552pub async fn policy_scan_for_networks<'a>(
559 client_controller: fidl_policy::ClientControllerProxy,
560) -> Vec<fidl_policy::ScanResult> {
561 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
576pub 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}