pub struct Celery {
pub name: String,
pub hostname: String,
pub broker: Box<dyn Broker>,
pub default_queue: String,
pub task_options: TaskOptions,
/* private fields */
}Expand description
Fields§
§name: StringAn arbitrary, human-readable name for the app.
hostname: StringNode name of the app.
broker: Box<dyn Broker>The app’s broker.
default_queue: StringThe default queue to send and receive from.
task_options: TaskOptionsDefault task options.
Implementations§
Source§impl Celery
impl Celery
Sourcepub async fn display_pretty(&self)
pub async fn display_pretty(&self)
Print a pretty ASCII art logo and configuration settings.
This is useful and fun to print from a worker application right after
the Celery app is initialized.
Sourcepub async fn send_task<T: Task>(
&self,
task_sig: Signature<T>,
) -> Result<AsyncResult, CeleryError>
pub async fn send_task<T: Task>( &self, task_sig: Signature<T>, ) -> Result<AsyncResult, CeleryError>
Send a task to a remote worker. Returns an AsyncResult with the task ID of the task
if it was successfully sent.
Sourcepub async fn register_task<T: Task + 'static>(&self) -> Result<(), CeleryError>
pub async fn register_task<T: Task + 'static>(&self) -> Result<(), CeleryError>
Register a task.
Sourcepub async fn close(&self) -> Result<(), CeleryError>
pub async fn close(&self) -> Result<(), CeleryError>
Close channels and connections.
Sourcepub async fn consume(self: &Arc<Self>) -> Result<(), CeleryError>
pub async fn consume(self: &Arc<Self>) -> Result<(), CeleryError>
Consume tasks from the default queue.
Sourcepub async fn consume_from(
self: &Arc<Self>,
queues: &[&str],
) -> Result<(), CeleryError>
pub async fn consume_from( self: &Arc<Self>, queues: &[&str], ) -> Result<(), CeleryError>
Consume tasks from any number of queues.
Auto Trait Implementations§
impl !Freeze for Celery
impl !RefUnwindSafe for Celery
impl Send for Celery
impl Sync for Celery
impl Unpin for Celery
impl !UnwindSafe for Celery
Blanket Implementations§
Source§impl<'a, T, E> AsTaggedExplicit<'a, E> for Twhere
T: 'a,
impl<'a, T, E> AsTaggedExplicit<'a, E> for Twhere
T: 'a,
Source§impl<'a, T, E> AsTaggedImplicit<'a, E> for Twhere
T: 'a,
impl<'a, T, E> AsTaggedImplicit<'a, E> for Twhere
T: 'a,
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
Mutably borrows from an owned value. Read more