Secure your code as it's written. Use Snyk Code to scan source code in minutes - no build needed - and fix issues immediately.
def test_on_success__SystemExit(self,
errors=(SystemExit, KeyboardInterrupt)):
for exc in errors:
einfo = None
try:
raise exc()
except exc:
einfo = ExceptionInfo()
with pytest.raises(exc):
self.zRequest(id=uuid()).on_success((True, einfo, 1.0))
name = ev("APP_NAME", "robopubsub")
log = build_colorized_logger(
name=name)
broker_url = ev("PUB_BROKER_URL", "pyamqp://rabbitmq:rabbitmq@localhost:5672//")
exchange_name = ev("PUBLISH_EXCHANGE", "ecomm.api")
exchange_type = ev("PUBLISH_EXCHANGE_TYPE", "topic")
routing_key = ev("PUBLISH_ROUTING_KEY", "ecomm.api.west")
queue_name = ev("PUBLISH_QUEUE", "ecomm.api.west")
prefetch_count = int(ev("PREFETCH_COUNT", "1"))
priority_routing = {"high": queue_name,
"low": queue_name}
use_exchange = Exchange(exchange_name, type=exchange_type)
use_routing_key = routing_key
use_queue = Queue(queue_name, exchange=use_exchange, routing_key=routing_key)
task_queues = [
use_queue
]
ssl_options = build_ssl_options()
transport_options = {}
def send_task_msg(conn=None,
data={},
exchange=None, # kombu.Exchange object
routing_key=None, # string
priority="high",
priority_routing={},
serializer="json",
**kwargs):
def test_maybe_queue():
app = Mock()
app.amqp.queues = {'foo': 313}
assert _maybe_queue(app, 'foo') == 313
assert _maybe_queue(app, Queue('foo')) == Queue('foo')
def test_revive__with_prefetch_count(self):
channel = Mock(name='channel')
b1 = Queue('qname1', self.exchange, 'rkey')
Consumer(channel, [b1], prefetch_count=14)
channel.basic_qos.assert_called_with(0, 14, False)
def setUp(self):
super(NotificationTest, self).setUp()
self.exchange = kombu.Exchange('heat', 'topic', durable=False)
queue = kombu.Queue(exchange=self.exchange,
routing_key='notifications.info',
exclusive=True)
self.conn = kombu.Connection(get_url(
transport.get_transport(cfg.CONF).conf))
self.ch = self.conn.channel()
self.queue = queue(self.ch)
self.queue.declare()
def test_accept__content_disallowed(self):
conn = Connection('memory://')
q = Queue('foo', exchange=self.exchange)
p = conn.Producer()
p.publish(
{'complex': object()},
declare=[q], exchange=self.exchange, serializer='pickle',
)
callback = Mock(name='callback')
with conn.Consumer(queues=[q], callbacks=[callback]) as consumer:
with pytest.raises(consumer.ContentDisallowed):
conn.drain_events(timeout=1)
callback.assert_not_called()
def listen_bus_events(cls, routing_key):
exchange = Exchange(BUS_EXCHANGE_NAME, type=BUS_EXCHANGE_TYPE)
with Connection(BUS_URL) as conn:
queue = Queue(BUS_QUEUE_NAME, exchange=exchange, routing_key=routing_key, channel=conn.channel())
queue.declare()
queue.purge()
cls.bus_queue = queue
def test_multiple_bindings(self):
chan = Mock()
q = Queue('mul', [
binding(Exchange('mul1'), 'rkey1'),
binding(Exchange('mul2'), 'rkey2'),
binding(Exchange('mul3'), 'rkey3'),
])
q(chan).declare()
assert call(
nowait=False,
exchange='mul1',
auto_delete=False,
passive=False,
arguments=None,
type='direct',
durable=True,
) in chan.exchange_declare.call_args_list
def __assure_exchange(self, connection, exchange_name, exchange_type):
exchange = Exchange(exchange_name, type=exchange_type)
bound_exchange = exchange(connection)
bound_exchange.declare()
def __setup_rackhd_style_amqp(self):
"""
Need to make exchanges and named queus to make this
look like a RackHD instance amqp.
"""
con = Connection(hostname=self.host, port=self.ssl_port, ssl=False)
on_task = self.__assure_exchange(con, 'on.task', 'topic')
self.__assure_named_queue(con, on_task, 'ipmi.command.sel.result')
self.__assure_named_queue(con, on_task, 'ipmi.command.sdr.result')
self.__assure_named_queue(con, on_task, 'ipmi.command.chassis.result')
on_events = self.__assure_exchange(con, 'on.events', 'topic')
self.__assure_named_queue(con, on_events, 'graph.finished')
self.__assure_named_queue(con, on_events, 'polleralert.sel.updated', '#')
self.__assure_exchange(con, 'on.heartbeat', 'topic')