input_pipeline/
autorepeater.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// TODO(https://fxbug.dev/42170553): Check what happens with the modifier keys - we should perhaps maintain
6// them.
7
8//! Implements hardware key autorepeat.
9//!
10//! The [Autorepeater] is a bit of an exception among the stages of the input pipeline.  This
11//! handler does not implement [input_pipeline::InputHandler], as it requires a different approach
12//! to event processing.
13//!
14//! Specifically, it requires the ability to interleave the events it generates into the
15//! flow of "regular" events through the input pipeline.  While the [input_pipeline::InputHandler]
16//! trait could in principle be modified to admit this sort of approach to event processing, in
17//! practice the [Autorepeater] is for now the only stage that requires this approach, so it is
18//! not cost effective to retrofit all other handlers just for the sake of this one.  We may
19//! revisit this decision if we grow more stages that need autorepeat.
20
21use crate::input_device::{self, Handled, InputDeviceDescriptor, InputDeviceEvent, InputEvent};
22use crate::input_handler::InputHandlerStatus;
23use crate::keyboard_binding::KeyboardEvent;
24use crate::metrics;
25use anyhow::{anyhow, Context, Result};
26use fidl_fuchsia_settings as fsettings;
27use fidl_fuchsia_ui_input3::{self as finput3, KeyEventType, KeyMeaning};
28use fuchsia_async::{MonotonicInstant, Task, Timer};
29use fuchsia_inspect::health::Reporter;
30use futures::channel::mpsc::{self, UnboundedReceiver, UnboundedSender};
31use futures::StreamExt;
32use metrics_registry::*;
33use std::cell::RefCell;
34use std::rc::Rc;
35use zx::MonotonicDuration;
36
37/// The value range reserved for the modifier key meanings.  See the documentation for
38/// `fuchsia.ui.input3/NonPrintableKey` for details.
39const RESERVED_MODIFIER_RANGE: std::ops::Range<u32> = finput3::NonPrintableKey::Alt.into_primitive()
40    ..finput3::NonPrintableKey::Enter.into_primitive();
41
42/// Typed autorepeat settings.  Use [Default::default()] and the `into_with_*`
43/// to create a new instance.
44#[derive(Debug, PartialEq, Clone, Copy)]
45pub struct Settings {
46    // The time delay before autorepeat kicks in.
47    delay: MonotonicDuration,
48    // The average period between two successive autorepeats.  A reciprocal of
49    // the autorepeat rate.
50    period: MonotonicDuration,
51}
52
53impl Default for Settings {
54    fn default() -> Self {
55        Settings {
56            delay: MonotonicDuration::from_millis(250),
57            period: MonotonicDuration::from_millis(50),
58        }
59    }
60}
61
62impl From<fsettings::Autorepeat> for Settings {
63    /// Conversion, since [fsettings::Autorepeat] has untyped delay and period.
64    fn from(s: fsettings::Autorepeat) -> Self {
65        Self {
66            delay: MonotonicDuration::from_nanos(s.delay),
67            period: MonotonicDuration::from_nanos(s.period),
68        }
69    }
70}
71
72impl Settings {
73    /// Modifies the delay.
74    pub fn into_with_delay(self, delay: MonotonicDuration) -> Self {
75        Self { delay, ..self }
76    }
77
78    /// Modifies the period.
79    pub fn into_with_period(self, period: MonotonicDuration) -> Self {
80        Self { period, ..self }
81    }
82}
83
84// Whether the key is repeatable.
85enum Repeatability {
86    // The key may autorepeat.
87    Yes,
88    // The key may not autorepeat.
89    No,
90}
91
92/// Determines whether the given key meaning corresponds to a key effect that
93/// should be repeated.
94fn repeatability(key_meaning: Option<KeyMeaning>) -> Repeatability {
95    match key_meaning {
96        Some(KeyMeaning::Codepoint(0)) => Repeatability::No,
97        Some(KeyMeaning::Codepoint(_)) => Repeatability::Yes, // A code point.
98        Some(KeyMeaning::NonPrintableKey(k)) => {
99            if RESERVED_MODIFIER_RANGE.contains(&k.into_primitive()) {
100                Repeatability::No
101            } else {
102                Repeatability::Yes
103            }
104        }
105        None => Repeatability::Yes, // Printable with US QWERTY keymap.
106    }
107}
108
109// An events multiplexer.
110#[derive(Debug, Clone)]
111enum AnyEvent {
112    // A keyboard input event.
113    Keyboard(KeyboardEvent, InputDeviceDescriptor, zx::MonotonicInstant, Handled),
114    // An input event other than keyboard.
115    NonKeyboard(InputEvent),
116    // A timer event.
117    Timeout,
118}
119
120impl TryInto<InputEvent> for AnyEvent {
121    type Error = anyhow::Error;
122
123    fn try_into(self) -> Result<InputEvent> {
124        match self {
125            AnyEvent::NonKeyboard(ev) => Ok(ev),
126            AnyEvent::Keyboard(ev, device_descriptor, event_time, handled) => Ok(InputEvent {
127                device_event: InputDeviceEvent::Keyboard(ev.into_with_folded_event()),
128                device_descriptor: device_descriptor,
129                event_time,
130                handled,
131                trace_id: None,
132            }),
133            _ => Err(anyhow!("not an InputEvent: {:?}", &self)),
134        }
135    }
136}
137
138// The state of the autorepeat generator.
139#[allow(clippy::large_enum_variant)] // TODO(https://fxbug.dev/401086995)
140#[derive(Debug, Clone)]
141enum State {
142    /// Autorepeat is not active.
143    Dormant,
144    /// Autorepeat is armed, we are waiting for a timer event to expire, and when
145    /// it does, we generate a repeat event.
146    Armed {
147        // The keyboard event that caused the state to become Armed.
148        armed_event: KeyboardEvent,
149        // The descriptor is used to reconstruct an InputEvent when needed.
150        armed_descriptor: InputDeviceDescriptor,
151        // The autorepeat timer is used in the various stages of autorepeat
152        // waits.
153        // Not used directly, but rather kept because of its side effect.
154        _delay_timer: Rc<Task<()>>,
155    },
156}
157
158impl Default for State {
159    fn default() -> Self {
160        State::Dormant
161    }
162}
163
164// Logs an `event` before sending to `sink` for debugging.
165fn unbounded_send_logged<T>(sink: &UnboundedSender<T>, event: T) -> Result<()>
166where
167    for<'a> &'a T: std::fmt::Debug,
168    T: 'static + Sync + Send,
169{
170    log::debug!("unbounded_send_logged: {:?}", &event);
171    sink.unbounded_send(event)?;
172    Ok(())
173}
174
175/// Creates a new autorepeat timer task.
176///
177/// The task will wait for the amount of time given in `delay`, and then send
178/// a [AnyEvent::Timeout] to `sink`; unless it is canceled.
179fn new_autorepeat_timer(
180    sink: UnboundedSender<AnyEvent>,
181    delay: MonotonicDuration,
182    metrics_logger: metrics::MetricsLogger,
183) -> Rc<Task<()>> {
184    let task = Task::local(async move {
185        Timer::new(MonotonicInstant::after(delay)).await;
186        log::debug!("autorepeat timeout");
187        unbounded_send_logged(&sink, AnyEvent::Timeout).unwrap_or_else(|e| {
188            metrics_logger.log_error(
189                InputPipelineErrorMetricDimensionEvent::AutorepeatCouldNotFireTimer,
190                std::format!("could not fire autorepeat timer: {:?}", e),
191            );
192        });
193    });
194    Rc::new(task)
195}
196
197/// Maintains the internal autorepeat state.
198///
199/// The autorepeat tracks key presses and generates autorepeat key events for
200/// the keys that are eligible for autorepeat.
201pub struct Autorepeater {
202    // Internal events are multiplexed into this sender.  We may make multiple
203    // clones to serialize async events.
204    event_sink: UnboundedSender<AnyEvent>,
205
206    // This end is consumed to get the multiplexed ordered events.
207    event_source: RefCell<UnboundedReceiver<AnyEvent>>,
208
209    // The current autorepeat state.
210    state: RefCell<State>,
211
212    // The autorepeat settings.
213    settings: Settings,
214
215    // The task that feeds input events into the processing loop.
216    _event_feeder: Task<()>,
217
218    /// The inventory of this handler's Inspect status.
219    inspect_status: InputHandlerStatus,
220
221    // The metrics logger.
222    metrics_logger: metrics::MetricsLogger,
223}
224
225impl Autorepeater {
226    /// Creates a new [Autorepeater].  The `source` is a receiver end through which
227    /// the input pipeline events are sent.  You must submit [Autorepeater::run]
228    /// to an executor to start the event processing.
229    pub fn new(
230        source: UnboundedReceiver<InputEvent>,
231        input_handlers_node: &fuchsia_inspect::Node,
232        metrics_logger: metrics::MetricsLogger,
233    ) -> Rc<Self> {
234        Self::new_with_settings(source, Default::default(), input_handlers_node, metrics_logger)
235    }
236
237    fn new_with_settings(
238        mut source: UnboundedReceiver<InputEvent>,
239        settings: Settings,
240        input_handlers_node: &fuchsia_inspect::Node,
241        metrics_logger: metrics::MetricsLogger,
242    ) -> Rc<Self> {
243        let (event_sink, event_source) = mpsc::unbounded();
244        let inspect_status = InputHandlerStatus::new(
245            input_handlers_node,
246            "autorepeater",
247            /* generates_events */ true,
248        );
249        let cloned_metrics_logger = metrics_logger.clone();
250
251        // We need a task to feed input events into the channel read by `run()`.
252        // The task will run until there is at least one sender. When there
253        // are no more senders, `source.next().await` will return None, and
254        // this task will exit.  The task will close the `event_sink` to
255        // signal to the other end that it will send no more events, which can
256        // be used for orderly shutdown.
257        let event_feeder = {
258            let event_sink = event_sink.clone();
259            Task::local(async move {
260                while let Some(event) = source.next().await {
261                    match event {
262                        InputEvent {
263                            device_event: InputDeviceEvent::Keyboard(k),
264                            device_descriptor,
265                            event_time,
266                            handled,
267                            trace_id: _,
268                        } if handled == Handled::No => unbounded_send_logged(
269                            &event_sink,
270                            AnyEvent::Keyboard(k, device_descriptor, event_time, handled),
271                        )
272                        .context("while forwarding a keyboard event"),
273                        InputEvent {
274                            device_event: _,
275                            device_descriptor: _,
276                            event_time: _,
277                            handled: _,
278                            trace_id: _,
279                        } => unbounded_send_logged(&event_sink, AnyEvent::NonKeyboard(event))
280                            .context("while forwarding a non-keyboard event"),
281                    }
282                    .unwrap_or_else(|e| {
283                        cloned_metrics_logger.log_error(
284                            InputPipelineErrorMetricDimensionEvent::AutorepeatCouldNotRunAutorepeat,
285                            std::format!("could not run autorepeat: {:?}", e),
286                        );
287                    });
288                }
289                event_sink.close_channel();
290            })
291        };
292
293        Rc::new(Autorepeater {
294            event_sink,
295            event_source: RefCell::new(event_source),
296            state: RefCell::new(Default::default()),
297            settings,
298            _event_feeder: event_feeder,
299            inspect_status,
300            metrics_logger,
301        })
302    }
303
304    /// Run this function in an executor to start processing events. The
305    /// transformed event stream is available in `output`.
306    pub async fn run(self: &Rc<Self>, output: UnboundedSender<InputEvent>) -> Result<()> {
307        log::info!("key autorepeater installed");
308        let src = &mut *(self.event_source.borrow_mut());
309        while let Some(event) = src.next().await {
310            match event {
311                // Anything not a keyboard or any handled event gets forwarded as is.
312                AnyEvent::NonKeyboard(input_event) => unbounded_send_logged(&output, input_event)?,
313                AnyEvent::Keyboard(_, _, _, _) => {
314                    if let Ok(e) = event.clone().try_into() {
315                        self.inspect_status.count_received_event(e);
316                    }
317                    self.process_event(event, &output).await?
318                }
319                AnyEvent::Timeout => self.process_event(event, &output).await?,
320            }
321        }
322        // If we got to here, that means `src` was closed.
323        // Ensure that the channel closure is propagated correctly.
324        output.close_channel();
325
326        // In production we never expect `src` to close as the autorepeater
327        // should be operating continuously, so if we're here and we're in prod
328        // this is unexpected. That is why we return an error.
329        //
330        // But, in tests it is acceptable to ignore this error and let the
331        // function return.  An orderly shutdown will result.
332        Err(anyhow!("recv loop is never supposed to terminate"))
333    }
334
335    pub fn set_handler_healthy(self: std::rc::Rc<Self>) {
336        self.inspect_status.health_node.borrow_mut().set_ok();
337    }
338
339    pub fn set_handler_unhealthy(self: std::rc::Rc<Self>, msg: &str) {
340        self.inspect_status.health_node.borrow_mut().set_unhealthy(msg);
341    }
342
343    // Replace the autorepeater state with a new one.
344    fn set_state(self: &Rc<Self>, state: State) {
345        log::debug!("set state: {:?}", &state);
346        self.state.replace(state);
347    }
348
349    // Get a copy of the current autorepeater state.
350    fn get_state(self: &Rc<Self>) -> State {
351        self.state.borrow().clone()
352    }
353
354    // Process a single `event`.  Any forwarded or generated events are emitted
355    // into `output.
356    async fn process_event(
357        self: &Rc<Self>,
358        event: AnyEvent,
359        output: &UnboundedSender<InputEvent>,
360    ) -> Result<()> {
361        let old_state = self.get_state();
362        log::debug!("process_event: current state: {:?}", &old_state);
363        log::debug!("process_event: inbound event: {:?}", &event);
364        match (old_state, event.clone()) {
365            // This is the initial state.  We wait for a key event with a printable
366            // character, since those are autorepeatable.
367            (State::Dormant, AnyEvent::Keyboard(ev, descriptor, ..)) => {
368                match (ev.get_event_type_folded(), repeatability(ev.get_key_meaning())) {
369                    // Only a printable key is a candidate for repeating.
370                    // We start a delay timer and go to waiting.
371                    (KeyEventType::Pressed, Repeatability::Yes) => {
372                        let _delay_timer = new_autorepeat_timer(
373                            self.event_sink.clone(),
374                            self.settings.delay,
375                            self.metrics_logger.clone(),
376                        );
377                        self.set_state(State::Armed {
378                            armed_event: ev,
379                            armed_descriptor: descriptor,
380                            _delay_timer,
381                        });
382                    }
383
384                    // Any other key type or key event does not get repeated.
385                    (_, _) => {}
386                }
387                unbounded_send_logged(&output, event.try_into()?)?;
388            }
389
390            // A timeout comes while we are in dormant state.  We expect
391            // no timeouts in this state. Perhaps this is a timer task
392            // that fired after it was canceled?  In any case, do not act on it,
393            // but issue a warning.
394            (State::Dormant, AnyEvent::Timeout) => {
395                // This is unexpected, but not fatal.  If you see this in the
396                // logs, we probably need to revisit the fuchsia_async::Task
397                // semantics.
398                log::warn!("spurious timeout in the autorepeater");
399            }
400
401            // A keyboard event comes in while autorepeat is armed.
402            //
403            // If the keyboard event comes in about the same key that was armed, we
404            // restart the repeat timer, to ensure repeated keypresses on the
405            // same key don't generate even more repetitions.
406            //
407            // If the keyboard event is about a different repeatable key, we
408            // restart the autorepeat timer with the new key.  This means that
409            // an autorepeated sequence 'aaaaaabbbbbb' will pause for an
410            // additional repeat delay between the last 'a' and the first 'b'
411            // in the sequence.
412            //
413            // In all cases, pass the event onwards.  No events are dropped
414            // from the event stream.
415            (State::Armed { armed_event, .. }, AnyEvent::Keyboard(ev, descriptor, ..)) => {
416                match (ev.get_event_type_folded(), repeatability(ev.get_key_meaning())) {
417                    (KeyEventType::Pressed, Repeatability::Yes) => {
418                        let _delay_timer = new_autorepeat_timer(
419                            self.event_sink.clone(),
420                            self.settings.delay,
421                            self.metrics_logger.clone(),
422                        );
423                        self.set_state(State::Armed {
424                            armed_event: ev,
425                            armed_descriptor: descriptor,
426                            _delay_timer,
427                        });
428                    }
429
430                    (KeyEventType::Released, Repeatability::Yes) => {
431                        // If the armed key was released, stop autorepeat.
432                        // If the release was for another key, remain in the
433                        // armed state.
434                        if KeyboardEvent::same_key(&armed_event, &ev) {
435                            self.set_state(State::Dormant);
436                        }
437                    }
438
439                    // Any other event causes nothing special to happen.
440                    _ => {}
441                }
442                unbounded_send_logged(&output, event.try_into()?)?;
443            }
444
445            // The timeout triggered while we are armed.  This is an autorepeat!
446            (State::Armed { armed_event, armed_descriptor, .. }, AnyEvent::Timeout) => {
447                let _delay_timer = new_autorepeat_timer(
448                    self.event_sink.clone(),
449                    self.settings.period,
450                    self.metrics_logger.clone(),
451                );
452                let new_event = armed_event
453                    .clone()
454                    .into_with_repeat_sequence(armed_event.get_repeat_sequence() + 1);
455                let new_event_time = input_device::event_time_or_now(None);
456
457                self.set_state(State::Armed {
458                    armed_event: new_event.clone(),
459                    armed_descriptor: armed_descriptor.clone(),
460                    _delay_timer,
461                });
462                // Generate a new autorepeat event and ship it out.
463                let autorepeat_event =
464                    AnyEvent::Keyboard(new_event, armed_descriptor, new_event_time, Handled::No);
465                unbounded_send_logged(&output, autorepeat_event.try_into()?)?;
466            }
467
468            // Forward all other events unmodified.
469            (_, AnyEvent::NonKeyboard(event)) => {
470                unbounded_send_logged(&output, event)?;
471            }
472        }
473        Ok(())
474    }
475}
476
477#[cfg(test)]
478mod tests {
479    use super::*;
480    use crate::testing_utilities;
481    use fidl_fuchsia_input::Key;
482    use fuchsia_async::TestExecutor;
483
484    use futures::Future;
485    use pretty_assertions::assert_eq;
486    use std::pin::pin;
487    use std::task::Poll;
488
489    // Default autorepeat settings used for test.  If these settings are changed,
490    // any tests may fail, since the tests are tuned to the precise timing that
491    // is set here.
492    fn default_settings() -> Settings {
493        Settings {
494            delay: MonotonicDuration::from_millis(500),
495            period: MonotonicDuration::from_seconds(1),
496        }
497    }
498
499    // Creates a new keyboard event for testing.
500    fn new_event(
501        key: Key,
502        event_type: KeyEventType,
503        key_meaning: Option<KeyMeaning>,
504        repeat_sequence: u32,
505    ) -> InputEvent {
506        testing_utilities::create_keyboard_event_with_key_meaning_and_repeat_sequence(
507            key,
508            event_type,
509            /*modifiers=*/ None,
510            /*event_time*/ zx::MonotonicInstant::ZERO,
511            &InputDeviceDescriptor::Fake,
512            /*keymap=*/ None,
513            key_meaning,
514            repeat_sequence,
515        )
516    }
517
518    fn new_handled_event(
519        key: Key,
520        event_type: KeyEventType,
521        key_meaning: Option<KeyMeaning>,
522        repeat_sequence: u32,
523    ) -> InputEvent {
524        let event = new_event(key, event_type, key_meaning, repeat_sequence);
525        // Somewhat surprisingly, this works.
526        InputEvent { handled: Handled::Yes, ..event }
527    }
528
529    // A shorthand for blocking the specified number of milliseconds, asynchronously.
530    async fn wait_for_millis(millis: i64) {
531        wait_for_duration(zx::MonotonicDuration::from_millis(millis)).await;
532    }
533
534    async fn wait_for_duration(duration: MonotonicDuration) {
535        fuchsia_async::Timer::new(MonotonicInstant::after(duration)).await;
536    }
537
538    // Strip event time for these events, for comparison.  The event times are
539    // unpredictable since they are read off of the real time monotonic clock,
540    // and will be different in every run.
541    fn remove_event_time(events: Vec<InputEvent>) -> Vec<InputEvent> {
542        events
543            .into_iter()
544            .map(
545                |InputEvent {
546                     device_event,
547                     device_descriptor,
548                     event_time: _,
549                     handled,
550                     trace_id: _,
551                 }| {
552                    InputEvent {
553                        device_event,
554                        device_descriptor,
555                        event_time: zx::MonotonicInstant::ZERO,
556                        handled,
557                        trace_id: None,
558                    }
559                },
560            )
561            .collect()
562    }
563
564    // Wait for this long (in fake time) before asserting events to ensure
565    // that all events have been drained and all timers have fired.
566    const SLACK_DURATION: MonotonicDuration = zx::MonotonicDuration::from_millis(5000);
567
568    // Checks whether the events read from `output` match supplied `expected` events.
569    async fn assert_events(output: UnboundedReceiver<InputEvent>, expected: Vec<InputEvent>) {
570        // Spends a little while longer in the processing loop to ensure that all events have been
571        // drained before we take the events out.  The wait is in fake time, so it does not
572        // introduce nondeterminism into the tests.
573        wait_for_duration(SLACK_DURATION).await;
574        assert_eq!(
575            remove_event_time(output.take(expected.len()).collect::<Vec<InputEvent>>().await),
576            expected
577        );
578    }
579
580    // Run the future `main_fut` in fake time.  The fake time is being advanced
581    // in relatively small increments until a specified `total_duration` has
582    // elapsed.
583    //
584    // This complication is needed to ensure that any expired
585    // timers are awoken in the correct sequence because the test executor does
586    // not automatically wake the timers. For the fake time execution to
587    // be comparable to a real time execution, we need each timer to have the
588    // chance of waking up, so that we can properly process the consequences
589    // of that timer firing.
590    //
591    // We require that `main_fut` has completed at `total_duration`, and panic
592    // if it has not.  This ensures that we never block forever in fake time.
593    //
594    // This method could possibly be implemented in [TestExecutor] for those
595    // test executor users who do not care to wake the timers in any special
596    // way.
597    fn run_in_fake_time<F>(
598        executor: &mut TestExecutor,
599        main_fut: &mut F,
600        total_duration: MonotonicDuration,
601    ) where
602        F: Future<Output = ()> + Unpin,
603    {
604        const INCREMENT: MonotonicDuration = zx::MonotonicDuration::from_millis(13);
605        // Run the loop for a bit longer than the fake time needed to pump all
606        // the events, to allow the event queue to drain.
607        let total_duration = total_duration + SLACK_DURATION;
608        let mut current = zx::MonotonicDuration::from_millis(0);
609        let mut poll_status = Poll::Pending;
610
611        // We run until either the future completes or the timeout is reached,
612        // whichever comes first.
613        // Running the future after it returns Poll::Ready is not allowed, so
614        // we must exit the loop then.
615        while current < total_duration && poll_status == Poll::Pending {
616            executor.set_fake_time(MonotonicInstant::after(INCREMENT));
617            executor.wake_expired_timers();
618            poll_status = executor.run_until_stalled(main_fut);
619            current = current + INCREMENT;
620        }
621        assert_eq!(
622            poll_status,
623            Poll::Ready(()),
624            "the main future did not complete, perhaps increase total_duration?"
625        );
626    }
627
628    // A general note for all the tests here.
629    //
630    // The autorepeat generator is tightly coupled with the real time clock. Such
631    // a system would be hard to test robustly if we relied on the passage of
632    // real time, since we can not do precise pauses, and are sensitive to
633    // the scheduling delays in the emulators that run the tests.
634    //
635    // Instead, we use an executor with fake time: we have to advance the fake
636    // time manually, and poke the executor such that we eventually run through
637    // the predictable sequence of scheduled asynchronous events.
638    //
639    // The first few tests in this suite will have extra comments that explain
640    // the general testing techniques.  Repeated uses of the same techniques
641    // will not be specially pointed out in the later tests.
642
643    // This test pushes a regular key press and release through the autorepeat
644    // handler. It is used more to explain how the event processing works, than
645    // it is exercising a specific feature of the autorepeat handler.
646    #[test]
647    fn basic_press_and_release_only() {
648        // TestExecutor puts itself as the thread local executor. Any local
649        // task spawned from here on will run on the test executor in fake time,
650        // and will need `run_with_fake_time` to drive it to completion.
651        let mut executor = TestExecutor::new_with_fake_time();
652
653        // `input` is where the test fixture will inject the fake input events.
654        // `receiver` is where the autorepeater will read these events from.
655        let (input, receiver) = mpsc::unbounded();
656
657        let inspector = fuchsia_inspect::Inspector::default();
658        let test_node = inspector.root().create_child("test_node");
659
660        // The autorepeat handler takes a receiver end of one channel to get
661        // the input from, and the send end of another channel to place the
662        // output into. Since we must formally start the handling process in
663        // an async task, the API requires you to call `run` to
664        // start the process and supply the sender side of the output.
665        //
666        // This API ensures that the handler is fully configured when started,
667        // all the while leaving the user with an option of when and how exactly
668        // to start the handler, including not immediately upon creation.
669        let handler = Autorepeater::new_with_settings(
670            receiver,
671            default_settings(),
672            &test_node,
673            metrics::MetricsLogger::default(),
674        );
675
676        // `sender` is where the autorepeat handler will send processed input
677        // events into.  `output` is where we will read the results of the
678        // autorepeater's work.
679        let (sender, output) = mpsc::unbounded();
680
681        // It is up to the caller to decide where to spawn the handler task.
682        let handler_task = Task::local(async move { handler.run(sender).await });
683
684        // `main_fut` is the task that exercises the handler.
685        let main_fut = async move {
686            // Inject a keyboard event into the autorepeater.
687            //
688            // The mpsc channel of which 'input' is the receiver will be closed when all consumers
689            // go out of scope.
690            input
691                .unbounded_send(new_event(
692                    Key::A,
693                    KeyEventType::Pressed,
694                    Some(KeyMeaning::Codepoint('a' as u32)),
695                    0,
696                ))
697                .unwrap();
698
699            // This will wait in fake time.  The tests are not actually delayed because of this
700            // call.
701            wait_for_millis(1).await;
702
703            input
704                .unbounded_send(new_event(
705                    Key::A,
706                    KeyEventType::Released,
707                    Some(KeyMeaning::Codepoint('a' as u32)),
708                    0,
709                ))
710                .unwrap();
711
712            // Assertions are also here in the async domain since reading from
713            // output must be asynchronous.
714            assert_events(
715                output,
716                vec![
717                    new_event(
718                        Key::A,
719                        KeyEventType::Pressed,
720                        Some(KeyMeaning::Codepoint('a' as u32)),
721                        0,
722                    ),
723                    new_event(
724                        Key::A,
725                        KeyEventType::Released,
726                        Some(KeyMeaning::Codepoint('a' as u32)),
727                        0,
728                    ),
729                ],
730            )
731            .await;
732        };
733
734        // Drive both the test fixture task and the handler task in parallel,
735        // and both in fake time.  `run_in_fake_time` advances the fake time from
736        // zero in increments of about 10ms until all futures complete.
737        let mut joined_fut = Task::local(async move {
738            let _r = futures::join!(handler_task, main_fut);
739        });
740        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
741    }
742
743    #[test]
744    fn basic_sync_and_cancel_only() {
745        let mut executor = TestExecutor::new_with_fake_time();
746        let (input, receiver) = mpsc::unbounded();
747        let inspector = fuchsia_inspect::Inspector::default();
748        let test_node = inspector.root().create_child("test_node");
749        let handler = Autorepeater::new_with_settings(
750            receiver,
751            default_settings(),
752            &test_node,
753            metrics::MetricsLogger::default(),
754        );
755        let (sender, output) = mpsc::unbounded();
756        let handler_task = Task::local(async move { handler.run(sender).await });
757
758        let main_fut = async move {
759            input
760                .unbounded_send(new_event(
761                    Key::A,
762                    KeyEventType::Sync,
763                    Some(KeyMeaning::Codepoint('a' as u32)),
764                    0,
765                ))
766                .unwrap();
767            wait_for_millis(1).await;
768
769            input
770                .unbounded_send(new_event(
771                    Key::A,
772                    KeyEventType::Cancel,
773                    Some(KeyMeaning::Codepoint('a' as u32)),
774                    0,
775                ))
776                .unwrap();
777            assert_events(
778                output,
779                vec![
780                    new_event(
781                        Key::A,
782                        KeyEventType::Pressed,
783                        Some(KeyMeaning::Codepoint('a' as u32)),
784                        0,
785                    ),
786                    new_event(
787                        Key::A,
788                        KeyEventType::Released,
789                        Some(KeyMeaning::Codepoint('a' as u32)),
790                        0,
791                    ),
792                ],
793            )
794            .await;
795        };
796        let mut joined_fut = Task::local(async move {
797            let _r = futures::join!(handler_task, main_fut);
798        });
799        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
800    }
801
802    // Ensures that we forward but not act on handled events.
803    #[test]
804    fn handled_events_are_forwarded() {
805        let mut executor = TestExecutor::new_with_fake_time();
806        let (input, receiver) = mpsc::unbounded();
807        let inspector = fuchsia_inspect::Inspector::default();
808        let test_node = inspector.root().create_child("test_node");
809        let handler = Autorepeater::new_with_settings(
810            receiver,
811            default_settings(),
812            &test_node,
813            metrics::MetricsLogger::default(),
814        );
815        let (sender, output) = mpsc::unbounded();
816        let handler_task = Task::local(async move { handler.run(sender).await });
817
818        let main_fut = async move {
819            input
820                .unbounded_send(new_handled_event(
821                    Key::A,
822                    KeyEventType::Pressed,
823                    Some(KeyMeaning::Codepoint('a' as u32)),
824                    0,
825                ))
826                .unwrap();
827
828            wait_for_millis(2000).await;
829
830            input
831                .unbounded_send(new_handled_event(
832                    Key::A,
833                    KeyEventType::Released,
834                    Some(KeyMeaning::Codepoint('a' as u32)),
835                    0,
836                ))
837                .unwrap();
838
839            assert_events(
840                output,
841                vec![
842                    new_handled_event(
843                        Key::A,
844                        KeyEventType::Pressed,
845                        Some(KeyMeaning::Codepoint('a' as u32)),
846                        0,
847                    ),
848                    new_handled_event(
849                        Key::A,
850                        KeyEventType::Released,
851                        Some(KeyMeaning::Codepoint('a' as u32)),
852                        0,
853                    ),
854                ],
855            )
856            .await;
857        };
858
859        let mut joined_fut = Task::local(async move {
860            let _r = futures::join!(handler_task, main_fut);
861        });
862        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
863    }
864
865    // In this test, we wait with a pressed key for long enough that the default
866    // settings should trigger the autorepeat.
867    #[test]
868    fn autorepeat_simple() {
869        let mut executor = TestExecutor::new_with_fake_time();
870
871        let (input, receiver) = mpsc::unbounded();
872        let inspector = fuchsia_inspect::Inspector::default();
873        let test_node = inspector.root().create_child("test_node");
874        let handler = Autorepeater::new_with_settings(
875            receiver,
876            default_settings(),
877            &test_node,
878            metrics::MetricsLogger::default(),
879        );
880        let (sender, output) = mpsc::unbounded();
881        let handler_task = Task::local(async move { handler.run(sender).await });
882
883        let main_fut = async move {
884            input
885                .unbounded_send(new_event(
886                    Key::A,
887                    KeyEventType::Pressed,
888                    Some(KeyMeaning::Codepoint('a' as u32)),
889                    0,
890                ))
891                .unwrap();
892
893            wait_for_millis(2000).await;
894
895            input
896                .unbounded_send(new_event(
897                    Key::A,
898                    KeyEventType::Released,
899                    Some(KeyMeaning::Codepoint('a' as u32)),
900                    0,
901                ))
902                .unwrap();
903
904            // The total fake time during which the autorepeat key was actuated
905            // was 2 seconds.  By default the delay to first autorepeat is 500ms,
906            // then 1000ms for each additional autorepeat. This means we should
907            // see three `Pressed` events: one at the outset, a second one after
908            // 500ms, and a third one after 1500ms.
909            assert_events(
910                output,
911                vec![
912                    new_event(
913                        Key::A,
914                        KeyEventType::Pressed,
915                        Some(KeyMeaning::Codepoint('a' as u32)),
916                        0,
917                    ),
918                    new_event(
919                        Key::A,
920                        KeyEventType::Pressed,
921                        Some(KeyMeaning::Codepoint('a' as u32)),
922                        1,
923                    ),
924                    new_event(
925                        Key::A,
926                        KeyEventType::Pressed,
927                        Some(KeyMeaning::Codepoint('a' as u32)),
928                        2,
929                    ),
930                    new_event(
931                        Key::A,
932                        KeyEventType::Released,
933                        Some(KeyMeaning::Codepoint('a' as u32)),
934                        0,
935                    ),
936                ],
937            )
938            .await;
939        };
940        let mut joined_fut = Task::local(async move {
941            let _r = futures::join!(handler_task, main_fut);
942        });
943        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
944    }
945
946    // This test is the same as above, but we hold the autorepeat for a little
947    // while longer and check that the autorepeat event stream has grown
948    // accordingly.
949    #[test]
950    fn autorepeat_simple_longer() {
951        let mut executor = TestExecutor::new_with_fake_time();
952
953        let (input, receiver) = mpsc::unbounded();
954        let inspector = fuchsia_inspect::Inspector::default();
955        let test_node = inspector.root().create_child("test_node");
956        let handler = Autorepeater::new_with_settings(
957            receiver,
958            default_settings(),
959            &test_node,
960            metrics::MetricsLogger::default(),
961        );
962        let (sender, output) = mpsc::unbounded();
963        let handler_task = Task::local(async move { handler.run(sender).await });
964
965        let main_fut = async move {
966            input
967                .unbounded_send(new_event(
968                    Key::A,
969                    KeyEventType::Pressed,
970                    Some(KeyMeaning::Codepoint('a' as u32)),
971                    0,
972                ))
973                .unwrap();
974
975            wait_for_millis(3000).await;
976
977            input
978                .unbounded_send(new_event(
979                    Key::A,
980                    KeyEventType::Released,
981                    Some(KeyMeaning::Codepoint('a' as u32)),
982                    0,
983                ))
984                .unwrap();
985
986            assert_events(
987                output,
988                vec![
989                    new_event(
990                        Key::A,
991                        KeyEventType::Pressed,
992                        Some(KeyMeaning::Codepoint('a' as u32)),
993                        0,
994                    ),
995                    new_event(
996                        Key::A,
997                        KeyEventType::Pressed,
998                        Some(KeyMeaning::Codepoint('a' as u32)),
999                        1,
1000                    ),
1001                    new_event(
1002                        Key::A,
1003                        KeyEventType::Pressed,
1004                        Some(KeyMeaning::Codepoint('a' as u32)),
1005                        2,
1006                    ),
1007                    new_event(
1008                        Key::A,
1009                        KeyEventType::Pressed,
1010                        Some(KeyMeaning::Codepoint('a' as u32)),
1011                        3,
1012                    ),
1013                    new_event(
1014                        Key::A,
1015                        KeyEventType::Released,
1016                        Some(KeyMeaning::Codepoint('a' as u32)),
1017                        0,
1018                    ),
1019                ],
1020            )
1021            .await;
1022        };
1023        let mut joined_fut = Task::local(async move {
1024            let _r = futures::join!(handler_task, main_fut);
1025        });
1026        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
1027    }
1028
1029    // In this test, keys A and B compete for autorepeat:
1030    //
1031    //     @0ms ->|<- 1.6s ->|<- 2s ->|<- 1s ->|
1032    // A """""""""\___________________/"""""""""""""
1033    //            :          :                 :
1034    // B """"""""""""""""""""\_________________/""""
1035    #[test]
1036    fn autorepeat_takeover() {
1037        let mut executor = TestExecutor::new_with_fake_time();
1038
1039        let (input, receiver) = mpsc::unbounded();
1040        let inspector = fuchsia_inspect::Inspector::default();
1041        let test_node = inspector.root().create_child("test_node");
1042        let handler = Autorepeater::new_with_settings(
1043            receiver,
1044            default_settings(),
1045            &test_node,
1046            metrics::MetricsLogger::default(),
1047        );
1048        let (sender, output) = mpsc::unbounded();
1049        let handler_task = Task::local(async move { handler.run(sender).await });
1050
1051        let main_fut = async move {
1052            input
1053                .unbounded_send(new_event(
1054                    Key::A,
1055                    KeyEventType::Pressed,
1056                    Some(KeyMeaning::Codepoint('a' as u32)),
1057                    0,
1058                ))
1059                .unwrap();
1060
1061            wait_for_millis(1600).await;
1062
1063            input
1064                .unbounded_send(new_event(
1065                    Key::B,
1066                    KeyEventType::Pressed,
1067                    Some(KeyMeaning::Codepoint('b' as u32)),
1068                    0,
1069                ))
1070                .unwrap();
1071
1072            wait_for_millis(2000).await;
1073
1074            input
1075                .unbounded_send(new_event(
1076                    Key::A,
1077                    KeyEventType::Released,
1078                    Some(KeyMeaning::Codepoint('a' as u32)),
1079                    0,
1080                ))
1081                .unwrap();
1082
1083            wait_for_millis(1000).await;
1084
1085            input
1086                .unbounded_send(new_event(
1087                    Key::B,
1088                    KeyEventType::Released,
1089                    Some(KeyMeaning::Codepoint('b' as u32)),
1090                    0,
1091                ))
1092                .unwrap();
1093
1094            assert_events(
1095                output,
1096                vec![
1097                    new_event(
1098                        Key::A,
1099                        KeyEventType::Pressed,
1100                        Some(KeyMeaning::Codepoint('a' as u32)),
1101                        0,
1102                    ),
1103                    new_event(
1104                        Key::A,
1105                        KeyEventType::Pressed,
1106                        Some(KeyMeaning::Codepoint('a' as u32)),
1107                        1,
1108                    ),
1109                    new_event(
1110                        Key::A,
1111                        KeyEventType::Pressed,
1112                        Some(KeyMeaning::Codepoint('a' as u32)),
1113                        2,
1114                    ),
1115                    new_event(
1116                        Key::B,
1117                        KeyEventType::Pressed,
1118                        Some(KeyMeaning::Codepoint('b' as u32)),
1119                        0,
1120                    ),
1121                    new_event(
1122                        Key::B,
1123                        KeyEventType::Pressed,
1124                        Some(KeyMeaning::Codepoint('b' as u32)),
1125                        1,
1126                    ),
1127                    new_event(
1128                        Key::B,
1129                        KeyEventType::Pressed,
1130                        Some(KeyMeaning::Codepoint('b' as u32)),
1131                        2,
1132                    ),
1133                    new_event(
1134                        Key::A,
1135                        KeyEventType::Released,
1136                        Some(KeyMeaning::Codepoint('a' as u32)),
1137                        0,
1138                    ),
1139                    new_event(
1140                        Key::B,
1141                        KeyEventType::Pressed,
1142                        Some(KeyMeaning::Codepoint('b' as u32)),
1143                        3,
1144                    ),
1145                    new_event(
1146                        Key::B,
1147                        KeyEventType::Released,
1148                        Some(KeyMeaning::Codepoint('b' as u32)),
1149                        0,
1150                    ),
1151                ],
1152            )
1153            .await;
1154        };
1155        let mut joined_fut = Task::local(async move {
1156            let _r = futures::join!(handler_task, main_fut);
1157        });
1158        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
1159    }
1160
1161    // In this test, keys A and B compete for autorepeat:
1162    //
1163    //     @0ms ->|<- 2s ->|<- 2s ->|<- 2s ->|
1164    // A """""""""\__________________________/""""
1165    //            :        :        :        :
1166    // B """"""""""""""""""\________/"""""""""""""
1167    #[test]
1168    fn autorepeat_takeover_and_back() {
1169        let mut executor = TestExecutor::new_with_fake_time();
1170
1171        let (input, receiver) = mpsc::unbounded();
1172        let inspector = fuchsia_inspect::Inspector::default();
1173        let test_node = inspector.root().create_child("test_node");
1174        let handler = Autorepeater::new_with_settings(
1175            receiver,
1176            default_settings(),
1177            &test_node,
1178            metrics::MetricsLogger::default(),
1179        );
1180        let (sender, output) = mpsc::unbounded();
1181        let handler_task = Task::local(async move { handler.run(sender).await });
1182
1183        let main_fut = async move {
1184            input
1185                .unbounded_send(new_event(
1186                    Key::A,
1187                    KeyEventType::Pressed,
1188                    Some(KeyMeaning::Codepoint('a' as u32)),
1189                    0,
1190                ))
1191                .unwrap();
1192
1193            wait_for_millis(2000).await;
1194
1195            input
1196                .unbounded_send(new_event(
1197                    Key::B,
1198                    KeyEventType::Pressed,
1199                    Some(KeyMeaning::Codepoint('b' as u32)),
1200                    0,
1201                ))
1202                .unwrap();
1203
1204            wait_for_millis(2000).await;
1205
1206            input
1207                .unbounded_send(new_event(
1208                    Key::B,
1209                    KeyEventType::Released,
1210                    Some(KeyMeaning::Codepoint('b' as u32)),
1211                    0,
1212                ))
1213                .unwrap();
1214
1215            wait_for_millis(2000).await;
1216
1217            input
1218                .unbounded_send(new_event(
1219                    Key::A,
1220                    KeyEventType::Released,
1221                    Some(KeyMeaning::Codepoint('a' as u32)),
1222                    0,
1223                ))
1224                .unwrap();
1225
1226            // Try to elicit autorepeat.  There won't be any.
1227            wait_for_millis(2000).await;
1228
1229            assert_events(
1230                output,
1231                vec![
1232                    new_event(
1233                        Key::A,
1234                        KeyEventType::Pressed,
1235                        Some(KeyMeaning::Codepoint('a' as u32)),
1236                        0,
1237                    ),
1238                    new_event(
1239                        Key::A,
1240                        KeyEventType::Pressed,
1241                        Some(KeyMeaning::Codepoint('a' as u32)),
1242                        1,
1243                    ),
1244                    new_event(
1245                        Key::A,
1246                        KeyEventType::Pressed,
1247                        Some(KeyMeaning::Codepoint('a' as u32)),
1248                        2,
1249                    ),
1250                    new_event(
1251                        Key::B,
1252                        KeyEventType::Pressed,
1253                        Some(KeyMeaning::Codepoint('b' as u32)),
1254                        0,
1255                    ),
1256                    new_event(
1257                        Key::B,
1258                        KeyEventType::Pressed,
1259                        Some(KeyMeaning::Codepoint('b' as u32)),
1260                        1,
1261                    ),
1262                    new_event(
1263                        Key::B,
1264                        KeyEventType::Pressed,
1265                        Some(KeyMeaning::Codepoint('b' as u32)),
1266                        2,
1267                    ),
1268                    new_event(
1269                        Key::B,
1270                        KeyEventType::Released,
1271                        Some(KeyMeaning::Codepoint('b' as u32)),
1272                        0,
1273                    ),
1274                    // No autorepeat after B is released.
1275                    new_event(
1276                        Key::A,
1277                        KeyEventType::Released,
1278                        Some(KeyMeaning::Codepoint('a' as u32)),
1279                        0,
1280                    ),
1281                ],
1282            )
1283            .await;
1284        };
1285        let mut joined_fut = Task::local(async move {
1286            let _r = futures::join!(handler_task, main_fut);
1287        });
1288        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
1289    }
1290
1291    #[test]
1292    fn no_autorepeat_for_left_shift() {
1293        let mut executor = TestExecutor::new_with_fake_time();
1294
1295        let (input, receiver) = mpsc::unbounded();
1296        let inspector = fuchsia_inspect::Inspector::default();
1297        let test_node = inspector.root().create_child("test_node");
1298        let handler = Autorepeater::new_with_settings(
1299            receiver,
1300            default_settings(),
1301            &test_node,
1302            metrics::MetricsLogger::default(),
1303        );
1304        let (sender, output) = mpsc::unbounded();
1305        let handler_task = Task::local(async move { handler.run(sender).await });
1306
1307        let main_fut = async move {
1308            input
1309                .unbounded_send(new_event(
1310                    Key::LeftShift,
1311                    KeyEventType::Pressed,
1312                    // Keys that do not contribute to text editing have code
1313                    // point set to zero. We use this as a discriminator for
1314                    // which keys may or may not repeat.
1315                    Some(KeyMeaning::Codepoint(0)),
1316                    0,
1317                ))
1318                .unwrap();
1319
1320            wait_for_millis(5000).await;
1321
1322            input
1323                .unbounded_send(new_event(
1324                    Key::LeftShift,
1325                    KeyEventType::Released,
1326                    Some(KeyMeaning::Codepoint(0)),
1327                    0,
1328                ))
1329                .unwrap();
1330
1331            assert_events(
1332                output,
1333                vec![
1334                    new_event(
1335                        Key::LeftShift,
1336                        KeyEventType::Pressed,
1337                        Some(KeyMeaning::Codepoint(0)),
1338                        0,
1339                    ),
1340                    new_event(
1341                        Key::LeftShift,
1342                        KeyEventType::Released,
1343                        Some(KeyMeaning::Codepoint(0)),
1344                        0,
1345                    ),
1346                ],
1347            )
1348            .await;
1349        };
1350        let mut joined_fut = Task::local(async move {
1351            let _r = futures::join!(handler_task, main_fut);
1352        });
1353        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
1354    }
1355
1356    //       @0ms ->|<- 2s ->|<- 2s ->|<- 2s ->|
1357    // A         """"""""""""\________/"""""""""""""
1358    // LeftShift """\__________________________/""""
1359    #[test]
1360    fn shift_a_encapsulated() {
1361        let mut executor = TestExecutor::new_with_fake_time();
1362
1363        let (input, receiver) = mpsc::unbounded();
1364        let inspector = fuchsia_inspect::Inspector::default();
1365        let test_node = inspector.root().create_child("test_node");
1366        let handler = Autorepeater::new_with_settings(
1367            receiver,
1368            default_settings(),
1369            &test_node,
1370            metrics::MetricsLogger::default(),
1371        );
1372        let (sender, output) = mpsc::unbounded();
1373        let handler_task = Task::local(async move { handler.run(sender).await });
1374
1375        let main_fut = async move {
1376            input
1377                .unbounded_send(new_event(
1378                    Key::LeftShift,
1379                    KeyEventType::Pressed,
1380                    Some(KeyMeaning::Codepoint(0)),
1381                    0,
1382                ))
1383                .unwrap();
1384
1385            wait_for_millis(2000).await;
1386
1387            input
1388                .unbounded_send(new_event(
1389                    Key::A,
1390                    KeyEventType::Pressed,
1391                    Some(KeyMeaning::Codepoint('A' as u32)),
1392                    0,
1393                ))
1394                .unwrap();
1395
1396            wait_for_millis(2000).await;
1397
1398            input
1399                .unbounded_send(new_event(
1400                    Key::A,
1401                    KeyEventType::Released,
1402                    Some(KeyMeaning::Codepoint('A' as u32)),
1403                    0,
1404                ))
1405                .unwrap();
1406
1407            wait_for_millis(2000).await;
1408
1409            input
1410                .unbounded_send(new_event(
1411                    Key::LeftShift,
1412                    KeyEventType::Released,
1413                    Some(KeyMeaning::Codepoint(0)),
1414                    0,
1415                ))
1416                .unwrap();
1417
1418            assert_events(
1419                output,
1420                vec![
1421                    new_event(
1422                        Key::LeftShift,
1423                        KeyEventType::Pressed,
1424                        Some(KeyMeaning::Codepoint(0)),
1425                        0,
1426                    ),
1427                    new_event(
1428                        Key::A,
1429                        KeyEventType::Pressed,
1430                        Some(KeyMeaning::Codepoint('A' as u32)),
1431                        0,
1432                    ),
1433                    new_event(
1434                        Key::A,
1435                        KeyEventType::Pressed,
1436                        Some(KeyMeaning::Codepoint('A' as u32)),
1437                        1,
1438                    ),
1439                    new_event(
1440                        Key::A,
1441                        KeyEventType::Pressed,
1442                        Some(KeyMeaning::Codepoint('A' as u32)),
1443                        2,
1444                    ),
1445                    new_event(
1446                        Key::A,
1447                        KeyEventType::Released,
1448                        Some(KeyMeaning::Codepoint('A' as u32)),
1449                        0,
1450                    ),
1451                    new_event(
1452                        Key::LeftShift,
1453                        KeyEventType::Released,
1454                        Some(KeyMeaning::Codepoint(0)),
1455                        0,
1456                    ),
1457                ],
1458            )
1459            .await;
1460        };
1461        let mut joined_fut = Task::local(async move {
1462            let _r = futures::join!(handler_task, main_fut);
1463        });
1464        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
1465    }
1466
1467    //       @0ms ->|<- 2s ->|<- 2s ->|<- 2s ->|
1468    // A         """"""""""""\_________________/""
1469    // LeftShift """\_________________/"""""""""""
1470    #[test]
1471    fn shift_a_interleaved() {
1472        let mut executor = TestExecutor::new_with_fake_time();
1473
1474        let (input, receiver) = mpsc::unbounded();
1475        let inspector = fuchsia_inspect::Inspector::default();
1476        let test_node = inspector.root().create_child("test_node");
1477        let handler = Autorepeater::new_with_settings(
1478            receiver,
1479            default_settings(),
1480            &test_node,
1481            metrics::MetricsLogger::default(),
1482        );
1483        let (sender, output) = mpsc::unbounded();
1484        let handler_task = Task::local(async move { handler.run(sender).await });
1485
1486        let main_fut = async move {
1487            input
1488                .unbounded_send(new_event(
1489                    Key::LeftShift,
1490                    KeyEventType::Pressed,
1491                    Some(KeyMeaning::Codepoint(0)),
1492                    0,
1493                ))
1494                .unwrap();
1495
1496            wait_for_millis(2000).await;
1497
1498            input
1499                .unbounded_send(new_event(
1500                    Key::A,
1501                    KeyEventType::Pressed,
1502                    Some(KeyMeaning::Codepoint('A' as u32)),
1503                    0,
1504                ))
1505                .unwrap();
1506
1507            wait_for_millis(2000).await;
1508
1509            input
1510                .unbounded_send(new_event(
1511                    Key::LeftShift,
1512                    KeyEventType::Released,
1513                    Some(KeyMeaning::Codepoint(0)),
1514                    0,
1515                ))
1516                .unwrap();
1517
1518            wait_for_millis(2000).await;
1519
1520            input
1521                .unbounded_send(new_event(
1522                    Key::A,
1523                    KeyEventType::Released,
1524                    Some(KeyMeaning::Codepoint('A' as u32)),
1525                    0,
1526                ))
1527                .unwrap();
1528
1529            assert_events(
1530                output,
1531                vec![
1532                    new_event(
1533                        Key::LeftShift,
1534                        KeyEventType::Pressed,
1535                        Some(KeyMeaning::Codepoint(0)),
1536                        0,
1537                    ),
1538                    new_event(
1539                        Key::A,
1540                        KeyEventType::Pressed,
1541                        Some(KeyMeaning::Codepoint('A' as u32)),
1542                        0,
1543                    ),
1544                    new_event(
1545                        Key::A,
1546                        KeyEventType::Pressed,
1547                        Some(KeyMeaning::Codepoint('A' as u32)),
1548                        1,
1549                    ),
1550                    new_event(
1551                        Key::A,
1552                        KeyEventType::Pressed,
1553                        Some(KeyMeaning::Codepoint('A' as u32)),
1554                        2,
1555                    ),
1556                    new_event(
1557                        Key::LeftShift,
1558                        KeyEventType::Released,
1559                        Some(KeyMeaning::Codepoint(0)),
1560                        0,
1561                    ),
1562                    // This will continue autorepeating capital A, but we'd need
1563                    // to autorepeat 'a'.  May need to reapply the keymap at
1564                    // this point, but this may require redoing the keymap stage.
1565                    // Alternative - stop autorepeat, would be easier.
1566                    // The current behavior may be enough, however.
1567                    new_event(
1568                        Key::A,
1569                        KeyEventType::Pressed,
1570                        Some(KeyMeaning::Codepoint('A' as u32)),
1571                        3,
1572                    ),
1573                    new_event(
1574                        Key::A,
1575                        KeyEventType::Pressed,
1576                        Some(KeyMeaning::Codepoint('A' as u32)),
1577                        4,
1578                    ),
1579                    new_event(
1580                        Key::A,
1581                        KeyEventType::Released,
1582                        Some(KeyMeaning::Codepoint('A' as u32)),
1583                        0,
1584                    ),
1585                ],
1586            )
1587            .await;
1588        };
1589        let mut joined_fut = pin!(async move {
1590            let _r = futures::join!(main_fut, handler_task);
1591        });
1592        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
1593    }
1594
1595    #[test]
1596    fn autorepeater_initialized_with_inspect_node() {
1597        let _executor = TestExecutor::new_with_fake_time();
1598
1599        let (_, receiver) = mpsc::unbounded();
1600        let inspector = fuchsia_inspect::Inspector::default();
1601        let fake_handlers_node = inspector.root().create_child("input_handlers_node");
1602        let _autorepeater =
1603            Autorepeater::new(receiver, &fake_handlers_node, metrics::MetricsLogger::default());
1604        diagnostics_assertions::assert_data_tree!(inspector, root: {
1605            input_handlers_node: {
1606                autorepeater: {
1607                    events_received_count: 0u64,
1608                    events_handled_count: 0u64,
1609                    last_received_timestamp_ns: 0u64,
1610                    "fuchsia.inspect.Health": {
1611                        status: "STARTING_UP",
1612                        // Timestamp value is unpredictable and not relevant in this context,
1613                        // so we only assert that the property is present.
1614                        start_timestamp_nanos: diagnostics_assertions::AnyProperty
1615                    },
1616                }
1617            }
1618        });
1619    }
1620
1621    #[test]
1622    fn autorepeat_inspect_counts_events() {
1623        let mut executor = TestExecutor::new_with_fake_time();
1624
1625        let (input, receiver) = mpsc::unbounded();
1626        let inspector = fuchsia_inspect::Inspector::default();
1627        let fake_handlers_node = inspector.root().create_child("input_handlers_node");
1628        let handler = Autorepeater::new_with_settings(
1629            receiver,
1630            default_settings(),
1631            &fake_handlers_node,
1632            metrics::MetricsLogger::default(),
1633        );
1634        let (sender, _output) = mpsc::unbounded();
1635        let handler_task = Task::local(async move { handler.run(sender).await });
1636
1637        let main_fut = async move {
1638            input
1639                .unbounded_send(new_event(
1640                    Key::A,
1641                    KeyEventType::Pressed,
1642                    Some(KeyMeaning::Codepoint('a' as u32)),
1643                    0,
1644                ))
1645                .unwrap();
1646
1647            wait_for_millis(1600).await;
1648
1649            input
1650                .unbounded_send(new_event(
1651                    Key::B,
1652                    KeyEventType::Pressed,
1653                    Some(KeyMeaning::Codepoint('b' as u32)),
1654                    0,
1655                ))
1656                .unwrap();
1657
1658            wait_for_millis(2000).await;
1659
1660            input
1661                .unbounded_send(new_event(
1662                    Key::A,
1663                    KeyEventType::Released,
1664                    Some(KeyMeaning::Codepoint('a' as u32)),
1665                    0,
1666                ))
1667                .unwrap();
1668
1669            wait_for_millis(1000).await;
1670
1671            input
1672                .unbounded_send(new_handled_event(
1673                    Key::C,
1674                    KeyEventType::Pressed,
1675                    Some(KeyMeaning::Codepoint('c' as u32)),
1676                    0,
1677                ))
1678                .unwrap();
1679
1680            input
1681                .unbounded_send(new_event(
1682                    Key::B,
1683                    KeyEventType::Released,
1684                    Some(KeyMeaning::Codepoint('b' as u32)),
1685                    0,
1686                ))
1687                .unwrap();
1688
1689            wait_for_duration(SLACK_DURATION).await;
1690
1691            // Inspect should only count unhandled events received from driver, not generated
1692            // autorepeat events or already handled input events.
1693            diagnostics_assertions::assert_data_tree!(inspector, root: {
1694                input_handlers_node: {
1695                    autorepeater: {
1696                        events_received_count: 4u64,
1697                        events_handled_count: 0u64,
1698                        last_received_timestamp_ns: 0u64,
1699                        "fuchsia.inspect.Health": {
1700                            status: "STARTING_UP",
1701                            // Timestamp value is unpredictable and not relevant in this context,
1702                            // so we only assert that the property is present.
1703                            start_timestamp_nanos: diagnostics_assertions::AnyProperty
1704                        },
1705                    }
1706                }
1707            });
1708        };
1709        let mut joined_fut = Task::local(async move {
1710            let _r = futures::join!(handler_task, main_fut);
1711        });
1712        run_in_fake_time(&mut executor, &mut joined_fut, zx::MonotonicDuration::from_seconds(10));
1713    }
1714}