Эх сурвалжийг харах

docs: document all un-documented APIs (#39)

*Whew*, that was a pain!

We should have more or less complete API docs now, though.

Signed-off-by: Eliza Weisman <eliza@buoyant.io>
Eliza Weisman 3 жил өмнө
parent
commit
b6527a8609

+ 6 - 1
README.md

@@ -110,7 +110,12 @@ With the `std` feature disabled, `thingbuf` will depend only on `libcore`. This
 means that APIs that require dynamic memory allocation will not be enabled.
 Statically allocated [channels][static-mpsc] and [queues][static-queue] are
 available for code without a memory allocator, if the `static` feature flag is
-enabled.
+enabled:
+
+```toml
+[dependencies]
+thingbuf = { version = "0.1", default-features = false, features = ["static"] }
+```
 
 However, if a memory allocator _is_ available, `#![no_std]` code can also enable
 the `alloc` feature flag to depend on `liballoc`:

+ 4 - 8
bench/benches/sync_spsc.rs

@@ -33,10 +33,8 @@ aaaaaaaaaaaaaa";
                     }
                 });
                 for _ in 0..i {
-                    let r = rx.recv_ref().unwrap();
-                    r.with(|val| {
-                        criterion::black_box(val);
-                    });
+                    let val = rx.recv_ref().unwrap();
+                    criterion::black_box(val);
                 }
                 drop(rx);
                 producer.join().unwrap();
@@ -114,10 +112,8 @@ aaaaaaaaaaaaaa";
                     }
                 });
                 for _ in 0..i {
-                    let r = rx.recv_ref().unwrap();
-                    r.with(|val| {
-                        criterion::black_box(val);
-                    });
+                    let val = rx.recv_ref().unwrap();
+                    criterion::black_box(val);
                 }
                 drop(rx);
                 producer.join().unwrap();

+ 19 - 4
src/lib.rs

@@ -1,6 +1,7 @@
-#![cfg_attr(docsrs, doc = include_str!("../README.md"))]
 #![cfg_attr(not(feature = "std"), no_std)]
 #![cfg_attr(docsrs, feature(doc_cfg, doc_auto_cfg))]
+#![doc = include_str!("../README.md")]
+#![warn(missing_docs)]
 use core::{cmp, fmt, mem::MaybeUninit, ops, ptr};
 #[macro_use]
 mod macros;
@@ -13,7 +14,7 @@ mod wait;
 
 pub use self::recycling::Recycle;
 
-#[cfg_attr(docsrs, doc = include_str!("../mpsc_perf_comparison.md"))]
+#[doc = include_str!("../mpsc_perf_comparison.md")]
 pub mod mpsc_perf_comparison {
     // Empty module, used only for documentation.
 }
@@ -41,6 +42,20 @@ use crate::{
 };
 
 /// A reference to an entry in a [`ThingBuf`].
+///
+/// A `Ref` represents the exclusive permission to mutate a given element in a
+/// queue. A `Ref<T>` [implements `DerefMut<T>`] to allow writing to that
+/// element.
+///
+/// `Ref`s are returned by the [`ThingBuf::push_ref`] and [`ThingBuf::pop_ref`]
+/// methods. When the `Ref` is dropped, the exclusive write access to that
+/// element is released, and the push or pop operation is completed &mdash;
+/// calling `push_ref` or `pop_ref` *begins* a push or pop operation, which ends
+/// when the returned `Ref` is complete. When the `Ref` is dropped, the pushed
+/// element will become available to a subsequent `pop_ref`, or the popped
+/// element will be able to be written to by a `push_ref`, respectively.
+///
+/// [implements `DerefMut<T>`]: #impl-DerefMut
 pub struct Ref<'slot, T> {
     ptr: MutPtr<MaybeUninit<T>>,
     slot: &'slot Slot<T>,
