pub struct JoinHandle<T> { /* private fields */ }Expand description
An owned permission to join on a task (await its termination).
This can be thought of as the equivalent of std::thread::JoinHandle
for a Tokio task rather than a thread. Note that the background task
associated with this JoinHandle started running immediately when you
called spawn, even if you have not yet awaited the JoinHandle.
A JoinHandle detaches the associated task when it is dropped, which
means that there is no longer any handle to the task, and no way to join
on it.
This struct is created by the task::spawn and task::spawn_blocking
functions.
§Cancel safety
The &mut JoinHandle<T> type is cancel safe. If it is used as the event
in a tokio::select! statement and some other branch completes first,
then it is guaranteed that the output of the task is not lost.
If a JoinHandle is dropped, then the task continues running in the
background and its return value is lost.
§Examples
Creation from task::spawn:
use tokio::task;
let join_handle: task::JoinHandle<_> = task::spawn(async {
    // some work here
});Creation from task::spawn_blocking:
use tokio::task;
let join_handle: task::JoinHandle<_> = task::spawn_blocking(|| {
    // some blocking work here
});The generic parameter T in JoinHandle<T> is the return type of the spawned task.
If the return value is an i32, the join handle has type JoinHandle<i32>:
use tokio::task;
let join_handle: task::JoinHandle<i32> = task::spawn(async {
    5 + 3
});
If the task does not have a return value, the join handle has type JoinHandle<()>:
use tokio::task;
let join_handle: task::JoinHandle<()> = task::spawn(async {
    println!("I return nothing.");
});Note that handle.await doesn’t give you the return type directly. It is wrapped in a
Result because panics in the spawned task are caught by Tokio. The ? operator has
to be double chained to extract the returned value:
use tokio::task;
use std::io;
#[tokio::main]
async fn main() -> io::Result<()> {
    let join_handle: task::JoinHandle<Result<i32, io::Error>> = tokio::spawn(async {
        Ok(5 + 3)
    });
    let result = join_handle.await??;
    assert_eq!(result, 8);
    Ok(())
}If the task panics, the error is a JoinError that contains the panic:
use tokio::task;
use std::io;
use std::panic;
#[tokio::main]
async fn main() -> io::Result<()> {
    let join_handle: task::JoinHandle<Result<i32, io::Error>> = tokio::spawn(async {
        panic!("boom");
    });
    let err = join_handle.await.unwrap_err();
    assert!(err.is_panic());
    Ok(())
}
Child being detached and outliving its parent:
use tokio::task;
use tokio::time;
use std::time::Duration;
let original_task = task::spawn(async {
    let _detached_task = task::spawn(async {
        // Here we sleep to make sure that the first task returns before.
        time::sleep(Duration::from_millis(10)).await;
        // This will be called, even though the JoinHandle is dropped.
        println!("♫ Still alive ♫");
    });
});
original_task.await.expect("The task being joined has panicked");
println!("Original task is joined.");
// We make sure that the new task has time to run, before the main
// task returns.
time::sleep(Duration::from_millis(1000)).await;Implementations§
Source§impl<T> JoinHandle<T>
 
impl<T> JoinHandle<T>
Sourcepub fn abort(&self)
 
pub fn abort(&self)
Abort the task associated with the handle.
Awaiting a cancelled task might complete as usual if the task was
already completed at the time it was cancelled, but most likely it
will fail with a cancelled JoinError.
Be aware that tasks spawned using spawn_blocking cannot be aborted
because they are not async. If you call abort on a spawn_blocking
task, then this will not have any effect, and the task will continue
running normally. The exception is if the task has not started running
yet; in that case, calling abort may prevent the task from starting.
See also the module level docs for more information on cancellation.
use tokio::time;
let mut handles = Vec::new();
handles.push(tokio::spawn(async {
   time::sleep(time::Duration::from_secs(10)).await;
   true
}));
handles.push(tokio::spawn(async {
   time::sleep(time::Duration::from_secs(10)).await;
   false
}));
for handle in &handles {
    handle.abort();
}
for handle in handles {
    assert!(handle.await.unwrap_err().is_cancelled());
}Sourcepub fn is_finished(&self) -> bool
 
pub fn is_finished(&self) -> bool
Checks if the task associated with this JoinHandle has finished.
Please note that this method can return false even if abort has been
called on the task. This is because the cancellation process may take
some time, and this method does not return true until it has
completed.
use tokio::time;
let handle1 = tokio::spawn(async {
    // do some stuff here
});
let handle2 = tokio::spawn(async {
    // do some other stuff here
    time::sleep(time::Duration::from_secs(10)).await;
});
// Wait for the task to finish
handle2.abort();
time::sleep(time::Duration::from_secs(1)).await;
assert!(handle1.is_finished());
assert!(handle2.is_finished());Sourcepub fn abort_handle(&self) -> AbortHandle
 
pub fn abort_handle(&self) -> AbortHandle
Returns a new AbortHandle that can be used to remotely abort this task.
Awaiting a task cancelled by the AbortHandle might complete as usual if the task was
already completed at the time it was cancelled, but most likely it
will fail with a cancelled JoinError.
use tokio::{time, task};
let mut handles = Vec::new();
handles.push(tokio::spawn(async {
   time::sleep(time::Duration::from_secs(10)).await;
   true
}));
handles.push(tokio::spawn(async {
   time::sleep(time::Duration::from_secs(10)).await;
   false
}));
let abort_handles: Vec<task::AbortHandle> = handles.iter().map(|h| h.abort_handle()).collect();
for handle in abort_handles {
    handle.abort();
}
for handle in handles {
    assert!(handle.await.unwrap_err().is_cancelled());
}Trait Implementations§
Source§impl<T> Debug for JoinHandle<T>where
    T: Debug,
 
