| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270 | .. currentmodule:: celery.. automodule:: celery    .. contents::        :local:    Application    -----------    .. class:: Celery(main=None, broker="amqp://guest:guest@localhost:5672//",                      loader="app", backend=None)        :param main: Name of the main module if running as `__main__`.        :keyword broker: URL of the default broker used.        :keyword loader: The loader class, or the name of the loader class to use.                         Default is :class:`celery.loaders.app.AppLoader`.        :keyword backend: The result store backend class, or the name of the                         backend class to use. Default is the value of the                        :setting:`CELERY_RESULT_BACKEND` setting.        :keyword amqp: AMQP object or class name.        :keyword events: Events object or class name.        :keyword log: Log object or class name.        :keyword control: Control object or class name.        :keyword set_as_current:  Make this the global current app.        :keyword tasks: A task registry or the name of a registry class.        .. attribute:: main            Name of the `__main__` module.  Required for standalone scripts.            If set this will be used instead of `__main__` when automatically            generating task names.        .. attribute:: conf            Current configuration.        .. attribute:: amqp            AMQP related functionality: :class:`~@amqp`.        .. attribute:: backend            Current backend instance.        .. attribute:: loader            Current loader instance.        .. attribute:: control            Remote control: :class:`~@control`.        .. attribute:: events            Consuming and sending events: :class:`~@events`.        .. attribute:: log            Logging: :class:`~@log`.        .. attribute:: tasks            Task registry.        .. attribute:: pool            Broker connection pool: :class:`~@pool`.        .. attribute:: Task            Base task class for this app.        .. method:: bugreport            Returns a string with information useful for the Celery core            developers when reporting a bug.        .. method:: config_from_object(obj, silent=False)            Reads configuration from object, where object is either            an object or the name of a module to import.            :keyword silent: If true then import errors will be ignored.            .. code-block:: python                >>> celery.config_from_object("myapp.celeryconfig")                >>> from myapp import celeryconfig                >>> celery.config_from_object(celeryconfig)        .. method:: config_from_envvar(variable_name, silent=False)            Read configuration from environment variable.            The value of the environment variable must be the name            of a module to import.            .. code-block:: python                >>> os.environ["CELERY_CONFIG_MODULE"] = "myapp.celeryconfig"                >>> celery.config_from_envvar("CELERY_CONFIG_MODULE")        .. method:: config_from_cmdline(argv, namespace="celery")            Parses argv for configuration strings.            Configuration strings must be located after a '--' sequence,            e.g.::                program arg1 arg2 -- celeryd.concurrency=10            :keyword namespace: Default namespace if omitted.        .. method:: start(argv=None)            Run :program:`celery` using `argv`.            Uses :data:`sys.argv` if `argv` is not specified.        .. method:: task(fun, **options)            Decorator to create a task class out of any callable.            **Examples:**            .. code-block:: python                @task                def refresh_feed(url):                    return ...            with setting extra options:            .. code-block:: python                @task(exchange="feeds")                def refresh_feed(url):                    return ...            .. admonition:: App Binding                For custom apps the task decorator returns proxy                objects, so that the act of creating the task is not performed                until the task is used or the task registry is accessed.                If you are depending on binding to be deferred, then you must                not access any attributes on the returned object until the                application is fully set up (finalized).        .. method:: send_task(name, args=(), kwargs={}, countdown=None,                eta=None, task_id=None, publisher=None, connection=None,                result_cls=AsyncResult, expires=None, queues=None, **options)            Send task by **name**.            :param name: Name of task to execute (e.g. `"tasks.add"`).            :keyword result_cls: Specify custom result class. Default is                using :meth:`AsyncResult`.            Otherwise supports the same arguments as :meth:`~@Task.apply_async`.        .. attribute:: AsyncResult            Create new result instance. See :class:`~celery.result.AsyncResult`.        .. attribute:: TaskSetResult            Create new taskset result instance.            See :class:`~celery.result.TaskSetResult`.        .. method:: worker_main(argv=None)            Run :program:`celeryd` using `argv`.            Uses :data:`sys.argv` if `argv` is not specified."""        .. attribute:: Worker            Worker application. See :class:`~@Worker`.        .. attribute:: WorkController            Embeddable worker. See :class:`~@WorkController`.        .. attribute:: Beat            Celerybeat scheduler application.            See :class:`~@Beat`.        .. method:: broker_connection(url="amqp://guest:guest@localhost:5672//",               ssl=False, transport_options={})            Establish a connection to the message broker.            :param url: Either the URL or the hostname of the broker to use.            :keyword hostname: defaults to the :setting:`BROKER_HOST` setting.            :keyword userid: defaults to the :setting:`BROKER_USER` setting.            :keyword password: defaults to the :setting:`BROKER_PASSWORD` setting.            :keyword virtual_host: defaults to the :setting:`BROKER_VHOST` setting.            :keyword port: defaults to the :setting:`BROKER_PORT` setting.            :keyword ssl: defaults to the :setting:`BROKER_USE_SSL` setting.            :keyword insist: defaults to the :setting:`BROKER_INSIST` setting.            :keyword backend_cls: defaults to the :setting:`BROKER_TRANSPORT`                setting.            :returns :class:`kombu.connection.BrokerConnection`:        """        .. method:: default_connection(connection=None)            For use within a with-statement to get a connection from the pool            if one is not already provided.            :keyword connection: If not provided, then a connection will be                                 acquired from the connection pool.        .. method:: mail_admins(subject, body, fail_silently=False)            Sends an email to the admins in the :setting:`ADMINS` setting.        .. method:: select_queues(queues=[])            Select a subset of queues, where queues must be a list of queue            names to keep.        .. method:: now()            Returns the current time and date as a :class:`~datetime.datetime`            object.        .. method:: set_current()            Makes this the current app for this thread.        .. method:: finalize()            Finalizes the app by loading built-in tasks,            and evaluating pending task decorators        .. attribute:: Pickler            Helper class used to pickle this application.    Grouping Tasks    --------------    .. autofunction:: group    .. autofunction:: chain    .. autofunction:: chord    .. autofunction:: subtask    Proxies    -------    .. data:: current_app        The currently set app for this thread.    .. data:: current_task        The task currently being executed        (only set in the worker, or when eager/apply is used).
 |