@@ -374,7 +389,7 @@ impl Drop for Core {
 
 impl<T> Ref<'_, T> {
     #[inline]
-    pub fn with<U>(&self, f: impl FnOnce(&T) -> U) -> U {
+    fn with<U>(&self, f: impl FnOnce(&T) -> U) -> U {
         self.ptr.with(|value| unsafe {
             // Safety: if a `Ref` exists, we have exclusive ownership of the
             // slot. A `Ref` is only created if the slot has already been
@@ -386,7 +401,7 @@ impl<T> Ref<'_, T> {
     }
 
     #[inline]
-    pub fn with_mut<U>(&mut self, f: impl FnOnce(&mut T) -> U) -> U {
+    fn with_mut<U>(&mut self, f: impl FnOnce(&mut T) -> U) -> U {
         self.ptr.with(|value| unsafe {
             // Safety: if a `Ref` exists, we have exclusive ownership of the
             // slot.

+ 12 - 26
src/mpsc.rs

@@ -18,13 +18,21 @@ use crate::{
 };
 use core::{fmt, ops::Index, task::Poll};
 
+/// Error returned by the [`Sender::try_send`] (and [`StaticSender::try_send`])
+/// methods.
 #[derive(Debug)]
 #[non_exhaustive]
 pub enum TrySendError<T = ()> {
+    /// The data could not be sent on the channel because the channel is
+    /// currently full and sending would require waiting for capacity.
     Full(T),
+    /// The data could not be sent because the [`Receiver`] half of the channel
+    /// has been dropped.
     Closed(T),
 }
 
+/// Error returned by [`Sender::send`] and [`Sender::send_ref`], if the
+/// [`Receiver`] half of the channel has been dropped.
 #[derive(Debug)]
 pub struct Closed<T = ()>(T);
 
@@ -271,21 +279,10 @@ impl<N: Notify + Unpin> Drop for NotifyTx<'_, N> {
 }
 
 macro_rules! impl_send_ref {
-    (pub struct $name:ident<$notify:ty>;) => {
+    ($(#[$m:meta])* pub struct $name:ident<$notify:ty>;) => {
+        $(#[$m])*
         pub struct $name<'sender, T>(SendRefInner<'sender, T, $notify>);
 
-        impl<T> $name<'_, T> {
-            #[inline]
-            pub fn with<U>(&self, f: impl FnOnce(&T) -> U) -> U {
-                self.0.with(f)
-            }
-
-            #[inline]
-            pub fn with_mut<U>(&mut self, f: impl FnOnce(&mut T) -> U) -> U {
-                self.0.with_mut(f)
-            }
-        }
-
         impl<T> core::ops::Deref for $name<'_, T> {
             type Target = T;
 
@@ -334,7 +331,8 @@ macro_rules! impl_send_ref {
 }
 
 macro_rules! impl_recv_ref {
-    (pub struct $name:ident<$notify:ty>;) => {
+    ($(#[$m:meta])* pub struct $name:ident<$notify:ty>;) => {
+        $(#[$m])*
         pub struct $name<'recv, T> {
             // /!\ LOAD BEARING STRUCT DROP ORDER /!\
             //
@@ -355,18 +353,6 @@ macro_rules! impl_recv_ref {
             _notify: crate::mpsc::NotifyTx<'recv, $notify>,
         }
 
-        impl<T> $name<'_, T> {
-            #[inline]
-            pub fn with<U>(&self, f: impl FnOnce(&T) -> U) -> U {
-                self.slot.with(f)
-            }
-
-            #[inline]
-            pub fn with_mut<U>(&mut self, f: impl FnOnce(&mut T) -> U) -> U {
-                self.slot.with_mut(f)
-            }
-        }
-
         impl<T> core::ops::Deref for $name<'_, T> {
             type Target = T;
 

+ 732 - 38
src/mpsc/async_impl.rs

@@ -17,13 +17,18 @@ feature! {
 
     use crate::loom::sync::Arc;
 
-    /// Returns a new asynchronous multi-producer, single consumer channel.
+    /// Returns a new asynchronous multi-producer, single consumer (MPSC)
+    /// channel with the provided capacity.
+    ///
+    /// This channel will use the [default recycling policy].
+    ///
+    /// [recycling policy]: crate::recycling::DefaultRecycle
     pub fn channel<T: Default + Clone>(capacity: usize) -> (Sender<T>, Receiver<T>) {
         with_recycle(capacity, recycling::DefaultRecycle::new())
     }
 
-    /// Returns a new asynchronous multi-producer, single consumer channel with
-    /// the provided [recycling policy].
+    /// Returns a new asynchronous multi-producer, single consumer (MPSC)
+    /// channel with the provided capacity and [recycling policy].
     ///
     /// [recycling policy]: crate::recycling::Recycle
     pub fn with_recycle<T, R: Recycle<T>>(capacity: usize, recycle: R) -> (Sender<T, R>, Receiver<T, R>) {
@@ -40,11 +45,20 @@ feature! {
         (tx, rx)
     }
 
+
+    /// Asynchronously receives values from associated [`Sender`]s.
+    ///
+    /// Instances of this struct are created by the [`channel`] and
+    /// [`with_recycle`] functions.
     #[derive(Debug)]
     pub struct Receiver<T, R = recycling::DefaultRecycle> {
         inner: Arc<Inner<T, R>>,
     }
 
+    /// Asynchronously sends values to an associated [`Receiver`].
+    ///
+    /// Instances of this struct are created by the [`channel`] and
+    /// [`with_recycle`] functions.
     #[derive(Debug)]
     pub struct Sender<T, R = recycling::DefaultRecycle> {
         inner: Arc<Inner<T, R>>,
@@ -62,19 +76,55 @@ feature! {
     where
         R: Recycle<T>,
     {
-        pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
-            self.inner
-                .core
-                .try_send_ref(self.inner.slots.as_ref(), &self.inner.recycle)
-                .map(SendRef)
-        }
-
-        pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
-            self.inner
-                .core
-                .try_send(self.inner.slots.as_ref(), val, &self.inner.recycle)
-        }
-
+        /// Reserves a slot in the channel to mutate in place, waiting until
+        /// there is a free slot to write to.
+        ///
+        /// This is similar to the [`send`] method, but, rather than taking a
+        /// message by value to write to the channel, this method reserves a
+        /// writable slot in the channel, and returns a [`SendRef`] that allows
+        /// mutating the slot in place. If the [`Receiver`] end of the channel
+        /// uses the [`Receiver::recv_ref`] or [`Receiver::poll_recv_ref`]
+        /// methods for receiving from the channel, this allows allocations for
+        /// channel messages to be reused in place.
+        ///
+        /// # Errors
+        ///
+        /// If the [`Receiver`] end of the channel has been dropped, this
+        /// returns a [`Closed`] error.
+        ///
+        /// # Examples
+        ///
+        /// Sending formatted strings by writing them directly to channel slots,
+        /// in place:
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// use thingbuf::mpsc;
+        /// use std::fmt::Write;
+        ///
+        /// # async fn example() {
+        /// let (tx, rx) = mpsc::channel::<String>(8);
+        ///
+        /// // Spawn a task that prints each message received from the channel:
+        /// tokio::spawn(async move {
+        ///     while let Some(msg) = rx.recv_ref().await {
+        ///         println!("{}", msg);
+        ///     }
+        /// });
+        ///
+        /// // Until the channel closes, write formatted messages to the channel.
+        /// let mut count = 1;
+        /// while let Ok(mut value) = tx.send_ref().await {
+        ///     // Writing to the `SendRef` will reuse the *existing* string
+        ///     // allocation in place.
+        ///     write!(value, "hello from message {}", count)
+        ///         .expect("writing to a `String` should never fail");
+        ///     count += 1;
+        /// }
+        /// # }
+        /// ```
+        /// [`send`]: Self::send
         pub async fn send_ref(&self) -> Result<SendRef<'_, T>, Closed> {
             SendRefFuture {
                 core: &self.inner.core,
@@ -86,15 +136,125 @@ feature! {
             .await
         }
 
+        /// Sends a message by value, waiting until there is a free slot to
+        /// write to.
+        ///
+        /// This method takes the message by value, and replaces any previous
+        /// value in the slot. This means that the channel will *not* function
+        /// as an object pool while sending messages with `send`. This method is
+        /// most appropriate when messages don't own reusable heap allocations,
+        /// or when the [`Receiver`] end of the channel must receive messages by
+        /// moving them out of the channel by value (using the
+        /// [`Receiver::recv`] method). When messages in the channel own
+        /// reusable heap allocations (such as `String`s or `Vec`s), and the
+        /// [`Receiver`] doesn't need to receive them by value, consider using
+        /// [`send_ref`] instead, to enable allocation reuse.
+        ///
+        /// # Errors
+        ///
+        /// If the [`Receiver`] end of the channel has been dropped, this
+        /// returns a [`Closed`] error containing the sent value.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// use thingbuf::mpsc;
+        /// # async fn example() {
+        /// let (tx, rx) = mpsc::channel(8);
+        ///
+        /// // Spawn a task that prints each message received from the channel:
+        /// tokio::spawn(async move {
+        ///     while let Some(msg) = rx.recv().await {
+        ///         println!("received message {}", msg);
+        ///     }
+        /// });
+        ///
+        /// // Until the channel closes, write the current iteration to the channel.
+        /// let mut count = 1;
+        /// while tx.send(count).await.is_ok() {
+        ///     count += 1;
+        /// }
+        /// # }
+        /// ```
+        /// [`send_ref`]: Self::send_ref
         pub async fn send(&self, val: T) -> Result<(), Closed<T>> {
             match self.send_ref().await {
                 Err(Closed(())) => Err(Closed(val)),
                 Ok(mut slot) => {
-                    slot.with_mut(|slot| *slot = val);
+                    *slot = val;
                     Ok(())
                 }
             }
         }
+
+        /// Attempts to reserve a slot in the channel to mutate in place,
+        /// without waiting for capacity.
+        ///
+        /// This method differs from [`send_ref`] by returning immediately if the
+        /// channel’s buffer is full or no [`Receiver`] exists. Compared with
+        /// [`send_ref`], this method has two failure cases instead of one (one for
+        /// disconnection, one for a full buffer), and this method is not
+        /// `async`, because it will never wait.
+        ///
+        /// Like [`send_ref`], this method returns a [`SendRef`] that may be
+        /// used to mutate a slot in the channel's buffer in place. Dropping the
+        /// [`SendRef`] completes the send operation and makes the mutated value
+        /// available to the [`Receiver`].
+        ///
+        /// # Errors
+        ///
+        /// If the channel capacity has been reached (i.e., the channel has `n`
+        /// buffered values where `n` is the argument passed to
+        /// [`channel`]/[`with_recycle`]), then [`TrySendError::Full`] is
+        /// returned. In this case, a future call to `try_send` may succeed if
+        /// additional capacity becomes available.
+        ///
+        /// If the receive half of the channel is closed (i.e., the [`Receiver`]
+        /// handle was dropped), the function returns [`TrySendError::Closed`].
+        /// Once the channel has closed, subsequent calls to `try_send_ref` will
+        /// never succeed.
+        ///
+        /// [`send_ref`]: Self::send_ref
+        pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
+            self.inner
+                .core
+                .try_send_ref(self.inner.slots.as_ref(), &self.inner.recycle)
+                .map(SendRef)
+        }
+
+        /// Attempts to send a message by value immediately, without waiting for
+        /// capacity.
+        ///
+        /// This method differs from [`send`] by returning immediately if the
+        /// channel’s buffer is full or no [`Receiver`] exists. Compared with
+        /// [`send`], this method has two failure cases instead of one (one for
+        /// disconnection, one for a full buffer), and this method is not
+        /// `async`, because it will never wait.
+        ///
+        /// # Errors
+        ///
+        /// If the channel capacity has been reached (i.e., the channel has `n`
+        /// buffered values where `n` is the argument passed to
+        /// [`channel`]/[`with_recycle`]), then [`TrySendError::Full`] is
+        /// returned. In this case, a future call to `try_send` may succeed if
+        /// additional capacity becomes available.
+        ///
+        /// If the receive half of the channel is closed (i.e., the [`Receiver`]
+        /// handle was dropped), the function returns [`TrySendError::Closed`].
+        /// Once the channel has closed, subsequent calls to `try_send` will
+        /// never succeed.
+        ///
+        /// In both cases, the error includes the value passed to `try_send`.
+        ///
+        /// [`send`]: Self::send
+        pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
+            self.inner
+                .core
+                .try_send(self.inner.slots.as_ref(), val, &self.inner.recycle)
+        }
     }
 
     impl<T, R> Clone for Sender<T, R> {
@@ -122,6 +282,69 @@ feature! {
     // === impl Receiver ===
 
     impl<T, R> Receiver<T, R> {
+        /// Receives the next message for this receiver, **by reference**.
+        ///
+        /// This method returns `None` if the channel has been closed and there are
+        /// no remaining messages in the channel's buffer. This indicates that no
+        /// further values can ever be received from this `Receiver`. The channel is
+        /// closed when all [`Sender`]s have been dropped.
+        ///
+        /// If there are no messages in the channel's buffer, but the channel has
+        /// not yet been closed, this method will wait until a message is sent or
+        /// the channel is closed.
+        ///
+        /// This method returns a [`RecvRef`] that can be used to read from (or
+        /// mutate) the received message by reference. When the [`RecvRef`] is
+        /// dropped, the receive operation completes and the slot occupied by
+        /// the received message becomes usable for a future [`send_ref`] operation.
+        ///
+        /// If all [`Sender`]s for this channel write to the channel's slots in
+        /// place by using the [`send_ref`] or [`try_send_ref`] methods, this
+        /// method allows messages that own heap allocations to be reused in
+        /// place.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// # async fn docs() {
+        /// use thingbuf::mpsc;
+        /// use std::fmt::Write;
+        ///
+        /// let (tx, rx) = mpsc::channel::<String>(100);
+        ///
+        /// tokio::spawn(async move {
+        ///     let mut value = tx.send_ref().await.unwrap();
+        ///     write!(value, "hello world!")
+        ///         .expect("writing to a `String` should never fail");
+        /// });
+        ///
+        /// assert_eq!(Some("hello world!"), rx.recv_ref().await.as_deref().map(String::as_str));
+        /// assert_eq!(None, rx.recv().await.as_deref());
+        /// # }
+        /// ```
+        ///
+        /// Values are buffered:
+        ///
+        /// ```
+        /// # async fn docs() {
+        /// use thingbuf::mpsc;
+        /// use std::fmt::Write;
+        ///
+        /// let (tx, rx) = mpsc::channel::<String>(100);
+        ///
+        /// write!(tx.send_ref().await.unwrap(), "hello").unwrap();
+        /// write!(tx.send_ref().await.unwrap(), "world").unwrap();
+        ///
+        /// assert_eq!("hello", rx.recv_ref().await.unwrap().as_str());
+        /// assert_eq!("world", rx.recv_ref().await.unwrap().as_str());
+        /// # }
+        /// ```
+        ///
+        /// [`send_ref`]: Sender::send_ref
+        /// [`try_send_ref`]: Sender::try_send_ref
         pub fn recv_ref(&self) -> RecvRefFuture<'_, T> {
             RecvRefFuture {
                 core: &self.inner.core,
@@ -129,6 +352,64 @@ feature! {
             }
         }
 
+        /// Receives the next message for this receiver, **by value**.
+        ///
+        /// This method returns `None` if the channel has been closed and there are
+        /// no remaining messages in the channel's buffer. This indicates that no
+        /// further values can ever be received from this `Receiver`. The channel is
+        /// closed when all [`Sender`]s have been dropped.
+        ///
+        /// If there are no messages in the channel's buffer, but the channel has
+        /// not yet been closed, this method will wait until a message is sent or
+        /// the channel is closed.
+        ///
+        /// When a message is received, it is moved out of the channel by value,
+        /// and replaced with a new slot according to the configured [recycling
+        /// policy]. If all [`Sender`]s for this channel write to the channel's
+        /// slots in place by using the [`send_ref`] or [`try_send_ref`] methods,
+        /// consider using the [`recv_ref`] method instead, to enable the
+        /// reuse of heap allocations.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// # async fn docs() {
+        /// use thingbuf::mpsc;
+        ///
+        /// let (tx, rx) = mpsc::channel(100);
+        ///
+        /// tokio::spawn(async move {
+        ///    tx.send(1).await.unwrap();
+        /// });
+        ///
+        /// assert_eq!(Some(1), rx.recv().await);
+        /// assert_eq!(None, rx.recv().await);
+        /// # }
+        /// ```
+        ///
+        /// Values are buffered:
+        ///
+        /// ```
+        /// # async fn docs() {
+        /// use thingbuf::mpsc;
+        ///
+        /// let (tx, rx) = mpsc::channel(100);
+        ///
+        /// tx.send(1).await.unwrap();
+        /// tx.send(2).await.unwrap();
+        ///
+        /// assert_eq!(Some(1), rx.recv().await);
+        /// assert_eq!(Some(2), rx.recv().await);
+        /// # }
+        /// ```
+        ///
+        /// [`send_ref`]: Sender::send_ref
+        /// [`try_send_ref`]: Sender::try_send_ref
+        /// [recycling policy]: crate::recycling::Recycle
+        /// [`recv_ref`]: Self::recv_ref
         pub fn recv(&self) -> RecvFuture<'_, T, R>
         where
             R: Recycle<T>,
@@ -140,36 +421,82 @@ feature! {
             }
         }
 
+        /// Attempts to receive a message *by reference* from this channel,
+        /// registering the current task for wakeup if the a message is not yet
+        /// available, and returning `None` if the channel has closed and all
+        /// messages have been received.
+        ///
+        /// Like [`Receiver::recv_ref`], this method returns a [`RecvRef`] that
+        /// can be used to read from (or mutate) the received message by
+        /// reference. When the [`RecvRef`] is dropped, the receive operation
+        /// completes and the slot occupied by the received message becomes
+        /// usable for a future [`send_ref`] operation.
+        ///
+        /// If all [`Sender`]s for this channel write to the channel's slots in
+        /// place by using the [`send_ref`] or [`try_send_ref`] methods, this
+        /// method allows messages that own heap allocations to be reused in
+        /// place.
+        ///
+        /// To wait asynchronously until a message becomes available, use the
+        /// [`recv_ref`] method instead.
+        ///
         /// # Returns
         ///
         ///  * `Poll::Pending` if no messages are available but the channel is not
         ///    closed, or if a spurious failure happens.
-        ///  * `Poll::Ready(Some(Ref<T>))` if a message is available.
-        ///  * `Poll::Ready(None)` if the channel has been closed and all messages
-        ///    sent before it was closed have been received.
+        ///  * `Poll::Ready(Some(RecvRef<T>))` if a message is available.
+        ///  * `Poll::Ready(None)` if the channel has been closed (i.e., all
+        ///    [`Sender`]s have been dropped), and all messages sent before it
+        ///    was closed have been received.
         ///
         /// When the method returns [`Poll::Pending`], the [`Waker`] in the provided
         /// [`Context`] is scheduled to receive a wakeup when a message is sent on any
         /// sender, or when the channel is closed.  Note that on multiple calls to
         /// `poll_recv_ref`, only the [`Waker`] from the [`Context`] passed to the most
         /// recent call is scheduled to receive a wakeup.
+        ///
+        /// [`send_ref`]: Sender::send_ref
+        /// [`try_send_ref`]: Sender::try_send_ref
+        /// [`recv_ref`]: Self::recv_ref
         pub fn poll_recv_ref(&self, cx: &mut Context<'_>) -> Poll<Option<RecvRef<'_, T>>> {
             poll_recv_ref(&self.inner.core, &self.inner.slots, cx)
         }
 
+        /// Attempts to receive a message *by value* from this channel,
+        /// registering the current task for wakeup if the value is not yet
+        /// available, and returning `None` if the channel has closed and all
+        /// messages have been received.
+        ///
+        /// When a message is received, it is moved out of the channel by value,
+        /// and replaced with a new slot according to the configured [recycling
+        /// policy]. If all [`Sender`]s for this channel write to the channel's
+        /// slots in place by using the [`send_ref`] or [`try_send_ref`] methods,
+        /// consider using the [`poll_recv_ref`] method instead, to enable the
+        /// reuse of heap allocations.
+        ///
+        /// To wait asynchronously until a message becomes available, use the
+        /// [`recv`] method instead.
+        ///
         /// # Returns
         ///
         ///  * `Poll::Pending` if no messages are available but the channel is not
         ///    closed, or if a spurious failure happens.
         ///  * `Poll::Ready(Some(message))` if a message is available.
-        ///  * `Poll::Ready(None)` if the channel has been closed and all messages
-        ///    sent before it was closed have been received.
+        ///  * `Poll::Ready(None)` if the channel has been closed (i.e., all
+        ///    [`Sender`]s have been dropped) and all messages sent before it
+        ///    was closed have been received.
         ///
         /// When the method returns [`Poll::Pending`], the [`Waker`] in the provided
         /// [`Context`] is scheduled to receive a wakeup when a message is sent on any
         /// sender, or when the channel is closed.  Note that on multiple calls to
         /// `poll_recv`, only the [`Waker`] from the [`Context`] passed to the most
         /// recent call is scheduled to receive a wakeup.
+        ///
+        /// [`send_ref`]: Sender::send_ref
+        /// [`try_send_ref`]: Sender::try_send_ref
+        /// [recycling policy]: crate::recycling::Recycle
+        /// [`poll_recv_ref`]: Self::poll_recv_ref
+        /// [`recv`]: Self::recv
         pub fn poll_recv(&self, cx: &mut Context<'_>) -> Poll<Option<T>>
         where
             R: Recycle<T>,
@@ -178,6 +505,11 @@ feature! {
                 .map(|opt| opt.map(|mut r| recycling::take(&mut *r, &self.inner.recycle)))
         }
 
+        /// Returns `true` if the channel has closed (all corresponding
+        /// [`Sender`]s have been dropped).
+        ///
+        /// If this method returns `true`, no new messages will become available
+        /// on this channel. Previously sent messages may still be available.
         pub fn is_closed(&self) -> bool {
             test_dbg!(self.inner.core.tx_count.load(Ordering::SeqCst)) <= 1
         }
@@ -249,12 +581,20 @@ feature! {
         is_split: AtomicBool,
     }
 
+    /// Asynchronously sends values to an associated [`StaticReceiver`].
+    ///
+    /// Instances of this struct are created by the [`StaticChannel::split`] and
+    /// [``StaticChannel::try_split`] functions.
     pub struct StaticSender<T: 'static, R: 'static = recycling::DefaultRecycle> {
         core: &'static ChannelCore<Waker>,
         recycle: &'static R,
         slots: &'static [Slot<T>],
     }
 
+    /// Asynchronously receives values from associated [`StaticSender`]s.
+    ///
+    /// Instances of this struct are created by the [`StaticChannel::split`] and
+    /// [``StaticChannel::try_split`] functions.
     pub struct StaticReceiver<T: 'static, R: 'static = recycling::DefaultRecycle> {
         core: &'static ChannelCore<Waker>,
         recycle: &'static R,
@@ -351,16 +691,56 @@ feature! {
     where
         R: Recycle<T>,
     {
-        pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
-            self.core
-                .try_send_ref(self.slots, self.recycle)
-                .map(SendRef)
-        }
-
-        pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
-            self.core.try_send(self.slots, val, self.recycle)
-        }
-
+        /// Reserves a slot in the channel to mutate in place, waiting until
+        /// there is a free slot to write to.
+        ///
+        /// This is similar to the [`send`] method, but, rather than taking a
+        /// message by value to write to the channel, this method reserves a
+        /// writable slot in the channel, and returns a [`SendRef`] that allows
+        /// mutating the slot in place. If the [`StaticReceiver`] end of the
+        /// channel uses the [`StaticReceiver::recv_ref`] or
+        /// [`StaticReceiver::poll_recv_ref`] methods for receiving from the
+        /// channel, this allows allocations for channel messages to be reused in place.
+        ///
+        /// # Errors
+        ///
+        /// If the [`StaticReceiver`] end of the channel has been dropped, this
+        /// returns a [`Closed`] error.
+        ///
+        /// # Examples
+        ///
+        /// Sending formatted strings by writing them directly to channel slots,
+        /// in place:
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// use thingbuf::mpsc;
+        /// use std::fmt::Write;
+        ///
+        /// # async fn example() {
+        /// static CHANNEL: mpsc::StaticChannel<String, 8> = mpsc::StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// // Spawn a task that prints each message received from the channel:
+        /// tokio::spawn(async move {
+        ///     while let Some(msg) = rx.recv_ref().await {
+        ///         println!("{}", msg);
+        ///     }
+        /// });
+        ///
+        /// // Until the channel closes, write formatted messages to the channel.
+        /// let mut count = 1;
+        /// while let Ok(mut value) = tx.send_ref().await {
+        ///     // Writing to the `SendRef` will reuse the *existing* string
+        ///     // allocation in place.
+        ///     write!(value, "hello from message {}", count)
+        ///         .expect("writing to a `String` should never fail");
+        ///     count += 1;
+        /// }
+        /// # }
+        /// ```
+        /// [`send`]: Self::send
         pub async fn send_ref(&self) -> Result<SendRef<'_, T>, Closed> {
             SendRefFuture {
                 core: self.core,
@@ -372,15 +752,124 @@ feature! {
             .await
         }
 
+        /// Sends a message by value, waiting until there is a free slot to
+        /// write to.
+        ///
+        /// This method takes the message by value, and replaces any previous
+        /// value in the slot. This means that the channel will *not* function
+        /// as an object pool while sending messages with `send`. This method is
+        /// most appropriate when messages don't own reusable heap allocations,
+        /// or when the [`StaticReceiver`] end of the channel must receive
+        /// messages by moving them out of the channel by value (using the
+        /// [`StaticReceiver::recv`] method). When messages in the channel own
+        /// reusable heap allocations (such as `String`s or `Vec`s), and the
+        /// [`StaticReceiver`] doesn't need to receive them by value, consider
+        /// using [`send_ref`] instead, to enable allocation reuse.
+        ///
+        /// # Errors
+        ///
+        /// If the [`StaticReceiver`] end of the channel has been dropped, this
+        /// returns a [`Closed`] error containing the sent value.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// use thingbuf::mpsc;
+        /// # async fn example() {
+        ///
+        /// static CHANNEL: mpsc::StaticChannel<i32, 8> = mpsc::StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// // Spawn a task that prints each message received from the channel:
+        /// tokio::spawn(async move {
+        ///     while let Some(msg) = rx.recv().await {
+        ///         println!("received message {}", msg);
+        ///     }
+        /// });
+        ///
+        /// // Until the channel closes, write the current iteration to the channel.
+        /// let mut count = 1;
+        /// while tx.send(count).await.is_ok() {
+        ///     count += 1;
+        /// }
+        /// # }
+        /// ```
+        /// [`send_ref`]: Self::send_ref
         pub async fn send(&self, val: T) -> Result<(), Closed<T>> {
             match self.send_ref().await {
                 Err(Closed(())) => Err(Closed(val)),
                 Ok(mut slot) => {
-                    slot.with_mut(|slot| *slot = val);
+                    *slot = val;
                     Ok(())
                 }
             }
         }
+
+        /// Attempts to reserve a slot in the channel to mutate in place,
+        /// without waiting for capacity.
+        ///
+        /// This method differs from [`send_ref`] by returning immediately if the
+        /// channel’s buffer is full or no [`Receiver`] exists. Compared with
+        /// [`send_ref`], this method has two failure cases instead of one (one for
+        /// disconnection, one for a full buffer), and this method is not
+        /// `async`, because it will never wait.
+        ///
+        /// Like [`send_ref`], this method returns a [`SendRef`] that may be
+        /// used to mutate a slot in the channel's buffer in place. Dropping the
+        /// [`SendRef`] completes the send operation and makes the mutated value
+        /// available to the [`Receiver`].
+        ///
+        /// # Errors
+        ///
+        /// If the channel capacity has been reached (i.e., the channel has `n`
+        /// buffered values where `n` is the `usize` const generic parameter of
+        /// the [`StaticChannel`]), then [`TrySendError::Full`] is returned. In
+        /// this case, a future call to `try_send` may succeed if additional
+        /// capacity becomes available.
+        ///
+        /// If the receive half of the channel is closed (i.e., the
+        /// [`StaticReceiver`] handle was dropped), the function returns
+        /// [`TrySendError::Closed`]. Once the channel has closed, subsequent
+        /// calls to `try_send_ref` will never succeed.
+        ///
+        /// [`send_ref`]: Self::send_ref
+        pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
+            self.core
+                .try_send_ref(self.slots, self.recycle)
+                .map(SendRef)
+        }
+
+        /// Attempts to send a message by value immediately, without waiting for
+        /// capacity.
+        ///
+        /// This method differs from [`send`] by returning immediately if the
+        /// channel’s buffer is full or no [`StaticReceiver`] exists. Compared with
+        /// [`send`], this method has two failure cases instead of one (one for
+        /// disconnection, one for a full buffer), and this method is not
+        /// `async`, because it will never wait.
+        ///
+        /// # Errors
+        ///
+        /// If the channel capacity has been reached (i.e., the channel has `n`
+        /// buffered values where `n` is the `usize` const generic parameter of
+        /// the [`StaticChannel`]), then [`TrySendError::Full`] is returned. In
+        /// this case, a future call to `try_send` may succeed if additional
+        /// capacity becomes available.
+        ///
+        /// If the receive half of the channel is closed (i.e., the
+        /// [`StaticReceiver`] handle was dropped), the function returns
+        /// [`TrySendError::Closed`]. Once the channel has closed, subsequent
+        /// calls to `try_send` will never succeed.
+        ///
+        /// In both cases, the error includes the value passed to `try_send`.
+        ///
+        /// [`send`]: Self::send
+        pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
+            self.core.try_send(self.slots, val, self.recycle)
+        }
     }
 
     impl<T> Clone for StaticSender<T> {
@@ -420,6 +909,72 @@ feature! {
     // === impl StaticReceiver ===
 
     impl<T, R> StaticReceiver<T, R> {
+        /// Receives the next message for this receiver, **by reference**.
+        ///
+        /// This method returns `None` if the channel has been closed and there are
+        /// no remaining messages in the channel's buffer. This indicates that no
+        /// further values can ever be received from this `StaticReceiver`. The
+        /// channel is closed when all [`StaticSender`]s have been dropped.
+        ///
+        /// If there are no messages in the channel's buffer, but the channel has
+        /// not yet been closed, this method will wait until a message is sent or
+        /// the channel is closed.
+        ///
+        /// This method returns a [`RecvRef`] that can be used to read from (or
+        /// mutate) the received message by reference. When the [`RecvRef`] is
+        /// dropped, the receive operation completes and the slot occupied by
+        /// the received message becomes usable for a future [`send_ref`] operation.
+        ///
+        /// If all [`StaticSender`]s for this channel write to the channel's slots in
+        /// place by using the [`send_ref`] or [`try_send_ref`] methods, this
+        /// method allows messages that own heap allocations to be reused in
+        /// place.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// # async fn docs() {
+        /// use thingbuf::mpsc::StaticChannel;
+        /// use std::fmt::Write;
+        ///
+        /// static CHANNEL: StaticChannel<String, 100> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// tokio::spawn(async move {
+        ///     let mut value = tx.send_ref().await.unwrap();
+        ///     write!(value, "hello world!")
+        ///         .expect("writing to a `String` should never fail");
+        /// });
+        ///
+        /// assert_eq!(Some("hello world!"), rx.recv_ref().await.as_deref().map(String::as_str));
+        /// assert_eq!(None, rx.recv().await.as_deref());
+        /// # }
+        /// ```
+        ///
+        /// Values are buffered:
+        ///
+        /// ```
+        /// # async fn docs() {
+        /// use thingbuf::mpsc::StaticChannel;
+        /// use std::fmt::Write;
+        ///
+        /// static CHANNEL: StaticChannel<String, 100> = StaticChannel::new();
+        ///
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// write!(tx.send_ref().await.unwrap(), "hello").unwrap();
+        /// write!(tx.send_ref().await.unwrap(), "world").unwrap();
+        ///
+        /// assert_eq!("hello", rx.recv_ref().await.unwrap().as_str());
+        /// assert_eq!("world", rx.recv_ref().await.unwrap().as_str());
+        /// # }
+        /// ```
+        ///
+        /// [`send_ref`]: StaticSender::send_ref
+        /// [`try_send_ref`]: StaticSender::try_send_ref
         pub fn recv_ref(&self) -> RecvRefFuture<'_, T> {
             RecvRefFuture {
                 core: self.core,
@@ -427,6 +982,66 @@ feature! {
             }
         }
 
+        /// Receives the next message for this receiver, **by value**.
+        ///
+        /// This method returns `None` if the channel has been closed and there are
+        /// no remaining messages in the channel's buffer. This indicates that no
+        /// further values can ever be received from this `StaticReceiver`. The
+        /// channel is closed when all [`StaticSender`]s have been dropped.
+        ///
+        /// If there are no messages in the channel's buffer, but the channel has
+        /// not yet been closed, this method will wait until a message is sent or
+        /// the channel is closed.
+        ///
+        /// When a message is received, it is moved out of the channel by value,
+        /// and replaced with a new slot according to the configured [recycling
+        /// policy]. If all [`StaticSender`]s for this channel write to the channel's
+        /// slots in place by using the [`send_ref`] or [`try_send_ref`] methods,
+        /// consider using the [`recv_ref`] method instead, to enable the
+        /// reuse of heap allocations.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// # mod tokio {
+        /// # pub fn spawn(_: impl std::future::Future) {}
+        /// # }
+        /// # async fn docs() {
+        /// use thingbuf::mpsc::StaticChannel;
+        ///
+        /// static CHANNEL: StaticChannel<i32, 100> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// tokio::spawn(async move {
+        ///    tx.send(1).await.unwrap();
+        /// });
+        ///
+        /// assert_eq!(Some(1), rx.recv().await);
+        /// assert_eq!(None, rx.recv().await);
+        /// # }
+        /// ```
+        ///
+        /// Values are buffered:
+        ///
+        /// ```
+        /// # async fn docs() {
+        /// use thingbuf::mpsc::StaticChannel;
+        ///
+        /// static CHANNEL: StaticChannel<i32, 100> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// tx.send(1).await.unwrap();
+        /// tx.send(2).await.unwrap();
+        ///
+        /// assert_eq!(Some(1), rx.recv().await);
+        /// assert_eq!(Some(2), rx.recv().await);
+        /// # }
+        /// ```
+        ///
+        /// [`send_ref`]: StaticSender::send_ref
+        /// [`try_send_ref`]: StaticSender::try_send_ref
+        /// [recycling policy]: crate::recycling::Recycle
+        /// [`recv_ref`]: Self::recv_ref
         pub fn recv(&self) -> RecvFuture<'_, T, R>
         where
             R: Recycle<T>,
@@ -438,36 +1053,82 @@ feature! {
             }
         }
 
+        /// Attempts to receive a message *by reference* from this channel,
+        /// registering the current task for wakeup if the a message is not yet
+        /// available, and returning `None` if the channel has closed and all
+        /// messages have been received.
+        ///
+        /// Like [`StaticReceiver::recv_ref`], this method returns a [`RecvRef`]
+        /// that can be used to read from (or mutate) the received message by
+        /// reference. When the [`RecvRef`] is dropped, the receive operation
+        /// completes and the slot occupied by the received message becomes
+        /// usable for a future [`send_ref`] operation.
+        ///
+        /// If all [`StaticSender`]s for this channel write to the channel's slots in
+        /// place by using the [`send_ref`] or [`try_send_ref`] methods, this
+        /// method allows messages that own heap allocations to be reused in
+        /// place.
+        ///
+        /// To wait asynchronously until a message becomes available, use the
+        /// [`recv_ref`] method instead.
+        ///
         /// # Returns
         ///
         ///  * `Poll::Pending` if no messages are available but the channel is not
         ///    closed, or if a spurious failure happens.
-        ///  * `Poll::Ready(Some(Ref<T>))` if a message is available.
-        ///  * `Poll::Ready(None)` if the channel has been closed and all messages
-        ///    sent before it was closed have been received.
+        ///  * `Poll::Ready(Some(RecvRef<T>))` if a message is available.
+        ///  * `Poll::Ready(None)` if the channel has been closed (i.e., all
+        ///    [`StaticSender`]s have been dropped), and all messages sent before it
+        ///    was closed have been received.
         ///
         /// When the method returns [`Poll::Pending`], the [`Waker`] in the provided
         /// [`Context`] is scheduled to receive a wakeup when a message is sent on any
         /// sender, or when the channel is closed.  Note that on multiple calls to
         /// `poll_recv_ref`, only the [`Waker`] from the [`Context`] passed to the most
         /// recent call is scheduled to receive a wakeup.
+        ///
+        /// [`send_ref`]: StaticSender::send_ref
+        /// [`try_send_ref`]: StaticSender::try_send_ref
+        /// [`recv_ref`]: Self::recv_ref
         pub fn poll_recv_ref(&self, cx: &mut Context<'_>) -> Poll<Option<RecvRef<'_, T>>> {
             poll_recv_ref(self.core, self.slots, cx)
         }
 
+        /// Attempts to receive a message *by value* from this channel,
+        /// registering the current task for wakeup if the value is not yet
+        /// available, and returning `None` if the channel has closed and all
+        /// messages have been received.
+        ///
+        /// When a message is received, it is moved out of the channel by value,
+        /// and replaced with a new slot according to the configured [recycling
+        /// policy]. If all [`StaticSender`]s for this channel write to the channel's
+        /// slots in place by using the [`send_ref`] or [`try_send_ref`] methods,
+        /// consider using the [`poll_recv_ref`] method instead, to enable the
+        /// reuse of heap allocations.
+        ///
+        /// To wait asynchronously until a message becomes available, use the
+        /// [`recv`] method instead.
+        ///
         /// # Returns
         ///
         ///  * `Poll::Pending` if no messages are available but the channel is not
         ///    closed, or if a spurious failure happens.
         ///  * `Poll::Ready(Some(message))` if a message is available.
-        ///  * `Poll::Ready(None)` if the channel has been closed and all messages
-        ///    sent before it was closed have been received.
+        ///  * `Poll::Ready(None)` if the channel has been closed (i.e., all
+        ///    [`StaticSender`]s have been dropped) and all messages sent before it
+        ///    was closed have been received.
         ///
         /// When the method returns [`Poll::Pending`], the [`Waker`] in the provided
         /// [`Context`] is scheduled to receive a wakeup when a message is sent on any
         /// sender, or when the channel is closed.  Note that on multiple calls to
         /// `poll_recv`, only the [`Waker`] from the [`Context`] passed to the most
         /// recent call is scheduled to receive a wakeup.
+        ///
+        /// [`send_ref`]: StaticSender::send_ref
+        /// [`try_send_ref`]: StaticSender::try_send_ref
+        /// [recycling policy]: crate::recycling::Recycle
+        /// [`poll_recv_ref`]: Self::poll_recv_ref
+        /// [`recv`]: Self::recv
         pub fn poll_recv(&self, cx: &mut Context<'_>) -> Poll<Option<T>>
         where
             R: Recycle<T>,
@@ -476,6 +1137,11 @@ feature! {
                 .map(|opt| opt.map(|mut r| recycling::take(&mut *r, self.recycle)))
         }
 
+        /// Returns `true` if the channel has closed (all corresponding
+        /// [`StaticSender`]s have been dropped).
+        ///
+        /// If this method returns `true`, no new messages will become available
+        /// on this channel. Previously sent messages may still be available.
         pub fn is_closed(&self) -> bool {
             test_dbg!(self.core.tx_count.load(Ordering::SeqCst)) <= 1
         }
@@ -499,10 +1165,38 @@ feature! {
 }
 
 impl_send_ref! {
+    /// A reference to a message being sent to an asynchronous channel.
+    ///
+    /// A `SendRef` represents the exclusive permission to mutate a given
+    /// element in a channel. A `SendRef<T>` [implements `DerefMut<T>`] to allow
+    /// writing to that element. This is analogous to the [`Ref`] type, except
+    /// that it completes a `send_ref` or `try_send_ref` operation when it is
+    /// dropped.
+    ///
+    /// This type is returned by the [`Sender::send_ref`] and
+    /// [`Sender::try_send_ref`] (or [`StaticSender::send_ref`] and
+    /// [`StaticSender::try_send_ref`]) methods.
+    ///
+    /// [implements `DerefMut<T>`]: #impl-DerefMut
+    /// [`Ref`]: crate::Ref
     pub struct SendRef<Waker>;
 }
 
 impl_recv_ref! {
+    /// A reference to a message being received from an asynchronous channel.
+    ///
+    /// A `RecvRef` represents the exclusive permission to mutate a given
+    /// element in a channel. A `RecvRef<T>` [implements `DerefMut<T>`] to allow
+    /// writing to that element. This is analogous to the [`Ref`] type, except
+    /// that it completes a `recv_ref` or `poll_recv_ref` operation when it is
+    /// dropped.
+    ///
+    /// This type is returned by the [`Receiver::recv_ref`] and
+    /// [`Receiver::poll_recv_ref`] (or [`StaticReceiver::recv_ref`] and
+    /// [`StaticReceiver::poll_recv_ref`]) methods.
+    ///
+    /// [implements `DerefMut<T>`]: #impl-DerefMut
+    /// [`Ref`]: crate::Ref
     pub struct RecvRef<Waker>;
 }
 

+ 585 - 29
src/mpsc/sync.rs

@@ -1,7 +1,7 @@
 //! A synchronous multi-producer, single-consumer channel.
 //!
 //! This provides an equivalent API to the [`mpsc`](crate::mpsc) module, but the
-//! [`Receiver`] type in this module waits by blocking the current thread,
+//! [`Receiver`] types in this module wait by blocking the current thread,
 //! rather than asynchronously yielding.
 use super::*;
 use crate::{
@@ -17,7 +17,12 @@ use crate::{
 };
 use core::{fmt, pin::Pin};
 
-/// Returns a new synchronous multi-producer, single consumer channel.
+/// Returns a new synchronous multi-producer, single consumer (MPSC)
+/// channel with  the provided capacity.
+///
+/// This channel will use the [default recycling policy].
+///
+/// [recycling policy]: crate::recycling::DefaultRecycle
 pub fn channel<T: Default + Clone>(capacity: usize) -> (Sender<T>, Receiver<T>) {
     with_recycle(capacity, recycling::DefaultRecycle::new())
 }
@@ -42,12 +47,19 @@ pub fn with_recycle<T, R: Recycle<T>>(
     let rx = Receiver { inner };
     (tx, rx)
 }
-
+/// Synchronously receives values from associated [`Sender`]s.
+///
+/// Instances of this struct are created by the [`channel`] and
+/// [`with_recycle`] functions.
 #[derive(Debug)]
 pub struct Sender<T, R = recycling::DefaultRecycle> {
     inner: Arc<Inner<T, R>>,
 }
 
+/// Synchronously sends values to an associated [`Receiver`].
+///
+/// Instances of this struct are created by the [`channel`] and
+/// [`with_recycle`] functions.
 #[derive(Debug)]
 pub struct Receiver<T, R = recycling::DefaultRecycle> {
     inner: Arc<Inner<T, R>>,
@@ -85,7 +97,7 @@ feature! {
     /// # Examples
     ///
     /// ```
-    /// use thingbuf::mpsc::StaticChannel;
+    /// use thingbuf::mpsc::sync::StaticChannel;
     ///
     /// // Construct a statically-allocated channel of `usize`s with a capacity
     /// // of 16 messages.
@@ -110,12 +122,20 @@ feature! {
         recycle: R,
     }
 
+    /// Synchronously sends values to an associated [`StaticReceiver`].
+    ///
+    /// Instances of this struct are created by the [`StaticChannel::split`] and
+    /// [``StaticChannel::try_split`] functions.
     pub struct StaticSender<T: 'static, R: 'static = recycling::DefaultRecycle> {
         core: &'static ChannelCore<Thread>,
         slots: &'static [Slot<T>],
         recycle: &'static R,
     }
 
+    /// Synchronously receives values from associated [`StaticSender`]s.
+    ///
+    /// Instances of this struct are created by the [`StaticChannel::split`] and
+    /// [``StaticChannel::try_split`] functions.
     pub struct StaticReceiver<T: 'static, R: 'static = recycling::DefaultRecycle> {
         core: &'static ChannelCore<Thread>,
         slots: &'static [Slot<T>],
@@ -219,29 +239,171 @@ feature! {
     where
         R: Recycle<T>,
     {
-        pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
-            self.core
-                .try_send_ref(self.slots, self.recycle)
-                .map(SendRef)
-        }
-
-        pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
-            self.core.try_send(self.slots, val, self.recycle)
-        }
-
+        /// Reserves a slot in the channel to mutate in place, blocking until
+        /// there is a free slot to write to.
+        ///
+        /// This is similar to the [`send`] method, but, rather than taking a
+        /// message by value to write to the channel, this method reserves a
+        /// writable slot in the channel, and returns a [`SendRef`] that allows
+        /// mutating the slot in place. If the [`StaticReceiver`] end of the
+        /// channel uses the [`StaticReceiver::recv_ref`] method for receiving
+        /// from the channel, this allows allocations for channel messages to be
+        /// reused in place.
+        ///
+        /// # Errors
+        ///
+        /// If the [`StaticReceiver`] end of the channel has been dropped, this
+        /// returns a [`Closed`] error.
+        ///
+        /// # Examples
+        ///
+        /// Sending formatted strings by writing them directly to channel slots,
+        /// in place:
+        /// ```
+        /// use thingbuf::mpsc::sync::StaticChannel;
+        /// use std::{fmt::Write, thread};
+        ///
+        /// static CHANNEL: StaticChannel<String, 8> = StaticChannel::new();
+        ///
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// // Spawn a thread that prints each message received from the channel:
+        /// thread::spawn(move || {
+        ///     for _ in 0..10 {
+        ///         let msg = rx.recv_ref().unwrap();
+        ///         println!("{}", msg);
+        ///     }
+        /// });
+        ///
+        /// // Until the channel closes, write formatted messages to the channel.
+        /// let mut count = 1;
+        /// while let Ok(mut value) = tx.send_ref() {
+        ///     // Writing to the `SendRef` will reuse the *existing* string
+        ///     // allocation in place.
+        ///     write!(value, "hello from message {}", count)
+        ///         .expect("writing to a `String` should never fail");
+        ///     count += 1;
+        /// }
+        /// ```
+        ///
+        /// [`send`]: Self::send
         pub fn send_ref(&self) -> Result<SendRef<'_, T>, Closed> {
             send_ref(self.core, self.slots, self.recycle)
         }
 
+        /// Sends a message by value, blocking until there is a free slot to
+        /// write to.
+        ///
+        /// This method takes the message by value, and replaces any previous
+        /// value in the slot. This means that the channel will *not* function
+        /// as an object pool while sending messages with `send`. This method is
+        /// most appropriate when messages don't own reusable heap allocations,
+        /// or when the [`StaticReceiver`] end of the channel must receive messages
+        /// by moving them out of the channel by value (using the
+        /// [`StaticReceiver::recv`] method). When messages in the channel own
+        /// reusable heap allocations (such as `String`s or `Vec`s), and the
+        /// [`StaticReceiver`] doesn't need to receive them by value, consider using
+        /// [`send_ref`] instead, to enable allocation reuse.
+        ///
+        /// # Errors
+        ///
+        /// If the [`StaticReceiver`] end of the channel has been dropped, this
+        /// returns a [`Closed`] error containing the sent value.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// use thingbuf::mpsc::sync::StaticChannel;
+        /// use std::{fmt::Write, thread};
+        ///
+        /// static CHANNEL: StaticChannel<i32, 8> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// // Spawn a thread that prints each message received from the channel:
+        /// thread::spawn(move || {
+        ///     for _ in 0..10 {
+        ///         let msg = rx.recv().unwrap();
+        ///         println!("received message {}", msg);
+        ///     }
+        /// });
+        ///
+        /// // Until the channel closes, write the current iteration to the channel.
+        /// let mut count = 1;
+        /// while tx.send(count).is_ok() {
+        ///     count += 1;
+        /// }
+        /// ```
+        /// [`send_ref`]: Self::send_ref
         pub fn send(&self, val: T) -> Result<(), Closed<T>> {
             match self.send_ref() {
                 Err(Closed(())) => Err(Closed(val)),
                 Ok(mut slot) => {
-                    slot.with_mut(|slot| *slot = val);
+                    *slot = val;
                     Ok(())
                 }
             }
         }
+
+        /// Attempts to reserve a slot in the channel to mutate in place,
+        /// without blocking until capacity is available.
+        ///
+        /// This method differs from [`send_ref`] by returning immediately if the
+        /// channel’s buffer is full or no [`StaticReceiver`] exists. Compared with
+        /// [`send_ref`], this method has two failure cases instead of one (one for
+        /// disconnection, one for a full buffer), and this method will never block.
+        ///
+        /// Like [`send_ref`], this method returns a [`SendRef`] that may be
+        /// used to mutate a slot in the channel's buffer in place. Dropping the
+        /// [`SendRef`] completes the send operation and makes the mutated value
+        /// available to the [`StaticReceiver`].
+        ///
+        /// # Errors
+        ///
+        /// If the channel capacity has been reached (i.e., the channel has `n`
+        /// buffered values where `n` is the `usize` const generic parameter of
+        /// the [`StaticChannel`]), then [`TrySendError::Full`] is returned. In
+        /// this case, a future call to `try_send` may succeed if additional
+        /// capacity becomes available.
+        ///
+        /// If the receive half of the channel is closed (i.e., the [`StaticReceiver`]
+        /// handle was dropped), the function returns [`TrySendError::Closed`].
+        /// Once the channel has closed, subsequent calls to `try_send_ref` will
+        /// never succeed.
+        ///
+        /// [`send_ref`]: Self::send_ref
+        pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
+            self.core
+                .try_send_ref(self.slots, self.recycle)
+                .map(SendRef)
+        }
+
+        /// Attempts to send a message by value immediately, without blocking until
+        /// capacity is available.
+        ///
+        /// This method differs from [`send`] by returning immediately if the
+        /// channel’s buffer is full or no [`StaticReceiver`] exists. Compared
+        /// with  [`send`], this method has two failure cases instead of one (one for
+        /// disconnection, one for a full buffer), and this method will never block.
+        ///
+        /// # Errors
+        ///
+        /// If the channel capacity has been reached (i.e., the channel has `n`
+        /// buffered values where `n` is the `usize` const generic parameter of
+        /// the [`StaticChannel`]), then [`TrySendError::Full`] is returned. In
+        /// this case, a future call to `try_send` may succeed if additional
+        /// capacity becomes available.
+        ///
+        /// If the receive half of the channel is closed (i.e., the
+        /// [`StaticReceiver`]  handle was dropped), the function returns
+        /// [`TrySendError::Closed`]. Once the channel has closed, subsequent
+        /// calls to `try_send` will  never succeed.
+        ///
+        /// In both cases, the error includes the value passed to `try_send`.
+        ///
+        /// [`send`]: Self::send
+        pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
+            self.core.try_send(self.slots, val, self.recycle)
+        }
     }
 
     impl<T, R> Clone for StaticSender<T, R> {
@@ -282,10 +444,122 @@ feature! {
     // === impl StaticReceiver ===
 
     impl<T, R> StaticReceiver<T, R> {
+        /// Receives the next message for this receiver, **by reference**.
+        ///
+        /// This method returns `None` if the channel has been closed and there are
+        /// no remaining messages in the channel's buffer. This indicates that no
+        /// further values can ever be received from this `StaticReceiver`. The channel is
+        /// closed when all [`StaticSender`]s have been dropped.
+        ///
+        /// If there are no messages in the channel's buffer, but the channel has
+        /// not yet been closed, this method will block until a message is sent or
+        /// the channel is closed.
+        ///
+        /// This method returns a [`RecvRef`] that can be used to read from (or
+        /// mutate) the received message by reference. When the [`RecvRef`] is
+        /// dropped, the receive operation completes and the slot occupied by
+        /// the received message becomes usable for a future [`send_ref`] operation.
+        ///
+        /// If all [`StaticSender`]s for this channel write to the channel's
+        /// slots in place by using the [`send_ref`] or [`try_send_ref`]
+        /// methods, this method allows messages that own heap allocations to be reused in
+        /// place.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// use thingbuf::mpsc::sync::StaticChannel;
+        /// use std::{thread, fmt::Write};
+        ///
+        /// static CHANNEL: StaticChannel<String, 100> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// thread::spawn(move || {
+        ///     let mut value = tx.send_ref().unwrap();
+        ///     write!(value, "hello world!")
+        ///         .expect("writing to a `String` should never fail");
+        /// });
+        ///
+        /// assert_eq!(Some("hello world!"), rx.recv_ref().as_deref().map(String::as_str));
+        /// assert_eq!(None, rx.recv().as_deref());
+        /// ```
+        ///
+        /// Values are buffered:
+        ///
+        /// ```
+        /// use thingbuf::mpsc::sync::StaticChannel;
+        /// use std::fmt::Write;
+        ///
+        /// static CHANNEL: StaticChannel<String, 100> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// write!(tx.send_ref().unwrap(), "hello").unwrap();
+        /// write!(tx.send_ref().unwrap(), "world").unwrap();
+        ///
+        /// assert_eq!("hello", rx.recv_ref().unwrap().as_str());
+        /// assert_eq!("world", rx.recv_ref().unwrap().as_str());
+        /// ```
+        ///
+        /// [`send_ref`]: StaticSender::send_ref
+        /// [`try_send_ref`]: StaticSender::try_send_ref
         pub fn recv_ref(&self) -> Option<RecvRef<'_, T>> {
             recv_ref(self.core, self.slots)
         }
 
+        /// Receives the next message for this receiver, **by value**.
+        ///
+        /// This method returns `None` if the channel has been closed and there are
+        /// no remaining messages in the channel's buffer. This indicates that no
+        /// further values can ever be received from this `StaticReceiver`. The channel is
+        /// closed when all [`StaticSender`]s have been dropped.
+        ///
+        /// If there are no messages in the channel's buffer, but the channel has
+        /// not yet been closed, this method will block until a message is sent or
+        /// the channel is closed.
+        ///
+        /// When a message is received, it is moved out of the channel by value,
+        /// and replaced with a new slot according to the configured [recycling
+        /// policy]. If all [`StaticSender`]s for this channel write to the channel's
+        /// slots in place by using the [`send_ref`] or [`try_send_ref`] methods,
+        /// consider using the [`recv_ref`] method instead, to enable the
+        /// reuse of heap allocations.
+        ///
+        /// # Examples
+        ///
+        /// ```
+        /// use thingbuf::mpsc::sync::StaticChannel;
+        /// use std::thread;
+        ///
+        /// static CHANNEL: StaticChannel<i32, 100> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// thread::spawn(move || {
+        ///    tx.send(1).unwrap();
+        /// });
+        ///
+        /// assert_eq!(Some(1), rx.recv());
+        /// assert_eq!(None, rx.recv());
+        /// ```
+        ///
+        /// Values are buffered:
+        ///
+        /// ```
+        /// use thingbuf::mpsc::sync::StaticChannel;
+        ///
+        /// static CHANNEL: StaticChannel<i32, 100> = StaticChannel::new();
+        /// let (tx, rx) = CHANNEL.split();
+        ///
+        /// tx.send(1).unwrap();
+        /// tx.send(2).unwrap();
+        ///
+        /// assert_eq!(Some(1), rx.recv());
+        /// assert_eq!(Some(2), rx.recv());
+        /// ```
+        ///
+        /// [`send_ref`]: StaticSender::send_ref
+        /// [`try_send_ref`]: StaticSender::try_send_ref
+        /// [recycling policy]: crate::recycling::Recycle
+        /// [`recv_ref`]: Self::recv_ref
         pub fn recv(&self) -> Option<T>
         where
             R: Recycle<T>,
@@ -294,6 +568,11 @@ feature! {
             Some(recycling::take(&mut *val, self.recycle))
         }
 
+        /// Returns `true` if the channel has closed (all corresponding
+        /// [`StaticSender`]s have been dropped).
+        ///
+        /// If this method returns `true`, no new messages will become available
+        /// on this channel. Previously sent messages may still be available.
         pub fn is_closed(&self) -> bool {
             test_dbg!(self.core.tx_count.load(Ordering::SeqCst)) <= 1
         }
@@ -325,10 +604,36 @@ feature! {
 }
 
 impl_send_ref! {
+    /// A reference to a message being sent to a blocking channel.
+    ///
+    /// A `SendRef` represents the exclusive permission to mutate a given
+    /// element in a channel. A `SendRef<T>` [implements `DerefMut<T>`] to allow
+    /// writing to that element. This is analogous to the [`Ref`] type, except
+    /// that it completes a `send_ref` or `try_send_ref` operation when it is
+    /// dropped.
+    ///
+    /// This type is returned by the [`Sender::send_ref`] and
+    /// [`Sender::try_send_ref`] (or [`StaticSender::send_ref`] and
+    /// [`StaticSender::try_send_ref`]) methods.
+    ///
+    /// [implements `DerefMut<T>`]: #impl-DerefMut
+    /// [`Ref`]: crate::Ref
     pub struct SendRef<Thread>;
 }
 
 impl_recv_ref! {
+    /// A reference to a message being received from a blocking channel.
+    ///
+    /// A `RecvRef` represents the exclusive permission to mutate a given
+    /// element in a channel. A `RecvRef<T>` [implements `DerefMut<T>`] to allow
+    /// writing to that element. This is analogous to the [`Ref`] type, except
+    /// that it completes a `recv_ref` operation when it is dropped.
+    ///
+    /// This type is returned by the [`Receiver::recv_ref`] and
+    /// [`StaticReceiver::recv_ref`] methods.
+    ///
+    /// [implements `DerefMut<T>`]: #impl-DerefMut
+    /// [`Ref`]: crate::Ref
     pub struct RecvRef<Thread>;
 }
 
@@ -338,19 +643,51 @@ impl<T, R> Sender<T, R>
 where
     R: Recycle<T>,
 {
-    pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
-        self.inner
-            .core
-            .try_send_ref(self.inner.slots.as_ref(), &self.inner.recycle)
-            .map(SendRef)
-    }
-
-    pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
-        self.inner
-            .core
-            .try_send(self.inner.slots.as_ref(), val, &self.inner.recycle)
-    }
-
+    /// Reserves a slot in the channel to mutate in place, blocking until
+    /// there is a free slot to write to.
+    ///
+    /// This is similar to the [`send`] method, but, rather than taking a
+    /// message by value to write to the channel, this method reserves a
+    /// writable slot in the channel, and returns a [`SendRef`] that allows
+    /// mutating the slot in place. If the [`Receiver`] end of the channel
+    /// uses the [`Receiver::recv_ref`] method for receiving from the channel,
+    /// this allows allocations for channel messages to be reused in place.
+    ///
+    /// # Errors
+    ///
+    /// If the [`Receiver`] end of the channel has been dropped, this
+    /// returns a [`Closed`] error.
+    ///
+    /// # Examples
+    ///
+    /// Sending formatted strings by writing them directly to channel slots,
+    /// in place:
+    /// ```
+    /// use thingbuf::mpsc::sync;
+    /// use std::{fmt::Write, thread};
+    ///
+    /// let (tx, rx) = sync::channel::<String>(8);
+    ///
+    /// // Spawn a thread that prints each message received from the channel:
+    /// thread::spawn(move || {
+    ///     for _ in 0..10 {
+    ///         let msg = rx.recv_ref().unwrap();
+    ///         println!("{}", msg);
+    ///     }
+    /// });
+    ///
+    /// // Until the channel closes, write formatted messages to the channel.
+    /// let mut count = 1;
+    /// while let Ok(mut value) = tx.send_ref() {
+    ///     // Writing to the `SendRef` will reuse the *existing* string
+    ///     // allocation in place.
+    ///     write!(value, "hello from message {}", count)
+    ///         .expect("writing to a `String` should never fail");
+    ///     count += 1;
+    /// }
+    /// ```
+    ///
+    /// [`send`]: Self::send
     pub fn send_ref(&self) -> Result<SendRef<'_, T>, Closed> {
         send_ref(
             &self.inner.core,
@@ -359,15 +696,121 @@ where
         )
     }
 
+    /// Sends a message by value, blocking until there is a free slot to
+    /// write to.
+    ///
+    /// This method takes the message by value, and replaces any previous
+    /// value in the slot. This means that the channel will *not* function
+    /// as an object pool while sending messages with `send`. This method is
+    /// most appropriate when messages don't own reusable heap allocations,
+    /// or when the [`Receiver`] end of the channel must receive messages by
+    /// moving them out of the channel by value (using the
+    /// [`Receiver::recv`] method). When messages in the channel own
+    /// reusable heap allocations (such as `String`s or `Vec`s), and the
+    /// [`Receiver`] doesn't need to receive them by value, consider using
+    /// [`send_ref`] instead, to enable allocation reuse.
+    ///
+    /// # Errors
+    ///
+    /// If the [`Receiver`] end of the channel has been dropped, this
+    /// returns a [`Closed`] error containing the sent value.
+    ///
+    /// # Examples
+    ///
+    /// ```
+    /// use thingbuf::mpsc::sync;
+    /// use std::thread;
+    ///
+    /// let (tx, rx) = sync::channel(8);
+    ///
+    /// // Spawn a thread that prints each message received from the channel:
+    /// thread::spawn(move || {
+    ///     for _ in 0..10 {
+    ///         let msg = rx.recv().unwrap();
+    ///         println!("received message {}", msg);
+    ///     }
+    /// });
+    ///
+    /// // Until the channel closes, write the current iteration to the channel.
+    /// let mut count = 1;
+    /// while tx.send(count).is_ok() {
+    ///     count += 1;
+    /// }
+    /// ```
+    /// [`send_ref`]: Self::send_ref
     pub fn send(&self, val: T) -> Result<(), Closed<T>> {
         match self.send_ref() {
             Err(Closed(())) => Err(Closed(val)),
             Ok(mut slot) => {
-                slot.with_mut(|slot| *slot = val);
+                *slot = val;
                 Ok(())
             }
         }
     }
+
+    /// Attempts to reserve a slot in the channel to mutate in place,
+    /// without blocking until capacity is available.
+    ///
+    /// This method differs from [`send_ref`] by returning immediately if the
+    /// channel’s buffer is full or no [`Receiver`] exists. Compared with
+    /// [`send_ref`], this method has two failure cases instead of one (one for
+    /// disconnection, one for a full buffer), and this method will never block.
+    ///
+    /// Like [`send_ref`], this method returns a [`SendRef`] that may be
+    /// used to mutate a slot in the channel's buffer in place. Dropping the
+    /// [`SendRef`] completes the send operation and makes the mutated value
+    /// available to the [`Receiver`].
+    ///
+    /// # Errors
+    ///
+    /// If the channel capacity has been reached (i.e., the channel has `n`
+    /// buffered values where `n` is the argument passed to
+    /// [`channel`]/[`with_recycle`]), then [`TrySendError::Full`] is
+    /// returned. In this case, a future call to `try_send` may succeed if
+    /// additional capacity becomes available.
+    ///
+    /// If the receive half of the channel is closed (i.e., the [`Receiver`]
+    /// handle was dropped), the function returns [`TrySendError::Closed`].
+    /// Once the channel has closed, subsequent calls to `try_send_ref` will
+    /// never succeed.
+    ///
+    /// [`send_ref`]: Self::send_ref
+    pub fn try_send_ref(&self) -> Result<SendRef<'_, T>, TrySendError> {
+        self.inner
+            .core
+            .try_send_ref(self.inner.slots.as_ref(), &self.inner.recycle)
+            .map(SendRef)
+    }
+
+    /// Attempts to send a message by value immediately, without blocking until
+    /// capacity is available.
+    ///
+    /// This method differs from [`send`] by returning immediately if the
+    /// channel’s buffer is full or no [`Receiver`] exists. Compared with
+    /// [`send`], this method has two failure cases instead of one (one for
+    /// disconnection, one for a full buffer), and this method will never block.
+    ///
+    /// # Errors
+    ///
+    /// If the channel capacity has been reached (i.e., the channel has `n`
+    /// buffered values where `n` is the argument passed to
+    /// [`channel`]/[`with_recycle`]), then [`TrySendError::Full`] is
+    /// returned. In this case, a future call to `try_send` may succeed if
+    /// additional capacity becomes available.
+    ///
+    /// If the receive half of the channel is closed (i.e., the [`Receiver`]
+    /// handle was dropped), the function returns [`TrySendError::Closed`].
+    /// Once the channel has closed, subsequent calls to `try_send` will
+    /// never succeed.
+    ///
+    /// In both cases, the error includes the value passed to `try_send`.
+    ///
+    /// [`send`]: Self::send
+    pub fn try_send(&self, val: T) -> Result<(), TrySendError<T>> {
+        self.inner
+            .core
+            .try_send(self.inner.slots.as_ref(), val, &self.inner.recycle)
+    }
 }
 
 impl<T, R> Clone for Sender<T, R> {
@@ -396,10 +839,118 @@ impl<T, R> Drop for Sender<T, R> {
 // === impl Receiver ===
 
 impl<T, R> Receiver<T, R> {
+    /// Receives the next message for this receiver, **by reference**.
+    ///
+    /// This method returns `None` if the channel has been closed and there are
+    /// no remaining messages in the channel's buffer. This indicates that no
+    /// further values can ever be received from this `Receiver`. The channel is
+    /// closed when all [`Sender`]s have been dropped.
+    ///
+    /// If there are no messages in the channel's buffer, but the channel has
+    /// not yet been closed, this method will block until a message is sent or
+    /// the channel is closed.
+    ///
+    /// This method returns a [`RecvRef`] that can be used to read from (or
+    /// mutate) the received message by reference. When the [`RecvRef`] is
+    /// dropped, the receive operation completes and the slot occupied by
+    /// the received message becomes usable for a future [`send_ref`] operation.
+    ///
+    /// If all [`Sender`]s for this channel write to the channel's slots in
+    /// place by using the [`send_ref`] or [`try_send_ref`] methods, this
+    /// method allows messages that own heap allocations to be reused in
+    /// place.
+    ///
+    /// # Examples
+    ///
+    /// ```
+    /// use thingbuf::mpsc::sync;
+    /// use std::{thread, fmt::Write};
+    ///
+    /// let (tx, rx) = sync::channel::<String>(100);
+    ///
+    /// thread::spawn(move || {
+    ///     let mut value = tx.send_ref().unwrap();
+    ///     write!(value, "hello world!")
+    ///         .expect("writing to a `String` should never fail");
+    /// });
+    ///
+    /// assert_eq!(Some("hello world!"), rx.recv_ref().as_deref().map(String::as_str));
+    /// assert_eq!(None, rx.recv().as_deref());
+    /// ```
+    ///
+    /// Values are buffered:
+    ///
+    /// ```
+    /// use thingbuf::mpsc::sync;
+    /// use std::fmt::Write;
+    ///
+    /// let (tx, rx) = sync::channel::<String>(100);
+    ///
+    /// write!(tx.send_ref().unwrap(), "hello").unwrap();
+    /// write!(tx.send_ref().unwrap(), "world").unwrap();
+    ///
+    /// assert_eq!("hello", rx.recv_ref().unwrap().as_str());
+    /// assert_eq!("world", rx.recv_ref().unwrap().as_str());
+    /// ```
+    ///
+    /// [`send_ref`]: Sender::send_ref
+    /// [`try_send_ref`]: Sender::try_send_ref
     pub fn recv_ref(&self) -> Option<RecvRef<'_, T>> {
         recv_ref(&self.inner.core, self.inner.slots.as_ref())
     }
 
+    /// Receives the next message for this receiver, **by value**.
+    ///
+    /// This method returns `None` if the channel has been closed and there are
+    /// no remaining messages in the channel's buffer. This indicates that no
+    /// further values can ever be received from this `Receiver`. The channel is
+    /// closed when all [`Sender`]s have been dropped.
+    ///
+    /// If there are no messages in the channel's buffer, but the channel has
+    /// not yet been closed, this method will block until a message is sent or
+    /// the channel is closed.
+    ///
+    /// When a message is received, it is moved out of the channel by value,
+    /// and replaced with a new slot according to the configured [recycling
+    /// policy]. If all [`Sender`]s for this channel write to the channel's
+    /// slots in place by using the [`send_ref`] or [`try_send_ref`] methods,
+    /// consider using the [`recv_ref`] method instead, to enable the
+    /// reuse of heap allocations.
+    ///
+    /// # Examples
+    ///
+    /// ```
+    /// use thingbuf::mpsc::sync;
+    /// use std::{thread, fmt::Write};
+    ///
+    /// let (tx, rx) = sync::channel(100);
+    ///
+    /// thread::spawn(move || {
+    ///    tx.send(1).unwrap();
+    /// });
+    ///
+    /// assert_eq!(Some(1), rx.recv());
+    /// assert_eq!(None, rx.recv());
+    /// ```
+    ///
+    /// Values are buffered:
+    ///
+    /// ```
+    /// use thingbuf::mpsc::sync;
+    ///
+    /// let (tx, rx) = sync::channel(100);
+    ///
+    /// tx.send(1).unwrap();
+    /// tx.send(2).unwrap();
+    ///
+    /// assert_eq!(Some(1), rx.recv());
+    /// assert_eq!(Some(2), rx.recv());
+    /// ```
+    ///
+    /// [`send_ref`]: Sender::send_ref
+    /// [`try_send_ref`]: Sender::try_send_ref
+    /// [recycling policy]: crate::recycling::Recycle
+    /// [`recv_ref`]: Self::recv_ref
     pub fn recv(&self) -> Option<T>
     where
         R: Recycle<T>,
@@ -408,6 +959,11 @@ impl<T, R> Receiver<T, R> {
         Some(recycling::take(&mut *val, &self.inner.recycle))
     }
 
+    /// Returns `true` if the channel has closed (all corresponding
+    /// [`Sender`]s have been dropped).
+    ///
+    /// If this method returns `true`, no new messages will become available
+    /// on this channel. Previously sent messages may still be available.
     pub fn is_closed(&self) -> bool {
         test_dbg!(self.inner.core.tx_count.load(Ordering::SeqCst)) <= 1
     }

+ 29 - 2
src/recycling.rs

@@ -1,12 +1,38 @@
 //! Configurable policies for element reuse.
 
+/// A policy defining how pooled elements of type `T` are reused.
+///
+/// A recycling policy provides two operations: [`Recycle::new_element`], which
+/// defines how new elements of type `T` are *initially* constructed, and
+/// [`Recycle::recycle`], which, given an `&mut T`, prepares that element for
+/// reuse.
+///
+/// This trait is intended to allow defining custom policies to reuse values
+/// that are expensive to create or destroy. If a type `T` owns a large memory
+/// allocation or other reuseable resource (such as a file descriptor, network
+/// connection, worker thread, et cetera), the [`recycle`](Self::recycle)
+/// operation can clear any *data* associated with a particular use of that
+/// value while retaining its memory allocation or other resources. For example,
+/// the [`WithCapacity`] recycling policy clears standard library collections
+/// such as `String` and `Vec` in place, retaining their allocated heap
+/// capacity, so that future uses of those collections do not need to
+/// reallocate.
 pub trait Recycle<T> {
     /// Returns a new instance of type `T`.
+    ///
+    /// This method will be called to populate the pool with the initial set of
+    /// elements. It may also be called if an element is permanently removed
+    /// from the pool and will not be returned.
     fn new_element(&self) -> T;
 
-    /// Resets `element` in place.
+    /// Prepares `element` element for reuse.
+    ///
+    /// Typically, this clears any data stored in `element` in place, but
+    /// retains any previous heap allocations owned by `element` so that they
+    /// can be used again.
     ///
-    /// Typically, this retains any previous allocations.
+    /// This method is called when a `T` value is returned to the pool that owns
+    /// it.
     fn recycle(&self, element: &mut T);
 }
 
@@ -175,6 +201,7 @@ where
 }
 
 impl DefaultRecycle {
+    /// Returns a new `DefaultRecycle`.
     pub const fn new() -> Self {
         Self(())
     }

+ 9 - 1
src/static_thingbuf.rs

@@ -202,13 +202,21 @@ pub struct StaticThingBuf<T, const CAP: usize, R = recycling::DefaultRecycle> {
 
 #[cfg(not(test))]
 impl<T, const CAP: usize> StaticThingBuf<T, CAP> {
-    /// Returns a new `StaticThingBuf` with space for `capacity` elements.
+    /// Returns a new `StaticThingBuf` with space for `CAP` elements.
+    ///
+    /// This queue will use the [default recycling policy].
+    ///
+    /// [recycling policy]: crate::recycling::DefaultRecycle
     pub const fn new() -> Self {
         Self::with_recycle(recycling::DefaultRecycle::new())
     }
 }
 
 impl<T, const CAP: usize, R> StaticThingBuf<T, CAP, R> {
+    /// Returns a new `StaticThingBuf` with space for `CAP` elements and
+    /// the provided [recycling policy].
+    ///
+    /// [recycling policy]: crate::recycling::Recycle
     pub const fn with_recycle(recycle: R) -> Self {
         StaticThingBuf {
             core: Core::new(CAP),

+ 4 - 0
src/thingbuf.rs

@@ -296,6 +296,10 @@ impl<T, R> ThingBuf<T, R>
 where
     R: Recycle<T>,
 {
+    /// Returns a new `ThingBuf` with space for `capacity` elements and
+    /// the provided [recycling policy].
+    ///
+    /// [recycling policy]: crate::recycling::Recycle
     pub fn with_recycle(capacity: usize, recycle: R) -> Self {
         assert!(capacity > 0);
         Self {

+ 5 - 7
tests/static_storage.rs

@@ -19,7 +19,7 @@ fn static_storage_thingbuf() {
                     _ => thread::yield_now(),
                 }
             };
-            thing.with_mut(|thing| *thing = i);
+            *thing = i;
         }
         PRODUCER_LIVE.store(false, Ordering::Release);
     });
@@ -30,10 +30,10 @@ fn static_storage_thingbuf() {
     // results string.
     while PRODUCER_LIVE.load(Ordering::Acquire) {
         match BUF.pop_ref() {
-            Some(thing) => thing.with(|thing| {
+            Some(thing) => {
                 assert_eq!(*thing, i);
                 i += 1;
-            }),
+            }
             None => thread::yield_now(),
         }
     }
@@ -42,10 +42,8 @@ fn static_storage_thingbuf() {
 
     // drain the queue.
     while let Some(thing) = BUF.pop_ref() {
-        thing.with(|thing| {
-            assert_eq!(*thing, i);
-            i += 1;
-        })
+        assert_eq!(*thing, i);
+        i += 1;
     }
 }