impl<T> Debug for JoinHandle<T>where
    T: Debug,
Source§impl<T> Drop for JoinHandle<T>
 
impl<T> Drop for JoinHandle<T>
Source§impl<T> Future for JoinHandle<T>
 
impl<T> Future for JoinHandle<T>
impl<T> RefUnwindSafe for JoinHandle<T>
impl<T> Send for JoinHandle<T>where
    T: Send,
impl<T> Sync for JoinHandle<T>where
    T: Send,
impl<T> Unpin for JoinHandle<T>
impl<T> UnwindSafe for JoinHandle<T>
Auto Trait Implementations§
impl<T> Freeze for JoinHandle<T>
Blanket Implementations§
Source§impl<T> BorrowMut<T> for Twhere
    T: ?Sized,
 
impl<T> BorrowMut<T> for Twhere
    T: ?Sized,
Source§fn borrow_mut(&mut self) -> &mut T
 
fn borrow_mut(&mut self) -> &mut T
Source§impl<T> FutureExt for T
 
impl<T> FutureExt for T
Source§fn with_cancellation_token(
    self,
    cancellation_token: &CancellationToken,
) -> WithCancellationTokenFuture<'_, Self>where
    Self: Sized,
 
fn with_cancellation_token(
    self,
    cancellation_token: &CancellationToken,
) -> WithCancellationTokenFuture<'_, Self>where
    Self: Sized,
CancellationToken::run_until_cancelled,
but with the advantage that it is easier to write fluent call chains,
and biased towards waiting for CancellationToken to complete. Read moreSource§fn with_cancellation_token_owned(
    self,
    cancellation_token: CancellationToken,
) -> WithCancellationTokenFutureOwned<Self>where
    Self: Sized,
 
fn with_cancellation_token_owned(
    self,
    cancellation_token: CancellationToken,
) -> WithCancellationTokenFutureOwned<Self>where
    Self: Sized,
CancellationToken::run_until_cancelled_owned,
but with the advantage that it is easier to write fluent call chains,
and biased towards waiting for CancellationToken to complete. Read moreSource§impl<T> FutureExt for T
 
impl<T> FutureExt for T
Source§fn map<U, F>(self, f: F) -> Map<Self, F>
 
fn map<U, F>(self, f: F) -> Map<Self, F>
Source§fn map_into<U>(self) -> MapInto<Self, U>
 
fn map_into<U>(self) -> MapInto<Self, U>
Source§fn then<Fut, F>(self, f: F) -> Then<Self, Fut, F>
 
fn then<Fut, F>(self, f: F) -> Then<Self, Fut, F>
f. Read moreSource§fn left_future<B>(self) -> Either<Self, B>
 
fn left_future<B>(self) -> Either<Self, B>
Source§fn right_future<A>(self) -> Either<A, Self>
 
fn right_future<A>(self) -> Either<A, Self>
Source§fn into_stream(self) -> IntoStream<Self>where
    Self: Sized,
 
fn into_stream(self) -> IntoStream<Self>where
    Self: Sized,
Source§fn flatten(self) -> Flatten<Self>
 
fn flatten(self) -> Flatten<Self>
Source§fn flatten_stream(self) -> FlattenStream<Self>
 
fn flatten_stream(self) -> FlattenStream<Self>
Source§fn fuse(self) -> Fuse<Self>where
    Self: Sized,
 
fn fuse(self) -> Fuse<Self>where
    Self: Sized,
poll will never again be called once it has
completed. This method can be used to turn any Future into a
FusedFuture. Read moreSource§fn inspect<F>(self, f: F) -> Inspect<Self, F>
 
fn inspect<F>(self, f: F) -> Inspect<Self, F>
Source§fn catch_unwind(self) -> CatchUnwind<Self>where
    Self: Sized + UnwindSafe,
 
fn catch_unwind(self) -> CatchUnwind<Self>where
    Self: Sized + UnwindSafe,
Source§fn remote_handle(self) -> (Remote<Self>, RemoteHandle<Self::Output>)where
    Self: Sized,
 
fn remote_handle(self) -> (Remote<Self>, RemoteHandle<Self::Output>)where
    Self: Sized,
() on completion and sends
its output to another future on a separate task. Read moreSource§fn boxed<'a>(self) -> Pin<Box<dyn Future<Output = Self::Output> + Send + 'a>>
 
fn boxed<'a>(self) -> Pin<Box<dyn Future<Output = Self::Output> + Send + 'a>>
Source§fn boxed_local<'a>(self) -> Pin<Box<dyn Future<Output = Self::Output> + 'a>>where
    Self: Sized + 'a,
 
fn boxed_local<'a>(self) -> Pin<Box<dyn Future<Output = Self::Output> + 'a>>where
    Self: Sized + 'a,
Source§fn unit_error(self) -> UnitError<Self>where
    Self: Sized,
 
fn unit_error(self) -> UnitError<Self>where
    Self: Sized,
Future<Output = T> into a
TryFuture<Ok = T, Error = ()>.Source§fn never_error(self) -> NeverError<Self>where
    Self: Sized,
 
fn never_error(self) -> NeverError<Self>where
    Self: Sized,
Future<Output = T> into a
TryFuture<Ok = T, Error = Never>.