API Reference

aio_pika.AMQPException

alias of aiormq.exceptions.AMQPError

class aio_pika.Channel(connection: aio_pika.abc.AbstractConnection, channel_number: Optional[int] = None, publisher_confirms: bool = True, on_return_raises: bool = False)[source]

Channel abstraction

Parameters:
  • connectionaio_pika.adapter.AsyncioConnection instance
  • loop – Event loop (asyncio.get_event_loop() when None)
  • future_storeaio_pika.common.FutureStore instance
  • publisher_confirms – False if you don’t need delivery confirmations (in pursuit of performance)
EXCHANGE_CLASS

alias of aio_pika.exchange.Exchange

QUEUE_CLASS

alias of aio_pika.queue.Queue

declare_exchange(name: str, type: Union[aio_pika.abc.ExchangeType, str] = <ExchangeType.DIRECT: 'direct'>, *, durable: bool = False, auto_delete: bool = False, internal: bool = False, passive: bool = False, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → aio_pika.abc.AbstractExchange[source]

Declare an exchange.

Parameters:
  • name – string with exchange name or aio_pika.exchange.Exchange instance
  • type – Exchange type. Enum ExchangeType value or string. String values must be one of ‘fanout’, ‘direct’, ‘topic’, ‘headers’, ‘x-delayed-message’, ‘x-consistent-hash’.
  • durable – Durability (exchange survive broker restart)
  • auto_delete – Delete queue when channel will be closed.
  • internal – Do not send it to broker just create an object
  • passive – Do not fail when entity was declared previously but has another params. Raises aio_pika.exceptions.ChannelClosed when exchange doesn’t exist.
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

aio_pika.exchange.Exchange instance

declare_queue(name: str = None, *, durable: bool = False, exclusive: bool = False, passive: bool = False, auto_delete: bool = False, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → aio_pika.abc.AbstractQueue[source]
Parameters:
  • name – queue name
  • durable – Durability (queue survive broker restart)
  • exclusive – Makes this queue exclusive. Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes. Passive declaration of an exclusive queue by other connections are not allowed.
  • passive – Do not fail when entity was declared previously but has another params. Raises aio_pika.exceptions.ChannelClosed when queue doesn’t exist.
  • auto_delete – Delete queue when channel will be closed.
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

aio_pika.queue.Queue instance

Raises:

aio_pika.exceptions.ChannelClosed instance

get_exchange(name: str, *, ensure: bool = True) → aio_pika.abc.AbstractExchange[source]

With ensure=True, it’s a shortcut for .declare_exchange(..., passive=True); otherwise, it returns an exchange instance without checking its existence.

When the exchange does not exist, if ensure=True, will raise aio_pika.exceptions.ChannelClosed.

Use this method in a separate channel (or as soon as channel created). This is only a way to get an exchange without declaring a new one.

Parameters:
  • name – exchange name
  • ensure – ensure that the exchange exists
Returns:

aio_pika.exchange.Exchange instance

Raises:

aio_pika.exceptions.ChannelClosed instance

get_queue(name: str, *, ensure: bool = True) → aio_pika.abc.AbstractQueue[source]

With ensure=True, it’s a shortcut for .declare_queue(..., passive=True); otherwise, it returns a queue instance without checking its existence.

When the queue does not exist, if ensure=True, will raise aio_pika.exceptions.ChannelClosed.

Use this method in a separate channel (or as soon as channel created). This is only a way to get a queue without declaring a new one.

Parameters:
  • name – queue name
  • ensure – ensure that the queue exists
Returns:

aio_pika.queue.Queue instance

Raises:

aio_pika.exceptions.ChannelClosed instance

is_closed

Returns True when the channel has been closed from the broker side or after the close() method has been called.

is_initialized

Returns True when the channel has been opened and ready for interaction

class aio_pika.Connection(url: yarl.URL, loop: Optional[asyncio.events.AbstractEventLoop] = None, **kwargs)[source]

Connection abstraction

CHANNEL_CLASS

alias of aio_pika.channel.Channel

channel(channel_number: int = None, publisher_confirms: bool = True, on_return_raises: bool = False) → aio_pika.abc.AbstractChannel[source]

Coroutine which returns new instance of Channel.

Example:

import aio_pika

async def main(loop):
    connection = await aio_pika.connect(
        "amqp://guest:guest@127.0.0.1/"
    )

    channel1 = connection.channel()
    await channel1.close()

    # Creates channel with specific channel number
    channel42 = connection.channel(42)
    await channel42.close()

    # For working with transactions
    channel_no_confirms = connection.channel(
        publisher_confirms=True
    )
    await channel_no_confirms.close()

Also available as an asynchronous context manager:

import aio_pika

async def main(loop):
    connection = await aio_pika.connect(
        "amqp://guest:guest@127.0.0.1/"
    )

    async with connection.channel() as channel:
        # channel is open and available

    # channel is now closed
Parameters:
  • channel_number – specify the channel number explicit
  • publisher_confirms – if True the aio_pika.Exchange.publish() method will be return bool after publish is complete. Otherwise the aio_pika.Exchange.publish() method will be return None
  • on_return_raises – raise an aio_pika.exceptions.DeliveryError when mandatory message will be returned
connect(timeout: Union[float, int, None] = None, **kwargs) → None[source]

Connect to AMQP server. This method should be called after aio_pika.connection.Connection.__init__()

Note

This method is called by connect(). You shouldn’t call it explicitly.

class aio_pika.DeliveryMode[source]

An enumeration.

class aio_pika.Exchange(connection: aio_pika.abc.AbstractConnection, channel: aio_pika.abc.AbstractChannel, name: str, type: Union[aio_pika.abc.ExchangeType, str] = <ExchangeType.DIRECT: 'direct'>, *, auto_delete: bool = False, durable: bool = False, internal: bool = False, passive: bool = False, arguments: Optional[Dict[str, FieldValue]] = None)[source]

Exchange abstraction

bind(exchange: Union[AbstractExchange, str], routing_key: str = '', *, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → pamqp.commands.Exchange.BindOk[source]

A binding can also be a relationship between two exchanges. This can be simply read as: this exchange is interested in messages from another exchange.

Bindings can take an extra routing_key parameter. To avoid the confusion with a basic_publish parameter we’re going to call it a binding key.

client = await connect()

routing_key = 'simple_routing_key'
src_exchange_name = "source_exchange"
dest_exchange_name = "destination_exchange"

channel = await client.channel()
src_exchange = await channel.declare_exchange(
    src_exchange_name, auto_delete=True
)
dest_exchange = await channel.declare_exchange(
    dest_exchange_name, auto_delete=True
)
queue = await channel.declare_queue(auto_delete=True)

await queue.bind(dest_exchange, routing_key)
await dest_exchange.bind(src_exchange, routing_key)
Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

None

delete(if_unused: bool = False, timeout: Union[float, int, None] = None) → pamqp.commands.Exchange.DeleteOk[source]

Delete the queue

Parameters:
  • timeout – operation timeout
  • if_unused – perform deletion when queue has no bindings.
publish(message: aio_pika.abc.AbstractMessage, routing_key: str, *, mandatory: bool = True, immediate: bool = False, timeout: Union[float, int, None] = None) → Union[pamqp.commands.Basic.Ack, pamqp.commands.Basic.Nack, pamqp.commands.Basic.Reject, None][source]

Publish the message to the queue. aio-pika uses publisher confirms extension for message delivery.

unbind(exchange: Union[AbstractExchange, str], routing_key: str = '', arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → pamqp.commands.Exchange.UnbindOk[source]

Remove exchange-to-exchange binding for this Exchange instance

Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

None

class aio_pika.ExchangeType[source]

An enumeration.

class aio_pika.IncomingMessage(message: aiormq.abc.DeliveredMessage, no_ack: bool = False)[source]

Incoming message is seems like Message but has additional methods for message acknowledgement.

Depending on the acknowledgement mode used, RabbitMQ can consider a message to be successfully delivered either immediately after it is sent out (written to a TCP socket) or when an explicit (“manual”) client acknowledgement is received. Manually sent acknowledgements can be positive or negative and use one of the following protocol methods:

  • basic.ack is used for positive acknowledgements
  • basic.nack is used for negative acknowledgements (note: this is a RabbitMQ extension to AMQP 0-9-1)
  • basic.reject is used for negative acknowledgements but has one limitations compared to basic.nack

Positive acknowledgements simply instruct RabbitMQ to record a message as delivered. Negative acknowledgements with basic.reject have the same effect. The difference is primarily in the semantics: positive acknowledgements assume a message was successfully processed while their negative counterpart suggests that a delivery wasn’t processed but still should be deleted.

Create an instance of IncomingMessage

ack(multiple: bool = False) → None[source]

Send basic.ack is used for positive acknowledgements

Note

This method looks like a blocking-method, but actually it just sends bytes to the socket and doesn’t require any responses from the broker.

Parameters:multiple – If set to True, the message’s delivery tag is treated as “up to and including”, so that multiple messages can be acknowledged with a single method. If set to False, the ack refers to a single message.
Returns:None
info() → dict[source]

Method returns dict representation of the message

process(requeue: bool = False, reject_on_redelivered: bool = False, ignore_processed: bool = False) → aio_pika.abc.AbstractProcessContext[source]

Context manager for processing the message

>>> async def on_message_received(message: IncomingMessage):
...    async with message.process():
...        # When exception will be raised
...        # the message will be rejected
...        print(message.body)

Example with ignore_processed=True

>>> async def on_message_received(message: IncomingMessage):
...    async with message.process(ignore_processed=True):
...        # Now (with ignore_processed=True) you may reject
...        # (or ack) message manually too
...        if True:  # some reasonable condition here
...            await message.reject()
...        print(message.body)
Parameters:
  • requeue – Requeue message when exception.
  • reject_on_redelivered – When True message will be rejected only when message was redelivered.
  • ignore_processed – Do nothing if message already processed
reject(requeue: bool = False) → None[source]

When requeue=True the message will be returned to queue. Otherwise message will be dropped.

Note

This method looks like a blocking-method, but actually it just sends bytes to the socket and doesn’t require any responses from the broker.

Parameters:requeue – bool
class aio_pika.Message(body: bytes, *, headers: MutableMapping[str, Union[bool, bytearray, decimal.Decimal, List[FieldValue], Dict[str, FieldValue], float, int, None, str, datetime.datetime, bytes, Set[Union[bool, bytearray, decimal.Decimal, List[FieldValue], Dict[str, FieldValue], float, int, None, str, datetime.datetime, bytes]], Tuple[Union[bool, bytearray, decimal.Decimal, List[FieldValue], Dict[str, FieldValue], float, int, None, str, datetime.datetime, bytes], ...], FrozenSet[Union[bool, bytearray, decimal.Decimal, List[FieldValue], Dict[str, FieldValue], float, int, None, str, datetime.datetime, bytes]]]] = None, content_type: Optional[str] = None, content_encoding: Optional[str] = None, delivery_mode: Union[aio_pika.abc.DeliveryMode, int] = None, priority: Optional[int] = None, correlation_id: Optional[str] = None, reply_to: Optional[str] = None, expiration: Union[int, datetime.datetime, float, datetime.timedelta, None] = None, message_id: Optional[str] = None, timestamp: Union[int, datetime.datetime, float, datetime.timedelta, None] = None, type: Optional[str] = None, user_id: Optional[str] = None, app_id: Optional[str] = None)[source]

AMQP message abstraction

Creates a new instance of Message

Parameters:
  • body – message body
  • headers – message headers
  • headers_raw – message raw headers
  • content_type – content type
  • content_encoding – content encoding
  • delivery_mode – delivery mode
  • priority – priority
  • correlation_id – correlation id
  • reply_to – reply to
  • expiration – expiration in seconds (or datetime or timedelta)
  • message_id – message id
  • timestamp – timestamp
  • type – type
  • user_id – user id
  • app_id – app id
info() → dict[source]

Create a dict with message attributes

{
    "body_size": 100,
    "headers": {},
    "content_type": "text/plain",
    "content_encoding": "",
    "delivery_mode": DeliveryMode.NOT_PERSISTENT,
    "priority": 0,
    "correlation_id": "",
    "reply_to": "",
    "expiration": "",
    "message_id": "",
    "timestamp": "",
    "type": "",
    "user_id": "",
    "app_id": "",
}
lock() → None[source]

Set lock flag to True

locked

is message locked

Returns:bool
properties

Build aiormq.spec.Basic.Properties object

exception aio_pika.MessageProcessError[source]
class aio_pika.Queue(channel: aio_pika.abc.AbstractChannel, name: Optional[str], durable: bool, exclusive: bool, auto_delete: bool, arguments: Optional[Dict[str, FieldValue]], passive: bool = False)[source]

AMQP queue abstraction

bind(exchange: Union[AbstractExchange, str], routing_key: str = None, *, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → pamqp.commands.Queue.BindOk[source]

A binding is a relationship between an exchange and a queue. This can be simply read as: the queue is interested in messages from this exchange.

Bindings can take an extra routing_key parameter. To avoid the confusion with a basic_publish parameter we’re going to call it a binding key.

Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Raises:

asyncio.TimeoutError – when the binding timeout period has elapsed.

Returns:

None

cancel(consumer_tag: str, timeout: Union[float, int, None] = None, nowait: bool = False) → pamqp.commands.Basic.CancelOk[source]

This method cancels a consumer. This does not affect already delivered messages, but it does mean the server will not send any more messages for that consumer. The client may receive an arbitrary number of messages in between sending the cancel method and receiving the cancel-ok reply. It may also be sent from the server to the client in the event of the consumer being unexpectedly cancelled (i.e. cancelled for any reason other than the server receiving the corresponding basic.cancel from the client). This allows clients to be notified of the loss of consumers due to events such as queue deletion.

Parameters:
  • consumer_tag – consumer tag returned by consume()
  • timeout – execution timeout
  • nowait (bool) – Do not expect a Basic.CancelOk response
Returns:

Basic.CancelOk when operation completed successfully

consume(callback: Callable[[aio_pika.abc.AbstractIncomingMessage], Any], no_ack: bool = False, exclusive: bool = False, arguments: Optional[Dict[str, FieldValue]] = None, consumer_tag: str = None, timeout: Union[float, int, None] = None) → str[source]

Start to consuming the Queue.

Parameters:
  • timeoutasyncio.TimeoutError will be raises when the Future was not finished after this time.
  • callback – Consuming callback. Could be a coroutine.
  • no_ack – if True you don’t need to call aio_pika.message.IncomingMessage.ack()
  • exclusive – Makes this queue exclusive. Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes. Passive declaration of an exclusive queue by other connections are not allowed.
  • arguments – additional arguments
  • consumer_tag – optional consumer tag
Raises:

asyncio.TimeoutError – when the consuming timeout period has elapsed.

Return str:

consumer tag str

declare(timeout: Union[float, int, None] = None) → pamqp.commands.Queue.DeclareOk[source]

Declare queue.

Parameters:
  • timeout – execution timeout
  • passive – Only check to see if the queue exists.
Returns:

None

delete(*, if_unused: bool = True, if_empty: bool = True, timeout: Union[float, int, None] = None) → pamqp.commands.Queue.DeleteOk[source]

Delete the queue.

Parameters:
  • if_unused – Perform delete only when unused
  • if_empty – Perform delete only when empty
  • timeout – execution timeout
Returns:

None

get(*, no_ack: bool = False, fail: bool = True, timeout: Union[float, int, None] = 5) → Optional[aio_pika.message.IncomingMessage][source]

Get message from the queue.

Parameters:
  • no_ack – if True you don’t need to call aio_pika.message.IncomingMessage.ack()
  • timeout – execution timeout
  • fail – Should return None instead of raise an exception aio_pika.exceptions.QueueEmpty.
Returns:

aio_pika.message.IncomingMessage

iterator(**kwargs) → aio_pika.abc.AbstractQueueIterator[source]

Returns an iterator for async for expression.

Full example:

import aio_pika

async def main():
    connection = await aio_pika.connect()

    async with connection:
        channel = await connection.channel()

        queue = await channel.declare_queue('test')

        async with queue.iterator() as q:
            async for message in q:
                print(message.body)

When your program runs with run_forever the iterator will be closed in background. In this case the context processor for iterator might be skipped and the queue might be used in the “async for” expression directly.

import aio_pika

async def main():
    connection = await aio_pika.connect()

    async with connection:
        channel = await connection.channel()

        queue = await channel.declare_queue('test')

        async for message in queue:
            print(message.body)
Returns:QueueIterator
purge(no_wait: bool = False, timeout: Union[float, int, None] = None) → pamqp.commands.Queue.PurgeOk[source]

Purge all messages from the queue.

Parameters:
  • no_wait – no wait response
  • timeout – execution timeout
Returns:

None

unbind(exchange: Union[AbstractExchange, str], routing_key: str = None, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → pamqp.commands.Queue.UnbindOk[source]

Remove binding from exchange for this Queue instance

Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Raises:

asyncio.TimeoutError – when the unbinding timeout period has elapsed.

Returns:

None

class aio_pika.RobustChannel(connection: aio_pika.abc.AbstractRobustConnection, channel_number: int = None, publisher_confirms: bool = True, on_return_raises: bool = False)[source]

Channel abstraction

Parameters:
  • connectionaio_pika.adapter.AsyncioConnection instance
  • loop – Event loop (asyncio.get_event_loop() when None)
  • future_storeaio_pika.common.FutureStore instance
  • publisher_confirms – False if you don’t need delivery confirmations (in pursuit of performance)
EXCHANGE_CLASS

alias of aio_pika.robust_exchange.RobustExchange

QUEUE_CLASS

alias of aio_pika.robust_queue.RobustQueue

declare_exchange(name: str, type: Union[aio_pika.abc.ExchangeType, str] = <ExchangeType.DIRECT: 'direct'>, durable: bool = False, auto_delete: bool = False, internal: bool = False, passive: bool = False, arguments: dict = None, timeout: Union[float, int, None] = None, robust: bool = True) → aio_pika.abc.AbstractRobustExchange[source]

Declare an exchange.

Parameters:
  • name – string with exchange name or aio_pika.exchange.Exchange instance
  • type – Exchange type. Enum ExchangeType value or string. String values must be one of ‘fanout’, ‘direct’, ‘topic’, ‘headers’, ‘x-delayed-message’, ‘x-consistent-hash’.
  • durable – Durability (exchange survive broker restart)
  • auto_delete – Delete queue when channel will be closed.
  • internal – Do not send it to broker just create an object
  • passive – Do not fail when entity was declared previously but has another params. Raises aio_pika.exceptions.ChannelClosed when exchange doesn’t exist.
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

aio_pika.exchange.Exchange instance

declare_queue(name: str = None, *, durable: bool = False, exclusive: bool = False, passive: bool = False, auto_delete: bool = False, arguments: dict = None, timeout: Union[float, int, None] = None, robust: bool = True) → aio_pika.abc.AbstractRobustQueue[source]
Parameters:
  • name – queue name
  • durable – Durability (queue survive broker restart)
  • exclusive – Makes this queue exclusive. Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes. Passive declaration of an exclusive queue by other connections are not allowed.
  • passive – Do not fail when entity was declared previously but has another params. Raises aio_pika.exceptions.ChannelClosed when queue doesn’t exist.
  • auto_delete – Delete queue when channel will be closed.
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

aio_pika.queue.Queue instance

Raises:

aio_pika.exceptions.ChannelClosed instance

class aio_pika.RobustConnection(url: yarl.URL, loop: asyncio.events.AbstractEventLoop = None, **kwargs)[source]

Robust connection

CHANNEL_CLASS

alias of aio_pika.robust_channel.RobustChannel

add_reconnect_callback(callback: Callable[[RobustConnection], None], weak: bool = False) → None[source]

Add callback which will be called after reconnect.

Returns:None
channel(channel_number: int = None, publisher_confirms: bool = True, on_return_raises: bool = False) → aio_pika.abc.AbstractRobustChannel[source]

Coroutine which returns new instance of Channel.

Example:

import aio_pika

async def main(loop):
    connection = await aio_pika.connect(
        "amqp://guest:guest@127.0.0.1/"
    )

    channel1 = connection.channel()
    await channel1.close()

    # Creates channel with specific channel number
    channel42 = connection.channel(42)
    await channel42.close()

    # For working with transactions
    channel_no_confirms = connection.channel(
        publisher_confirms=True
    )
    await channel_no_confirms.close()

Also available as an asynchronous context manager:

import aio_pika

async def main(loop):
    connection = await aio_pika.connect(
        "amqp://guest:guest@127.0.0.1/"
    )

    async with connection.channel() as channel:
        # channel is open and available

    # channel is now closed
Parameters:
  • channel_number – specify the channel number explicit
  • publisher_confirms – if True the aio_pika.Exchange.publish() method will be return bool after publish is complete. Otherwise the aio_pika.Exchange.publish() method will be return None
  • on_return_raises – raise an aio_pika.exceptions.DeliveryError when mandatory message will be returned
connect(timeout: Union[float, int, None] = None, **kwargs) → None[source]

Connect to AMQP server. This method should be called after aio_pika.connection.Connection.__init__()

Note

This method is called by connect(). You shouldn’t call it explicitly.

is_closed

Is this connection is closed

class aio_pika.RobustExchange(connection: aio_pika.abc.AbstractConnection, channel: aio_pika.abc.AbstractChannel, name: str, type: Union[aio_pika.abc.ExchangeType, str] = <ExchangeType.DIRECT: 'direct'>, *, auto_delete: bool = False, durable: bool = False, internal: bool = False, passive: bool = False, arguments: Optional[Dict[str, FieldValue]] = None)[source]

Exchange abstraction

bind(exchange: Union[AbstractExchange, str], routing_key: str = '', *, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None, robust: bool = True) → pamqp.commands.Exchange.BindOk[source]

A binding can also be a relationship between two exchanges. This can be simply read as: this exchange is interested in messages from another exchange.

Bindings can take an extra routing_key parameter. To avoid the confusion with a basic_publish parameter we’re going to call it a binding key.

client = await connect()

routing_key = 'simple_routing_key'
src_exchange_name = "source_exchange"
dest_exchange_name = "destination_exchange"

channel = await client.channel()
src_exchange = await channel.declare_exchange(
    src_exchange_name, auto_delete=True
)
dest_exchange = await channel.declare_exchange(
    dest_exchange_name, auto_delete=True
)
queue = await channel.declare_queue(auto_delete=True)

await queue.bind(dest_exchange, routing_key)
await dest_exchange.bind(src_exchange, routing_key)
Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

None

unbind(exchange: Union[AbstractExchange, str], routing_key: str = '', arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → pamqp.commands.Exchange.UnbindOk[source]

Remove exchange-to-exchange binding for this Exchange instance

Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Returns:

None

class aio_pika.RobustQueue(channel: aio_pika.abc.AbstractChannel, name: Optional[str], durable: bool = False, exclusive: bool = False, auto_delete: bool = False, arguments: Optional[Dict[str, FieldValue]] = None, passive: bool = False)[source]
bind(exchange: Union[AbstractExchange, str], routing_key: str = None, *, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None, robust: bool = True) → pamqp.commands.Queue.BindOk[source]

A binding is a relationship between an exchange and a queue. This can be simply read as: the queue is interested in messages from this exchange.

Bindings can take an extra routing_key parameter. To avoid the confusion with a basic_publish parameter we’re going to call it a binding key.

Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Raises:

asyncio.TimeoutError – when the binding timeout period has elapsed.

Returns:

None

cancel(consumer_tag: str, timeout: Union[float, int, None] = None, nowait: bool = False) → pamqp.commands.Basic.CancelOk[source]

This method cancels a consumer. This does not affect already delivered messages, but it does mean the server will not send any more messages for that consumer. The client may receive an arbitrary number of messages in between sending the cancel method and receiving the cancel-ok reply. It may also be sent from the server to the client in the event of the consumer being unexpectedly cancelled (i.e. cancelled for any reason other than the server receiving the corresponding basic.cancel from the client). This allows clients to be notified of the loss of consumers due to events such as queue deletion.

Parameters:
  • consumer_tag – consumer tag returned by consume()
  • timeout – execution timeout
  • nowait (bool) – Do not expect a Basic.CancelOk response
Returns:

Basic.CancelOk when operation completed successfully

consume(callback: Callable[[aio_pika.abc.AbstractIncomingMessage], Any], no_ack: bool = False, exclusive: bool = False, arguments: Optional[Dict[str, FieldValue]] = None, consumer_tag: str = None, timeout: Union[float, int, None] = None, robust: bool = True) → str[source]

Start to consuming the Queue.

Parameters:
  • timeoutasyncio.TimeoutError will be raises when the Future was not finished after this time.
  • callback – Consuming callback. Could be a coroutine.
  • no_ack – if True you don’t need to call aio_pika.message.IncomingMessage.ack()
  • exclusive – Makes this queue exclusive. Exclusive queues may only be accessed by the current connection, and are deleted when that connection closes. Passive declaration of an exclusive queue by other connections are not allowed.
  • arguments – additional arguments
  • consumer_tag – optional consumer tag
Raises:

asyncio.TimeoutError – when the consuming timeout period has elapsed.

Return str:

consumer tag str

unbind(exchange: Union[AbstractExchange, str], routing_key: str = None, arguments: Optional[Dict[str, FieldValue]] = None, timeout: Union[float, int, None] = None) → pamqp.commands.Queue.UnbindOk[source]

Remove binding from exchange for this Queue instance

Parameters:
  • exchangeaio_pika.exchange.Exchange instance
  • routing_key – routing key
  • arguments – additional arguments
  • timeout – execution timeout
Raises:

asyncio.TimeoutError – when the unbinding timeout period has elapsed.

Returns:

None

aio_pika.connect(url: Union[str, yarl.URL] = None, *, host: str = 'localhost', port: int = 5672, login: str = 'guest', password: str = 'guest', virtualhost: str = '/', ssl: bool = False, loop: asyncio.events.AbstractEventLoop = None, ssl_options: dict = None, timeout: Union[float, int, None] = None, client_properties: Dict[str, FieldValue] = None, connection_class: Type[aio_pika.abc.AbstractConnection] = <class 'aio_pika.connection.Connection'>, **kwargs) → aio_pika.abc.AbstractConnection[source]

Make connection to the broker.

Example:

import aio_pika

async def main():
    connection = await aio_pika.connect(
        "amqp://guest:guest@127.0.0.1/"
    )

Connect to localhost with default credentials:

import aio_pika

async def main():
    connection = await aio_pika.connect()

Note

The available keys for ssl_options parameter are:
  • cert_reqs
  • certfile
  • keyfile
  • ssl_version

For an information on what the ssl_options can be set to reference the official Python documentation .

Set connection name for RabbitMQ admin panel:

read_connection = await connect(
    client_properties={
        'connection_name': 'Read connection'
    }
)

write_connection = await connect(
    client_properties={
        'connection_name': 'Write connection'
    }
)

URL string might be contain ssl parameters e.g. amqps://user:pass@host//?ca_certs=ca.pem&certfile=crt.pem&keyfile=key.pem

Parameters:
  • client_properties – add custom client capability.
  • urlRFC3986 formatted broker address. When None will be used keyword arguments.
  • host – hostname of the broker
  • port – broker port 5672 by default
  • login – username string. ‘guest’ by default.
  • password – password string. ‘guest’ by default.
  • virtualhost – virtualhost parameter. ‘/’ by default
  • ssl – use SSL for connection. Should be used with addition kwargs.
  • ssl_options – A dict of values for the SSL connection.
  • timeout – connection timeout in seconds
  • loop – Event loop (asyncio.get_event_loop() when None)
  • connection_class – Factory of a new connection
  • kwargs – addition parameters which will be passed to the connection.
Returns:

aio_pika.connection.Connection

aio_pika.connect_robust(url: Union[str, yarl.URL] = None, *, host: str = 'localhost', port: int = 5672, login: str = 'guest', password: str = 'guest', virtualhost: str = '/', ssl: bool = False, loop: asyncio.events.AbstractEventLoop = None, ssl_options: dict = None, timeout: Union[float, int, None] = None, client_properties: Dict[str, FieldValue] = None, connection_class: Type[aio_pika.abc.AbstractRobustConnection] = <class 'aio_pika.robust_connection.RobustConnection'>, **kwargs) → aio_pika.abc.AbstractRobustConnection[source]

Make connection to the broker.

Example:

import aio_pika

async def main():
    connection = await aio_pika.connect(
        "amqp://guest:guest@127.0.0.1/"
    )

Connect to localhost with default credentials:

import aio_pika

async def main():
    connection = await aio_pika.connect()

Note

The available keys for ssl_options parameter are:
  • cert_reqs
  • certfile
  • keyfile
  • ssl_version

For an information on what the ssl_options can be set to reference the official Python documentation .

Set connection name for RabbitMQ admin panel:

read_connection = await connect(
    client_properties={
        'connection_name': 'Read connection'
    }
)

write_connection = await connect(
    client_properties={
        'connection_name': 'Write connection'
    }
)

URL string might be contain ssl parameters e.g. amqps://user:pass@host//?ca_certs=ca.pem&certfile=crt.pem&keyfile=key.pem

Parameters:
  • client_properties – add custom client capability.
  • urlRFC3986 formatted broker address. When None will be used keyword arguments.
  • host – hostname of the broker
  • port – broker port 5672 by default
  • login – username string. ‘guest’ by default.
  • password – password string. ‘guest’ by default.
  • virtualhost – virtualhost parameter. ‘/’ by default
  • ssl – use SSL for connection. Should be used with addition kwargs.
  • ssl_options – A dict of values for the SSL connection.
  • timeout – connection timeout in seconds
  • loop – Event loop (asyncio.get_event_loop() when None)
  • connection_class – Factory of a new connection
  • kwargs – addition parameters which will be passed to the connection.
Returns:

aio_pika.connection.Connection

aio_pika.patterns.base

alias of aio_pika.patterns.base

class aio_pika.patterns.Master(channel: aio_pika.abc.AbstractChannel, requeue: bool = True, reject_on_redelivered: bool = False)[source]

Implements Master/Worker pattern. Usage example:

worker.py

master = Master(channel)
worker = await master.create_worker('test_worker', lambda x: print(x))

master.py

master = Master(channel)
await master.proxy.test_worker('foo')

Creates a new Master instance.

Parameters:channel – Initialized instance of aio_pika.Channel
create_task(channel_name: str, kwargs: Mapping[str, Any] = mappingproxy({}), **message_kwargs) → Union[pamqp.commands.Basic.Ack, pamqp.commands.Basic.Nack, pamqp.commands.Basic.Reject, None][source]

Creates a new task for the worker

create_worker(channel_name: str, func: Callable[[...], Any], **kwargs) → aio_pika.patterns.master.Worker[source]

Creates a new Worker instance.

deserialize(data: bytes) → Any[source]

Deserialize data from bytes. Uses pickle by default. You should overlap this method when you want to change serializer

Parameters:data – Data which will be deserialized
Returns:Any
serialize(data: Any) → bytes[source]

Serialize data to the bytes. Uses pickle by default. You should overlap this method when you want to change serializer

Parameters:data – Data which will be serialized
Returns:bytes
class aio_pika.patterns.Worker(queue: aio_pika.abc.AbstractQueue, consumer_tag: str, loop: asyncio.events.AbstractEventLoop)[source]
close() → Awaitable[None][source]

Cancel subscription to the channel

Returns:asyncio.Task
class aio_pika.patterns.RPC(channel: aio_pika.abc.AbstractChannel)[source]

Remote Procedure Call helper.

Create an instance

rpc = await RPC.create(channel)

Registering python function

# RPC instance passes only keyword arguments
def multiply(*, x, y):
    return x * y

await rpc.register("multiply", multiply)

Call function through proxy

assert await rpc.proxy.multiply(x=2, y=3) == 6

Call function explicit

assert await rpc.call('multiply', dict(x=2, y=3)) == 6
call(method_name: str, kwargs: Optional[Dict[str, Any]] = None, *, expiration: Optional[int] = None, priority: int = 5, delivery_mode: aio_pika.abc.DeliveryMode = <DeliveryMode.NOT_PERSISTENT: 1>) → Any[source]

Call remote method and awaiting result.

Parameters:
  • method_name – Name of method
  • kwargs – Methos kwargs
  • expiration – If not None messages which staying in queue longer will be returned and asyncio.TimeoutError will be raised.
  • priority – Message priority
  • delivery_mode – Call message delivery mode
Raises:
  • asyncio.TimeoutError – when message expired
  • CancelledError – when called RPC.cancel()
  • RuntimeError – internal error
classmethod create(channel: aio_pika.abc.AbstractChannel, **kwargs) → aio_pika.patterns.rpc.RPC[source]

Creates a new instance of aio_pika.patterns.RPC. You should use this method instead of __init__(), because create() returns coroutine and makes async initialize

Parameters:channel – initialized instance of aio_pika.Channel
Returns:RPC
deserialize(data: bytes) → Any[source]

Deserialize data from bytes. Uses pickle by default. You should overlap this method when you want to change serializer

Parameters:data – Data which will be deserialized
Returns:Any
execute(func: Callable[[...], T], payload: Dict[str, Any]) → T[source]

Executes rpc call. Might be overlapped.

register(method_name: str, func: Callable[[...], T], **kwargs) → Any[source]

Method creates a queue with name which equal of method_name argument. Then subscribes this queue.

Parameters:
  • method_name – Method name
  • func – target function. Function MUST accept only keyword arguments.
  • kwargs – arguments which will be passed to queue_declare
Raises:

RuntimeError – Function already registered in this RPC instance or method_name already used.

serialize(data: Any) → bytes[source]

Serialize data to the bytes. Uses pickle by default. You should overlap this method when you want to change serializer

Parameters:data – Data which will be serialized
Returns:bytes
serialize_exception(exception: Exception) → bytes[source]

Serialize python exception to bytes

Parameters:exceptionException
Returns:bytes
unregister(func: Callable[[...], T]) → None[source]

Cancels subscription to the method-queue.

Parameters:func – Function