executor: Replace NonNull<TaskHeader> with TaskRef

This commit is contained in:
Grant Miller 2023-01-29 12:55:06 -06:00
parent 7e251a2550
commit 48e1aab762
5 changed files with 76 additions and 57 deletions

View file

@ -43,14 +43,11 @@ pub(crate) const STATE_RUN_QUEUED: u32 = 1 << 1;
pub(crate) const STATE_TIMER_QUEUED: u32 = 1 << 2; pub(crate) const STATE_TIMER_QUEUED: u32 = 1 << 2;
/// Raw task header for use in task pointers. /// Raw task header for use in task pointers.
/// pub(crate) struct TaskHeader {
/// This is an opaque struct, used for raw pointers to tasks, for use
/// with funtions like [`wake_task`] and [`task_from_waker`].
pub struct TaskHeader {
pub(crate) state: AtomicU32, pub(crate) state: AtomicU32,
pub(crate) run_queue_item: RunQueueItem, pub(crate) run_queue_item: RunQueueItem,
pub(crate) executor: Cell<*const Executor>, // Valid if state != 0 pub(crate) executor: Cell<*const Executor>, // Valid if state != 0
pub(crate) poll_fn: UninitCell<unsafe fn(NonNull<TaskHeader>)>, // Valid if STATE_SPAWNED pub(crate) poll_fn: UninitCell<unsafe fn(TaskRef)>, // Valid if STATE_SPAWNED
#[cfg(feature = "integrated-timers")] #[cfg(feature = "integrated-timers")]
pub(crate) expires_at: Cell<Instant>, pub(crate) expires_at: Cell<Instant>,
@ -59,7 +56,7 @@ pub struct TaskHeader {
} }
impl TaskHeader { impl TaskHeader {
pub(crate) const fn new() -> Self { const fn new() -> Self {
Self { Self {
state: AtomicU32::new(0), state: AtomicU32::new(0),
run_queue_item: RunQueueItem::new(), run_queue_item: RunQueueItem::new(),
@ -74,6 +71,36 @@ impl TaskHeader {
} }
} }
/// This is essentially a `&'static TaskStorage<F>` where the type of the future has been erased.
#[derive(Clone, Copy)]
pub struct TaskRef {
ptr: NonNull<TaskHeader>,
}
impl TaskRef {
fn new<F: Future + 'static>(task: &'static TaskStorage<F>) -> Self {
Self {
ptr: NonNull::from(task).cast(),
}
}
/// Safety: The pointer must have been obtained with `Task::as_ptr`
pub(crate) unsafe fn from_ptr(ptr: *const TaskHeader) -> Self {
Self {
ptr: NonNull::new_unchecked(ptr as *mut TaskHeader),
}
}
pub(crate) fn header(self) -> &'static TaskHeader {
unsafe { self.ptr.as_ref() }
}
/// The returned pointer is valid for the entire TaskStorage.
pub(crate) fn as_ptr(self) -> *const TaskHeader {
self.ptr.as_ptr()
}
}
/// Raw storage in which a task can be spawned. /// Raw storage in which a task can be spawned.
/// ///
/// This struct holds the necessary memory to spawn one task whose future is `F`. /// This struct holds the necessary memory to spawn one task whose future is `F`.
@ -135,14 +162,14 @@ impl<F: Future + 'static> TaskStorage<F> {
.is_ok() .is_ok()
} }
unsafe fn spawn_initialize(&'static self, future: impl FnOnce() -> F) -> NonNull<TaskHeader> { unsafe fn spawn_initialize(&'static self, future: impl FnOnce() -> F) -> TaskRef {
// Initialize the task // Initialize the task
self.raw.poll_fn.write(Self::poll); self.raw.poll_fn.write(Self::poll);
self.future.write(future()); self.future.write(future());
NonNull::new_unchecked(self as *const TaskStorage<F> as *const TaskHeader as *mut TaskHeader) TaskRef::new(self)
} }
unsafe fn poll(p: NonNull<TaskHeader>) { unsafe fn poll(p: TaskRef) {
let this = &*(p.as_ptr() as *const TaskStorage<F>); let this = &*(p.as_ptr() as *const TaskStorage<F>);
let future = Pin::new_unchecked(this.future.as_mut()); let future = Pin::new_unchecked(this.future.as_mut());
@ -307,7 +334,7 @@ impl Executor {
/// - `task` must be set up to run in this executor. /// - `task` must be set up to run in this executor.
/// - `task` must NOT be already enqueued (in this executor or another one). /// - `task` must NOT be already enqueued (in this executor or another one).
#[inline(always)] #[inline(always)]
unsafe fn enqueue(&self, cs: CriticalSection, task: NonNull<TaskHeader>) { unsafe fn enqueue(&self, cs: CriticalSection, task: TaskRef) {
#[cfg(feature = "rtos-trace")] #[cfg(feature = "rtos-trace")]
trace::task_ready_begin(task.as_ptr() as u32); trace::task_ready_begin(task.as_ptr() as u32);
@ -325,8 +352,8 @@ impl Executor {
/// It is OK to use `unsafe` to call this from a thread that's not the executor thread. /// It is OK to use `unsafe` to call this from a thread that's not the executor thread.
/// In this case, the task's Future must be Send. This is because this is effectively /// In this case, the task's Future must be Send. This is because this is effectively
/// sending the task to the executor thread. /// sending the task to the executor thread.
pub(super) unsafe fn spawn(&'static self, task: NonNull<TaskHeader>) { pub(super) unsafe fn spawn(&'static self, task: TaskRef) {
task.as_ref().executor.set(self); task.header().executor.set(self);
#[cfg(feature = "rtos-trace")] #[cfg(feature = "rtos-trace")]
trace::task_new(task.as_ptr() as u32); trace::task_new(task.as_ptr() as u32);
@ -359,7 +386,7 @@ impl Executor {
self.timer_queue.dequeue_expired(Instant::now(), |task| wake_task(task)); self.timer_queue.dequeue_expired(Instant::now(), |task| wake_task(task));
self.run_queue.dequeue_all(|p| { self.run_queue.dequeue_all(|p| {
let task = p.as_ref(); let task = p.header();
#[cfg(feature = "integrated-timers")] #[cfg(feature = "integrated-timers")]
task.expires_at.set(Instant::MAX); task.expires_at.set(Instant::MAX);
@ -378,7 +405,7 @@ impl Executor {
trace::task_exec_begin(p.as_ptr() as u32); trace::task_exec_begin(p.as_ptr() as u32);
// Run the task // Run the task
task.poll_fn.read()(p as _); task.poll_fn.read()(p);
#[cfg(feature = "rtos-trace")] #[cfg(feature = "rtos-trace")]
trace::task_exec_end(); trace::task_exec_end();
@ -424,9 +451,9 @@ impl Executor {
/// # Safety /// # Safety
/// ///
/// `task` must be a valid task pointer obtained from [`task_from_waker`]. /// `task` must be a valid task pointer obtained from [`task_from_waker`].
pub unsafe fn wake_task(task: NonNull<TaskHeader>) { pub unsafe fn wake_task(task: TaskRef) {
critical_section::with(|cs| { critical_section::with(|cs| {
let header = task.as_ref(); let header = task.header();
let state = header.state.load(Ordering::Relaxed); let state = header.state.load(Ordering::Relaxed);
// If already scheduled, or if not started, // If already scheduled, or if not started,
@ -450,7 +477,7 @@ struct TimerQueue;
impl embassy_time::queue::TimerQueue for TimerQueue { impl embassy_time::queue::TimerQueue for TimerQueue {
fn schedule_wake(&'static self, at: Instant, waker: &core::task::Waker) { fn schedule_wake(&'static self, at: Instant, waker: &core::task::Waker) {
let task = waker::task_from_waker(waker); let task = waker::task_from_waker(waker);
let task = unsafe { task.as_ref() }; let task = task.header();
let expires_at = task.expires_at.get(); let expires_at = task.expires_at.get();
task.expires_at.set(expires_at.min(at)); task.expires_at.set(expires_at.min(at));
} }

View file

@ -4,7 +4,7 @@ use core::ptr::NonNull;
use atomic_polyfill::{AtomicPtr, Ordering}; use atomic_polyfill::{AtomicPtr, Ordering};
use critical_section::CriticalSection; use critical_section::CriticalSection;
use super::TaskHeader; use super::{TaskHeader, TaskRef};
pub(crate) struct RunQueueItem { pub(crate) struct RunQueueItem {
next: AtomicPtr<TaskHeader>, next: AtomicPtr<TaskHeader>,
@ -46,25 +46,26 @@ impl RunQueue {
/// ///
/// `item` must NOT be already enqueued in any queue. /// `item` must NOT be already enqueued in any queue.
#[inline(always)] #[inline(always)]
pub(crate) unsafe fn enqueue(&self, _cs: CriticalSection, task: NonNull<TaskHeader>) -> bool { pub(crate) unsafe fn enqueue(&self, _cs: CriticalSection, task: TaskRef) -> bool {
let prev = self.head.load(Ordering::Relaxed); let prev = self.head.load(Ordering::Relaxed);
task.as_ref().run_queue_item.next.store(prev, Ordering::Relaxed); task.header().run_queue_item.next.store(prev, Ordering::Relaxed);
self.head.store(task.as_ptr(), Ordering::Relaxed); self.head.store(task.as_ptr() as _, Ordering::Relaxed);
prev.is_null() prev.is_null()
} }
/// Empty the queue, then call `on_task` for each task that was in the queue. /// Empty the queue, then call `on_task` for each task that was in the queue.
/// NOTE: It is OK for `on_task` to enqueue more tasks. In this case they're left in the queue /// NOTE: It is OK for `on_task` to enqueue more tasks. In this case they're left in the queue
/// and will be processed by the *next* call to `dequeue_all`, *not* the current one. /// and will be processed by the *next* call to `dequeue_all`, *not* the current one.
pub(crate) fn dequeue_all(&self, on_task: impl Fn(NonNull<TaskHeader>)) { pub(crate) fn dequeue_all(&self, on_task: impl Fn(TaskRef)) {
// Atomically empty the queue. // Atomically empty the queue.
let mut ptr = self.head.swap(ptr::null_mut(), Ordering::AcqRel); let mut ptr = self.head.swap(ptr::null_mut(), Ordering::AcqRel);
// Iterate the linked list of tasks that were previously in the queue. // Iterate the linked list of tasks that were previously in the queue.
while let Some(task) = NonNull::new(ptr) { while let Some(task) = NonNull::new(ptr) {
let task = unsafe { TaskRef::from_ptr(task.as_ptr()) };
// If the task re-enqueues itself, the `next` pointer will get overwritten. // If the task re-enqueues itself, the `next` pointer will get overwritten.
// Therefore, first read the next pointer, and only then process the task. // Therefore, first read the next pointer, and only then process the task.
let next = unsafe { task.as_ref() }.run_queue_item.next.load(Ordering::Relaxed); let next = task.header().run_queue_item.next.load(Ordering::Relaxed);
on_task(task); on_task(task);

View file

@ -1,45 +1,39 @@
use core::cell::Cell; use core::cell::Cell;
use core::cmp::min; use core::cmp::min;
use core::ptr;
use core::ptr::NonNull;
use atomic_polyfill::Ordering; use atomic_polyfill::Ordering;
use embassy_time::Instant; use embassy_time::Instant;
use super::{TaskHeader, STATE_TIMER_QUEUED}; use super::{TaskRef, STATE_TIMER_QUEUED};
pub(crate) struct TimerQueueItem { pub(crate) struct TimerQueueItem {
next: Cell<*mut TaskHeader>, next: Cell<Option<TaskRef>>,
} }
impl TimerQueueItem { impl TimerQueueItem {
pub const fn new() -> Self { pub const fn new() -> Self {
Self { Self { next: Cell::new(None) }
next: Cell::new(ptr::null_mut()),
}
} }
} }
pub(crate) struct TimerQueue { pub(crate) struct TimerQueue {
head: Cell<*mut TaskHeader>, head: Cell<Option<TaskRef>>,
} }
impl TimerQueue { impl TimerQueue {
pub const fn new() -> Self { pub const fn new() -> Self {
Self { Self { head: Cell::new(None) }
head: Cell::new(ptr::null_mut()),
}
} }
pub(crate) unsafe fn update(&self, p: NonNull<TaskHeader>) { pub(crate) unsafe fn update(&self, p: TaskRef) {
let task = p.as_ref(); let task = p.header();
if task.expires_at.get() != Instant::MAX { if task.expires_at.get() != Instant::MAX {
let old_state = task.state.fetch_or(STATE_TIMER_QUEUED, Ordering::AcqRel); let old_state = task.state.fetch_or(STATE_TIMER_QUEUED, Ordering::AcqRel);
let is_new = old_state & STATE_TIMER_QUEUED == 0; let is_new = old_state & STATE_TIMER_QUEUED == 0;
if is_new { if is_new {
task.timer_queue_item.next.set(self.head.get()); task.timer_queue_item.next.set(self.head.get());
self.head.set(p.as_ptr()); self.head.set(Some(p));
} }
} }
} }
@ -47,7 +41,7 @@ impl TimerQueue {
pub(crate) unsafe fn next_expiration(&self) -> Instant { pub(crate) unsafe fn next_expiration(&self) -> Instant {
let mut res = Instant::MAX; let mut res = Instant::MAX;
self.retain(|p| { self.retain(|p| {
let task = p.as_ref(); let task = p.header();
let expires = task.expires_at.get(); let expires = task.expires_at.get();
res = min(res, expires); res = min(res, expires);
expires != Instant::MAX expires != Instant::MAX
@ -55,9 +49,9 @@ impl TimerQueue {
res res
} }
pub(crate) unsafe fn dequeue_expired(&self, now: Instant, on_task: impl Fn(NonNull<TaskHeader>)) { pub(crate) unsafe fn dequeue_expired(&self, now: Instant, on_task: impl Fn(TaskRef)) {
self.retain(|p| { self.retain(|p| {
let task = p.as_ref(); let task = p.header();
if task.expires_at.get() <= now { if task.expires_at.get() <= now {
on_task(p); on_task(p);
false false
@ -67,11 +61,10 @@ impl TimerQueue {
}); });
} }
pub(crate) unsafe fn retain(&self, mut f: impl FnMut(NonNull<TaskHeader>) -> bool) { pub(crate) unsafe fn retain(&self, mut f: impl FnMut(TaskRef) -> bool) {
let mut prev = &self.head; let mut prev = &self.head;
while !prev.get().is_null() { while let Some(p) = prev.get() {
let p = NonNull::new_unchecked(prev.get()); let task = p.header();
let task = &*p.as_ptr();
if f(p) { if f(p) {
// Skip to next // Skip to next
prev = &task.timer_queue_item.next; prev = &task.timer_queue_item.next;

View file

@ -1,8 +1,7 @@
use core::mem; use core::mem;
use core::ptr::NonNull;
use core::task::{RawWaker, RawWakerVTable, Waker}; use core::task::{RawWaker, RawWakerVTable, Waker};
use super::{wake_task, TaskHeader}; use super::{wake_task, TaskHeader, TaskRef};
const VTABLE: RawWakerVTable = RawWakerVTable::new(clone, wake, wake, drop); const VTABLE: RawWakerVTable = RawWakerVTable::new(clone, wake, wake, drop);
@ -11,14 +10,14 @@ unsafe fn clone(p: *const ()) -> RawWaker {
} }
unsafe fn wake(p: *const ()) { unsafe fn wake(p: *const ()) {
wake_task(NonNull::new_unchecked(p as *mut TaskHeader)) wake_task(TaskRef::from_ptr(p as *const TaskHeader))
} }
unsafe fn drop(_: *const ()) { unsafe fn drop(_: *const ()) {
// nop // nop
} }
pub(crate) unsafe fn from_task(p: NonNull<TaskHeader>) -> Waker { pub(crate) unsafe fn from_task(p: TaskRef) -> Waker {
Waker::from_raw(RawWaker::new(p.as_ptr() as _, &VTABLE)) Waker::from_raw(RawWaker::new(p.as_ptr() as _, &VTABLE))
} }
@ -33,7 +32,7 @@ pub(crate) unsafe fn from_task(p: NonNull<TaskHeader>) -> Waker {
/// # Panics /// # Panics
/// ///
/// Panics if the waker is not created by the Embassy executor. /// Panics if the waker is not created by the Embassy executor.
pub fn task_from_waker(waker: &Waker) -> NonNull<TaskHeader> { pub fn task_from_waker(waker: &Waker) -> TaskRef {
// safety: OK because WakerHack has the same layout as Waker. // safety: OK because WakerHack has the same layout as Waker.
// This is not really guaranteed because the structs are `repr(Rust)`, it is // This is not really guaranteed because the structs are `repr(Rust)`, it is
// indeed the case in the current implementation. // indeed the case in the current implementation.
@ -43,8 +42,8 @@ pub fn task_from_waker(waker: &Waker) -> NonNull<TaskHeader> {
panic!("Found waker not created by the Embassy executor. `embassy_time::Timer` only works with the Embassy executor.") panic!("Found waker not created by the Embassy executor. `embassy_time::Timer` only works with the Embassy executor.")
} }
// safety: we never create a waker with a null data pointer. // safety: our wakers are always created with `TaskRef::as_ptr`
unsafe { NonNull::new_unchecked(hack.data as *mut TaskHeader) } unsafe { TaskRef::from_ptr(hack.data as *const TaskHeader) }
} }
struct WakerHack { struct WakerHack {

View file

@ -1,7 +1,6 @@
use core::future::poll_fn; use core::future::poll_fn;
use core::marker::PhantomData; use core::marker::PhantomData;
use core::mem; use core::mem;
use core::ptr::NonNull;
use core::task::Poll; use core::task::Poll;
use super::raw; use super::raw;
@ -22,12 +21,12 @@ use super::raw;
/// Once you've invoked a task function and obtained a SpawnToken, you *must* spawn it. /// Once you've invoked a task function and obtained a SpawnToken, you *must* spawn it.
#[must_use = "Calling a task function does nothing on its own. You must spawn the returned SpawnToken, typically with Spawner::spawn()"] #[must_use = "Calling a task function does nothing on its own. You must spawn the returned SpawnToken, typically with Spawner::spawn()"]
pub struct SpawnToken<S> { pub struct SpawnToken<S> {
raw_task: Option<NonNull<raw::TaskHeader>>, raw_task: Option<raw::TaskRef>,
phantom: PhantomData<*mut S>, phantom: PhantomData<*mut S>,
} }
impl<S> SpawnToken<S> { impl<S> SpawnToken<S> {
pub(crate) unsafe fn new(raw_task: NonNull<raw::TaskHeader>) -> Self { pub(crate) unsafe fn new(raw_task: raw::TaskRef) -> Self {
Self { Self {
raw_task: Some(raw_task), raw_task: Some(raw_task),
phantom: PhantomData, phantom: PhantomData,
@ -92,7 +91,7 @@ impl Spawner {
pub async fn for_current_executor() -> Self { pub async fn for_current_executor() -> Self {
poll_fn(|cx| unsafe { poll_fn(|cx| unsafe {
let task = raw::task_from_waker(cx.waker()); let task = raw::task_from_waker(cx.waker());
let executor = (*task.as_ptr()).executor.get(); let executor = task.header().executor.get();
Poll::Ready(Self::new(&*executor)) Poll::Ready(Self::new(&*executor))
}) })
.await .await
@ -168,7 +167,7 @@ impl SendSpawner {
pub async fn for_current_executor() -> Self { pub async fn for_current_executor() -> Self {
poll_fn(|cx| unsafe { poll_fn(|cx| unsafe {
let task = raw::task_from_waker(cx.waker()); let task = raw::task_from_waker(cx.waker());
let executor = (*task.as_ptr()).executor.get(); let executor = task.header().executor.get();
Poll::Ready(Self::new(&*executor)) Poll::Ready(Self::new(&*executor))
}) })
.await .await