mirror of
https://github.com/GSA/notifications-api.git
synced 2025-12-23 08:51:30 -05:00
Previously we passed along this piece of state via the kwargs for a task, but this runs the risk of the task accidentally receiving the extra kwarg unless we've covered all the code paths that could invoke it directly e.g. retries don't invoke __call__. This switches to using Celery "headers" to pass the extra state. It turns out that a Celery has two "header" concepts, which leads to some confusion and even a bug with the framework [1]: - In older (pre v4.4) versions of Celery, the "headers" specified by apply_async() would become _the_ headers in the message that gets passed around workers, etc. These would be available later on via "self.request.headers". - Since Celery protocol v2, the meaning of "headers" in the message changed to become (basically) _all_ metadata about the task [2], with the "headers" option in apply_async() being merged [3] into the big dict of metadata. This makes using headers a bit confusing unfortunately, since the data structure we put in is subtly different to what comes out in the request context. Nonetheless, it still works. I've added some comments to try and clarify it. Note that one of the original tests is no longer necessary, since we don't need to worry about argument passing styles with headers. [1]: https://github.com/celery/celery/issues/4875 [2]:663e4d3a0b (diff-07a65448b2db3252a9711766beec23372715cd7597c3e309bf53859eabc0107fR343)[3]:681a922220/celery/app/amqp.py (L495)
167 lines
5.1 KiB
Python
167 lines
5.1 KiB
Python
import uuid
|
|
|
|
import pytest
|
|
from flask import g
|
|
from freezegun import freeze_time
|
|
|
|
from app import notify_celery
|
|
|
|
|
|
# requiring notify_api ensures notify_celery.init_app has been called
|
|
@pytest.fixture(scope='session')
|
|
def celery_task(notify_api):
|
|
@notify_celery.task(name=uuid.uuid4(), base=notify_celery.task_cls)
|
|
def test_task(delivery_info=None): pass
|
|
return test_task
|
|
|
|
|
|
@pytest.fixture
|
|
def async_task(celery_task):
|
|
celery_task.push_request(delivery_info={'routing_key': 'test-queue'})
|
|
yield celery_task
|
|
celery_task.pop_request()
|
|
|
|
|
|
@pytest.fixture
|
|
def request_id_task(celery_task):
|
|
# Note that each header is a direct attribute of the
|
|
# task context (aka "request").
|
|
celery_task.push_request(notify_request_id='1234')
|
|
yield celery_task
|
|
celery_task.pop_request()
|
|
|
|
|
|
def test_success_should_log_and_call_statsd(mocker, notify_api, async_task):
|
|
statsd = mocker.patch.object(notify_api.statsd_client, 'timing')
|
|
logger = mocker.patch.object(notify_api.logger, 'info')
|
|
|
|
with freeze_time() as frozen:
|
|
async_task()
|
|
frozen.tick(5)
|
|
|
|
async_task.on_success(
|
|
retval=None, task_id=1234, args=[], kwargs={}
|
|
)
|
|
|
|
statsd.assert_called_once_with(f'celery.test-queue.{async_task.name}.success', 5.0)
|
|
logger.assert_called_once_with(f'Celery task {async_task.name} (queue: test-queue) took 5.0000')
|
|
|
|
|
|
def test_success_queue_when_applied_synchronously(mocker, notify_api, celery_task):
|
|
statsd = mocker.patch.object(notify_api.statsd_client, 'timing')
|
|
logger = mocker.patch.object(notify_api.logger, 'info')
|
|
|
|
with freeze_time() as frozen:
|
|
celery_task()
|
|
frozen.tick(5)
|
|
|
|
celery_task.on_success(
|
|
retval=None, task_id=1234, args=[], kwargs={}
|
|
)
|
|
|
|
statsd.assert_called_once_with(f'celery.none.{celery_task.name}.success', 5.0)
|
|
logger.assert_called_once_with(f'Celery task {celery_task.name} (queue: none) took 5.0000')
|
|
|
|
|
|
def test_failure_should_log_and_call_statsd(mocker, notify_api, async_task):
|
|
statsd = mocker.patch.object(notify_api.statsd_client, 'incr')
|
|
logger = mocker.patch.object(notify_api.logger, 'exception')
|
|
|
|
async_task.on_failure(
|
|
exc=Exception, task_id=1234, args=[], kwargs={}, einfo=None
|
|
)
|
|
|
|
statsd.assert_called_once_with(f'celery.test-queue.{async_task.name}.failure')
|
|
logger.assert_called_once_with(f'Celery task {async_task.name} (queue: test-queue) failed')
|
|
|
|
|
|
def test_failure_queue_when_applied_synchronously(mocker, notify_api, celery_task):
|
|
statsd = mocker.patch.object(notify_api.statsd_client, 'incr')
|
|
logger = mocker.patch.object(notify_api.logger, 'exception')
|
|
|
|
celery_task.on_failure(
|
|
exc=Exception, task_id=1234, args=[], kwargs={}, einfo=None
|
|
)
|
|
|
|
statsd.assert_called_once_with(f'celery.none.{celery_task.name}.failure')
|
|
logger.assert_called_once_with(f'Celery task {celery_task.name} (queue: none) failed')
|
|
|
|
|
|
def test_call_exports_request_id_from_headers(mocker, request_id_task):
|
|
g = mocker.patch('app.celery.celery.g')
|
|
request_id_task()
|
|
assert g.request_id == '1234'
|
|
|
|
|
|
def test_call_copes_if_request_id_not_in_headers(mocker, celery_task):
|
|
g = mocker.patch('app.celery.celery.g')
|
|
celery_task()
|
|
assert g.request_id is None
|
|
|
|
|
|
def test_send_task_injects_global_request_id_into_headers(mocker, notify_api):
|
|
super_apply = mocker.patch('celery.Celery.send_task')
|
|
g.request_id = '1234'
|
|
notify_celery.send_task('some-task')
|
|
|
|
super_apply.assert_called_with(
|
|
'some-task', # name
|
|
None, # args
|
|
None, # kwargs
|
|
headers={'notify_request_id': '1234'} # other kwargs
|
|
)
|
|
|
|
|
|
def test_send_task_injects_request_id_with_existing_headers(mocker, notify_api):
|
|
super_apply = mocker.patch('celery.Celery.send_task')
|
|
g.request_id = '1234'
|
|
|
|
notify_celery.send_task(
|
|
'some-task',
|
|
None, # args
|
|
None, # kwargs
|
|
headers={'something': 'else'} # other kwargs
|
|
)
|
|
|
|
super_apply.assert_called_with(
|
|
'some-task', # name
|
|
None, # args
|
|
None, # kwargs
|
|
headers={'notify_request_id': '1234', 'something': 'else'} # other kwargs
|
|
)
|
|
|
|
|
|
def test_send_task_injects_request_id_with_none_headers(mocker, notify_api):
|
|
super_apply = mocker.patch('celery.Celery.send_task')
|
|
g.request_id = '1234'
|
|
|
|
notify_celery.send_task(
|
|
'some-task',
|
|
None, # args
|
|
None, # kwargs
|
|
headers=None, # other kwargs (task retry set headers to "None")
|
|
)
|
|
|
|
super_apply.assert_called_with(
|
|
'some-task', # name
|
|
None, # args
|
|
None, # kwargs
|
|
headers={'notify_request_id': '1234'} # other kwargs
|
|
)
|
|
|
|
|
|
def test_send_task_injects_id_into_kwargs_from_request(mocker, notify_api):
|
|
super_apply = mocker.patch('celery.Celery.send_task')
|
|
request_id_header = notify_api.config['NOTIFY_TRACE_ID_HEADER']
|
|
request_headers = {request_id_header: '1234'}
|
|
|
|
with notify_api.test_request_context(headers=request_headers):
|
|
notify_celery.send_task('some-task')
|
|
|
|
super_apply.assert_called_with(
|
|
'some-task', # name
|
|
None, # args
|
|
None, # kwargs
|
|
headers={'notify_request_id': '1234'} # other kwargs
|
|
)
|