test_harness/
lib.rs

1// Copyright 2020 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
5use anyhow::{format_err, Context as _, Error};
6use fuchsia_async as fasync;
7use fuchsia_sync::Mutex;
8use futures::future::BoxFuture;
9use futures::stream::TryStreamExt;
10use futures::{future, select, Future, FutureExt};
11use std::any::{Any, TypeId};
12use std::collections::hash_map::Entry;
13use std::collections::HashMap;
14use std::pin::pin;
15use std::sync::Arc;
16
17pub const SHARED_STATE_TEST_COMPONENT_INDEX: &str = "TEST-COMPONENT";
18
19/// SharedState is a string-indexed map used to share state across multiple TestHarnesses that are
20/// tupled together. For example, the state could be a Bluetooth emulator instance and core
21/// component/driver hierarchy manipulated by two distinct Harnesses during a test. The map's value
22/// types use runtime polymorphism (`Box<dyn Any>`) so that any type of state may be shared. Once
23/// added, entries cannot be removed from the SharedState, although they may be modified.
24type InnerSharedState = HashMap<String, Arc<dyn Any + Send + Sync + 'static>>;
25
26#[derive(Default)]
27pub struct SharedState(Mutex<InnerSharedState>);
28
29impl SharedState {
30    /// Returns None if no entry exists for `key`. Returns Some(Err) if an entry exists for `key`,
31    /// but is not of type T. Returns Some(Ok(Arc<T>)) if the existing entry is successfully
32    /// downcasted to T.
33    pub fn get<T: Send + Sync + 'static>(&self, key: &str) -> Option<Result<Arc<T>, Error>> {
34        self.0.lock().get(key).cloned().map(Self::downcast_with_err)
35    }
36
37    /// Insert `val` at `key` if `key` is not yet occupied. If SharedState did not have an entry
38    /// for `key`, returns Ok(Arc<the inserted `val`>). Otherwise, does not insert `val` and returns
39    /// Err(Arc<existing value>)
40    pub fn try_insert<T: Send + Sync + 'static>(
41        &self,
42        key: &str,
43        val: T,
44    ) -> Result<Arc<T>, Arc<dyn Any + Send + Sync + 'static>> {
45        match self.0.lock().entry(key.to_string()) {
46            Entry::Occupied(existing) => Err(existing.get().clone()),
47            Entry::Vacant(empty) => {
48                let entry = Arc::new(val);
49                let _ = empty.insert(entry.clone());
50                Ok(entry)
51            }
52        }
53    }
54
55    /// This takes two type parameters, F and T. The inserter F is used in case `key` is not yet
56    /// associated with an existing state value to create the value associated with `key`. T is the
57    /// type of state expected to be associated with `key`. After possibly inserting the state
58    /// associated with `key` in the map, we dynamically cast `key`s state into type T. Errors can
59    /// stem from `inserter` failures, or existing types in the map not matching T.
60    pub async fn get_or_insert_with<F, Fut, T>(
61        &self,
62        key: &str,
63        inserter: F,
64    ) -> Result<Arc<T>, Error>
65    where
66        F: FnOnce() -> Fut,
67        Fut: Future<Output = Result<T, Error>>,
68        T: Send + Sync + 'static,
69    {
70        if let Some(res) = self.get(key) {
71            return res;
72        }
73        let state = inserter().await?;
74        // It's possible and OK for us to be preempted while running inserter.
75        self.try_insert(key, state).or_else(Self::downcast_with_err)
76    }
77
78    fn downcast_with_err<T: Send + Sync + 'static>(
79        any: Arc<dyn Any + Send + Sync + 'static>,
80    ) -> Result<Arc<T>, Error> {
81        any.downcast()
82            .map_err(|_| format_err!("failed to downcast to type {:?}", TypeId::of::<T>()))
83    }
84}
85
86/// A `TestHarness` is a type that provides an interface to test cases for interacting with
87/// functionality under test. For example, a WidgetHarness might provide controls for interacting
88/// with and measuring a Widget, allowing us to easily write tests for Widget functionality.
89///
90/// A `TestHarness` defines how to initialize (via `init()`) the harness resources and how to
91/// terminate (via `terminate()`) them when done. The `init()` function can also provide some
92/// environment resources (`env`) to be held for the test duration, and also a task (`runner`) that
93/// can be executed to perform asynchronous behavior necessary for the test harness to function
94/// correctly.
95pub trait TestHarness: Sized {
96    /// The type of environment needed to be held whilst the test runs. This is normally used to
97    /// keep resources open during the test, and allow a graceful shutdown in `terminate`.
98    type Env: Send + 'static;
99
100    /// A future that models any background computation the harness needs to process. If no
101    /// processing is needed, implementations should use `future::Pending` to model a future that
102    /// never returns Poll::Ready
103    type Runner: Future<Output = Result<(), Error>> + Unpin + Send + 'static;
104
105    /// Initialize a TestHarness, creating the harness itself, any hidden environment, and a runner
106    /// task to execute background behavior. May index into shared_state to access state that needs
107    /// to be shared across Harnesses. If `init` needs to access `shared_state` inside the returned
108    /// future, it should clone the state outside of the future and move it into the future.
109    ///
110    /// `shared_state` will be dropped before the test code executes, so if a shared state entry
111    /// must exist for the duration of the test, Harnesses should add it to their `Env`.
112    fn init(
113        shared_state: &Arc<SharedState>,
114    ) -> BoxFuture<'static, Result<(Self, Self::Env, Self::Runner), Error>>;
115
116    /// Terminate the TestHarness. This should clear up any and all resources that were created by
117    /// init()
118    fn terminate(env: Self::Env) -> BoxFuture<'static, Result<(), Error>>;
119}
120
121/// We can run any test which is an async function from some harness `H` to a result
122pub async fn run_with_harness<H, F, Fut>(test_func: F, test_component: Option<String>)
123where
124    H: TestHarness,
125    F: FnOnce(H) -> Fut + Send + 'static,
126    Fut: Future<Output = ()> + Send + 'static,
127{
128    diagnostics_log::initialize(diagnostics_log::PublishOptions::default()).expect("init logging");
129    let state: Arc<SharedState> = Default::default();
130    if test_component.is_some() {
131        let _ = state
132            .try_insert(SHARED_STATE_TEST_COMPONENT_INDEX, test_component.unwrap())
133            .expect("insert test_component");
134    }
135    let (harness, env, runner) = H::init(&state).await.expect("couldn't initialize harness");
136    // Drop `state` so that SharedState entries may be dropped if not needed during test execution.
137    // See Harness::init doc comment for further explanation.
138    drop(state);
139
140    let run_test = test_func(harness);
141    let run_test = pin!(run_test);
142    let runner = pin!(runner);
143
144    let result = select! {
145        () = run_test.fuse() => Ok(()),
146        runner_result = runner.fuse() => runner_result.context("error running harness background task"),
147    };
148
149    let () = H::terminate(env).await.expect("couldn't terminate harness");
150    result.expect("error running test");
151}
152
153/// The Unit type can be used as the empty test-harness - it does no initialization and no
154/// termination.
155impl TestHarness for () {
156    type Env = ();
157    type Runner = future::Pending<Result<(), Error>>;
158
159    fn init(
160        _shared_state: &Arc<SharedState>,
161    ) -> BoxFuture<'static, Result<(Self, Self::Env, Self::Runner), Error>> {
162        async { Ok(((), (), future::pending())) }.boxed()
163    }
164    fn terminate(_env: Self::Env) -> BoxFuture<'static, Result<(), Error>> {
165        future::ok(()).boxed()
166    }
167}
168
169/// We can implement TestHarness for any tuples of types that are TestHarnesses - this macro can
170/// generate boilerplate implementations for tuples of arities by combining the init() and
171/// terminate() functions of the tuple components.
172///
173/// ----
174///
175/// To elaborate: This implementation is implied by the nature of _applicative functors_, which are
176/// a class of types that support 'tupling' of their type members. In particular, Functions, Tuples,
177/// Futures and Results are all applicative, and compositions of applicatives are _also_ applicative
178/// by definition. So a `Function that returns a Result of a Tuple` is applicative (e.g. `init()`),
179/// as is a `Function that returns a Future of a Result` (such as `terminate()`).
180///
181/// A TestHarness impl itself is really equivalent to a tuple of two functions - init() and
182/// terminate(). Again, by the composition of applicative functors, this itself is applicative, and
183/// therefore a tuple of TestHarness impls can be turned into an TestHarness impl of a tuple. Rustc
184/// isn't able to derive this automatically for us so we write this macro here to do the heavy
185/// lifting.
186///
187/// (Further caveat: The tupling of terminate() is technically slightly more complex as it's a
188/// function indexed by a type parameter (Self::Env), but it still shakes out much the same)
189macro_rules! generate_tuples {
190    ($(
191        ($($Harness:ident),*),
192    )*) => ($(
193            // The impl below re-uses type names as identifiers, so we allow non_snake_case to
194            // suppress warnings over using 'A' instead of 'a', etc.
195            #[allow(non_snake_case)]
196            impl<$($Harness: TestHarness + Send),*> TestHarness for ($($Harness),*) {
197                type Env = ($($Harness::Env),*);
198                type Runner = BoxFuture<'static, Result<(), Error>>;
199
200                fn init(shared_state: &Arc<SharedState>) -> BoxFuture<'static, Result<(Self, Self::Env, Self::Runner), Error>> {
201                    let shared_state = shared_state.clone();
202                    async move {
203                        $(
204                            let $Harness = $Harness::init(&shared_state).await?;
205                        )*
206
207                        // Create a stream of the result of each future
208                        let runners = futures::stream::select_all(
209                            vec![
210                                $( $Harness.2.boxed().into_stream()),*
211                            ]
212                        );
213
214                        // Use try_collect to return first error or continue to completion
215                        let runner = runners.try_collect::<()>().boxed();
216
217                        let harness = ($($Harness.0),*);
218                        let env = ($($Harness.1),*);
219                        Ok((harness, env, runner))
220                    }
221                    .boxed()
222                }
223
224                fn terminate(environment: Self::Env) -> BoxFuture<'static, Result<(), Error>> {
225                    let ($($Harness),*) = environment;
226                    async {
227                        $(
228                            let $Harness = $Harness::terminate($Harness).await;
229                        )*
230                        let done = Ok(());
231                        $(
232                            let done = done.and($Harness);
233                        )*
234                        done
235                    }.boxed()
236                }
237            }
238    )*)
239}
240
241// Generate TestHarness impls for tuples up to arity-6
242generate_tuples! {
243  (A, B),
244  (A, B, C),
245  (A, B, C, D),
246  (A, B, C, D, E),
247  (A, B, C, D, E, F),
248}
249
250// import the macro from the macro crate
251pub use test_harness_macro::run_singlethreaded_test;
252
253// Re-export from fuchsia_async to provide an unambiguous direct include from test_harness_macro
254/// Runs a test in an executor, potentially repeatedly and concurrently
255pub fn run_singlethreaded_test<F, Fut, R>(test: F) -> R
256where
257    F: 'static + Send + Sync + Fn(usize) -> Fut,
258    Fut: 'static + Future<Output = R>,
259    R: fasync::test_support::TestResult,
260{
261    fasync::test_support::run_singlethreaded_test(test)
262}