instance_id
stringlengths
10
57
patch
stringlengths
261
37.7k
repo
stringlengths
7
53
base_commit
stringlengths
40
40
hints_text
stringclasses
301 values
test_patch
stringlengths
212
2.22M
problem_statement
stringlengths
23
37.7k
version
stringclasses
1 value
environment_setup_commit
stringlengths
40
40
FAIL_TO_PASS
listlengths
1
4.94k
PASS_TO_PASS
listlengths
0
7.82k
meta
dict
created_at
stringlengths
25
25
license
stringclasses
8 values
__index_level_0__
int64
0
6.41k
agronholm__anyio-268
diff --git a/docs/synchronization.rst b/docs/synchronization.rst index e5400df..b737b54 100644 --- a/docs/synchronization.rst +++ b/docs/synchronization.rst @@ -119,15 +119,15 @@ Example:: await sleep(1) async with condition: - await condition.notify(1) + condition.notify(1) await sleep(1) async with condition: - await condition.notify(2) + condition.notify(2) await sleep(1) async with condition: - await condition.notify_all() + condition.notify_all() run(main) diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index e3eb2a1..95e4de2 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -3,6 +3,11 @@ Version history This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. +**UNRELEASED** + +- Fixed ``to_thread.run_sync()`` raising ``RuntimeError`` when no "root" task could be found for + setting up a cleanup callback + **3.0.0** - Curio support has been dropped (see the :doc:`FAQ <faq>` as for why) diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index 68fac2e..02053e4 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -17,8 +17,8 @@ from socket import AddressFamily, SocketKind, SocketType from threading import Thread from types import TracebackType from typing import ( - Any, Awaitable, Callable, Collection, Coroutine, Deque, Dict, Generator, List, Optional, - Sequence, Set, Tuple, Type, TypeVar, Union, cast) + Any, Awaitable, Callable, Collection, Coroutine, Deque, Dict, Generator, Iterable, List, + Optional, Sequence, Set, Tuple, Type, TypeVar, Union, cast) from weakref import WeakKeyDictionary from .. import CapacityLimiterStatistics, EventStatistics, TaskInfo, abc @@ -46,18 +46,14 @@ if sys.version_info >= (3, 7): from asyncio import all_tasks, create_task, current_task, get_running_loop from asyncio import run as native_run - def find_root_task() -> asyncio.Task: - for task in all_tasks(): - if task._callbacks: - for cb, context in task._callbacks: # type: ignore - if cb is _run_until_complete_cb or cb.__module__ == 'uvloop.loop': - return task - - raise RuntimeError('Cannot find root task for setting cleanup callback') + def _get_task_callbacks(task: asyncio.Task) -> Iterable[Callable]: + return [cb for cb, context in task._callbacks] # type: ignore else: - _T = TypeVar('_T') + def _get_task_callbacks(task: asyncio.Task) -> Iterable[Callable]: + return task._callbacks # type: ignore + def native_run(main, *, debug=False): # Snatched from Python 3.7 from asyncio import coroutines, events, tasks @@ -129,20 +125,43 @@ else: return asyncio.Task.current_task(loop) - def find_root_task() -> asyncio.Task: - for task in all_tasks(): - for cb in task._callbacks: - if cb is _run_until_complete_cb or cb.__module__ == 'uvloop.loop': - return task - - raise RuntimeError('Cannot find root task for setting cleanup callback') - T_Retval = TypeVar('T_Retval') # Check whether there is native support for task names in asyncio (3.8+) _native_task_names = hasattr(asyncio.Task, 'get_name') -WORKER_THREAD_MAX_IDLE_TIME = 10 # seconds + +_root_task: RunVar[Optional[asyncio.Task]] = RunVar('_root_task') + + +def find_root_task() -> asyncio.Task: + try: + root_task = _root_task.get() + except LookupError: + for task in all_tasks(): + if task._callbacks: + for cb in _get_task_callbacks(task): + if cb is _run_until_complete_cb or cb.__module__ == 'uvloop.loop': + _root_task.set(task) + return task + + _root_task.set(None) + else: + if root_task is not None: + return root_task + + # Look up the topmost task in the AnyIO task tree, if possible + task = cast(asyncio.Task, current_task()) + state = _task_states.get(task) + if state: + cancel_scope = state.cancel_scope + while cancel_scope and cancel_scope._parent_scope is not None: + cancel_scope = cancel_scope._parent_scope + + if cancel_scope is not None: + return cast(asyncio.Task, cancel_scope._host_task) + + return task def get_callable_name(func: Callable) -> str: @@ -650,41 +669,51 @@ class TaskGroup(abc.TaskGroup): _Retval_Queue_Type = Tuple[Optional[T_Retval], Optional[BaseException]] -def _thread_pool_worker(work_queue: Queue, loop: asyncio.AbstractEventLoop) -> None: - func: Callable - args: tuple - future: asyncio.Future - with claim_worker_thread('asyncio'): - loop = threadlocals.loop = loop - while True: - func, args, future = work_queue.get() - if func is None: - # Shutdown command received - return +class WorkerThread(Thread): + __slots__ = 'root_task', 'loop', 'queue', 'idle_since' - if not future.cancelled(): - try: - result = func(*args) - except BaseException as exc: - if not loop.is_closed() and not future.cancelled(): - loop.call_soon_threadsafe(future.set_exception, exc) - else: - if not loop.is_closed() and not future.cancelled(): - loop.call_soon_threadsafe(future.set_result, result) + MAX_IDLE_TIME = 10 # seconds + + def __init__(self, root_task: asyncio.Task): + super().__init__(name='AnyIO worker thread') + self.root_task = root_task + self.loop = root_task._loop + self.queue: Queue[Union[Tuple[Callable, tuple, asyncio.Future], None]] = Queue(2) + self.idle_since = current_time() + + def run(self) -> None: + with claim_worker_thread('asyncio'): + threadlocals.loop = self.loop + while True: + item = self.queue.get() + if item is None: + # Shutdown command received + return - work_queue.task_done() + func, args, future = item + if not future.cancelled(): + try: + result = func(*args) + except BaseException as exc: + if not self.loop.is_closed() and not future.cancelled(): + self.loop.call_soon_threadsafe(future.set_exception, exc) + else: + if not self.loop.is_closed() and not future.cancelled(): + self.loop.call_soon_threadsafe(future.set_result, result) + self.queue.task_done() -_threadpool_work_queue: RunVar[Queue] = RunVar('_threadpool_work_queue') -_threadpool_idle_workers: RunVar[Deque[Tuple[Thread, float]]] = RunVar( - '_threadpool_idle_workers') -_threadpool_workers: RunVar[Set[Thread]] = RunVar('_threadpool_workers') + def stop(self, f: Optional[asyncio.Task] = None) -> None: + self.queue.put_nowait(None) + _threadpool_workers.get().discard(self) + try: + _threadpool_idle_workers.get().remove(self) + except ValueError: + pass -def _loop_shutdown_callback(f: asyncio.Future) -> None: - """This is called when the root task has finished.""" - for _ in range(len(_threadpool_workers.get())): - _threadpool_work_queue.get().put_nowait((None, None, None)) +_threadpool_idle_workers: RunVar[Deque[WorkerThread]] = RunVar('_threadpool_idle_workers') +_threadpool_workers: RunVar[Set[WorkerThread]] = RunVar('_threadpool_workers') async def run_sync_in_worker_thread( @@ -694,45 +723,42 @@ async def run_sync_in_worker_thread( # If this is the first run in this event loop thread, set up the necessary variables try: - work_queue = _threadpool_work_queue.get() idle_workers = _threadpool_idle_workers.get() workers = _threadpool_workers.get() except LookupError: - work_queue = Queue() idle_workers = deque() workers = set() - _threadpool_work_queue.set(work_queue) _threadpool_idle_workers.set(idle_workers) _threadpool_workers.set(workers) - find_root_task().add_done_callback(_loop_shutdown_callback) async with (limiter or current_default_thread_limiter()): with CancelScope(shield=not cancellable): future: asyncio.Future = asyncio.Future() - work_queue.put_nowait((func, args, future)) + root_task = find_root_task() if not idle_workers: - thread = Thread(target=_thread_pool_worker, args=(work_queue, get_running_loop()), - name='AnyIO worker thread') - workers.add(thread) - thread.start() + worker = WorkerThread(root_task) + worker.start() + workers.add(worker) + root_task.add_done_callback(worker.stop) else: - thread, idle_since = idle_workers.pop() + worker = idle_workers.pop() - # Prune any other workers that have been idle for WORKER_MAX_IDLE_TIME seconds or - # longer + # Prune any other workers that have been idle for MAX_IDLE_TIME seconds or longer now = current_time() while idle_workers: - if now - idle_workers[0][1] < WORKER_THREAD_MAX_IDLE_TIME: + if now - idle_workers[0].idle_since < WorkerThread.MAX_IDLE_TIME: break - idle_workers.popleft() - work_queue.put_nowait(None) - workers.remove(thread) + worker = idle_workers.popleft() + worker.root_task.remove_done_callback(worker.stop) + worker.stop() + worker.queue.put_nowait((func, args, future)) try: return await future finally: - idle_workers.append((thread, current_time())) + worker.idle_since = current_time() + idle_workers.append(worker) def run_sync_from_thread(func: Callable[..., T_Retval], *args,
agronholm/anyio
5169f1d1d3812cd63109fb5be7a661b6f0f42cf2
diff --git a/tests/conftest.py b/tests/conftest.py index 92fc808..faf5c10 100644 --- a/tests/conftest.py +++ b/tests/conftest.py @@ -49,3 +49,12 @@ def client_context(ca): client_context = ssl.create_default_context(ssl.Purpose.SERVER_AUTH) ca.configure_trust(client_context) return client_context + + [email protected] +def asyncio_event_loop(): + loop = asyncio.DefaultEventLoopPolicy().new_event_loop() + asyncio.set_event_loop(loop) + yield loop + asyncio.set_event_loop(None) + loop.close() diff --git a/tests/test_debugging.py b/tests/test_debugging.py index 19a9179..80af499 100644 --- a/tests/test_debugging.py +++ b/tests/test_debugging.py @@ -53,9 +53,7 @@ async def test_get_running_tasks(): @pytest.mark.filterwarnings('ignore:"@coroutine" decorator is deprecated:DeprecationWarning') -def test_wait_generator_based_task_blocked(): - from asyncio import DefaultEventLoopPolicy, Event, coroutine, set_event_loop - +def test_wait_generator_based_task_blocked(asyncio_event_loop): async def native_coro_part(): await wait_all_tasks_blocked() assert not gen_task._coro.gi_running @@ -66,19 +64,13 @@ def test_wait_generator_based_task_blocked(): event.set() - @coroutine + @asyncio.coroutine def generator_part(): yield from event.wait() - loop = DefaultEventLoopPolicy().new_event_loop() - try: - set_event_loop(loop) - event = Event() - gen_task = loop.create_task(generator_part()) - loop.run_until_complete(native_coro_part()) - finally: - set_event_loop(None) - loop.close() + event = asyncio.Event() + gen_task = asyncio_event_loop.create_task(generator_part()) + asyncio_event_loop.run_until_complete(native_coro_part()) @pytest.mark.parametrize('anyio_backend', ['asyncio']) diff --git a/tests/test_from_thread.py b/tests/test_from_thread.py index d169b80..c596cb1 100644 --- a/tests/test_from_thread.py +++ b/tests/test_from_thread.py @@ -1,4 +1,5 @@ import threading +import time from concurrent.futures import CancelledError from contextlib import suppress @@ -53,7 +54,14 @@ class TestRunAsyncFromThread: # The thread should not exist after the event loop has been closed initial_count = threading.active_count() run(main, backend='asyncio') - assert threading.active_count() == initial_count + + for _ in range(10): + if threading.active_count() == initial_count: + return + + time.sleep(0.1) + + pytest.fail('Worker thread did not exit within 1 second') async def test_run_async_from_thread_exception(self): async def add(a, b): diff --git a/tests/test_to_thread.py b/tests/test_to_thread.py index c538b95..e39c052 100644 --- a/tests/test_to_thread.py +++ b/tests/test_to_thread.py @@ -84,6 +84,7 @@ async def test_cancel_worker_thread(cancellable, expected_last_active): """ def thread_worker(): + print('thread worker:', threading.current_thread(), flush=True) nonlocal last_active from_thread.run_sync(sleep_event.set) time.sleep(0.2) @@ -110,14 +111,40 @@ async def test_cancel_worker_thread(cancellable, expected_last_active): @pytest.mark.parametrize('anyio_backend', ['asyncio']) -async def test_cancel_asyncio_native_task(): +async def test_asyncio_cancel_native_task(): async def run_in_thread(): nonlocal task task = current_task() - await to_thread.run_sync(time.sleep, 1, cancellable=True) + await to_thread.run_sync(time.sleep, 0.2, cancellable=True) task = None async with create_task_group() as tg: tg.start_soon(run_in_thread) await wait_all_tasks_blocked() task.cancel() + + +def test_asyncio_no_root_task(asyncio_event_loop): + """ + Regression test for #264. + + Ensures that to_thread.run_sync() does not raise an error when there is no root task, but + instead tries to find the top most parent task by traversing the cancel scope tree, or failing + that, uses the current task to set up a shutdown callback. + + """ + async def run_in_thread(): + try: + await to_thread.run_sync(time.sleep, 0) + finally: + asyncio_event_loop.call_soon(asyncio_event_loop.stop) + + task = asyncio_event_loop.create_task(run_in_thread()) + asyncio_event_loop.run_forever() + task.result() + + # Wait for worker threads to exit + for t in threading.enumerate(): + if t.name == 'AnyIO worker thread': + t.join(2) + assert not t.is_alive()
to_thread.run_sync() doesn't work with the tornado event loop Hi there! [jupyter_server](https://github.com/jupyter-server/jupyter_server) uses the anyio v2 `run_sync_in_worker_thread` function , and I noticed a possible bug after upgrading to anyio v3. This is the error I see when using `to_thread.run_sync()`: ```python HTTPServerRequest(protocol='http', host='127.0.0.1:38403', method='GET', uri='/a%40b/api/contents/Directory%20with%20spaces%20in', version='HTTP/1.1', remote_ip='127.0.0.1') Traceback (most recent call last): File "/opt/hostedtoolcache/Python/3.7.10/x64/lib/python3.7/site-packages/anyio/_backends/_asyncio.py", line 697, in run_sync_in_worker_thread work_queue = _threadpool_work_queue.get() File "/opt/hostedtoolcache/Python/3.7.10/x64/lib/python3.7/site-packages/anyio/lowlevel.py", line 120, in get raise LookupError(f'Run variable "{self._name}" has no value and no default set') LookupError: Run variable "_threadpool_work_queue" has no value and no default set During handling of the above exception, another exception occurred: Traceback (most recent call last): File "/opt/hostedtoolcache/Python/3.7.10/x64/lib/python3.7/site-packages/tornado/web.py", line 1704, in _execute result = await result File "/home/runner/work/jupyter_server/jupyter_server/jupyter_server/services/contents/handlers.py", line 111, in get path=path, type=type, format=format, content=content, File "/home/runner/work/jupyter_server/jupyter_server/jupyter_server/utils.py", line 176, in ensure_async result = await obj File "/home/runner/work/jupyter_server/jupyter_server/jupyter_server/services/contents/filemanager.py", line 692, in get model = await self._dir_model(path, content=content) File "/home/runner/work/jupyter_server/jupyter_server/jupyter_server/services/contents/filemanager.py", line 574, in _dir_model dir_contents = await run_sync_in_worker_thread(os.listdir, os_dir) File "/opt/hostedtoolcache/Python/3.7.10/x64/lib/python3.7/site-packages/anyio/to_thread.py", line 37, in run_sync_in_worker_thread return await run_sync(func, *args, cancellable=cancellable, limiter=limiter) File "/opt/hostedtoolcache/Python/3.7.10/x64/lib/python3.7/site-packages/anyio/to_thread.py", line 29, in run_sync limiter=limiter) File "/opt/hostedtoolcache/Python/3.7.10/x64/lib/python3.7/site-packages/anyio/_backends/_asyncio.py", line 707, in run_sync_in_worker_thread find_root_task().add_done_callback(_loop_shutdown_callback) File "/opt/hostedtoolcache/Python/3.7.10/x64/lib/python3.7/site-packages/anyio/_backends/_asyncio.py", line 56, in find_root_task Error: raise RuntimeError('Cannot find root task for setting cleanup callback') ``` It looks like the `find_root_task` function is failing because the callback is a tornado.ioloop and not an uvloop.loop. Jupyter server is using the tornado event loop. For more context, this is the github issue: https://github.com/jupyter-server/jupyter_server/issues/487 **Possible Solution** I was able to fix it by updating the following code, but I'm not sure if this is a proper fix. [src/anyio/_backends/_asyncio.py line 50](https://github.com/agronholm/anyio/pull/227/files#diff-202c3fc4551e5a287df488a9bd96a25dcc1405ec135d5c7aceb6ef4c02755341R50) ```python if cb is _run_until_complete_cb or cb.__module__ in ('uvloop.loop', 'tornado.ioloop') ```
0.0
5169f1d1d3812cd63109fb5be7a661b6f0f42cf2
[ "tests/test_to_thread.py::test_asyncio_no_root_task" ]
[ "tests/test_debugging.py::test_main_task_name[asyncio]", "tests/test_debugging.py::test_main_task_name[asyncio+uvloop]", "tests/test_debugging.py::test_get_running_tasks[asyncio]", "tests/test_debugging.py::test_get_running_tasks[asyncio+uvloop]", "tests/test_debugging.py::test_wait_generator_based_task_blocked", "tests/test_debugging.py::test_wait_all_tasks_blocked_asend[asyncio]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_async_from_thread[asyncio]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_async_from_thread[asyncio+uvloop]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_sync_from_thread[asyncio]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_sync_from_thread[asyncio+uvloop]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_sync_from_thread_pooling", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_async_from_thread_exception[asyncio]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_async_from_thread_exception[asyncio+uvloop]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_sync_from_thread_exception[asyncio]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_sync_from_thread_exception[asyncio+uvloop]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_anyio_async_func_from_thread[asyncio]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_anyio_async_func_from_thread[asyncio+uvloop]", "tests/test_from_thread.py::TestRunAsyncFromThread::test_run_async_from_unclaimed_thread", "tests/test_from_thread.py::TestRunSyncFromThread::test_run_sync_from_unclaimed_thread", "tests/test_from_thread.py::TestBlockingPortal::test_successful_call[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_successful_call[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_aexit_with_exception[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_aexit_with_exception[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_aexit_without_exception[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_aexit_without_exception[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_call_portal_from_event_loop_thread[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_call_portal_from_event_loop_thread[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_with_new_event_loop[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_with_new_event_loop[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_with_nonexistent_backend", "tests/test_from_thread.py::TestBlockingPortal::test_call_stopped_portal[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_call_stopped_portal[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon_cancel_later[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon_cancel_later[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon_cancel_immediately[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon_cancel_immediately[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon_with_name[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_task_soon_with_name[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_async_context_manager_success[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_async_context_manager_success[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_async_context_manager_error[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_async_context_manager_error[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_async_context_manager_error_ignore[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_async_context_manager_error_ignore[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_no_value[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_no_value[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_with_value[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_with_value[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_crash_before_started_call[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_crash_before_started_call[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_crash_after_started_call[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_crash_after_started_call[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_no_started_call[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_no_started_call[asyncio+uvloop]", "tests/test_from_thread.py::TestBlockingPortal::test_start_with_name[asyncio]", "tests/test_from_thread.py::TestBlockingPortal::test_start_with_name[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio]", "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio+uvloop]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-cancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-cancellable]", "tests/test_to_thread.py::test_asyncio_cancel_native_task[asyncio]" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-04-24 12:32:38+00:00
mit
917
agronholm__anyio-273
diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index 02053e4..7a7eaaf 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -141,7 +141,8 @@ def find_root_task() -> asyncio.Task: for task in all_tasks(): if task._callbacks: for cb in _get_task_callbacks(task): - if cb is _run_until_complete_cb or cb.__module__ == 'uvloop.loop': + if (cb is _run_until_complete_cb + or getattr(cb, '__module__', None) == 'uvloop.loop'): _root_task.set(task) return task
agronholm/anyio
72baca901c599e7fdf22c2777b9b6a304ddd975d
diff --git a/.github/workflows/codeqa-test.yml b/.github/workflows/codeqa-test.yml index 21f0b69..5d7df2f 100644 --- a/.github/workflows/codeqa-test.yml +++ b/.github/workflows/codeqa-test.yml @@ -25,7 +25,7 @@ jobs: - name: Check types with Mypy run: mypy src - name: Run isort - run: isort -c src tests + run: isort -c --diff src tests test: needs: [lint] diff --git a/tests/test_to_thread.py b/tests/test_to_thread.py index e39c052..a0e43f1 100644 --- a/tests/test_to_thread.py +++ b/tests/test_to_thread.py @@ -2,6 +2,7 @@ import asyncio import sys import threading import time +from functools import partial import pytest @@ -148,3 +149,21 @@ def test_asyncio_no_root_task(asyncio_event_loop): if t.name == 'AnyIO worker thread': t.join(2) assert not t.is_alive() + + +def test_asyncio_future_callback_partial(asyncio_event_loop): + """ + Regression test for #272. + + Ensures that futures with partial callbacks are handled correctly when the root task + cannot be determined. + """ + def func(future): + pass + + async def sleep_sync(): + return await to_thread.run_sync(time.sleep, 0) + + task = asyncio_event_loop.create_task(sleep_sync()) + task.add_done_callback(partial(func)) + asyncio_event_loop.run_until_complete(task)
Handle partial asyncio future callbacks As discussed on gitter, ``` def find_root_task() -> asyncio.Task: try: root_task = _root_task.get() except LookupError: for task in all_tasks(): if task._callbacks: for cb in _get_task_callbacks(task): > if cb is _run_until_complete_cb or cb.__module__ == 'uvloop.loop': E AttributeError: 'functools.partial' object has no attribute '__module__' ``` Full trace: https://pastebin.com/hhqMvhpT, It happens roughly 10% of the time I run my tests. Triggered by: https://github.com/vinissimus/async-asgi-testclient/blob/f3243ea332b0a91f3990676aa850fdf68676ae93/async_asgi_testclient/utils.py#L75 ```python def create_monitored_task(coro, send): future = asyncio.ensure_future(coro) future.add_done_callback(partial(_callback, send)) return future ``` Anyio needs to handle the case where future callbacks are partial objects, and probably any kind of callable.
0.0
72baca901c599e7fdf22c2777b9b6a304ddd975d
[ "tests/test_to_thread.py::test_asyncio_future_callback_partial" ]
[ "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio]", "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio+uvloop]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-cancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-cancellable]", "tests/test_to_thread.py::test_asyncio_cancel_native_task[asyncio]", "tests/test_to_thread.py::test_asyncio_no_root_task" ]
{ "failed_lite_validators": [ "has_hyperlinks" ], "has_test_patch": true, "is_lite": false }
2021-04-30 19:59:31+00:00
mit
918
agronholm__anyio-275
diff --git a/docs/api.rst b/docs/api.rst index 8260bd7..d921f1b 100644 --- a/docs/api.rst +++ b/docs/api.rst @@ -8,6 +8,8 @@ Event loop .. autofunction:: anyio.get_all_backends .. autofunction:: anyio.get_cancelled_exc_class .. autofunction:: anyio.sleep +.. autofunction:: anyio.sleep_forever +.. autofunction:: anyio.sleep_until .. autofunction:: anyio.current_time Asynchronous resources diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index 4764d91..b640178 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -6,6 +6,7 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. **UNRELEASED** - Added ``env`` and ``cwd`` keyword arguments to ``run_process()`` and ``open_process``. +- Added the ``sleep_forever()`` and ``sleep_until()`` functions - Changed asyncio task groups so that if the host and child tasks have only raised ``CancelledErrors``, just one ``CancelledError`` will now be raised instead of an ``ExceptionGroup``, allowing asyncio to ignore it when it propagates out of the task diff --git a/setup.cfg b/setup.cfg index fe575f5..353182a 100644 --- a/setup.cfg +++ b/setup.cfg @@ -41,12 +41,14 @@ anyio = py.typed [options.extras_require] test = + mock >= 4; python_version < '3.8' coverage[toml] >= 4.5 hypothesis >= 4.0 pytest >= 6.0 + pytest-mock >= 3.6.1 trustme - uvloop < 0.15; python_version < '3.7' and platform_python_implementation == 'CPython' and platform_system != 'Windows' - uvloop >= 0.15; python_version >= '3.7' and platform_python_implementation == 'CPython' and platform_system != 'Windows' + uvloop < 0.15; python_version < '3.7' and (platform_python_implementation == 'CPython' and platform_system != 'Windows') + uvloop >= 0.15; python_version >= '3.7' and (platform_python_implementation == 'CPython' and platform_system != 'Windows') trio = trio >= 0.16 doc = sphinx_rtd_theme diff --git a/src/anyio/__init__.py b/src/anyio/__init__.py index da6124c..74caae8 100644 --- a/src/anyio/__init__.py +++ b/src/anyio/__init__.py @@ -3,6 +3,8 @@ __all__ = ( 'maybe_async_cm', 'run', 'sleep', + 'sleep_forever', + 'sleep_until', 'current_time', 'get_all_backends', 'get_cancelled_exc_class', @@ -71,7 +73,9 @@ __all__ = ( ) from ._core._compat import maybe_async, maybe_async_cm -from ._core._eventloop import current_time, get_all_backends, get_cancelled_exc_class, run, sleep +from ._core._eventloop import ( + current_time, get_all_backends, get_cancelled_exc_class, run, sleep, sleep_forever, + sleep_until) from ._core._exceptions import ( BrokenResourceError, BrokenWorkerProcess, BusyResourceError, ClosedResourceError, DelimiterNotFound, EndOfStream, ExceptionGroup, IncompleteRead, TypedAttributeLookupError, diff --git a/src/anyio/_core/_eventloop.py b/src/anyio/_core/_eventloop.py index ba14385..6021ab9 100644 --- a/src/anyio/_core/_eventloop.py +++ b/src/anyio/_core/_eventloop.py @@ -1,3 +1,4 @@ +import math import sys import threading from contextlib import contextmanager @@ -68,6 +69,32 @@ async def sleep(delay: float) -> None: return await get_asynclib().sleep(delay) +async def sleep_forever() -> None: + """ + Pause the current task until it's cancelled. + + This is a shortcut for ``sleep(math.inf)``. + + .. versionadded:: 3.1 + + """ + await sleep(math.inf) + + +async def sleep_until(deadline: float) -> None: + """ + Pause the current task until the given time. + + :param deadline: the absolute time to wake up at (according to the internal monotonic clock of + the event loop) + + .. versionadded:: 3.1 + + """ + now = current_time() + await sleep(max(deadline - now, 0)) + + def current_time() -> DeprecatedAwaitableFloat: """ Return the current value of the event loop's internal clock.
agronholm/anyio
4c87f0783549b4e00a09d856fecf7b124ffb5244
diff --git a/tests/test_eventloop.py b/tests/test_eventloop.py new file mode 100644 index 0000000..1fefde7 --- /dev/null +++ b/tests/test_eventloop.py @@ -0,0 +1,37 @@ +import math +import sys + +import pytest + +from anyio import sleep_forever, sleep_until + +if sys.version_info < (3, 8): + from mock import AsyncMock +else: + from unittest.mock import AsyncMock + +pytestmark = pytest.mark.anyio +fake_current_time = 1620581544.0 + + [email protected] +def fake_sleep(mocker): + mocker.patch('anyio._core._eventloop.current_time', return_value=fake_current_time) + return mocker.patch('anyio._core._eventloop.sleep', AsyncMock()) + + +async def test_sleep_until(fake_sleep): + deadline = fake_current_time + 500.102352 + await sleep_until(deadline) + fake_sleep.assert_called_once_with(deadline - fake_current_time) + + +async def test_sleep_until_in_past(fake_sleep): + deadline = fake_current_time - 500.102352 + await sleep_until(deadline) + fake_sleep.assert_called_once_with(0) + + +async def test_sleep_forever(fake_sleep): + await sleep_forever() + fake_sleep.assert_called_once_with(math.inf)
add sleep_until() Often it's less code to use `sleep_until()` rather than `sleep()`, since it handles times in the past. example: ```python3 elapsed = trio.current_time() - t_start await trio.sleep(max(0, period - elapsed)) ``` vs. ```python3 await trio.sleep_until(t_start + period) ```
0.0
4c87f0783549b4e00a09d856fecf7b124ffb5244
[ "tests/test_eventloop.py::test_sleep_until[asyncio]", "tests/test_eventloop.py::test_sleep_until[asyncio+uvloop]", "tests/test_eventloop.py::test_sleep_until_in_past[asyncio]", "tests/test_eventloop.py::test_sleep_until_in_past[asyncio+uvloop]", "tests/test_eventloop.py::test_sleep_forever[asyncio]", "tests/test_eventloop.py::test_sleep_forever[asyncio+uvloop]" ]
[]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-05-02 11:23:38+00:00
mit
919
agronholm__anyio-307
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index 5fa0671..74435e1 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -5,6 +5,8 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. **UNRELEASED** +- Fixed ``to_thread.run_sync()`` hanging on the second call on asyncio when used with + ``loop.run_until_complete()`` - Fixed the type annotation of ``open_signal_receiver()`` as a synchronous context manager - Fixed the type annotation of ``DeprecatedAwaitable(|List|Float).__await__`` to match the ``typing.Awaitable`` protocol diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index d6c9b47..b86e568 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -136,21 +136,18 @@ _root_task: RunVar[Optional[asyncio.Task]] = RunVar('_root_task') def find_root_task() -> asyncio.Task: - try: - root_task = _root_task.get() - except LookupError: - for task in all_tasks(): - if task._callbacks: - for cb in _get_task_callbacks(task): - if (cb is _run_until_complete_cb - or getattr(cb, '__module__', None) == 'uvloop.loop'): - _root_task.set(task) - return task - - _root_task.set(None) - else: - if root_task is not None: - return root_task + root_task = _root_task.get(None) + if root_task is not None and not root_task.done(): + return root_task + + # Look for a task that has been started via run_until_complete() + for task in all_tasks(): + if task._callbacks and not task.done(): + for cb in _get_task_callbacks(task): + if (cb is _run_until_complete_cb + or getattr(cb, '__module__', None) == 'uvloop.loop'): + _root_task.set(task) + return task # Look up the topmost task in the AnyIO task tree, if possible task = cast(asyncio.Task, current_task()) @@ -791,6 +788,7 @@ async def run_sync_in_worker_thread( try: return await future finally: + assert worker.is_alive() worker.idle_since = current_time() idle_workers.append(worker)
agronholm/anyio
99ec00e67c533d4b12d2a2aff8cb6aa2b0f0344f
diff --git a/tests/test_to_thread.py b/tests/test_to_thread.py index 7530d8a..5880ab4 100644 --- a/tests/test_to_thread.py +++ b/tests/test_to_thread.py @@ -183,3 +183,15 @@ def test_asyncio_run_sync_no_asyncio_run(asyncio_event_loop: asyncio.AbstractEve asyncio_event_loop.set_exception_handler(exception_handler) asyncio_event_loop.run_until_complete(to_thread.run_sync(time.sleep, 0)) assert not exceptions + + +def test_asyncio_run_sync_multiple(asyncio_event_loop: asyncio.AbstractEventLoop) -> None: + """Regression test for #304.""" + asyncio_event_loop.call_later(0.5, asyncio_event_loop.stop) + for _ in range(3): + asyncio_event_loop.run_until_complete(to_thread.run_sync(time.sleep, 0)) + + for t in threading.enumerate(): + if t.name == 'AnyIO worker thread': + t.join(2) + assert not t.is_alive()
`anyio.to_thread.run_sync()` hangs IPython when using top-level await expressions Not sure if this is a problem with IPython, `anyio` or something else. If you launch a IPython shell, like so: ```bash $ ipython Python 3.10.0b2+ (heads/3.10:9c89d62, Jun 2 2021, 20:22:16) [GCC 10.3.0] Type 'copyright', 'credits' or 'license' for more information IPython 7.24.1 -- An enhanced Interactive Python. Type '?' for help. In [1]: ``` And paste this example in, it will run once: ```python3 from time import sleep from anyio.to_thread import run_sync def sync_func(time: float): sleep(time) print(f'Slept {time} seconds.') await run_sync(sync_func, 0.5) ``` After it finishes executing, if you await another `anyio.to_thread.run_sync()` coroutine, it will hang the session: ```python3 In [6]: await run_sync(sync_func, 0.5) ``` Here's the stacktrace when you hit Ctrl-C: ```python3 In [6]: await run_sync(sync_func, 0.5) ^C--------------------------------------------------------------------------- KeyboardInterrupt Traceback (most recent call last) ~/.pyenv/versions/3.10-dev/lib/python3.10/site-packages/IPython/core/async_helpers.py in __call__(self, coro) 26 import asyncio 27 ---> 28 return asyncio.get_event_loop().run_until_complete(coro) 29 30 def __str__(self): ~/.pyenv/versions/3.10-dev/lib/python3.10/asyncio/base_events.py in run_until_complete(self, future) 626 future.add_done_callback(_run_until_complete_cb) 627 try: --> 628 self.run_forever() 629 except: 630 if new_task and future.done() and not future.cancelled(): ~/.pyenv/versions/3.10-dev/lib/python3.10/asyncio/base_events.py in run_forever(self) 593 events._set_running_loop(self) 594 while True: --> 595 self._run_once() 596 if self._stopping: 597 break ~/.pyenv/versions/3.10-dev/lib/python3.10/asyncio/base_events.py in _run_once(self) 1843 timeout = min(max(0, when - self.time()), MAXIMUM_SELECT_TIMEOUT) 1844 -> 1845 event_list = self._selector.select(timeout) 1846 self._process_events(event_list) 1847 ~/.pyenv/versions/3.10-dev/lib/python3.10/selectors.py in select(self, timeout) 467 ready = [] 468 try: --> 469 fd_event_list = self._selector.poll(timeout, max_ev) 470 except InterruptedError: 471 return ready KeyboardInterrupt: ``` If you use [`asyncio.to_thread()`](https://docs.python.org/3/library/asyncio-task.html#asyncio.to_thread), then awaiting coroutines in succession works without a problem: ```python3 In [7]: from asyncio import to_thread In [14]: await to_thread(sync_func, 0.5) Slept 0.5 seconds. In [15]: await to_thread(sync_func, 0.5) Slept 0.5 seconds. ``` Using top-level await expression when [launching Python via `python3 -m asyncio`](https://piccolo-orm.com/blog/top-level-await-in-python/) works, though. It also happens on Python 3.9.
0.0
99ec00e67c533d4b12d2a2aff8cb6aa2b0f0344f
[ "tests/test_to_thread.py::test_asyncio_run_sync_multiple" ]
[ "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio]", "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio+uvloop]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-cancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-cancellable]", "tests/test_to_thread.py::test_asyncio_cancel_native_task[asyncio]", "tests/test_to_thread.py::test_asyncio_no_root_task", "tests/test_to_thread.py::test_asyncio_future_callback_partial", "tests/test_to_thread.py::test_asyncio_run_sync_no_asyncio_run" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2021-06-08 07:42:01+00:00
mit
920
agronholm__anyio-319
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index 57e4e92..509bd8b 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -10,6 +10,8 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. synchronous context manager) - Fixed ``to_thread.run_sync()`` hanging on the second call on asyncio when used with ``loop.run_until_complete()`` +- Fixed ``to_thread.run_sync()`` prematurely marking a worker thread inactive when a task await on + the result is cancelled - Changed the default value of the ``use_uvloop`` asyncio backend option to ``False`` to prevent unsafe event loop policy changes in different threads - Fixed the type annotation of ``open_signal_receiver()`` as a synchronous context manager diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index 11bee85..556c2b9 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -712,6 +712,16 @@ class WorkerThread(Thread): self.queue: Queue[Union[Tuple[Callable, tuple, asyncio.Future], None]] = Queue(2) self.idle_since = current_time() + def _report_result(self, future: asyncio.Future, result: Any, + exc: Optional[BaseException]) -> None: + self.idle_since = current_time() + self.idle_workers.append(self) + if not future.cancelled(): + if exc is not None: + future.set_exception(exc) + else: + future.set_result(result) + def run(self) -> None: with claim_worker_thread('asyncio'): threadlocals.loop = self.loop @@ -723,14 +733,16 @@ class WorkerThread(Thread): func, args, future = item if not future.cancelled(): + result = None + exception: Optional[BaseException] = None try: result = func(*args) except BaseException as exc: - if not self.loop.is_closed() and not future.cancelled(): - self.loop.call_soon_threadsafe(future.set_exception, exc) - else: - if not self.loop.is_closed() and not future.cancelled(): - self.loop.call_soon_threadsafe(future.set_result, result) + exception = exc + + if not self.loop.is_closed(): + self.loop.call_soon_threadsafe( + self._report_result, future, result, exception) self.queue.task_done() @@ -785,12 +797,7 @@ async def run_sync_in_worker_thread( worker.stop() worker.queue.put_nowait((func, args, future)) - try: - return await future - finally: - assert worker.is_alive() - worker.idle_since = current_time() - idle_workers.append(worker) + return await future def run_sync_from_thread(func: Callable[..., T_Retval], *args: object,
agronholm/anyio
01374b8994e4f9d2012b3509717f4281e6392131
diff --git a/tests/test_to_thread.py b/tests/test_to_thread.py index 5880ab4..2e8f011 100644 --- a/tests/test_to_thread.py +++ b/tests/test_to_thread.py @@ -2,6 +2,7 @@ import asyncio import sys import threading import time +from concurrent.futures import Future from functools import partial from typing import Any, List, NoReturn, Optional @@ -114,6 +115,22 @@ async def test_cancel_worker_thread(cancellable: bool, expected_last_active: str assert last_active == expected_last_active +async def test_cancel_wait_on_thread() -> None: + event = threading.Event() + future: Future[bool] = Future() + + def wait_event() -> None: + future.set_result(event.wait(1)) + + async with create_task_group() as tg: + tg.start_soon(partial(to_thread.run_sync, cancellable=True), wait_event) + await wait_all_tasks_blocked() + tg.cancel_scope.cancel() + + await to_thread.run_sync(event.set) + assert future.result(1) + + @pytest.mark.parametrize('anyio_backend', ['asyncio']) async def test_asyncio_cancel_native_task() -> None: task: "Optional[asyncio.Task[None]]" = None
asyncio worker threads are prematurely shut-down on SIGINT ```python import anyio import time def thread(): print("thread start", time.time()) time.sleep(5) print("thread end", time.time()) async def main(): async with anyio.create_task_group() as tg: tg.start_soon(anyio.to_thread.run_sync, thread) try: await anyio.sleep_forever() finally: await anyio.to_thread.run_sync(thread) anyio.run(main, backend="asyncio") ``` If i run this and press CTRL-C while sleeping, it does this: ``` thread start 1623770620.0201666 ^Cthread end 1623770625.0241108 thread start 1623770625.0242603 thread end 1623770630.028106 ``` with `backend="trio"` I get what I expect: ``` thread start 1623770659.6473012 ^Cthread start 1623770660.5315428 thread end 1623770664.652128 thread end 1623770665.5361295 ``` One workaround for this issue is to use a signal receiver: ```python import anyio import time import signal def thread(): print("thread start", time.time()) time.sleep(5) print("thread end", time.time()) async def main(): async with anyio.create_task_group() as tg: tg.start_soon(anyio.to_thread.run_sync, thread) try: with anyio.open_signal_receiver(signal.SIGINT) as signals: async for signum in signals: break finally: await anyio.to_thread.run_sync(thread) anyio.run(main, backend="asyncio") ``` Another workaround (which I'm using) is to spawn threads manually (`threading.Thread(...).start()`) for tear-down. Both of these are asyncio-specific workarounds, and I think that anyio `to_thread.run_sync` should behave the same if running on asyncio or trio, if possible. My use case is this is working with something that is synchronous and must use worker threads. I must call the appropriate `close()` methods on the synchronous API from a thread so as to not block my async application.
0.0
01374b8994e4f9d2012b3509717f4281e6392131
[ "tests/test_to_thread.py::test_cancel_wait_on_thread[asyncio]", "tests/test_to_thread.py::test_cancel_wait_on_thread[asyncio+uvloop]" ]
[ "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio]", "tests/test_to_thread.py::test_run_in_thread_cancelled[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio]", "tests/test_to_thread.py::test_run_in_thread_exception[asyncio+uvloop]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio]", "tests/test_to_thread.py::test_run_in_custom_limiter[asyncio+uvloop]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio-cancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-uncancellable]", "tests/test_to_thread.py::test_cancel_worker_thread[asyncio+uvloop-cancellable]", "tests/test_to_thread.py::test_asyncio_cancel_native_task[asyncio]", "tests/test_to_thread.py::test_asyncio_no_root_task", "tests/test_to_thread.py::test_asyncio_future_callback_partial", "tests/test_to_thread.py::test_asyncio_run_sync_no_asyncio_run", "tests/test_to_thread.py::test_asyncio_run_sync_multiple" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-06-17 15:31:12+00:00
mit
921
agronholm__anyio-388
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index d198c4b..d129ca3 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -3,6 +3,12 @@ Version history This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. +**UNRELEASED** + +- Fixed race condition in ``Lock`` and ``Semaphore`` classes when a task waiting on ``acquire()`` + is cancelled while another task is waiting to acquire the same primitive + (`#387 <https://github.com/agronholm/anyio/issues/387>`_) + **3.3.4** - Fixed ``BrokenResourceError`` instead of ``EndOfStream`` being raised in ``TLSStream`` when the diff --git a/src/anyio/_core/_synchronization.py b/src/anyio/_core/_synchronization.py index 6c69177..0898ea3 100644 --- a/src/anyio/_core/_synchronization.py +++ b/src/anyio/_core/_synchronization.py @@ -127,6 +127,8 @@ class Lock: except BaseException: if not event.is_set(): self._waiters.remove(token) + elif self._owner_task == task: + self.release() raise @@ -302,6 +304,8 @@ class Semaphore: except BaseException: if not event.is_set(): self._waiters.remove(event) + else: + self.release() raise else:
agronholm/anyio
2fcfe886735f790f07e72673e74e24b3a4673a7d
diff --git a/tests/test_synchronization.py b/tests/test_synchronization.py index 747ee93..1bbfa95 100644 --- a/tests/test_synchronization.py +++ b/tests/test_synchronization.py @@ -5,7 +5,7 @@ import pytest from anyio import ( CancelScope, Condition, Event, Lock, Semaphore, WouldBlock, create_task_group, to_thread, wait_all_tasks_blocked) -from anyio.abc import CapacityLimiter +from anyio.abc import CapacityLimiter, TaskStatus pytestmark = pytest.mark.anyio @@ -65,23 +65,34 @@ class TestLock: assert lock.locked() tg.start_soon(try_lock) - async def test_cancel(self) -> None: - task_started = got_lock = False + @pytest.mark.parametrize('release_first', [ + pytest.param(False, id='releaselast'), + pytest.param(True, id='releasefirst') + ]) + async def test_cancel_during_acquire(self, release_first: bool) -> None: + acquired = False - async def task() -> None: - nonlocal task_started, got_lock - task_started = True + async def task(*, task_status: TaskStatus) -> None: + nonlocal acquired + task_status.started() async with lock: - got_lock = True + acquired = True lock = Lock() async with create_task_group() as tg: - async with lock: - tg.start_soon(task) - tg.cancel_scope.cancel() + await lock.acquire() + await tg.start(task) + tg.cancel_scope.cancel() + with CancelScope(shield=True): + if release_first: + lock.release() + await wait_all_tasks_blocked() + else: + await wait_all_tasks_blocked() + lock.release() - assert task_started - assert not got_lock + assert not acquired + assert not lock.locked() async def test_statistics(self) -> None: async def waiter() -> None: @@ -282,24 +293,34 @@ class TestSemaphore: assert semaphore.value == 0 pytest.raises(WouldBlock, semaphore.acquire_nowait) - async def test_acquire_cancel(self) -> None: - local_scope = acquired = None + @pytest.mark.parametrize('release_first', [ + pytest.param(False, id='releaselast'), + pytest.param(True, id='releasefirst') + ]) + async def test_cancel_during_acquire(self, release_first: bool) -> None: + acquired = False - async def task() -> None: - nonlocal local_scope, acquired - with CancelScope() as local_scope: - async with semaphore: - acquired = True + async def task(*, task_status: TaskStatus) -> None: + nonlocal acquired + task_status.started() + async with semaphore: + acquired = True semaphore = Semaphore(1) async with create_task_group() as tg: - async with semaphore: - tg.start_soon(task) - await wait_all_tasks_blocked() - assert local_scope is not None - local_scope.cancel() + await semaphore.acquire() + await tg.start(task) + tg.cancel_scope.cancel() + with CancelScope(shield=True): + if release_first: + semaphore.release() + await wait_all_tasks_blocked() + else: + await wait_all_tasks_blocked() + semaphore.release() assert not acquired + assert semaphore.value == 1 @pytest.mark.parametrize('max_value', [2, None]) async def test_max_value(self, max_value: Optional[int]) -> None:
Potential race condition in `Lock` Hello! I'm trying to debug an issue we sometimes hit in production through httpx. We're not using anyio ourselves directly (it's regular asyncio), but httpx is based on it. I'm not 100% sure the scenario I'm documenting here is the exact issue we're seeing, but there's a good chance. The symptoms we're seeing is that a lock instance gets stuck in the locked state with a finished task still set as the owner. Here's the rough sketch, involving two tasks: Task 1: * acquires the lock Task 2: * tries acquiring the lock, fails, creates an event and starts waiting on it Task 1: * cancels Task 2, releases the lock setting the lock `_owner_task` to Task 2, gets Task 2's event and sets it Task 2: * wakes up with CancelledError on `event.wait()`, propagates it The lock `_owner_task` is still set to Task 2, rendering the lock stuck. In our production code it's not Task 1 cancelling Task 2, but aiohttp (but that's not relevant to the example). Here's a Python snippet demonstrating the problem: ``` from asyncio import CancelledError, create_task, run, sleep from contextlib import suppress from anyio import Lock async def main(): lock = Lock() async def task_b(): await sleep(0.1) # Sleep to allow task_a to set up async with lock: pass t = create_task(task_b()) async def task_a(): async with lock: await sleep(0.1) # Sleep to allow task_b to try locking t.cancel() await sleep(0.2) print(t.done()) # True print(lock._owner_task) # TaskInfo(id=4337401360, name='Task-2') await task_a() with suppress(CancelledError): await t run(main()) ``` The lock should end up in a free state, but it gets stuck being owned by `task_b`.
0.0
2fcfe886735f790f07e72673e74e24b3a4673a7d
[ "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio-releasefirst]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio+uvloop-releasefirst]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio-releasefirst]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio+uvloop-releasefirst]" ]
[ "tests/test_synchronization.py::TestLock::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestLock::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestLock::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_acquire_nowait_wouldblock[asyncio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait_wouldblock[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio-releaselast]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio+uvloop-releaselast]", "tests/test_synchronization.py::TestLock::test_statistics[asyncio]", "tests/test_synchronization.py::TestLock::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_event[asyncio]", "tests/test_synchronization.py::TestEvent::test_event[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_event_cancel[asyncio]", "tests/test_synchronization.py::TestEvent::test_event_cancel[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_statistics[asyncio]", "tests/test_synchronization.py::TestEvent::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestCondition::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestCondition::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait_wouldblock[asyncio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait_wouldblock[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_wait_cancel[asyncio]", "tests/test_synchronization.py::TestCondition::test_wait_cancel[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_statistics[asyncio]", "tests/test_synchronization.py::TestCondition::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio-releaselast]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio+uvloop-releaselast]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio-2]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio-None]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio+uvloop-2]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio+uvloop-None]", "tests/test_synchronization.py::TestSemaphore::test_max_value_exceeded[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_max_value_exceeded[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_statistics[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_acquire_race[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_race[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_type[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_type[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_value[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_value[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_limit[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_limit[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow_twice[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow_twice[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_release[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_release[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_current_default_thread_limiter[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_current_default_thread_limiter[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_statistics[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_statistics[asyncio+uvloop]" ]
{ "failed_lite_validators": [ "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2021-11-14 13:25:23+00:00
mit
922
agronholm__anyio-399
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index d275dab..df01fcf 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -3,6 +3,12 @@ Version history This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. +**UNRELEASED** + +- Fixed deadlock in synchronization primitives on asyncio which can happen if a task acquiring a + primitive is hit with a native (not AnyIO) cancellation with just the right timing, leaving the + next acquiring task waiting forever (`#398 <https://github.com/agronholm/anyio/issues/398>`_) + **3.4.0** - Added context propagation to/from worker threads in ``to_thread.run_sync()``, diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index 82df30a..43b4c91 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -1743,7 +1743,11 @@ class CapacityLimiter(BaseCapacityLimiter): self._borrowers.add(borrower) else: - await cancel_shielded_checkpoint() + try: + await cancel_shielded_checkpoint() + except BaseException: + self.release() + raise def release(self) -> None: self.release_on_behalf_of(current_task()) diff --git a/src/anyio/_core/_synchronization.py b/src/anyio/_core/_synchronization.py index 0898ea3..d75afed 100644 --- a/src/anyio/_core/_synchronization.py +++ b/src/anyio/_core/_synchronization.py @@ -134,7 +134,11 @@ class Lock: assert self._owner_task == task else: - await cancel_shielded_checkpoint() + try: + await cancel_shielded_checkpoint() + except BaseException: + self.release() + raise def acquire_nowait(self) -> None: """ @@ -309,7 +313,11 @@ class Semaphore: raise else: - await cancel_shielded_checkpoint() + try: + await cancel_shielded_checkpoint() + except BaseException: + self.release() + raise def acquire_nowait(self) -> None: """
agronholm/anyio
cb5b64cfb31af68325d94c591a04d16bae2a8d70
diff --git a/tests/test_synchronization.py b/tests/test_synchronization.py index 1bbfa95..6697fbf 100644 --- a/tests/test_synchronization.py +++ b/tests/test_synchronization.py @@ -1,3 +1,4 @@ +import asyncio from typing import Optional import pytest @@ -114,6 +115,22 @@ class TestLock: assert not lock.statistics().locked assert lock.statistics().tasks_waiting == 0 + @pytest.mark.parametrize('anyio_backend', ['asyncio']) + async def test_asyncio_deadlock(self) -> None: + """Regression test for #398.""" + lock = Lock() + + async def acquire() -> None: + async with lock: + await asyncio.sleep(0) + + loop = asyncio.get_event_loop() + task1 = loop.create_task(acquire()) + task2 = loop.create_task(acquire()) + await asyncio.sleep(0) + task1.cancel() + await asyncio.wait_for(task2, 1) + class TestEvent: async def test_event(self) -> None: @@ -363,6 +380,22 @@ class TestSemaphore: semaphore.release() pytest.raises(WouldBlock, semaphore.acquire_nowait) + @pytest.mark.parametrize('anyio_backend', ['asyncio']) + async def test_asyncio_deadlock(self) -> None: + """Regression test for #398.""" + semaphore = Semaphore(1) + + async def acquire() -> None: + async with semaphore: + await asyncio.sleep(0) + + loop = asyncio.get_event_loop() + task1 = loop.create_task(acquire()) + task2 = loop.create_task(acquire()) + await asyncio.sleep(0) + task1.cancel() + await asyncio.wait_for(task2, 1) + class TestCapacityLimiter: async def test_bad_init_type(self) -> None: @@ -465,3 +498,19 @@ class TestCapacityLimiter: assert limiter.statistics().tasks_waiting == 0 assert limiter.statistics().borrowed_tokens == 0 + + @pytest.mark.parametrize('anyio_backend', ['asyncio']) + async def test_asyncio_deadlock(self) -> None: + """Regression test for #398.""" + limiter = CapacityLimiter(1) + + async def acquire() -> None: + async with limiter: + await asyncio.sleep(0) + + loop = asyncio.get_event_loop() + task1 = loop.create_task(acquire()) + task2 = loop.create_task(acquire()) + await asyncio.sleep(0) + task1.cancel() + await asyncio.wait_for(task2, 1)
Deadlock in anyio.Lock Related to this issue in httpcore: https://github.com/encode/httpcore/issues/454 TL;DR: With the right timing, the lock **acquire** step can be cancelled and the lock remain locked for other tasks because when using the lock context manager, if the task is cancelled during the `__aenter__` , `__aexit__` is not executed. This snippet reproduces the issue: ```python import asyncio import anyio class Holder: def __init__(self): # self.lock = asyncio.Lock() self.lock = anyio.Lock() async def work(self, index): print(f"Trying to acquire {index}") async with self.lock: print(f"Doing index {index}") await asyncio.sleep(5) async def main_anyio(): holder = Holder() t1 = asyncio.create_task(holder.work(1), name="holder 1") t2 = asyncio.create_task(holder.work(2), name="holder 2") print("Tasks created") await asyncio.sleep(0) print("Cancelling t1") t1.cancel() print("Waiting for t2") await asyncio.gather(t2) if __name__ == "__main__": asyncio.run(main_anyio()) ``` The issue goes away when using `asyncio.Lock` because that lock context manager never blocks during the acquire step. Even if the `__aenter__` method in `asyncio.Lock` is asynchronous, no asynchronous code is executed there.
0.0
cb5b64cfb31af68325d94c591a04d16bae2a8d70
[ "tests/test_synchronization.py::TestLock::test_asyncio_deadlock[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_asyncio_deadlock[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_asyncio_deadlock[asyncio]" ]
[ "tests/test_synchronization.py::TestLock::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestLock::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestLock::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_acquire_nowait_wouldblock[asyncio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait_wouldblock[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio-releaselast]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio-releasefirst]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio+uvloop-releaselast]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio+uvloop-releasefirst]", "tests/test_synchronization.py::TestLock::test_statistics[asyncio]", "tests/test_synchronization.py::TestLock::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_event[asyncio]", "tests/test_synchronization.py::TestEvent::test_event[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_event_cancel[asyncio]", "tests/test_synchronization.py::TestEvent::test_event_cancel[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_statistics[asyncio]", "tests/test_synchronization.py::TestEvent::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestCondition::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestCondition::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait_wouldblock[asyncio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait_wouldblock[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_wait_cancel[asyncio]", "tests/test_synchronization.py::TestCondition::test_wait_cancel[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_statistics[asyncio]", "tests/test_synchronization.py::TestCondition::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio-releaselast]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio-releasefirst]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio+uvloop-releaselast]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio+uvloop-releasefirst]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio-2]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio-None]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio+uvloop-2]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio+uvloop-None]", "tests/test_synchronization.py::TestSemaphore::test_max_value_exceeded[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_max_value_exceeded[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_statistics[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_acquire_race[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_race[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_type[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_type[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_value[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_value[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_limit[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_limit[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow_twice[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow_twice[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_release[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_release[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_current_default_thread_limiter[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_current_default_thread_limiter[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_statistics[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_statistics[asyncio+uvloop]" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-12-08 21:54:00+00:00
mit
923
agronholm__anyio-402
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index df01fcf..afc4b92 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -5,6 +5,7 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. **UNRELEASED** +- Added ``start_new_session`` keyword argument to ``run_process()`` and ``open_process()``. - Fixed deadlock in synchronization primitives on asyncio which can happen if a task acquiring a primitive is hit with a native (not AnyIO) cancellation with just the right timing, leaving the next acquiring task waiting forever (`#398 <https://github.com/agronholm/anyio/issues/398>`_) diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index 4cb5f3b..f2929b4 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -946,16 +946,18 @@ class Process(abc.Process): async def open_process(command: Union[str, Sequence[str]], *, shell: bool, stdin: int, stdout: int, stderr: int, cwd: Union[str, bytes, PathLike, None] = None, - env: Optional[Mapping[str, str]] = None) -> Process: + env: Optional[Mapping[str, str]] = None, + start_new_session: bool = False) -> Process: await checkpoint() if shell: process = await asyncio.create_subprocess_shell( command, stdin=stdin, stdout=stdout, # type: ignore[arg-type] - stderr=stderr, cwd=cwd, env=env, + stderr=stderr, cwd=cwd, env=env, start_new_session=start_new_session, ) else: process = await asyncio.create_subprocess_exec(*command, stdin=stdin, stdout=stdout, - stderr=stderr, cwd=cwd, env=env) + stderr=stderr, cwd=cwd, env=env, + start_new_session=start_new_session) stdin_stream = StreamWriterWrapper(process.stdin) if process.stdin else None stdout_stream = StreamReaderWrapper(process.stdout) if process.stdout else None diff --git a/src/anyio/_backends/_trio.py b/src/anyio/_backends/_trio.py index 34c65a5..440e54f 100644 --- a/src/anyio/_backends/_trio.py +++ b/src/anyio/_backends/_trio.py @@ -318,9 +318,11 @@ class Process(abc.Process): async def open_process(command: Union[str, Sequence[str]], *, shell: bool, stdin: int, stdout: int, stderr: int, cwd: Union[str, bytes, PathLike, None] = None, - env: Optional[Mapping[str, str]] = None) -> Process: + env: Optional[Mapping[str, str]] = None, + start_new_session: bool = False) -> Process: process = await trio_open_process(command, stdin=stdin, stdout=stdout, stderr=stderr, - shell=shell, cwd=cwd, env=env) + shell=shell, cwd=cwd, env=env, + start_new_session=start_new_session) stdin_stream = SendStreamWrapper(process.stdin) if process.stdin else None stdout_stream = ReceiveStreamWrapper(process.stdout) if process.stdout else None stderr_stream = ReceiveStreamWrapper(process.stderr) if process.stderr else None diff --git a/src/anyio/_core/_subprocesses.py b/src/anyio/_core/_subprocesses.py index 832184f..f4ae139 100644 --- a/src/anyio/_core/_subprocesses.py +++ b/src/anyio/_core/_subprocesses.py @@ -11,7 +11,8 @@ from ._tasks import create_task_group async def run_process(command: Union[str, Sequence[str]], *, input: Optional[bytes] = None, stdout: int = PIPE, stderr: int = PIPE, check: bool = True, cwd: Union[str, bytes, 'PathLike[str]', None] = None, - env: Optional[Mapping[str, str]] = None) -> 'CompletedProcess[bytes]': + env: Optional[Mapping[str, str]] = None, start_new_session: bool = False, + ) -> 'CompletedProcess[bytes]': """ Run an external command in a subprocess and wait until it completes. @@ -28,6 +29,8 @@ async def run_process(command: Union[str, Sequence[str]], *, input: Optional[byt :param cwd: If not ``None``, change the working directory to this before running the command :param env: if not ``None``, this mapping replaces the inherited environment variables from the parent process + :param start_new_session: if ``true`` the setsid() system call will be made in the child + process prior to the execution of the subprocess. (POSIX only) :return: an object representing the completed process :raises ~subprocess.CalledProcessError: if ``check`` is ``True`` and the process exits with a nonzero return code @@ -41,7 +44,8 @@ async def run_process(command: Union[str, Sequence[str]], *, input: Optional[byt stream_contents[index] = buffer.getvalue() async with await open_process(command, stdin=PIPE if input else DEVNULL, stdout=stdout, - stderr=stderr, cwd=cwd, env=env) as process: + stderr=stderr, cwd=cwd, env=env, + start_new_session=start_new_session) as process: stream_contents: List[Optional[bytes]] = [None, None] try: async with create_task_group() as tg: @@ -68,7 +72,8 @@ async def run_process(command: Union[str, Sequence[str]], *, input: Optional[byt async def open_process(command: Union[str, Sequence[str]], *, stdin: int = PIPE, stdout: int = PIPE, stderr: int = PIPE, cwd: Union[str, bytes, 'PathLike[str]', None] = None, - env: Optional[Mapping[str, str]] = None) -> Process: + env: Optional[Mapping[str, str]] = None, + start_new_session: bool = False) -> Process: """ Start an external command in a subprocess. @@ -83,9 +88,12 @@ async def open_process(command: Union[str, Sequence[str]], *, stdin: int = PIPE, :param cwd: If not ``None``, the working directory is changed before executing :param env: If env is not ``None``, it must be a mapping that defines the environment variables for the new process + :param start_new_session: if ``true`` the setsid() system call will be made in the child + process prior to the execution of the subprocess. (POSIX only) :return: an asynchronous process object """ shell = isinstance(command, str) return await get_asynclib().open_process(command, shell=shell, stdin=stdin, stdout=stdout, - stderr=stderr, cwd=cwd, env=env) + stderr=stderr, cwd=cwd, env=env, + start_new_session=start_new_session)
agronholm/anyio
59ae37602bf0b26f069bc9b7e997af3574ee877a
diff --git a/tests/test_subprocesses.py b/tests/test_subprocesses.py index 7402cbf..13b3936 100644 --- a/tests/test_subprocesses.py +++ b/tests/test_subprocesses.py @@ -85,3 +85,17 @@ async def test_process_env() -> None: cmd = [sys.executable, "-c", "import os; print(os.environ['foo'])"] result = await run_process(cmd, env=env) assert result.stdout.decode().strip() == env["foo"] + + [email protected](platform.system() == 'Windows', + reason='Windows does not have os.getsid()') +async def test_process_new_session_sid() -> None: + """Test that start_new_session is successfully passed to the subprocess implementation""" + sid = os.getsid(os.getpid()) + cmd = [sys.executable, "-c", "import os; print(os.getsid(os.getpid()))"] + + result = await run_process(cmd) + assert result.stdout.decode().strip() == str(sid) + + result = await run_process(cmd, start_new_session=True) + assert result.stdout.decode().strip() != str(sid)
Sub-processes get SIGINT before cancellation when signal receiver is used Maybe I'm doing something very silly here. What I'm trying to do is catch SIGINT and schedule cancellation of tasks (some running sub-processes) later. My example script below runs `bash -c "trap 'echo SIGINT CAUGHT' INT; sleep 100"` so that it will print `SIGINT CAUGHT` to stodut when it receives the signal and exits. `open_process_callback_output()` is used to immediately print stdout from this process for debug sake. ```python from contextlib import asynccontextmanager import signal import subprocess import time import anyio from anyio.streams.text import TextReceiveStream @asynccontextmanager async def open_process_callback_output(cmd, on_stdout = None, on_stderr = None): """ Open a process and if defined, call `on_stdout` for each line of stdout, and `on_stderr` for each line of stderr. """ async def process_output(stream, func) -> None: async for text in TextReceiveStream(stream): for line in text.splitlines(): func(line) proc = await anyio.open_process(cmd, stdout=PIPE, stderr=PIPE) async with anyio.create_task_group() as task_group: if on_stdout is not None: task_group.start_soon(process_output, proc.stdout, on_stdout) if on_stderr is not None: task_group.start_soon(process_output, proc.stderr, on_stderr) yield proc async def task(): async with open_process_callback_output('''bash -c "trap 'echo SIGINT CAUGHT' INT; sleep 100"''', on_stdout=lambda text: print(time.time(), f"\tstdout: {text}")) as proc: try: print(time.time(), "\ttask: waiting") await proc.wait() except anyio.get_cancelled_exc_class(): print(time.time(), "\ttask: cancelled") raise finally: print(time.time(), "\ttask: done") async def main(): async def signal_handler(): with anyio.open_signal_receiver(signal.SIGINT) as signals: async for signum in signals: print(time.time(), "\tsignal_handler: Got signal, cancel in 1 sec") await anyio.sleep(1) print(time.time(), "\tsignal_handler: cancelling") task_group.cancel_scope.cancel() async with anyio.create_task_group() as task_group: task_group.start_soon(task) task_group.start_soon(signal_handler) print("asyncio") anyio.run(main, backend='asyncio') print("\ntrio") anyio.run(main, backend='trio') ``` When I run this script and press CTRL-C after `task: waiting` is printed, I get: ``` asyncio 1639779714.8087683 task: waiting ^C1639779716.5815845 signal_handler: Got signal, cancel in 1 sec 1639779716.5836995 stdout: SIGINT CAUGHT 1639779716.5879638 task: done 1639779717.584897 signal_handler: cancelling trio 1639779717.951388 task: waiting ^C1639779718.873392 stdout: SIGINT CAUGHT 1639779718.8739002 signal_handler: Got signal, cancel in 1 sec 1639779718.8772044 task: done 1639779719.8766265 signal_handler: cancelling ``` This shows that for both asyncio and trio, the process receives a signal before the `signal_handler` task and thus the bash script exits. Soon after, the `task` coroutine exits (via `finally:`) without going through cancellation. What I'd expect to happen is that SIGINT/CTRL-C would be caught by the signal handler and not immediately passed to the process. Then, a second later the task would be cancelled, the process terminated, and so on. For example: ``` asyncio 1639779714.8087683 task: waiting ^C1639779716.5815845 signal_handler: Got signal, cancel in 1 sec 1639779717.584897 signal_handler: cancelling 1639779717.5856995 stdout: SIGINT CAUGHT 1639779716.5879638 task: cancelled 1639779716.5879638 task: done trio 1639779714.8087683 task: waiting ^C1639779716.5815845 signal_handler: Got signal, cancel in 1 sec 1639779717.584897 signal_handler: cancelling 1639779717.5856995 stdout: SIGINT CAUGHT 1639779716.5879638 task: cancelled 1639779716.5879638 task: done ```
0.0
59ae37602bf0b26f069bc9b7e997af3574ee877a
[ "tests/test_subprocesses.py::test_process_new_session_sid[asyncio]", "tests/test_subprocesses.py::test_process_new_session_sid[asyncio+uvloop]" ]
[ "tests/test_subprocesses.py::test_run_process[asyncio-shell]", "tests/test_subprocesses.py::test_run_process[asyncio-exec]", "tests/test_subprocesses.py::test_run_process[asyncio+uvloop-shell]", "tests/test_subprocesses.py::test_run_process[asyncio+uvloop-exec]", "tests/test_subprocesses.py::test_run_process_checked[asyncio]", "tests/test_subprocesses.py::test_run_process_checked[asyncio+uvloop]", "tests/test_subprocesses.py::test_terminate[asyncio]", "tests/test_subprocesses.py::test_terminate[asyncio+uvloop]", "tests/test_subprocesses.py::test_process_cwd[asyncio]", "tests/test_subprocesses.py::test_process_cwd[asyncio+uvloop]", "tests/test_subprocesses.py::test_process_env[asyncio]", "tests/test_subprocesses.py::test_process_env[asyncio+uvloop]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-12-17 23:16:17+00:00
mit
924
agronholm__anyio-604
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index 5ed601d..a7c5073 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -18,6 +18,10 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. - Re-added the ``item_type`` argument to ``create_memory_object_stream()`` (but using it raises a deprecation warning and does nothing with regards to the static types of the returned streams) +- Fixed processes spawned by ``anyio.to_process()`` being "lost" as unusable to the + process pool when processes that have idled over 5 minutes are pruned at part of the + ``to_process.run_sync()`` call, leading to increased memory consumption + (PR by Anael Gorfinkel) **4.0.0rc1** diff --git a/src/anyio/to_process.py b/src/anyio/to_process.py index dcfda5a..f3ccef5 100644 --- a/src/anyio/to_process.py +++ b/src/anyio/to_process.py @@ -118,14 +118,14 @@ async def run_sync( if now - idle_workers[0][1] < WORKER_MAX_IDLE_TIME: break - process, idle_since = idle_workers.popleft() - process.kill() - workers.remove(process) - killed_processes.append(process) + process_to_kill, idle_since = idle_workers.popleft() + process_to_kill.kill() + workers.remove(process_to_kill) + killed_processes.append(process_to_kill) with CancelScope(shield=True): - for process in killed_processes: - await process.aclose() + for killed_process in killed_processes: + await killed_process.aclose() break
agronholm/anyio
969f1884a335057c83ac2d5b59e4fa853f1f2491
diff --git a/tests/test_to_process.py b/tests/test_to_process.py index 4c6507d..ac0b4b5 100644 --- a/tests/test_to_process.py +++ b/tests/test_to_process.py @@ -5,6 +5,7 @@ import platform import sys import time from functools import partial +from unittest.mock import Mock import pytest @@ -15,6 +16,7 @@ from anyio import ( to_process, wait_all_tasks_blocked, ) +from anyio.abc import Process pytestmark = pytest.mark.anyio @@ -95,3 +97,30 @@ async def test_cancel_during() -> None: # The previous worker was killed so we should get a new one now assert await to_process.run_sync(os.getpid) != worker_pid + + +async def test_exec_while_pruning() -> None: + """ + Test that in the case when one or more idle workers are pruned, the originally + selected idle worker is re-added to the queue of idle workers. + """ + + worker_pid1 = await to_process.run_sync(os.getpid) + workers = to_process._process_pool_workers.get() + idle_workers = to_process._process_pool_idle_workers.get() + real_worker = next(iter(workers)) + + fake_idle_process = Mock(Process) + workers.add(fake_idle_process) + try: + # Add a mock worker process that's guaranteed to be eligible for pruning + idle_workers.appendleft( + (fake_idle_process, -to_process.WORKER_MAX_IDLE_TIME - 1) + ) + + worker_pid2 = await to_process.run_sync(os.getpid) + assert worker_pid1 == worker_pid2 + fake_idle_process.kill.assert_called_once_with() + assert idle_workers[0][0] is real_worker + finally: + workers.discard(fake_idle_process)
to_process.run_sync() causing high memory usage and exceeding defined process limit ### Things to check first - [X] I have searched the existing issues and didn't find my bug already reported there - [X] I have checked that my bug is still present in the latest release ### AnyIO version 3.7.0 ### Python version 3.10.11 ### What happened? I encountered an issue while utilizing `to_process.run_sync()` in conjunction with a process pool. The problem arises when the process pool loses track of instances, leading to excessive memory consumption. In my scenario, I needed to execute a CPU-intensive task asynchronously multiple times at unspecified intervals. Recognizing the overhead involved in process creation, I turned to the solution of maintaining a process pool. I implemented your provided code with the following parameters: 1. The capacity limiter was set to the number of available CPUs (I used 16 CPUs). 2. The CPU-intensive task was run multiple times (over 100). 3. Uncertainty of when the CPU-intensive task would be invoked. 4. The CPU-intensive task utilizes 1GB of memory by default. While I built my code upon your process pool maintenance solutions, I encountered a noticeable surge in memory consumption. Additionally, I observed that the count of active processes surpassed the limit I had set (exceeding 30 processes). Assumption Regarding the Root Cause: Upon investigating your code, I've observed that the issue may be related to AnyIO losing the process pointer while identifying idle processes that are meant to be terminated. Following my investigation, I engaged with your code locally and successfully resolved the problem. The code now functions as intended. ### How can we reproduce the bug? ``` from time import sleep import anyio import psutil from anyio import to_process from anyio._backends._asyncio import CapacityLimiter from anyio.to_process import WORKER_MAX_IDLE_TIME def cpu_intensive_callable() -> None: sleep(WORKER_MAX_IDLE_TIME + 5) # 5 minutes + 5 seconds class CpuIntensiveClass: async def cpu_intensive_method(self, capacity_limiter: CapacityLimiter) -> None: print("Running cpu intensive method") await to_process.run_sync(cpu_intensive_callable, cancellable=True, limiter=capacity_limiter) async def main() -> None: capacity_limiter = CapacityLimiter(total_tokens=2) # limit the number of concurrent processes to 2 cpu_intensive_class = CpuIntensiveClass() for _ in range(10): await cpu_intensive_class.cpu_intensive_method(capacity_limiter) print(f"Running python processes number is {sum(1 for p in psutil.process_iter(['pid', 'name']) if 'python' in str(p.name).lower())}") if __name__ == "__main__": anyio.run(main) ``` Notice that I used psutil package in order to track the current number of python processes.
0.0
969f1884a335057c83ac2d5b59e4fa853f1f2491
[ "tests/test_to_process.py::test_exec_while_pruning[asyncio]", "tests/test_to_process.py::test_exec_while_pruning[asyncio+uvloop]", "tests/test_to_process.py::test_exec_while_pruning[trio]" ]
[ "tests/test_to_process.py::test_run_sync_in_process_pool[asyncio]", "tests/test_to_process.py::test_run_sync_in_process_pool[asyncio+uvloop]", "tests/test_to_process.py::test_run_sync_in_process_pool[trio]", "tests/test_to_process.py::test_identical_sys_path[asyncio]", "tests/test_to_process.py::test_identical_sys_path[asyncio+uvloop]", "tests/test_to_process.py::test_identical_sys_path[trio]", "tests/test_to_process.py::test_partial[asyncio]", "tests/test_to_process.py::test_partial[asyncio+uvloop]", "tests/test_to_process.py::test_partial[trio]", "tests/test_to_process.py::test_exception[asyncio]", "tests/test_to_process.py::test_exception[asyncio+uvloop]", "tests/test_to_process.py::test_exception[trio]", "tests/test_to_process.py::test_print[asyncio]", "tests/test_to_process.py::test_print[asyncio+uvloop]", "tests/test_to_process.py::test_print[trio]", "tests/test_to_process.py::test_cancel_before[asyncio]", "tests/test_to_process.py::test_cancel_before[asyncio+uvloop]", "tests/test_to_process.py::test_cancel_before[trio]", "tests/test_to_process.py::test_cancel_during[asyncio]", "tests/test_to_process.py::test_cancel_during[asyncio+uvloop]", "tests/test_to_process.py::test_cancel_during[trio]" ]
{ "failed_lite_validators": [ "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2023-08-22 12:38:05+00:00
mit
928
agronholm__anyio-647
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index af625fd..78ef510 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -11,6 +11,8 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. - Fixed adjusting the total number of tokens in a ``CapacityLimiter`` on asyncio failing to wake up tasks waiting to acquire the limiter in certain edge cases (fixed with help from Egor Blagov) +- Fixed ``loop_factory`` and ``use_uvloop`` options not being used on the asyncio + backend (`#643 <https://github.com/agronholm/anyio/issues/643>`_) **4.1.0** diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index 7a10e17..bb6a9bf 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -16,7 +16,6 @@ from asyncio import ( get_running_loop, sleep, ) -from asyncio import run as native_run from asyncio.base_events import _run_until_complete_cb # type: ignore[attr-defined] from collections import OrderedDict, deque from collections.abc import AsyncIterator, Generator, Iterable @@ -165,7 +164,7 @@ else: if context is None: context = self._context - task = self._loop.create_task(coro, context=context) + task = context.run(self._loop.create_task, coro) if ( threading.current_thread() is threading.main_thread() @@ -1950,9 +1949,14 @@ class AsyncIOBackend(AsyncBackend): del _task_states[task] debug = options.get("debug", False) - options.get("loop_factory", None) - options.get("use_uvloop", False) - return native_run(wrapper(), debug=debug) + loop_factory = options.get("loop_factory", None) + if loop_factory is None and options.get("use_uvloop", False): + import uvloop + + loop_factory = uvloop.new_event_loop + + with Runner(debug=debug, loop_factory=loop_factory) as runner: + return runner.run(wrapper()) @classmethod def current_token(cls) -> object:
agronholm/anyio
b429c1a3202dd3eff2eaad0124b327b3cad15b01
diff --git a/tests/test_eventloop.py b/tests/test_eventloop.py index c0c8ab5..73ad0c2 100644 --- a/tests/test_eventloop.py +++ b/tests/test_eventloop.py @@ -2,6 +2,7 @@ from __future__ import annotations import asyncio import math +from asyncio import get_running_loop from unittest.mock import AsyncMock import pytest @@ -44,3 +45,32 @@ def test_run_task() -> None: result = run(asyncio.create_task, async_add(1, 2), backend="asyncio") assert result == 3 + + +class TestAsyncioOptions: + def test_debug(self) -> None: + async def main() -> bool: + return get_running_loop().get_debug() + + debug = run(main, backend="asyncio", backend_options={"debug": True}) + assert debug is True + + def test_loop_factory(self) -> None: + async def main() -> type: + return type(get_running_loop()) + + uvloop = pytest.importorskip("uvloop", reason="uvloop not installed") + loop_class = run( + main, + backend="asyncio", + backend_options={"loop_factory": uvloop.new_event_loop}, + ) + assert issubclass(loop_class, uvloop.Loop) + + def test_use_uvloop(self) -> None: + async def main() -> type: + return type(get_running_loop()) + + uvloop = pytest.importorskip("uvloop", reason="uvloop not installed") + loop_class = run(main, backend="asyncio", backend_options={"use_uvloop": True}) + assert issubclass(loop_class, uvloop.Loop)
Backend specific options don't appear to be used ### Things to check first - [X] I have searched the existing issues and didn't find my bug already reported there - [X] I have checked that my bug is still present in the latest release ### AnyIO version 4.1.0 ### Python version 3.11 ### What happened? As best as I can tell, the backend specific options for both the asyncio and trio options aren't being used https://github.com/agronholm/anyio/blob/cc18942a384dcb881e78a81c898d7e89d4e1ce0b/src/anyio/_backends/_asyncio.py#L1939-L1960 https://github.com/agronholm/anyio/blob/cc18942a384dcb881e78a81c898d7e89d4e1ce0b/src/anyio/_backends/_trio.py#L807-L814 ### How can we reproduce the bug? I'm sorry if I'm missing something, but the backend options don't appear to be used, except for `debug` for asyncio. I don't have a test case, however, so, I apologize again if I'm not seeing how the options are getting applied.
0.0
b429c1a3202dd3eff2eaad0124b327b3cad15b01
[ "tests/test_eventloop.py::TestAsyncioOptions::test_loop_factory", "tests/test_eventloop.py::TestAsyncioOptions::test_use_uvloop" ]
[ "tests/test_eventloop.py::test_sleep_until[asyncio]", "tests/test_eventloop.py::test_sleep_until[asyncio+uvloop]", "tests/test_eventloop.py::test_sleep_until[trio]", "tests/test_eventloop.py::test_sleep_until_in_past[asyncio]", "tests/test_eventloop.py::test_sleep_until_in_past[asyncio+uvloop]", "tests/test_eventloop.py::test_sleep_until_in_past[trio]", "tests/test_eventloop.py::test_sleep_forever[asyncio]", "tests/test_eventloop.py::test_sleep_forever[asyncio+uvloop]", "tests/test_eventloop.py::test_sleep_forever[trio]", "tests/test_eventloop.py::test_run_task", "tests/test_eventloop.py::TestAsyncioOptions::test_debug" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2023-12-09 11:07:58+00:00
mit
929
agronholm__anyio-666
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index 5f6500b..5d39e45 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -7,6 +7,9 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. - Added support for the Python 3.12 ``walk_up`` keyword argument in ``anyio.Path.relative_to()`` (PR by Colin Taylor) +- Fixed passing ``total_tokens`` to ``anyio.CapacityLimiter()`` as a keyword argument + not working on the ``trio`` backend + (`#515 <https://github.com/agronholm/anyio/issues/515>`_) **4.2.0** diff --git a/src/anyio/_backends/_trio.py b/src/anyio/_backends/_trio.py index a0d14c7..13b960f 100644 --- a/src/anyio/_backends/_trio.py +++ b/src/anyio/_backends/_trio.py @@ -631,14 +631,24 @@ class Event(BaseEvent): class CapacityLimiter(BaseCapacityLimiter): def __new__( - cls, *args: Any, original: trio.CapacityLimiter | None = None + cls, + total_tokens: float | None = None, + *, + original: trio.CapacityLimiter | None = None, ) -> CapacityLimiter: return object.__new__(cls) def __init__( - self, *args: Any, original: trio.CapacityLimiter | None = None + self, + total_tokens: float | None = None, + *, + original: trio.CapacityLimiter | None = None, ) -> None: - self.__original = original or trio.CapacityLimiter(*args) + if original is not None: + self.__original = original + else: + assert total_tokens is not None + self.__original = trio.CapacityLimiter(total_tokens) async def __aenter__(self) -> None: return await self.__original.__aenter__()
agronholm/anyio
6c70118450b97b6088046d5e71f6a90836ddbc04
diff --git a/tests/test_synchronization.py b/tests/test_synchronization.py index 5eddc06..d6f68f6 100644 --- a/tests/test_synchronization.py +++ b/tests/test_synchronization.py @@ -689,3 +689,8 @@ class TestCapacityLimiter: backend=anyio_backend_name, backend_options=anyio_backend_options, ) + + async def test_total_tokens_as_kwarg(self) -> None: + # Regression test for #515 + limiter = CapacityLimiter(total_tokens=1) + assert limiter.total_tokens == 1
On `trio` backend, `CapacityLimiter` does not take keyword arguments MWE: ``` import anyio async def test(): lim = anyio.CapacityLimiter(total_tokens=1) async with lim: await anyio.sleep(0.5) with anyio.start_blocking_portal(backend="trio") as portal: portal.start_task_soon(test).result() ``` fails with `TypeError: CapacityLimiter.__init__() got an unexpected keyword argument 'total_tokens'`. This doesn't happen when supplying the tokens as positional arguments or when using the `asyncio` backend.
0.0
6c70118450b97b6088046d5e71f6a90836ddbc04
[ "tests/test_synchronization.py::TestCapacityLimiter::test_total_tokens_as_kwarg[trio]" ]
[ "tests/test_synchronization.py::TestLock::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestLock::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_contextmanager[trio]", "tests/test_synchronization.py::TestLock::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestLock::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_manual_acquire[trio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_acquire_nowait[trio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait_wouldblock[asyncio]", "tests/test_synchronization.py::TestLock::test_acquire_nowait_wouldblock[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_acquire_nowait_wouldblock[trio]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio-releaselast]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio-releasefirst]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio+uvloop-releaselast]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[asyncio+uvloop-releasefirst]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[trio-releaselast]", "tests/test_synchronization.py::TestLock::test_cancel_during_acquire[trio-releasefirst]", "tests/test_synchronization.py::TestLock::test_statistics[asyncio]", "tests/test_synchronization.py::TestLock::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_statistics[trio]", "tests/test_synchronization.py::TestLock::test_asyncio_deadlock[asyncio]", "tests/test_synchronization.py::TestLock::test_instantiate_outside_event_loop[asyncio]", "tests/test_synchronization.py::TestLock::test_instantiate_outside_event_loop[asyncio+uvloop]", "tests/test_synchronization.py::TestLock::test_instantiate_outside_event_loop[trio]", "tests/test_synchronization.py::TestEvent::test_event[asyncio]", "tests/test_synchronization.py::TestEvent::test_event[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_event[trio]", "tests/test_synchronization.py::TestEvent::test_event_cancel[asyncio]", "tests/test_synchronization.py::TestEvent::test_event_cancel[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_event_cancel[trio]", "tests/test_synchronization.py::TestEvent::test_event_wait_before_set_before_cancel[asyncio]", "tests/test_synchronization.py::TestEvent::test_event_wait_before_set_before_cancel[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_event_wait_before_set_before_cancel[trio]", "tests/test_synchronization.py::TestEvent::test_statistics[asyncio]", "tests/test_synchronization.py::TestEvent::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_statistics[trio]", "tests/test_synchronization.py::TestEvent::test_instantiate_outside_event_loop[asyncio]", "tests/test_synchronization.py::TestEvent::test_instantiate_outside_event_loop[asyncio+uvloop]", "tests/test_synchronization.py::TestEvent::test_instantiate_outside_event_loop[trio]", "tests/test_synchronization.py::TestCondition::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestCondition::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_contextmanager[trio]", "tests/test_synchronization.py::TestCondition::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestCondition::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_manual_acquire[trio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait[trio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait_wouldblock[asyncio]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait_wouldblock[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_acquire_nowait_wouldblock[trio]", "tests/test_synchronization.py::TestCondition::test_wait_cancel[asyncio]", "tests/test_synchronization.py::TestCondition::test_wait_cancel[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_wait_cancel[trio]", "tests/test_synchronization.py::TestCondition::test_statistics[asyncio]", "tests/test_synchronization.py::TestCondition::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_statistics[trio]", "tests/test_synchronization.py::TestCondition::test_instantiate_outside_event_loop[asyncio]", "tests/test_synchronization.py::TestCondition::test_instantiate_outside_event_loop[asyncio+uvloop]", "tests/test_synchronization.py::TestCondition::test_instantiate_outside_event_loop[trio]", "tests/test_synchronization.py::TestSemaphore::test_contextmanager[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_contextmanager[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_contextmanager[trio]", "tests/test_synchronization.py::TestSemaphore::test_manual_acquire[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_manual_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_manual_acquire[trio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_nowait[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_nowait[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_acquire_nowait[trio]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio-releaselast]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio-releasefirst]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio+uvloop-releaselast]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[asyncio+uvloop-releasefirst]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[trio-releaselast]", "tests/test_synchronization.py::TestSemaphore::test_cancel_during_acquire[trio-releasefirst]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio-2]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio-None]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio+uvloop-2]", "tests/test_synchronization.py::TestSemaphore::test_max_value[asyncio+uvloop-None]", "tests/test_synchronization.py::TestSemaphore::test_max_value[trio-2]", "tests/test_synchronization.py::TestSemaphore::test_max_value[trio-None]", "tests/test_synchronization.py::TestSemaphore::test_max_value_exceeded[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_max_value_exceeded[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_max_value_exceeded[trio]", "tests/test_synchronization.py::TestSemaphore::test_statistics[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_statistics[trio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_race[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_acquire_race[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_acquire_race[trio]", "tests/test_synchronization.py::TestSemaphore::test_asyncio_deadlock[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_instantiate_outside_event_loop[asyncio]", "tests/test_synchronization.py::TestSemaphore::test_instantiate_outside_event_loop[asyncio+uvloop]", "tests/test_synchronization.py::TestSemaphore::test_instantiate_outside_event_loop[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_type[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_type[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_type[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_value[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_value[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_init_value[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_limit[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_limit[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_limit[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow_twice[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow_twice[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_borrow_twice[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_release[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_release[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_bad_release[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_current_default_thread_limiter[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_current_default_thread_limiter[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_current_default_thread_limiter[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_statistics[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_statistics[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_statistics[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_asyncio_deadlock[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_ordered_queue[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_ordered_queue[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_ordered_queue[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens_lets_others_acquire[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens_lets_others_acquire[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_increase_tokens_lets_others_acquire[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_instantiate_outside_event_loop[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_instantiate_outside_event_loop[asyncio+uvloop]", "tests/test_synchronization.py::TestCapacityLimiter::test_instantiate_outside_event_loop[trio]", "tests/test_synchronization.py::TestCapacityLimiter::test_total_tokens_as_kwarg[asyncio]", "tests/test_synchronization.py::TestCapacityLimiter::test_total_tokens_as_kwarg[asyncio+uvloop]" ]
{ "failed_lite_validators": [ "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2024-01-08 22:44:22+00:00
mit
930
agronholm__anyio-672
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index 5d39e45..db3dcb6 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -10,6 +10,18 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. - Fixed passing ``total_tokens`` to ``anyio.CapacityLimiter()`` as a keyword argument not working on the ``trio`` backend (`#515 <https://github.com/agronholm/anyio/issues/515>`_) +- Fixed ``Process.aclose()`` not performing the minimum level of necessary cleanup when + cancelled. Previously: + + - Cancellation of ``Process.aclose()`` could leak an orphan process + - Cancellation of ``run_process()`` could very briefly leak an orphan process. + - Cancellation of ``Process.aclose()`` or ``run_process()`` on Trio could leave + standard streams unclosed + + (PR by Ganden Schaffner) +- Fixed ``Process.stdin.aclose()``, ``Process.stdout.aclose()``, and + ``Process.stderr.aclose()`` not including a checkpoint on asyncio (PR by Ganden + Schaffner) **4.2.0** diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index e884f56..2699bf8 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -918,6 +918,7 @@ class StreamReaderWrapper(abc.ByteReceiveStream): async def aclose(self) -> None: self._stream.feed_eof() + await AsyncIOBackend.checkpoint() @dataclass(eq=False) @@ -930,6 +931,7 @@ class StreamWriterWrapper(abc.ByteSendStream): async def aclose(self) -> None: self._stream.close() + await AsyncIOBackend.checkpoint() @dataclass(eq=False) @@ -940,14 +942,22 @@ class Process(abc.Process): _stderr: StreamReaderWrapper | None async def aclose(self) -> None: - if self._stdin: - await self._stdin.aclose() - if self._stdout: - await self._stdout.aclose() - if self._stderr: - await self._stderr.aclose() - - await self.wait() + with CancelScope(shield=True): + if self._stdin: + await self._stdin.aclose() + if self._stdout: + await self._stdout.aclose() + if self._stderr: + await self._stderr.aclose() + + try: + await self.wait() + except BaseException: + self.kill() + with CancelScope(shield=True): + await self.wait() + + raise async def wait(self) -> int: return await self._process.wait() diff --git a/src/anyio/_backends/_trio.py b/src/anyio/_backends/_trio.py index 13b960f..1a47192 100644 --- a/src/anyio/_backends/_trio.py +++ b/src/anyio/_backends/_trio.py @@ -283,14 +283,21 @@ class Process(abc.Process): _stderr: abc.ByteReceiveStream | None async def aclose(self) -> None: - if self._stdin: - await self._stdin.aclose() - if self._stdout: - await self._stdout.aclose() - if self._stderr: - await self._stderr.aclose() - - await self.wait() + with CancelScope(shield=True): + if self._stdin: + await self._stdin.aclose() + if self._stdout: + await self._stdout.aclose() + if self._stderr: + await self._stderr.aclose() + + try: + await self.wait() + except BaseException: + self.kill() + with CancelScope(shield=True): + await self.wait() + raise async def wait(self) -> int: return await self._process.wait() diff --git a/src/anyio/_core/_subprocesses.py b/src/anyio/_core/_subprocesses.py index c161029..5d5d7b7 100644 --- a/src/anyio/_core/_subprocesses.py +++ b/src/anyio/_core/_subprocesses.py @@ -65,20 +65,18 @@ async def run_process( start_new_session=start_new_session, ) as process: stream_contents: list[bytes | None] = [None, None] - try: - async with create_task_group() as tg: - if process.stdout: - tg.start_soon(drain_stream, process.stdout, 0) - if process.stderr: - tg.start_soon(drain_stream, process.stderr, 1) - if process.stdin and input: - await process.stdin.send(input) - await process.stdin.aclose() - - await process.wait() - except BaseException: - process.kill() - raise + async with create_task_group() as tg: + if process.stdout: + tg.start_soon(drain_stream, process.stdout, 0) + + if process.stderr: + tg.start_soon(drain_stream, process.stderr, 1) + + if process.stdin and input: + await process.stdin.send(input) + await process.stdin.aclose() + + await process.wait() output, errors = stream_contents if check and process.returncode != 0:
agronholm/anyio
3f14df89fe4c6d5edebae345a95d04c30334bba2
diff --git a/tests/test_subprocesses.py b/tests/test_subprocesses.py index 640384c..cc54fc5 100644 --- a/tests/test_subprocesses.py +++ b/tests/test_subprocesses.py @@ -8,8 +8,9 @@ from subprocess import CalledProcessError from textwrap import dedent import pytest +from _pytest.fixtures import FixtureRequest -from anyio import open_process, run_process +from anyio import CancelScope, ClosedResourceError, open_process, run_process from anyio.streams.buffered import BufferedByteReceiveStream pytestmark = pytest.mark.anyio @@ -176,3 +177,61 @@ async def test_run_process_inherit_stdout(capfd: pytest.CaptureFixture[str]) -> out, err = capfd.readouterr() assert out == "stdout-text" + os.linesep assert err == "stderr-text" + os.linesep + + +async def test_process_aexit_cancellation_doesnt_orphan_process() -> None: + """ + Regression test for #669. + + Ensures that open_process.__aexit__() doesn't leave behind an orphan process when + cancelled. + + """ + with CancelScope() as scope: + async with await open_process( + [sys.executable, "-c", "import time; time.sleep(1)"] + ) as process: + scope.cancel() + + assert process.returncode is not None + assert process.returncode != 0 + + +async def test_process_aexit_cancellation_closes_standard_streams( + request: FixtureRequest, + anyio_backend_name: str, +) -> None: + """ + Regression test for #669. + + Ensures that open_process.__aexit__() closes standard streams when cancelled. Also + ensures that process.std{in.send,{out,err}.receive}() raise ClosedResourceError on a + closed stream. + + """ + if anyio_backend_name == "asyncio": + # Avoid pytest.xfail here due to https://github.com/pytest-dev/pytest/issues/9027 + request.node.add_marker( + pytest.mark.xfail(reason="#671 needs to be resolved first") + ) + + with CancelScope() as scope: + async with await open_process( + [sys.executable, "-c", "import time; time.sleep(1)"] + ) as process: + scope.cancel() + + assert process.stdin is not None + + with pytest.raises(ClosedResourceError): + await process.stdin.send(b"foo") + + assert process.stdout is not None + + with pytest.raises(ClosedResourceError): + await process.stdout.receive(1) + + assert process.stderr is not None + + with pytest.raises(ClosedResourceError): + await process.stderr.receive(1) diff --git a/tests/test_taskgroups.py b/tests/test_taskgroups.py index f4c87b3..bc4a289 100644 --- a/tests/test_taskgroups.py +++ b/tests/test_taskgroups.py @@ -185,6 +185,9 @@ async def test_start_cancelled() -> None: assert not finished [email protected]( + sys.version_info < (3, 9), reason="Requires a way to detect cancellation source" +) @pytest.mark.parametrize("anyio_backend", ["asyncio"]) async def test_start_native_host_cancelled() -> None: started = finished = False @@ -199,9 +202,6 @@ async def test_start_native_host_cancelled() -> None: async with create_task_group() as tg: await tg.start(taskfunc) - if sys.version_info < (3, 9): - pytest.xfail("Requires a way to detect cancellation source") - task = asyncio.get_running_loop().create_task(start_another()) await wait_all_tasks_blocked() task.cancel()
`run_process` with `fail_after` causes RuntimeError on timeout ### Things to check first - [X] I have searched the existing issues and didn't find my bug already reported there - [X] I have checked that my bug is still present in the latest release ### AnyIO version 4.2.0 ### Python version 3.12.1 ### What happened? I am using `fail_after` to timeout if some task group is taking too long, usually due to being stuck in some subprocess call longer than expected. I was able to reproduce this in a small script (posted in the other section) which results in the following exception after hitting the timeout handler in this case. ``` Exception ignored in: <function BaseSubprocessTransport.__del__ at 0x1011d8360> Traceback (most recent call last): File "/Users/jmayeres/.pyenv/versions/3.12.1/lib/python3.12/asyncio/base_subprocess.py", line 126, in __del__ self.close() File "/Users/jmayeres/.pyenv/versions/3.12.1/lib/python3.12/asyncio/base_subprocess.py", line 104, in close proto.pipe.close() File "/Users/jmayeres/.pyenv/versions/3.12.1/lib/python3.12/asyncio/unix_events.py", line 568, in close self._close(None) File "/Users/jmayeres/.pyenv/versions/3.12.1/lib/python3.12/asyncio/unix_events.py", line 592, in _close self._loop.call_soon(self._call_connection_lost, exc) File "/Users/jmayeres/.pyenv/versions/3.12.1/lib/python3.12/asyncio/base_events.py", line 792, in call_soon self._check_closed() File "/Users/jmayeres/.pyenv/versions/3.12.1/lib/python3.12/asyncio/base_events.py", line 539, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed ``` The expectation would be that no RuntimeError is raised. I noticed that I don't have this issue if I use `open_process` and handle the output via text streams, but if I use `run_process` like in this example I get errors when the timeout is raised. I believe there's also some other weird stuff happening with these exceptions but I wanted to keep the example simple (in our working code there's some nested task groups and it seems like we don't get the timeout exception handler reached but the exception gets absorbed somewhere). ### How can we reproduce the bug? Invoking the following in python results in an exception after printing "Timed out!". Note that I'm running this on macOS 14.2.1 ```python from anyio import create_task_group, fail_after, run, run_process async def subprocess_output_no_stream(): result = await run_process("while true; do ps aux; sleep 1; done") stdout = result.stdout print(f"Subprocess done: got {len(stdout)} bytes") async def main(): try: with fail_after(1): async with create_task_group() as tg: print("Starting") tg.start_soon(subprocess_output_no_stream) print("Task group done") except TimeoutError: print("Timed out!") if __name__ == "__main__": run(main) ```
0.0
3f14df89fe4c6d5edebae345a95d04c30334bba2
[ "tests/test_taskgroups.py::test_success[asyncio+uvloop]" ]
[ "tests/test_subprocesses.py::test_run_process[asyncio-shell]", "tests/test_subprocesses.py::test_run_process[asyncio-exec]", "tests/test_subprocesses.py::test_run_process[asyncio+uvloop-shell]", "tests/test_subprocesses.py::test_run_process[asyncio+uvloop-exec]", "tests/test_subprocesses.py::test_run_process[trio-shell]", "tests/test_subprocesses.py::test_run_process[trio-exec]", "tests/test_subprocesses.py::test_run_process_checked[asyncio]", "tests/test_subprocesses.py::test_run_process_checked[asyncio+uvloop]", "tests/test_subprocesses.py::test_run_process_checked[trio]", "tests/test_subprocesses.py::test_terminate[asyncio]", "tests/test_subprocesses.py::test_terminate[asyncio+uvloop]", "tests/test_subprocesses.py::test_terminate[trio]", "tests/test_subprocesses.py::test_process_cwd[asyncio]", "tests/test_subprocesses.py::test_process_cwd[asyncio+uvloop]", "tests/test_subprocesses.py::test_process_cwd[trio]", "tests/test_subprocesses.py::test_process_env[asyncio]", "tests/test_subprocesses.py::test_process_env[asyncio+uvloop]", "tests/test_subprocesses.py::test_process_env[trio]", "tests/test_subprocesses.py::test_process_new_session_sid[asyncio]", "tests/test_subprocesses.py::test_process_new_session_sid[asyncio+uvloop]", "tests/test_subprocesses.py::test_process_new_session_sid[trio]", "tests/test_subprocesses.py::test_run_process_connect_to_file[asyncio]", "tests/test_subprocesses.py::test_run_process_connect_to_file[asyncio+uvloop]", "tests/test_subprocesses.py::test_run_process_connect_to_file[trio]", "tests/test_subprocesses.py::test_run_process_inherit_stdout[asyncio]", "tests/test_subprocesses.py::test_run_process_inherit_stdout[asyncio+uvloop]", "tests/test_subprocesses.py::test_run_process_inherit_stdout[trio]", "tests/test_taskgroups.py::test_already_closed[asyncio]", "tests/test_taskgroups.py::test_already_closed[asyncio+uvloop]", "tests/test_taskgroups.py::test_already_closed[trio]", "tests/test_taskgroups.py::test_success[asyncio]", "tests/test_taskgroups.py::test_success[trio]", "tests/test_taskgroups.py::test_run_natively[asyncio]", "tests/test_taskgroups.py::test_run_natively[trio]", "tests/test_taskgroups.py::test_start_soon_while_running[asyncio]", "tests/test_taskgroups.py::test_start_soon_while_running[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_soon_while_running[trio]", "tests/test_taskgroups.py::test_start_soon_after_error[asyncio]", "tests/test_taskgroups.py::test_start_soon_after_error[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_soon_after_error[trio]", "tests/test_taskgroups.py::test_start_no_value[asyncio]", "tests/test_taskgroups.py::test_start_no_value[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_no_value[trio]", "tests/test_taskgroups.py::test_start_called_twice[asyncio]", "tests/test_taskgroups.py::test_start_called_twice[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_called_twice[trio]", "tests/test_taskgroups.py::test_start_with_value[asyncio]", "tests/test_taskgroups.py::test_start_with_value[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_with_value[trio]", "tests/test_taskgroups.py::test_start_crash_before_started_call[asyncio]", "tests/test_taskgroups.py::test_start_crash_before_started_call[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_crash_before_started_call[trio]", "tests/test_taskgroups.py::test_start_crash_after_started_call[asyncio]", "tests/test_taskgroups.py::test_start_crash_after_started_call[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_crash_after_started_call[trio]", "tests/test_taskgroups.py::test_start_no_started_call[asyncio]", "tests/test_taskgroups.py::test_start_no_started_call[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_no_started_call[trio]", "tests/test_taskgroups.py::test_start_cancelled[asyncio]", "tests/test_taskgroups.py::test_start_cancelled[trio]", "tests/test_taskgroups.py::test_start_native_host_cancelled[asyncio]", "tests/test_taskgroups.py::test_start_native_child_cancelled[asyncio]", "tests/test_taskgroups.py::test_propagate_native_cancellation_from_taskgroup[asyncio]", "tests/test_taskgroups.py::test_start_exception_delivery[asyncio]", "tests/test_taskgroups.py::test_start_exception_delivery[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_exception_delivery[trio]", "tests/test_taskgroups.py::test_start_cancel_after_error[asyncio]", "tests/test_taskgroups.py::test_start_cancel_after_error[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_cancel_after_error[trio]", "tests/test_taskgroups.py::test_host_exception[asyncio]", "tests/test_taskgroups.py::test_host_exception[asyncio+uvloop]", "tests/test_taskgroups.py::test_host_exception[trio]", "tests/test_taskgroups.py::test_level_cancellation[asyncio]", "tests/test_taskgroups.py::test_level_cancellation[asyncio+uvloop]", "tests/test_taskgroups.py::test_level_cancellation[trio]", "tests/test_taskgroups.py::test_failing_child_task_cancels_host[asyncio]", "tests/test_taskgroups.py::test_failing_child_task_cancels_host[asyncio+uvloop]", "tests/test_taskgroups.py::test_failing_child_task_cancels_host[trio]", "tests/test_taskgroups.py::test_failing_host_task_cancels_children[asyncio]", "tests/test_taskgroups.py::test_failing_host_task_cancels_children[asyncio+uvloop]", "tests/test_taskgroups.py::test_failing_host_task_cancels_children[trio]", "tests/test_taskgroups.py::test_cancel_scope_in_another_task[asyncio]", "tests/test_taskgroups.py::test_cancel_scope_in_another_task[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_scope_in_another_task[trio]", "tests/test_taskgroups.py::test_cancel_propagation[asyncio]", "tests/test_taskgroups.py::test_cancel_propagation[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_propagation[trio]", "tests/test_taskgroups.py::test_cancel_twice[asyncio]", "tests/test_taskgroups.py::test_cancel_twice[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_twice[trio]", "tests/test_taskgroups.py::test_cancel_exiting_task_group[asyncio]", "tests/test_taskgroups.py::test_cancel_exiting_task_group[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_exiting_task_group[trio]", "tests/test_taskgroups.py::test_cancel_before_entering_scope[asyncio]", "tests/test_taskgroups.py::test_cancel_before_entering_scope[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_before_entering_scope[trio]", "tests/test_taskgroups.py::test_exception_group_children[asyncio]", "tests/test_taskgroups.py::test_exception_group_children[asyncio+uvloop]", "tests/test_taskgroups.py::test_exception_group_children[trio]", "tests/test_taskgroups.py::test_exception_group_host[asyncio]", "tests/test_taskgroups.py::test_exception_group_host[asyncio+uvloop]", "tests/test_taskgroups.py::test_exception_group_host[trio]", "tests/test_taskgroups.py::test_escaping_cancelled_exception[asyncio]", "tests/test_taskgroups.py::test_escaping_cancelled_exception[asyncio+uvloop]", "tests/test_taskgroups.py::test_escaping_cancelled_exception[trio]", "tests/test_taskgroups.py::test_cancel_scope_cleared[asyncio]", "tests/test_taskgroups.py::test_cancel_scope_cleared[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_scope_cleared[trio]", "tests/test_taskgroups.py::test_fail_after[asyncio-instant]", "tests/test_taskgroups.py::test_fail_after[asyncio-delayed]", "tests/test_taskgroups.py::test_fail_after[asyncio+uvloop-instant]", "tests/test_taskgroups.py::test_fail_after[asyncio+uvloop-delayed]", "tests/test_taskgroups.py::test_fail_after[trio-instant]", "tests/test_taskgroups.py::test_fail_after[trio-delayed]", "tests/test_taskgroups.py::test_fail_after_no_timeout[asyncio]", "tests/test_taskgroups.py::test_fail_after_no_timeout[asyncio+uvloop]", "tests/test_taskgroups.py::test_fail_after_no_timeout[trio]", "tests/test_taskgroups.py::test_fail_after_after_cancellation[asyncio]", "tests/test_taskgroups.py::test_fail_after_after_cancellation[asyncio+uvloop]", "tests/test_taskgroups.py::test_fail_after_after_cancellation[trio]", "tests/test_taskgroups.py::test_fail_after_cancelled_before_deadline[asyncio]", "tests/test_taskgroups.py::test_fail_after_cancelled_before_deadline[asyncio+uvloop]", "tests/test_taskgroups.py::test_fail_after_cancelled_before_deadline[trio]", "tests/test_taskgroups.py::test_move_on_after[asyncio-instant]", "tests/test_taskgroups.py::test_move_on_after[asyncio-delayed]", "tests/test_taskgroups.py::test_move_on_after[asyncio+uvloop-instant]", "tests/test_taskgroups.py::test_move_on_after[asyncio+uvloop-delayed]", "tests/test_taskgroups.py::test_move_on_after[trio-instant]", "tests/test_taskgroups.py::test_move_on_after[trio-delayed]", "tests/test_taskgroups.py::test_move_on_after_no_timeout[asyncio]", "tests/test_taskgroups.py::test_move_on_after_no_timeout[asyncio+uvloop]", "tests/test_taskgroups.py::test_move_on_after_no_timeout[trio]", "tests/test_taskgroups.py::test_nested_move_on_after[asyncio]", "tests/test_taskgroups.py::test_nested_move_on_after[asyncio+uvloop]", "tests/test_taskgroups.py::test_nested_move_on_after[trio]", "tests/test_taskgroups.py::test_shielding[asyncio]", "tests/test_taskgroups.py::test_shielding[asyncio+uvloop]", "tests/test_taskgroups.py::test_shielding[trio]", "tests/test_taskgroups.py::test_cancel_from_shielded_scope[asyncio]", "tests/test_taskgroups.py::test_cancel_from_shielded_scope[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_from_shielded_scope[trio]", "tests/test_taskgroups.py::test_cancel_shielded_scope[asyncio]", "tests/test_taskgroups.py::test_cancel_shielded_scope[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_shielded_scope[trio]", "tests/test_taskgroups.py::test_cancelled_not_caught[asyncio]", "tests/test_taskgroups.py::test_cancelled_not_caught[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancelled_not_caught[trio]", "tests/test_taskgroups.py::test_cancel_host_asyncgen[asyncio]", "tests/test_taskgroups.py::test_shielding_immediate_scope_cancelled[asyncio]", "tests/test_taskgroups.py::test_shielding_immediate_scope_cancelled[asyncio+uvloop]", "tests/test_taskgroups.py::test_shielding_immediate_scope_cancelled[trio]", "tests/test_taskgroups.py::test_shielding_mutate[asyncio]", "tests/test_taskgroups.py::test_shielding_mutate[asyncio+uvloop]", "tests/test_taskgroups.py::test_shielding_mutate[trio]", "tests/test_taskgroups.py::test_cancel_scope_in_child_task[asyncio]", "tests/test_taskgroups.py::test_cancel_scope_in_child_task[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_scope_in_child_task[trio]", "tests/test_taskgroups.py::test_exception_cancels_siblings[asyncio]", "tests/test_taskgroups.py::test_exception_cancels_siblings[asyncio+uvloop]", "tests/test_taskgroups.py::test_exception_cancels_siblings[trio]", "tests/test_taskgroups.py::test_cancel_cascade[asyncio]", "tests/test_taskgroups.py::test_cancel_cascade[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_cascade[trio]", "tests/test_taskgroups.py::test_cancelled_parent[asyncio]", "tests/test_taskgroups.py::test_cancelled_parent[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancelled_parent[trio]", "tests/test_taskgroups.py::test_shielded_deadline[asyncio]", "tests/test_taskgroups.py::test_shielded_deadline[asyncio+uvloop]", "tests/test_taskgroups.py::test_shielded_deadline[trio]", "tests/test_taskgroups.py::test_deadline_reached_on_start[asyncio]", "tests/test_taskgroups.py::test_deadline_reached_on_start[asyncio+uvloop]", "tests/test_taskgroups.py::test_deadline_reached_on_start[trio]", "tests/test_taskgroups.py::test_deadline_moved[asyncio]", "tests/test_taskgroups.py::test_deadline_moved[asyncio+uvloop]", "tests/test_taskgroups.py::test_deadline_moved[trio]", "tests/test_taskgroups.py::test_timeout_error_with_multiple_cancellations[asyncio]", "tests/test_taskgroups.py::test_timeout_error_with_multiple_cancellations[asyncio+uvloop]", "tests/test_taskgroups.py::test_timeout_error_with_multiple_cancellations[trio]", "tests/test_taskgroups.py::test_nested_fail_after[asyncio]", "tests/test_taskgroups.py::test_nested_fail_after[asyncio+uvloop]", "tests/test_taskgroups.py::test_nested_fail_after[trio]", "tests/test_taskgroups.py::test_nested_shield[asyncio]", "tests/test_taskgroups.py::test_nested_shield[asyncio+uvloop]", "tests/test_taskgroups.py::test_nested_shield[trio]", "tests/test_taskgroups.py::test_triple_nested_shield_checkpoint_in_outer[asyncio]", "tests/test_taskgroups.py::test_triple_nested_shield_checkpoint_in_outer[asyncio+uvloop]", "tests/test_taskgroups.py::test_triple_nested_shield_checkpoint_in_outer[trio]", "tests/test_taskgroups.py::test_triple_nested_shield_checkpoint_in_middle[asyncio]", "tests/test_taskgroups.py::test_triple_nested_shield_checkpoint_in_middle[asyncio+uvloop]", "tests/test_taskgroups.py::test_triple_nested_shield_checkpoint_in_middle[trio]", "tests/test_taskgroups.py::test_task_group_in_generator[asyncio]", "tests/test_taskgroups.py::test_task_group_in_generator[asyncio+uvloop]", "tests/test_taskgroups.py::test_task_group_in_generator[trio]", "tests/test_taskgroups.py::test_exception_group_filtering[asyncio]", "tests/test_taskgroups.py::test_exception_group_filtering[asyncio+uvloop]", "tests/test_taskgroups.py::test_exception_group_filtering[trio]", "tests/test_taskgroups.py::test_cancel_propagation_with_inner_spawn[asyncio]", "tests/test_taskgroups.py::test_cancel_propagation_with_inner_spawn[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_propagation_with_inner_spawn[trio]", "tests/test_taskgroups.py::test_escaping_cancelled_error_from_cancelled_task[asyncio]", "tests/test_taskgroups.py::test_escaping_cancelled_error_from_cancelled_task[asyncio+uvloop]", "tests/test_taskgroups.py::test_escaping_cancelled_error_from_cancelled_task[trio]", "tests/test_taskgroups.py::test_cancel_generator_based_task", "tests/test_taskgroups.py::test_schedule_old_style_coroutine_func[asyncio]", "tests/test_taskgroups.py::test_cancel_native_future_tasks[asyncio]", "tests/test_taskgroups.py::test_cancel_native_future_tasks_cancel_scope[asyncio]", "tests/test_taskgroups.py::test_cancel_completed_task[asyncio]", "tests/test_taskgroups.py::test_task_in_sync_spawn_callback[asyncio]", "tests/test_taskgroups.py::test_task_in_sync_spawn_callback[asyncio+uvloop]", "tests/test_taskgroups.py::test_task_in_sync_spawn_callback[trio]", "tests/test_taskgroups.py::test_shielded_cancel_sleep_time[asyncio]", "tests/test_taskgroups.py::test_shielded_cancel_sleep_time[asyncio+uvloop]", "tests/test_taskgroups.py::test_shielded_cancel_sleep_time[trio]", "tests/test_taskgroups.py::test_cancelscope_wrong_exit_order[asyncio]", "tests/test_taskgroups.py::test_cancelscope_wrong_exit_order[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancelscope_wrong_exit_order[trio]", "tests/test_taskgroups.py::test_cancelscope_exit_before_enter[asyncio]", "tests/test_taskgroups.py::test_cancelscope_exit_before_enter[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancelscope_exit_before_enter[trio]", "tests/test_taskgroups.py::test_cancelscope_exit_in_wrong_task[asyncio]", "tests/test_taskgroups.py::test_unhandled_exception_group", "tests/test_taskgroups.py::test_single_cancellation_exc[asyncio]", "tests/test_taskgroups.py::test_single_cancellation_exc[asyncio+uvloop]", "tests/test_taskgroups.py::test_single_cancellation_exc[trio]", "tests/test_taskgroups.py::test_start_soon_parent_id[asyncio]", "tests/test_taskgroups.py::test_start_soon_parent_id[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_soon_parent_id[trio]", "tests/test_taskgroups.py::test_start_parent_id[asyncio]", "tests/test_taskgroups.py::test_start_parent_id[asyncio+uvloop]", "tests/test_taskgroups.py::test_start_parent_id[trio]", "tests/test_taskgroups.py::test_cancel_before_entering_task_group[asyncio]", "tests/test_taskgroups.py::test_cancel_before_entering_task_group[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_before_entering_task_group[trio]", "tests/test_taskgroups.py::test_reraise_cancelled_in_excgroup[asyncio]", "tests/test_taskgroups.py::test_reraise_cancelled_in_excgroup[asyncio+uvloop]", "tests/test_taskgroups.py::test_reraise_cancelled_in_excgroup[trio]", "tests/test_taskgroups.py::test_cancel_child_task_when_host_is_shielded[asyncio]", "tests/test_taskgroups.py::test_cancel_child_task_when_host_is_shielded[asyncio+uvloop]", "tests/test_taskgroups.py::test_cancel_child_task_when_host_is_shielded[trio]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2024-01-17 08:46:24+00:00
mit
931
agronholm__anyio-703
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index c813367..f07c289 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -9,6 +9,8 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. ``KeyError`` - Fixed the asyncio backend not respecting the ``PYTHONASYNCIODEBUG`` environment variable when setting the ``debug`` flag in ``anyio.run()`` +- Fixed ``SocketStream.receive()`` not detecting EOF on asyncio if there is also data in + the read buffer (`#701 <https://github.com/agronholm/anyio/issues/701>`_) **4.3.0** diff --git a/src/anyio/_backends/_asyncio.py b/src/anyio/_backends/_asyncio.py index dcf48cc..d64e553 100644 --- a/src/anyio/_backends/_asyncio.py +++ b/src/anyio/_backends/_asyncio.py @@ -1047,6 +1047,7 @@ class StreamProtocol(asyncio.Protocol): read_event: asyncio.Event write_event: asyncio.Event exception: Exception | None = None + is_at_eof: bool = False def connection_made(self, transport: asyncio.BaseTransport) -> None: self.read_queue = deque() @@ -1068,6 +1069,7 @@ class StreamProtocol(asyncio.Protocol): self.read_event.set() def eof_received(self) -> bool | None: + self.is_at_eof = True self.read_event.set() return True @@ -1123,15 +1125,16 @@ class SocketStream(abc.SocketStream): async def receive(self, max_bytes: int = 65536) -> bytes: with self._receive_guard: - await AsyncIOBackend.checkpoint() - if ( not self._protocol.read_event.is_set() and not self._transport.is_closing() + and not self._protocol.is_at_eof ): self._transport.resume_reading() await self._protocol.read_event.wait() self._transport.pause_reading() + else: + await AsyncIOBackend.checkpoint() try: chunk = self._protocol.read_queue.popleft()
agronholm/anyio
9f021d51ca14427783a5558e97c473b8b1fea23d
diff --git a/tests/test_sockets.py b/tests/test_sockets.py index a35b500..43c7058 100644 --- a/tests/test_sockets.py +++ b/tests/test_sockets.py @@ -28,6 +28,7 @@ from anyio import ( BrokenResourceError, BusyResourceError, ClosedResourceError, + EndOfStream, Event, TypedAttributeLookupError, connect_tcp, @@ -681,6 +682,29 @@ class TestTCPListener: tg.cancel_scope.cancel() + async def test_eof_after_send(self, family: AnyIPAddressFamily) -> None: + """Regression test for #701.""" + received_bytes = b"" + + async def handle(stream: SocketStream) -> None: + nonlocal received_bytes + async with stream: + received_bytes = await stream.receive() + with pytest.raises(EndOfStream), fail_after(1): + await stream.receive() + + tg.cancel_scope.cancel() + + multi = await create_tcp_listener(family=family, local_host="localhost") + async with multi, create_task_group() as tg: + with socket.socket(family) as client: + client.connect(multi.extra(SocketAttribute.local_address)) + client.send(b"Hello") + client.shutdown(socket.SHUT_WR) + await multi.serve(handle) + + assert received_bytes == b"Hello" + @skip_ipv6_mark @pytest.mark.skipif( sys.platform == "win32",
TCP listener handler does not disconnect on EOF (netcat -N) ### Things to check first - [X] I have searched the existing issues and didn't find my bug already reported there - [X] I have checked that my bug is still present in the latest release ### AnyIO version 4.3.0 ### Python version 3.11.8 ### What happened? While trying to implement a Python TCP receiver for a line based protocol using anyio, I have issues closing the stream with an EOF on the client side with netcat. This works with a pure Python synchronous implementation. The code uses the anyio backend. ### How can we reproduce the bug? ```python import anyio from anyio.streams.text import TextReceiveStream async def read_lines(port: int): """Read lines from TCP socket and output.""" # FIXME: GNU netcat does not deterministically shutdown after sending EOF (-N option), one has to use -w 0 to close on idle async def handle(client): async with client: receive_stream = TextReceiveStream(client) async for chunk in receive_stream: for line in chunk.splitlines(): print(f"Line: {line.rstrip()}") listener = await anyio.create_tcp_listener(local_port=port) await listener.serve(handle) anyio.run(read_lines, 1234) ``` Now, the following command hangs on most, but not all executions (it might have to do with buffering): `echo 'hello world' | netcat -N localhost 1234` The following works, but uses an idle workaround `echo 'hello world' | netcat -N -w 0 localhost 1234`
0.0
9f021d51ca14427783a5558e97c473b8b1fea23d
[ "tests/test_sockets.py::TestTCPListener::test_eof_after_send[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_eof_after_send[asyncio-ipv6]" ]
[ "tests/test_sockets.py::TestTCPStream::test_extra_attributes[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_extra_attributes[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_extra_attributes[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_extra_attributes[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_extra_attributes[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_extra_attributes[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_receive[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_receive[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_receive[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_receive[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_large_buffer[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_large_buffer[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_large_buffer[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_large_buffer[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_large_buffer[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_large_buffer[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_eof[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_eof[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_eof[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_eof[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_eof[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_eof[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_iterate[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_iterate[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_iterate[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_iterate[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_iterate[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_iterate[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_socket_options[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_socket_options[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_socket_options[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_socket_options[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_socket_options[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_socket_options[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[asyncio-dualstack]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[asyncio+uvloop-dualstack]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[trio-dualstack]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_happy_eyeballs[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_connection_refused[asyncio-multi]", "tests/test_sockets.py::TestTCPStream::test_connection_refused[asyncio-single]", "tests/test_sockets.py::TestTCPStream::test_connection_refused[asyncio+uvloop-multi]", "tests/test_sockets.py::TestTCPStream::test_connection_refused[asyncio+uvloop-single]", "tests/test_sockets.py::TestTCPStream::test_connection_refused[trio-multi]", "tests/test_sockets.py::TestTCPStream::test_connection_refused[trio-single]", "tests/test_sockets.py::TestTCPStream::test_receive_timeout[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_receive_timeout[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_receive_timeout[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_receive_timeout[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_receive_timeout[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_receive_timeout[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_concurrent_send[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_concurrent_send[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_concurrent_send[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_concurrent_send[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_concurrent_send[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_concurrent_send[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_concurrent_receive[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_concurrent_receive[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_concurrent_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_concurrent_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_concurrent_receive[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_concurrent_receive[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_close_during_receive[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_close_during_receive[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_close_during_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_close_during_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_close_during_receive[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_close_during_receive[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_receive_after_close[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_receive_after_close[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_receive_after_close[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_receive_after_close[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_receive_after_close[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_receive_after_close[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_after_close[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_after_close[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_after_close[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_after_close[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_after_close[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_after_close[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_after_peer_closed[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_after_peer_closed[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_after_peer_closed[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_after_peer_closed[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_send_after_peer_closed[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_send_after_peer_closed[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls_cert_check_fail[asyncio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls_cert_check_fail[asyncio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls_cert_check_fail[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls_cert_check_fail[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls_cert_check_fail[trio-ipv4]", "tests/test_sockets.py::TestTCPStream::test_connect_tcp_with_tls_cert_check_fail[trio-ipv6]", "tests/test_sockets.py::TestTCPStream::test_unretrieved_future_exception_server_crash[ipv4-asyncio]", "tests/test_sockets.py::TestTCPStream::test_unretrieved_future_exception_server_crash[ipv6-asyncio]", "tests/test_sockets.py::TestTCPListener::test_extra_attributes[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_extra_attributes[asyncio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_extra_attributes[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_extra_attributes[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_extra_attributes[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_extra_attributes[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_accept[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_accept[asyncio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_accept[asyncio-both]", "tests/test_sockets.py::TestTCPListener::test_accept[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_accept[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_accept[asyncio+uvloop-both]", "tests/test_sockets.py::TestTCPListener::test_accept[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_accept[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_accept[trio-both]", "tests/test_sockets.py::TestTCPListener::test_accept_after_close[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_accept_after_close[asyncio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_accept_after_close[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_accept_after_close[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_accept_after_close[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_accept_after_close[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_socket_options[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_socket_options[asyncio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_socket_options[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_socket_options[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_socket_options[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_socket_options[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_reuse_port[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_reuse_port[asyncio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_reuse_port[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_reuse_port[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_reuse_port[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_reuse_port[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_close_from_other_task[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_close_from_other_task[asyncio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_close_from_other_task[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_close_from_other_task[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_close_from_other_task[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_close_from_other_task[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_send_after_eof[asyncio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_send_after_eof[asyncio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_send_after_eof[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_send_after_eof[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_send_after_eof[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_send_after_eof[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_eof_after_send[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestTCPListener::test_eof_after_send[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestTCPListener::test_eof_after_send[trio-ipv4]", "tests/test_sockets.py::TestTCPListener::test_eof_after_send[trio-ipv6]", "tests/test_sockets.py::TestTCPListener::test_bind_link_local[asyncio]", "tests/test_sockets.py::TestTCPListener::test_bind_link_local[asyncio+uvloop]", "tests/test_sockets.py::TestTCPListener::test_bind_link_local[trio]", "tests/test_sockets.py::TestUNIXStream::test_extra_attributes[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_extra_attributes[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_extra_attributes[trio]", "tests/test_sockets.py::TestUNIXStream::test_send_receive[asyncio-str]", "tests/test_sockets.py::TestUNIXStream::test_send_receive[asyncio-path]", "tests/test_sockets.py::TestUNIXStream::test_send_receive[asyncio+uvloop-str]", "tests/test_sockets.py::TestUNIXStream::test_send_receive[asyncio+uvloop-path]", "tests/test_sockets.py::TestUNIXStream::test_send_receive[trio-str]", "tests/test_sockets.py::TestUNIXStream::test_send_receive[trio-path]", "tests/test_sockets.py::TestUNIXStream::test_receive_large_buffer[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_receive_large_buffer[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_receive_large_buffer[trio]", "tests/test_sockets.py::TestUNIXStream::test_send_large_buffer[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_send_large_buffer[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_send_large_buffer[trio]", "tests/test_sockets.py::TestUNIXStream::test_receive_fds[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_receive_fds[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_receive_fds[trio]", "tests/test_sockets.py::TestUNIXStream::test_receive_fds_bad_args[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_receive_fds_bad_args[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_receive_fds_bad_args[trio]", "tests/test_sockets.py::TestUNIXStream::test_send_fds[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_send_fds[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_send_fds[trio]", "tests/test_sockets.py::TestUNIXStream::test_send_eof[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_send_eof[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_send_eof[trio]", "tests/test_sockets.py::TestUNIXStream::test_iterate[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_iterate[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_iterate[trio]", "tests/test_sockets.py::TestUNIXStream::test_send_fds_bad_args[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_send_fds_bad_args[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_send_fds_bad_args[trio]", "tests/test_sockets.py::TestUNIXStream::test_concurrent_send[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_concurrent_send[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_concurrent_send[trio]", "tests/test_sockets.py::TestUNIXStream::test_concurrent_receive[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_concurrent_receive[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_concurrent_receive[trio]", "tests/test_sockets.py::TestUNIXStream::test_close_during_receive[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_close_during_receive[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_close_during_receive[trio]", "tests/test_sockets.py::TestUNIXStream::test_receive_after_close[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_receive_after_close[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_receive_after_close[trio]", "tests/test_sockets.py::TestUNIXStream::test_send_after_close[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_send_after_close[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_send_after_close[trio]", "tests/test_sockets.py::TestUNIXStream::test_cannot_connect[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_cannot_connect[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_cannot_connect[trio]", "tests/test_sockets.py::TestUNIXStream::test_connecting_using_bytes[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_connecting_using_bytes[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_connecting_using_bytes[trio]", "tests/test_sockets.py::TestUNIXStream::test_connecting_with_non_utf8[asyncio]", "tests/test_sockets.py::TestUNIXStream::test_connecting_with_non_utf8[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXStream::test_connecting_with_non_utf8[trio]", "tests/test_sockets.py::TestUNIXListener::test_extra_attributes[asyncio]", "tests/test_sockets.py::TestUNIXListener::test_extra_attributes[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXListener::test_extra_attributes[trio]", "tests/test_sockets.py::TestUNIXListener::test_accept[asyncio-str]", "tests/test_sockets.py::TestUNIXListener::test_accept[asyncio-path]", "tests/test_sockets.py::TestUNIXListener::test_accept[asyncio+uvloop-str]", "tests/test_sockets.py::TestUNIXListener::test_accept[asyncio+uvloop-path]", "tests/test_sockets.py::TestUNIXListener::test_accept[trio-str]", "tests/test_sockets.py::TestUNIXListener::test_accept[trio-path]", "tests/test_sockets.py::TestUNIXListener::test_socket_options[asyncio]", "tests/test_sockets.py::TestUNIXListener::test_socket_options[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXListener::test_socket_options[trio]", "tests/test_sockets.py::TestUNIXListener::test_send_after_eof[asyncio]", "tests/test_sockets.py::TestUNIXListener::test_send_after_eof[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXListener::test_send_after_eof[trio]", "tests/test_sockets.py::TestUNIXListener::test_bind_twice[asyncio]", "tests/test_sockets.py::TestUNIXListener::test_bind_twice[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXListener::test_bind_twice[trio]", "tests/test_sockets.py::TestUNIXListener::test_listening_bytes_path[asyncio]", "tests/test_sockets.py::TestUNIXListener::test_listening_bytes_path[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXListener::test_listening_bytes_path[trio]", "tests/test_sockets.py::TestUNIXListener::test_listening_invalid_ascii[asyncio]", "tests/test_sockets.py::TestUNIXListener::test_listening_invalid_ascii[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXListener::test_listening_invalid_ascii[trio]", "tests/test_sockets.py::test_multi_listener[asyncio]", "tests/test_sockets.py::test_multi_listener[asyncio+uvloop]", "tests/test_sockets.py::test_multi_listener[trio]", "tests/test_sockets.py::TestUDPSocket::test_extra_attributes[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_extra_attributes[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_extra_attributes[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_extra_attributes[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_extra_attributes[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_extra_attributes[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_send_receive[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_send_receive[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_send_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_send_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_send_receive[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_send_receive[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_iterate[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_iterate[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_iterate[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_iterate[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_iterate[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_iterate[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_reuse_port[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_reuse_port[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_reuse_port[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_reuse_port[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_reuse_port[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_reuse_port[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_concurrent_receive[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_concurrent_receive[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_concurrent_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_concurrent_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_concurrent_receive[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_concurrent_receive[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_close_during_receive[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_close_during_receive[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_close_during_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_close_during_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_close_during_receive[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_close_during_receive[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_receive_after_close[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_receive_after_close[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_receive_after_close[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_receive_after_close[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_receive_after_close[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_receive_after_close[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_send_after_close[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_send_after_close[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_send_after_close[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_send_after_close[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_send_after_close[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_send_after_close[trio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_create_unbound_socket[asyncio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_create_unbound_socket[asyncio-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_create_unbound_socket[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_create_unbound_socket[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestUDPSocket::test_create_unbound_socket[trio-ipv4]", "tests/test_sockets.py::TestUDPSocket::test_create_unbound_socket[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_extra_attributes[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_extra_attributes[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_extra_attributes[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_extra_attributes[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_extra_attributes[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_extra_attributes[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_receive[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_receive[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_receive[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_receive[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_iterate[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_iterate[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_iterate[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_iterate[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_iterate[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_iterate[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_reuse_port[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_reuse_port[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_reuse_port[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_reuse_port[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_reuse_port[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_reuse_port[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_concurrent_receive[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_concurrent_receive[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_concurrent_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_concurrent_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_concurrent_receive[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_concurrent_receive[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_close_during_receive[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_close_during_receive[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_close_during_receive[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_close_during_receive[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_close_during_receive[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_close_during_receive[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_receive_after_close[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_receive_after_close[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_receive_after_close[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_receive_after_close[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_receive_after_close[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_receive_after_close[trio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_after_close[asyncio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_after_close[asyncio-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_after_close[asyncio+uvloop-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_after_close[asyncio+uvloop-ipv6]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_after_close[trio-ipv4]", "tests/test_sockets.py::TestConnectedUDPSocket::test_send_after_close[trio-ipv6]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_extra_attributes[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_extra_attributes[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_extra_attributes[trio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_receive[asyncio-str]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_receive[asyncio-path]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_receive[asyncio+uvloop-str]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_receive[asyncio+uvloop-path]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_receive[trio-str]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_receive[trio-path]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_iterate[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_iterate[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_iterate[trio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_concurrent_receive[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_concurrent_receive[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_concurrent_receive[trio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_close_during_receive[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_close_during_receive[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_close_during_receive[trio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_receive_after_close[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_receive_after_close[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_receive_after_close[trio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_after_close[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_after_close[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_send_after_close[trio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_local_path_bytes[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_local_path_bytes[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_local_path_bytes[trio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_local_path_invalid_ascii[asyncio]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_local_path_invalid_ascii[asyncio+uvloop]", "tests/test_sockets.py::TestUNIXDatagramSocket::test_local_path_invalid_ascii[trio]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_extra_attributes[asyncio]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_extra_attributes[asyncio+uvloop]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_extra_attributes[trio]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio-str-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio-str-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio-path-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio-path-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio+uvloop-str-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio+uvloop-str-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio+uvloop-path-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[asyncio+uvloop-path-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[trio-str-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[trio-str-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[trio-path-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_receive[trio-path-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_iterate[asyncio]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_iterate[asyncio+uvloop]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_iterate[trio]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_concurrent_receive[asyncio]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_concurrent_receive[asyncio+uvloop]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_concurrent_receive[trio]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_close_during_receive[asyncio-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_close_during_receive[asyncio-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_close_during_receive[asyncio+uvloop-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_close_during_receive[asyncio+uvloop-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_close_during_receive[trio-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_close_during_receive[trio-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_receive_after_close[asyncio-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_receive_after_close[asyncio-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_receive_after_close[asyncio+uvloop-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_receive_after_close[asyncio+uvloop-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_receive_after_close[trio-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_receive_after_close[trio-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_after_close[asyncio-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_after_close[asyncio-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_after_close[asyncio+uvloop-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_after_close[asyncio+uvloop-peer_path]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_after_close[trio-peer_str]", "tests/test_sockets.py::TestConnectedUNIXDatagramSocket::test_send_after_close[trio-peer_path]", "tests/test_sockets.py::test_getaddrinfo[asyncio]", "tests/test_sockets.py::test_getaddrinfo[asyncio+uvloop]", "tests/test_sockets.py::test_getaddrinfo[trio]", "tests/test_sockets.py::test_getaddrinfo_ipv6addr[asyncio-SocketKind.SOCK_STREAM0]", "tests/test_sockets.py::test_getaddrinfo_ipv6addr[asyncio-SocketKind.SOCK_STREAM1]", "tests/test_sockets.py::test_getaddrinfo_ipv6addr[asyncio+uvloop-SocketKind.SOCK_STREAM0]", "tests/test_sockets.py::test_getaddrinfo_ipv6addr[asyncio+uvloop-SocketKind.SOCK_STREAM1]", "tests/test_sockets.py::test_getaddrinfo_ipv6addr[trio-SocketKind.SOCK_STREAM0]", "tests/test_sockets.py::test_getaddrinfo_ipv6addr[trio-SocketKind.SOCK_STREAM1]", "tests/test_sockets.py::test_getnameinfo[asyncio]", "tests/test_sockets.py::test_getnameinfo[asyncio+uvloop]", "tests/test_sockets.py::test_getnameinfo[trio]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2024-03-18 21:13:37+00:00
mit
932
agronholm__exceptiongroup-3
diff --git a/README.rst b/README.rst index 30fcdf5..c98ba00 100644 --- a/README.rst +++ b/README.rst @@ -19,9 +19,6 @@ It contains the following: * An exception hook that handles formatting of exception groups through ``TracebackException`` (installed on import) -The only difference with the Python 3.11 standard library implementation is that there -is no ``__note__`` attribute in ``BaseExceptionGroup`` or ``ExceptionGroup``. - If this package is imported on Python 3.11 or later, the built-in implementations of the exception group classes are used instead, ``TracebackException`` is not monkey patched and the exception hook won't be installed. diff --git a/src/exceptiongroup/_exceptions.py b/src/exceptiongroup/_exceptions.py index dda85e0..0d40a6b 100644 --- a/src/exceptiongroup/_exceptions.py +++ b/src/exceptiongroup/_exceptions.py @@ -70,6 +70,7 @@ class BaseExceptionGroup(BaseException, Generic[EBase]): super().__init__(__message, __exceptions, *args) self._message = __message self._exceptions = __exceptions + self.__note__ = None @property def message(self) -> str: @@ -149,7 +150,9 @@ class BaseExceptionGroup(BaseException, Generic[EBase]): return matching_group, nonmatching_group def derive(self: T, __excs: Sequence[EBase]) -> T: - return BaseExceptionGroup(self.message, __excs) + eg = BaseExceptionGroup(self.message, __excs) + eg.__note__ = self.__note__ + return eg def __str__(self) -> str: return self.message diff --git a/src/exceptiongroup/_formatting.py b/src/exceptiongroup/_formatting.py index 4bf973c..6c073c4 100644 --- a/src/exceptiongroup/_formatting.py +++ b/src/exceptiongroup/_formatting.py @@ -15,11 +15,11 @@ from ._exceptions import BaseExceptionGroup max_group_width = 15 max_group_depth = 10 _cause_message = ( - "\nThe above exception was the direct cause " "of the following exception:\n\n" + "\nThe above exception was the direct cause of the following exception:\n\n" ) _context_message = ( - "\nDuring handling of the above exception, " "another exception occurred:\n\n" + "\nDuring handling of the above exception, another exception occurred:\n\n" ) @@ -51,6 +51,7 @@ def traceback_exception_init( _seen=_seen, **kwargs, ) + self.__note__ = getattr(exc_value, "__note__", None) if exc_value else None seen_was_none = _seen is None @@ -134,6 +135,8 @@ def traceback_exception_format(self, *, chain=True, _ctx=None): yield from _ctx.emit("Traceback (most recent call last):\n") yield from _ctx.emit(exc.stack.format()) yield from _ctx.emit(exc.format_exception_only()) + if isinstance(exc.__note__, str): + yield from _ctx.emit(line + "\n" for line in exc.__note__.split("\n")) elif _ctx.exception_group_depth > max_group_depth: # exception group, but depth exceeds limit yield from _ctx.emit(f"... (max_group_depth is {max_group_depth})\n") @@ -151,6 +154,8 @@ def traceback_exception_format(self, *, chain=True, _ctx=None): yield from _ctx.emit(exc.stack.format()) yield from _ctx.emit(exc.format_exception_only()) + if isinstance(exc.__note__, str): + yield from _ctx.emit(line + "\n" for line in exc.__note__.split("\n")) num_excs = len(exc.exceptions) if num_excs <= max_group_width: n = num_excs
agronholm/exceptiongroup
6497dd07a4971a9e4f8f21d141c01bfc138d3acd
diff --git a/tests/test_exceptions.py b/tests/test_exceptions.py index 86f0540..2a19971 100644 --- a/tests/test_exceptions.py +++ b/tests/test_exceptions.py @@ -21,7 +21,9 @@ class TestExceptionGroupTypeHierarchy(unittest.TestCase): class BadConstructorArgs(unittest.TestCase): def test_bad_EG_construction__too_few_args(self): if sys.version_info >= (3, 11): - MSG = "function takes exactly 2 arguments" + MSG = ( + r"BaseExceptionGroup.__new__\(\) takes exactly 2 arguments \(1 given\)" + ) else: MSG = ( r"__new__\(\) missing 1 required positional argument: " @@ -35,7 +37,9 @@ class BadConstructorArgs(unittest.TestCase): def test_bad_EG_construction__too_many_args(self): if sys.version_info >= (3, 11): - MSG = "function takes exactly 2 arguments" + MSG = ( + r"BaseExceptionGroup.__new__\(\) takes exactly 2 arguments \(3 given\)" + ) else: MSG = r"__new__\(\) takes 3 positional arguments but 4 were given" @@ -61,7 +65,7 @@ class BadConstructorArgs(unittest.TestCase): ExceptionGroup("eg", []) def test_bad_EG_construction__nested_non_exceptions(self): - MSG = r"Item [0-9]+ of second argument \(exceptions\)" " is not an exception" + MSG = r"Item [0-9]+ of second argument \(exceptions\) is not an exception" with self.assertRaisesRegex(ValueError, MSG): ExceptionGroup("expect instance, not type", [OSError]) with self.assertRaisesRegex(ValueError, MSG): @@ -175,6 +179,14 @@ class ExceptionGroupFields(unittest.TestCase): with self.assertRaises(AttributeError): eg.exceptions = [OSError("xyz")] + def test_note_exists_and_is_string_or_none(self): + eg = create_simple_eg() + + note = "This is a happy note for the exception group" + self.assertIs(eg.__note__, None) + eg.__note__ = note + self.assertIs(eg.__note__, note) + class ExceptionGroupTestBase(unittest.TestCase): def assertMatchesTemplate(self, exc, exc_type, template): @@ -485,7 +497,7 @@ class ExceptionGroupSplitTestBase(ExceptionGroupTestBase): self.assertIs(eg.__cause__, part.__cause__) self.assertIs(eg.__context__, part.__context__) self.assertIs(eg.__traceback__, part.__traceback__) - # self.assertIs(eg.__note__, part.__note__) + self.assertIs(eg.__note__, part.__note__) def tbs_for_leaf(leaf, eg): for e, tbs in leaf_generator(eg): diff --git a/tests/test_formatting.py b/tests/test_formatting.py index 43060a7..5dc4f05 100644 --- a/tests/test_formatting.py +++ b/tests/test_formatting.py @@ -13,11 +13,13 @@ def test_formatting(capsys): try: raise RuntimeError("bar") except RuntimeError as exc: + exc.__note__ = "Note from bar handler" exceptions.append(exc) try: raise ExceptionGroup("test message", exceptions) except ExceptionGroup as exc: + exc.__note__ = "Displays notes attached to the group too" sys.excepthook(type(exc), exc, exc.__traceback__) lineno = test_formatting.__code__.co_firstlineno @@ -34,9 +36,10 @@ def test_formatting(capsys): assert output == ( f"""\ + Exception Group Traceback (most recent call last): - | File "{__file__}", line {lineno + 13}, in test_formatting + | File "{__file__}", line {lineno + 14}, in test_formatting | raise ExceptionGroup("test message", exceptions){underline1} | {module_prefix}ExceptionGroup: test message + | Displays notes attached to the group too +-+---------------- 1 ---------------- | Traceback (most recent call last): | File "{__file__}", line {lineno + 3}, in test_formatting @@ -47,6 +50,7 @@ def test_formatting(capsys): | File "{__file__}", line {lineno + 8}, in test_formatting | raise RuntimeError("bar"){underline3} | RuntimeError: bar + | Note from bar handler +------------------------------------ """ )
Display `__note__` from monkeypatched `TracebackException` type :wave: [PEP-678](https://www.python.org/dev/peps/pep-0678/) author here - I've been looking at how to port Hypothesis over to use `ExceptionGroup` (https://github.com/HypothesisWorks/hypothesis/pull/3191). If this backport started displaying the `__note__` string if present, I'd be able and very happy to throw out all* the old print-based code entirely! I'm happy to implement this, if you'd be willing to take a PR and cut the release? \*aside from a print-based, single-exception-only fallback for if monkeypatching is disabled on Python <3.11.
0.0
6497dd07a4971a9e4f8f21d141c01bfc138d3acd
[ "tests/test_exceptions.py::ExceptionGroupFields::test_note_exists_and_is_string_or_none", "tests/test_exceptions.py::NestedExceptionGroupSplitTest::test_split_BaseExceptionGroup", "tests/test_exceptions.py::NestedExceptionGroupSplitTest::test_split_by_type", "tests/test_exceptions.py::NestedExceptionGroupSubclassSplitTest::test_split_BaseExceptionGroup_subclass_no_derive_new_override", "tests/test_exceptions.py::NestedExceptionGroupSubclassSplitTest::test_split_ExceptionGroup_subclass_derive_and_new_overrides", "tests/test_exceptions.py::NestedExceptionGroupSubclassSplitTest::test_split_ExceptionGroup_subclass_no_derive_no_new_override", "tests/test_formatting.py::test_formatting" ]
[ "tests/test_exceptions.py::TestExceptionGroupTypeHierarchy::test_exception_group_is_generic_type", "tests/test_exceptions.py::TestExceptionGroupTypeHierarchy::test_exception_group_types", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__bad_excs_sequence", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__bad_message", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__nested_non_exceptions", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__too_few_args", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__too_many_args", "tests/test_exceptions.py::InstanceCreation::test_BEG_subclass_wraps_anything", "tests/test_exceptions.py::InstanceCreation::test_BEG_wraps_BaseException__creates_BEG", "tests/test_exceptions.py::InstanceCreation::test_BEG_wraps_Exceptions__creates_EG", "tests/test_exceptions.py::InstanceCreation::test_EG_subclass_wraps_anything", "tests/test_exceptions.py::InstanceCreation::test_EG_wraps_BaseException__raises_TypeError", "tests/test_exceptions.py::InstanceCreation::test_EG_wraps_Exceptions__creates_EG", "tests/test_exceptions.py::ExceptionGroupFields::test_basics_ExceptionGroup_fields", "tests/test_exceptions.py::ExceptionGroupFields::test_fields_are_readonly", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_predicate__match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_predicate__no_match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_predicate__passthrough", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_type__match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_type__no_match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_type__passthrough", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_split__bad_arg_type", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_predicate__match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_predicate__no_match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_predicate__passthrough", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_type__match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_type__no_match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_type__passthrough", "tests/test_exceptions.py::DeepRecursionInSplitAndSubgroup::test_deep_split", "tests/test_exceptions.py::DeepRecursionInSplitAndSubgroup::test_deep_subgroup", "tests/test_exceptions.py::LeafGeneratorTest::test_leaf_generator", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_iteration_full_tracebacks", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_nested_exception_group_tracebacks", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_nested_group_chaining", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_nested_group_matches_template", "tests/test_exceptions.py::test_repr" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2022-02-02 08:45:39+00:00
mit
933
agronholm__exceptiongroup-34
diff --git a/CHANGES.rst b/CHANGES.rst index 0c11a2c..8a847a8 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -3,6 +3,16 @@ Version history This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. +**UNRELEASED** + +- Fixed + ``AttributeError: 'PatchedTracebackException' object has no attribute '__cause__'`` + on Python 3.10 (only) when a traceback is printed from an exception where an exception + group is set as the cause (#33) +- Fixed a loop in exception groups being rendered incorrectly (#35) +- Fixed the patched formatting functions (``format_exception()``etc.) not passing the + ``compact=True`` flag on Python 3.10 like the original functions do + **1.0.0rc9** - Added custom versions of several ``traceback`` functions that work with exception diff --git a/src/exceptiongroup/_formatting.py b/src/exceptiongroup/_formatting.py index 2c74162..0bffd91 100644 --- a/src/exceptiongroup/_formatting.py +++ b/src/exceptiongroup/_formatting.py @@ -76,7 +76,7 @@ class PatchedTracebackException(traceback.TracebackException): self, exc_type: type[BaseException], exc_value: BaseException, - exc_traceback: TracebackType, + exc_traceback: TracebackType | None, *, limit: int | None = None, lookup_lines: bool = True, @@ -88,8 +88,6 @@ class PatchedTracebackException(traceback.TracebackException): if sys.version_info >= (3, 10): kwargs["compact"] = compact - # Capture the original exception and its cause and context as - # TracebackExceptions traceback_exception_original_init( self, exc_type, @@ -102,33 +100,82 @@ class PatchedTracebackException(traceback.TracebackException): **kwargs, ) - seen_was_none = _seen is None - + is_recursive_call = _seen is not None if _seen is None: _seen = set() + _seen.add(id(exc_value)) + + # Convert __cause__ and __context__ to `TracebackExceptions`s, use a + # queue to avoid recursion (only the top-level call gets _seen == None) + if not is_recursive_call: + queue = [(self, exc_value)] + while queue: + te, e = queue.pop() + + if e and e.__cause__ is not None and id(e.__cause__) not in _seen: + cause = PatchedTracebackException( + type(e.__cause__), + e.__cause__, + e.__cause__.__traceback__, + limit=limit, + lookup_lines=lookup_lines, + capture_locals=capture_locals, + _seen=_seen, + ) + else: + cause = None - # Capture each of the exceptions in the ExceptionGroup along with each of - # their causes and contexts - if isinstance(exc_value, BaseExceptionGroup): - embedded = [] - for exc in exc_value.exceptions: - if id(exc) not in _seen: - embedded.append( - PatchedTracebackException( + if compact: + need_context = ( + cause is None and e is not None and not e.__suppress_context__ + ) + else: + need_context = True + if ( + e + and e.__context__ is not None + and need_context + and id(e.__context__) not in _seen + ): + context = PatchedTracebackException( + type(e.__context__), + e.__context__, + e.__context__.__traceback__, + limit=limit, + lookup_lines=lookup_lines, + capture_locals=capture_locals, + _seen=_seen, + ) + else: + context = None + + # Capture each of the exceptions in the ExceptionGroup along with each + # of their causes and contexts + if e and isinstance(e, BaseExceptionGroup): + exceptions = [] + for exc in e.exceptions: + texc = PatchedTracebackException( type(exc), exc, exc.__traceback__, lookup_lines=lookup_lines, capture_locals=capture_locals, - # copy the set of _seen exceptions so that duplicates - # shared between sub-exceptions are not omitted - _seen=None if seen_was_none else set(_seen), + _seen=_seen, ) - ) - self.exceptions = embedded - self.msg = exc_value.message - else: - self.exceptions = None + exceptions.append(texc) + else: + exceptions = None + + te.__cause__ = cause + te.__context__ = context + te.exceptions = exceptions + if cause: + queue.append((te.__cause__, e.__cause__)) + if context: + queue.append((te.__context__, e.__context__)) + if exceptions: + queue.extend(zip(te.exceptions, e.exceptions)) + self.__notes__ = getattr(exc_value, "__notes__", ()) def format(self, *, chain=True, _ctx=None): @@ -280,7 +327,9 @@ if sys.excepthook is sys.__excepthook__: @singledispatch def format_exception_only(__exc: BaseException) -> List[str]: return list( - PatchedTracebackException(type(__exc), __exc, None).format_exception_only() + PatchedTracebackException( + type(__exc), __exc, None, compact=True + ).format_exception_only() ) @@ -297,7 +346,7 @@ def format_exception( ) -> List[str]: return list( PatchedTracebackException( - type(__exc), __exc, __exc.__traceback__, limit=limit + type(__exc), __exc, __exc.__traceback__, limit=limit, compact=True ).format(chain=chain) )
agronholm/exceptiongroup
91931b8284a141f3c2107d6ea87b457fa1025503
diff --git a/tests/test_formatting.py b/tests/test_formatting.py index 0270cb9..7cfc152 100644 --- a/tests/test_formatting.py +++ b/tests/test_formatting.py @@ -88,6 +88,70 @@ def test_exceptionhook(capsys: CaptureFixture) -> None: ) +def test_exceptiongroup_as_cause(capsys: CaptureFixture) -> None: + try: + raise Exception() from ExceptionGroup("", (Exception(),)) + except Exception as exc: + sys.excepthook(type(exc), exc, exc.__traceback__) + + lineno = test_exceptiongroup_as_cause.__code__.co_firstlineno + module_prefix = "" if sys.version_info >= (3, 11) else "exceptiongroup." + output = capsys.readouterr().err + assert output == ( + f"""\ + | {module_prefix}ExceptionGroup: (1 sub-exception) + +-+---------------- 1 ---------------- + | Exception + +------------------------------------ + +The above exception was the direct cause of the following exception: + +Traceback (most recent call last): + File "{__file__}", line {lineno + 2}, in test_exceptiongroup_as_cause + raise Exception() from ExceptionGroup("", (Exception(),)) +Exception +""" + ) + + +def test_exceptiongroup_loop(capsys: CaptureFixture) -> None: + e0 = Exception("e0") + eg0 = ExceptionGroup("eg0", (e0,)) + eg1 = ExceptionGroup("eg1", (eg0,)) + + try: + raise eg0 from eg1 + except ExceptionGroup as exc: + sys.excepthook(type(exc), exc, exc.__traceback__) + + lineno = test_exceptiongroup_loop.__code__.co_firstlineno + 6 + module_prefix = "" if sys.version_info >= (3, 11) else "exceptiongroup." + output = capsys.readouterr().err + assert output == ( + f"""\ + | {module_prefix}ExceptionGroup: eg1 (1 sub-exception) + +-+---------------- 1 ---------------- + | Exception Group Traceback (most recent call last): + | File "{__file__}", line {lineno}, in test_exceptiongroup_loop + | raise eg0 from eg1 + | {module_prefix}ExceptionGroup: eg0 (1 sub-exception) + +-+---------------- 1 ---------------- + | Exception: e0 + +------------------------------------ + +The above exception was the direct cause of the following exception: + + + Exception Group Traceback (most recent call last): + | File "{__file__}", line {lineno}, in test_exceptiongroup_loop + | raise eg0 from eg1 + | {module_prefix}ExceptionGroup: eg0 (1 sub-exception) + +-+---------------- 1 ---------------- + | Exception: e0 + +------------------------------------ +""" + ) + + def test_exceptionhook_format_exception_only(capsys: CaptureFixture) -> None: try: raise_excgroup()
Bizarre error in `sys.excepthook` with recursive calls ```python-traceback Error in sys.excepthook: Traceback (most recent call last): File "/root/.pyenv/versions/3.10.4/lib/python3.10/site-packages/exceptiongroup/_formatting.py", line 71, in exceptiongroup_excepthook sys.stderr.write("".join(traceback.format_exception(etype, value, tb))) File "/root/.pyenv/versions/3.10.4/lib/python3.10/traceback.py", line 136, in format_exception return list(te.format(chain=chain)) File "/root/.pyenv/versions/3.10.4/lib/python3.10/site-packages/exceptiongroup/_formatting.py", line 206, in format yield from exc.exceptions[i].format(chain=chain, _ctx=_ctx) File "/root/.pyenv/versions/3.10.4/lib/python3.10/site-packages/exceptiongroup/_formatting.py", line 142, in format if exc.__cause__ is not None: AttributeError: 'PatchedTracebackException' object has no attribute '__cause__'. Did you mean: '__class__'? ``` I'm pretty sure this is because [the upstream `__init__` method doesn't assign `__cause__` for recursive calls](https://github.com/python/cpython/blob/dddbbd9e3e4e12ed5a805dd4e08953e3332a15ea/Lib/traceback.py#L525-L567), and so if you happen to hit this (on `exceptiongroup == 1.0.0rc9`) you subsequently crash with an AttributeError. I think the obvious `getattr(exc, "__cause__", None)` patch is probably the best way forward; happy to write that if you'd like. Unfortunately I don't have a good reproducing case or indeed any way to reproduce this locally - it's consistently crashing _only_ in a particular build and CI system, and at time of writing I've worked out why but not constructed a repro.
0.0
91931b8284a141f3c2107d6ea87b457fa1025503
[ "tests/test_formatting.py::test_exceptiongroup_loop" ]
[ "tests/test_formatting.py::test_exceptionhook", "tests/test_formatting.py::test_exceptiongroup_as_cause", "tests/test_formatting.py::test_exceptionhook_format_exception_only", "tests/test_formatting.py::test_formatting_syntax_error", "tests/test_formatting.py::test_format_exception[patched-newstyle]", "tests/test_formatting.py::test_format_exception[patched-oldstyle]", "tests/test_formatting.py::test_format_exception[unpatched-newstyle]", "tests/test_formatting.py::test_format_exception[unpatched-oldstyle]", "tests/test_formatting.py::test_format_exception_only[patched-newstyle]", "tests/test_formatting.py::test_format_exception_only[patched-oldstyle]", "tests/test_formatting.py::test_format_exception_only[unpatched-newstyle]", "tests/test_formatting.py::test_format_exception_only[unpatched-oldstyle]", "tests/test_formatting.py::test_print_exception[patched-newstyle]", "tests/test_formatting.py::test_print_exception[patched-oldstyle]", "tests/test_formatting.py::test_print_exception[unpatched-newstyle]", "tests/test_formatting.py::test_print_exception[unpatched-oldstyle]", "tests/test_formatting.py::test_print_exc[patched]", "tests/test_formatting.py::test_print_exc[unpatched]" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2022-10-26 22:22:11+00:00
mit
934
agronholm__exceptiongroup-51
diff --git a/.pre-commit-config.yaml b/.pre-commit-config.yaml index 038c6c8..14901c8 100644 --- a/.pre-commit-config.yaml +++ b/.pre-commit-config.yaml @@ -21,13 +21,13 @@ repos: - id: isort - repo: https://github.com/asottile/pyupgrade - rev: v3.3.0 + rev: v3.3.1 hooks: - id: pyupgrade args: ["--py37-plus", "--keep-runtime-typing"] - repo: https://github.com/psf/black - rev: 22.10.0 + rev: 22.12.0 hooks: - id: black exclude: "tests/test_catch_py311.py" diff --git a/CHANGES.rst b/CHANGES.rst index c2af7ae..ee46dfd 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -3,6 +3,11 @@ Version history This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. +**UNRELEASED** + +- Backported upstream fix for gh-99553 (custom subclasses of ``BaseExceptionGroup`` that + also inherit from ``Exception`` should not be able to wrap base exceptions) + **1.0.4** - Fixed regression introduced in v1.0.3 where the code computing the suggestions would diff --git a/src/exceptiongroup/_exceptions.py b/src/exceptiongroup/_exceptions.py index ebdd172..a2ca092 100644 --- a/src/exceptiongroup/_exceptions.py +++ b/src/exceptiongroup/_exceptions.py @@ -67,6 +67,18 @@ class BaseExceptionGroup(BaseException, Generic[_BaseExceptionT_co]): if all(isinstance(exc, Exception) for exc in __exceptions): cls = ExceptionGroup + if issubclass(cls, Exception): + for exc in __exceptions: + if not isinstance(exc, Exception): + if cls is ExceptionGroup: + raise TypeError( + "Cannot nest BaseExceptions in an ExceptionGroup" + ) + else: + raise TypeError( + f"Cannot nest BaseExceptions in {cls.__name__!r}" + ) + return super().__new__(cls, __message, __exceptions) def __init__( @@ -219,15 +231,7 @@ class BaseExceptionGroup(BaseException, Generic[_BaseExceptionT_co]): class ExceptionGroup(BaseExceptionGroup[_ExceptionT_co], Exception): def __new__(cls, __message: str, __exceptions: Sequence[_ExceptionT_co]) -> Self: - instance: ExceptionGroup[_ExceptionT_co] = super().__new__( - cls, __message, __exceptions - ) - if cls is ExceptionGroup: - for exc in __exceptions: - if not isinstance(exc, Exception): - raise TypeError("Cannot nest BaseExceptions in an ExceptionGroup") - - return instance + return super().__new__(cls, __message, __exceptions) if TYPE_CHECKING:
agronholm/exceptiongroup
6abcee5c4177a09fac1bd0bc82ecba33e7d99478
diff --git a/.github/workflows/test.yml b/.github/workflows/test.yml index 77d65b2..311aec4 100644 --- a/.github/workflows/test.yml +++ b/.github/workflows/test.yml @@ -40,7 +40,7 @@ jobs: path: ~/.cache/pip key: pip-test-${{ matrix.python-version }}-${{ matrix.os }} - name: Install dependencies - run: pip install .[test] coverage[toml] coveralls + run: pip install .[test] coveralls coverage[toml] - name: Test with pytest run: coverage run -m pytest - name: Upload Coverage diff --git a/tests/test_exceptions.py b/tests/test_exceptions.py index d0d33cd..9a0e39b 100644 --- a/tests/test_exceptions.py +++ b/tests/test_exceptions.py @@ -3,6 +3,8 @@ import collections.abc import sys import unittest +import pytest + from exceptiongroup import BaseExceptionGroup, ExceptionGroup @@ -90,19 +92,35 @@ class InstanceCreation(unittest.TestCase): beg = BaseExceptionGroup("beg", [ValueError(1), KeyboardInterrupt(2)]) self.assertIs(type(beg), BaseExceptionGroup) - def test_EG_subclass_wraps_anything(self): + def test_EG_subclass_wraps_non_base_exceptions(self): class MyEG(ExceptionGroup): pass self.assertIs(type(MyEG("eg", [ValueError(12), TypeError(42)])), MyEG) - self.assertIs(type(MyEG("eg", [ValueError(12), KeyboardInterrupt(42)])), MyEG) - def test_BEG_subclass_wraps_anything(self): - class MyBEG(BaseExceptionGroup): + @pytest.mark.skipif( + sys.version_info[:3] == (3, 11, 0), + reason="Behavior was made stricter in 3.11.1", + ) + def test_EG_subclass_does_not_wrap_base_exceptions(self): + class MyEG(ExceptionGroup): + pass + + msg = "Cannot nest BaseExceptions in 'MyEG'" + with self.assertRaisesRegex(TypeError, msg): + MyEG("eg", [ValueError(12), KeyboardInterrupt(42)]) + + @pytest.mark.skipif( + sys.version_info[:3] == (3, 11, 0), + reason="Behavior was made stricter in 3.11.1", + ) + def test_BEG_and_E_subclass_does_not_wrap_base_exceptions(self): + class MyEG(BaseExceptionGroup, ValueError): pass - self.assertIs(type(MyBEG("eg", [ValueError(12), TypeError(42)])), MyBEG) - self.assertIs(type(MyBEG("eg", [ValueError(12), KeyboardInterrupt(42)])), MyBEG) + msg = "Cannot nest BaseExceptions in 'MyEG'" + with self.assertRaisesRegex(TypeError, msg): + MyEG("eg", [ValueError(12), KeyboardInterrupt(42)]) def create_simple_eg():
Needs update for 3.11.1 3.11.1 merged a fix to https://github.com/python/cpython/issues/99553 (PR: https://github.com/python/cpython/pull/99572) which included a change in behaviour. Currently `test_EG_subclass_wraps_anything` is broken, when run on 3.11.1.
0.0
6abcee5c4177a09fac1bd0bc82ecba33e7d99478
[ "tests/test_exceptions.py::InstanceCreation::test_BEG_and_E_subclass_does_not_wrap_base_exceptions", "tests/test_exceptions.py::InstanceCreation::test_EG_subclass_does_not_wrap_base_exceptions" ]
[ "tests/test_exceptions.py::TestExceptionGroupTypeHierarchy::test_exception_group_is_generic_type", "tests/test_exceptions.py::TestExceptionGroupTypeHierarchy::test_exception_group_types", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__bad_excs_sequence", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__bad_message", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__nested_non_exceptions", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__too_few_args", "tests/test_exceptions.py::BadConstructorArgs::test_bad_EG_construction__too_many_args", "tests/test_exceptions.py::InstanceCreation::test_BEG_wraps_BaseException__creates_BEG", "tests/test_exceptions.py::InstanceCreation::test_BEG_wraps_Exceptions__creates_EG", "tests/test_exceptions.py::InstanceCreation::test_EG_subclass_wraps_non_base_exceptions", "tests/test_exceptions.py::InstanceCreation::test_EG_wraps_BaseException__raises_TypeError", "tests/test_exceptions.py::InstanceCreation::test_EG_wraps_Exceptions__creates_EG", "tests/test_exceptions.py::ExceptionGroupFields::test_basics_ExceptionGroup_fields", "tests/test_exceptions.py::ExceptionGroupFields::test_fields_are_readonly", "tests/test_exceptions.py::ExceptionGroupFields::test_notes_is_list_of_strings_if_it_exists", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_predicate__match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_predicate__no_match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_predicate__passthrough", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_type__match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_type__no_match", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_by_type__passthrough", "tests/test_exceptions.py::ExceptionGroupSubgroupTests::test_basics_subgroup_split__bad_arg_type", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_predicate__match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_predicate__no_match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_predicate__passthrough", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_type__match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_type__no_match", "tests/test_exceptions.py::ExceptionGroupSplitTests::test_basics_split_by_type__passthrough", "tests/test_exceptions.py::DeepRecursionInSplitAndSubgroup::test_deep_split", "tests/test_exceptions.py::DeepRecursionInSplitAndSubgroup::test_deep_subgroup", "tests/test_exceptions.py::LeafGeneratorTest::test_leaf_generator", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_iteration_full_tracebacks", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_nested_exception_group_tracebacks", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_nested_group_chaining", "tests/test_exceptions.py::NestedExceptionGroupBasicsTest::test_nested_group_matches_template", "tests/test_exceptions.py::NestedExceptionGroupSplitTest::test_split_BaseExceptionGroup", "tests/test_exceptions.py::NestedExceptionGroupSplitTest::test_split_by_type", "tests/test_exceptions.py::NestedExceptionGroupSubclassSplitTest::test_split_BaseExceptionGroup_subclass_no_derive_new_override", "tests/test_exceptions.py::NestedExceptionGroupSubclassSplitTest::test_split_ExceptionGroup_subclass_derive_and_new_overrides", "tests/test_exceptions.py::NestedExceptionGroupSubclassSplitTest::test_split_ExceptionGroup_subclass_no_derive_no_new_override", "tests/test_exceptions.py::test_repr" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks", "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2022-12-10 14:15:05+00:00
mit
935
agronholm__smtpproto-2
diff --git a/docs/versionhistory.rst b/docs/versionhistory.rst index 2bc4d25..459ca8b 100644 --- a/docs/versionhistory.rst +++ b/docs/versionhistory.rst @@ -7,6 +7,8 @@ This library adheres to `Semantic Versioning 2.0 <http://semver.org/>`_. - Added missing ``authorization_id`` parameter to ``PlainAuthenticator`` (also fixes ``PLAIN`` authentication not working since this field was missing from the encoded output) +- Fixed sender/recipient addresses (in ``MAIL``/``RCPT`` commands) not being UTF-8 encoded in the + presence of the ``SMTPUTF8`` extension **1.0.0** diff --git a/setup.cfg b/setup.cfg index 98ba6a2..32510b1 100644 --- a/setup.cfg +++ b/setup.cfg @@ -18,6 +18,7 @@ classifiers = Programming Language :: Python :: 3.6 Programming Language :: Python :: 3.7 Programming Language :: Python :: 3.8 + Programming Language :: Python :: 3.9 [options] package_dir= @@ -26,7 +27,7 @@ packages = find: python_requires = >= 3.6.2 zip_safe = False install_requires = - anyio ~= 2.0.0b2 + anyio ~= 2.0 dataclasses; python_version < "3.7" [options.packages.find] diff --git a/src/smtpproto/protocol.py b/src/smtpproto/protocol.py index 4f5dcc2..e4ce01f 100644 --- a/src/smtpproto/protocol.py +++ b/src/smtpproto/protocol.py @@ -64,7 +64,7 @@ class SMTPClientProtocol: _response_code: Optional[int] = field(init=False, default=None) _response_lines: List[str] = field(init=False, default_factory=list) _command_sent: Optional[str] = field(init=False, default=None) - _args_sent: Optional[Tuple[str, ...]] = field(init=False, default=None) + _args_sent: Optional[Tuple[bytes, ...]] = field(init=False, default=None) _extensions: FrozenSet[str] = field(init=False, default_factory=frozenset) _auth_mechanisms: FrozenSet[str] = field(init=False, default_factory=frozenset) _max_message_size: Optional[int] = field(init=False, default=None) @@ -85,18 +85,36 @@ class SMTPClientProtocol: raise SMTPUnsupportedAuthMechanism( f'{mechanism} is not a supported authentication mechanism on this server') - def _send_command(self, command: str, *args: str) -> None: + def _encode_address(self, address: Union[str, Address]) -> bytes: + if isinstance(address, Address): + address_str = f'{address.username}@{address.domain}' + else: + address_str = address + + if 'SMTPUTF8' in self._extensions: + return address_str.encode('utf-8') + + # If SMPTUTF8 is not supported, the address must be ASCII compatible + try: + return address_str.encode('ascii') + except UnicodeEncodeError: + raise SMTPProtocolViolation( + f'The address {address_str!r} requires UTF-8 encoding but the server does not ' + f'support the SMTPUTF8 extension') + + def _send_command(self, command: str, *args: Union[str, bytes]) -> None: if self._command_sent is not None: raise SMTPProtocolViolation('Tried to send a command before the previous one received ' 'a response') - line = command - if args: - line += ' ' + ' '.join(args) + line = command.encode('ascii') + args_encoded = tuple(arg.encode('ascii') if isinstance(arg, str) else arg for arg in args) + if args_encoded: + line += b' ' + b' '.join(args_encoded) - self._out_buffer += line.encode('ascii') + b'\r\n' + self._out_buffer += line + b'\r\n' self._command_sent = command - self._args_sent = args + self._args_sent = args_encoded def _parse_extensions(self, lines: Iterable[str]) -> None: auth_mechanisms: List[str] = [] @@ -291,9 +309,10 @@ class SMTPClientProtocol: args = [] if '8BITMIME' in self._extensions: args.append('BODY=8BITMIME') + if 'SMTPUTF8' in self._extensions: + args.append('SMTPUTF8') - address = sender.addr_spec if isinstance(sender, Address) else sender - self._send_command('MAIL', 'FROM:<' + address + '>', *args) + self._send_command('MAIL', b'FROM:<' + self._encode_address(sender) + b'>', *args) def recipient(self, recipient: Union[str, Address]) -> None: """ @@ -305,8 +324,7 @@ class SMTPClientProtocol: """ self._require_state(ClientState.mailtx, ClientState.recipient_sent) - address = recipient.addr_spec if isinstance(recipient, Address) else recipient - self._send_command('RCPT', f'TO:<{address}>') + self._send_command('RCPT', b'TO:<' + self._encode_address(recipient) + b'>') def start_data(self) -> None: """
agronholm/smtpproto
dce2522587bfd0790837843e1fb5b9c6e9d83b3b
diff --git a/.github/workflows/codeqa-test.yml b/.github/workflows/codeqa-test.yml index 45ff699..764333a 100644 --- a/.github/workflows/codeqa-test.yml +++ b/.github/workflows/codeqa-test.yml @@ -34,7 +34,7 @@ jobs: strategy: fail-fast: false matrix: - python-version: [3.6, 3.7, 3.8] + python-version: [3.6, 3.7, 3.8, 3.9] runs-on: ubuntu-latest steps: - uses: actions/checkout@v2 diff --git a/tests/test_protocol.py b/tests/test_protocol.py index ae63149..14cccff 100644 --- a/tests/test_protocol.py +++ b/tests/test_protocol.py @@ -65,7 +65,12 @@ def exchange_greetings(protocol, esmtp=True): def start_mail_tx(protocol): # Start a mail transaction - extra_args = b' BODY=8BITMIME' if '8BITMIME' in protocol.extensions else b'' + extra_args = b'' + if '8BITMIME' in protocol.extensions: + extra_args += b' BODY=8BITMIME' + if 'SMTPUTF8' in protocol.extensions: + extra_args += b' SMTPUTF8' + call_protocol_method(protocol, lambda: protocol.mail('[email protected]'), b'MAIL FROM:<[email protected]>' + extra_args + b'\r\n') feed_bytes(protocol, b'250 OK\r\n', 250, 'OK', ClientState.mailtx) @@ -87,6 +92,14 @@ def start_mail_tx(protocol): 'Start mail input; end with <CRLF>.<CRLF>', ClientState.send_data) [email protected](params=[ + 'héllö@example.org', + Address('Héllö World', 'héllö', 'example.org') +], ids=['str', 'object']) +def unicode_address(request): + return request.param + + @pytest.fixture def protocol(): proto = SMTPClientProtocol() @@ -100,7 +113,7 @@ def protocol(): pytest.param(False, 'base64', 'This is a =?utf-8?q?subj=C3=ABct?=', 'VGhpcyBpcyDDpCB0ZXN0IG1lc3NhZ2UuCg==', id='7bit') ]) -def test_send_mail_utf8(protocol, esmtp, expected_cte, expected_subject, expected_body): +def test_send_mail_utf8_content(protocol, esmtp, expected_cte, expected_subject, expected_body): exchange_greetings(protocol, esmtp=esmtp) start_mail_tx(protocol) @@ -116,6 +129,29 @@ def test_send_mail_utf8(protocol, esmtp, expected_cte, expected_subject, expecte feed_bytes(protocol, b'250 OK\r\n', 250, 'OK', ClientState.ready) +def test_send_mail_utf8_addresses(protocol, unicode_address): + exchange_greetings(protocol) + protocol.mail(unicode_address) + feed_bytes(protocol, b'250 OK\r\n', 250, 'OK', ClientState.mailtx) + protocol.recipient(unicode_address) + feed_bytes(protocol, b'250 OK\r\n', 250, 'OK', ClientState.recipient_sent) + + +def test_send_mail_unicode_sender_encoding_error(protocol, unicode_address): + exchange_greetings(protocol, esmtp=False) + exc = pytest.raises(SMTPProtocolViolation, protocol.mail, unicode_address) + exc.match("^The address 'héllö@example.org' requires UTF-8") + + +def test_send_mail_unicode_recipient_encoding_error(protocol, unicode_address): + exchange_greetings(protocol, esmtp=False) + protocol.mail('[email protected]') + feed_bytes(protocol, b'250 OK\r\n', 250, 'OK', ClientState.mailtx) + + exc = pytest.raises(SMTPProtocolViolation, protocol.recipient, unicode_address) + exc.match("^The address 'héllö@example.org' requires UTF-8") + + def test_send_mail_escape_dots(protocol): exchange_greetings(protocol) start_mail_tx(protocol) @@ -158,7 +194,7 @@ def test_double_command(protocol): def test_authentication_required(protocol): exchange_greetings(protocol) call_protocol_method(protocol, lambda: protocol.mail('[email protected]'), - b'MAIL FROM:<[email protected]> BODY=8BITMIME\r\n') + b'MAIL FROM:<[email protected]> BODY=8BITMIME SMTPUTF8\r\n') feed_bytes(protocol, b'530 Authentication required\r\n', 530, 'Authentication required') @@ -277,7 +313,7 @@ def test_helo_error(protocol, error_code): def test_mail_error(protocol, error_code): exchange_greetings(protocol) call_protocol_method(protocol, lambda: protocol.mail('foo@bar'), - b'MAIL FROM:<foo@bar> BODY=8BITMIME\r\n') + b'MAIL FROM:<foo@bar> BODY=8BITMIME SMTPUTF8\r\n') feed_bytes(protocol, f'{error_code} Error\r\n'.encode(), error_code, 'Error') @@ -285,7 +321,7 @@ def test_mail_error(protocol, error_code): def test_rcpt_error(protocol, error_code): exchange_greetings(protocol) call_protocol_method(protocol, lambda: protocol.mail('foo@bar'), - b'MAIL FROM:<foo@bar> BODY=8BITMIME\r\n') + b'MAIL FROM:<foo@bar> BODY=8BITMIME SMTPUTF8\r\n') feed_bytes(protocol, b'250 OK\r\n', 250, 'OK') call_protocol_method(protocol, lambda: protocol.recipient('foo@bar'), b'RCPT TO:<foo@bar>\r\n') feed_bytes(protocol, f'{error_code} Error\r\n'.encode(), error_code, 'Error') @@ -295,7 +331,7 @@ def test_rcpt_error(protocol, error_code): def test_start_data_error(protocol, error_code): exchange_greetings(protocol) call_protocol_method(protocol, lambda: protocol.mail('foo@bar'), - b'MAIL FROM:<foo@bar> BODY=8BITMIME\r\n') + b'MAIL FROM:<foo@bar> BODY=8BITMIME SMTPUTF8\r\n') feed_bytes(protocol, b'250 OK\r\n', 250, 'OK') call_protocol_method(protocol, lambda: protocol.recipient('foo@bar'), b'RCPT TO:<foo@bar>\r\n') feed_bytes(protocol, b'250 OK\r\n', 250, 'OK')
SMTPUTF8 mail command handling It looks like smtpproto correctly handles the message body when the SMTPUTF8 extension is available. However, [per the spec](https://tools.ietf.org/html/rfc6531#section-3.4), the `MAIL FROM` command should include the `SMTPUTF8` option in that case. Currently there's no way to pass an option via the `mail` method. This could be solved by adding an options argument to that method. It also seems like all output is always ASCII encoded. However, if SMTPUTF8 is supported and being used for the message, the `MAIL FROM` command (and subsequent `RCPT` commands) should be sent UTF-8 encoded.
0.0
dce2522587bfd0790837843e1fb5b9c6e9d83b3b
[ "tests/test_protocol.py::test_send_mail_utf8_content[8bit]", "tests/test_protocol.py::test_send_mail_utf8_addresses[str]", "tests/test_protocol.py::test_send_mail_utf8_addresses[object]", "tests/test_protocol.py::test_send_mail_unicode_sender_encoding_error[str]", "tests/test_protocol.py::test_send_mail_unicode_sender_encoding_error[object]", "tests/test_protocol.py::test_send_mail_unicode_recipient_encoding_error[str]", "tests/test_protocol.py::test_send_mail_unicode_recipient_encoding_error[object]", "tests/test_protocol.py::test_send_mail_escape_dots", "tests/test_protocol.py::test_reset_mail_tx", "tests/test_protocol.py::test_authentication_required", "tests/test_protocol.py::test_mail_error[451]", "tests/test_protocol.py::test_mail_error[452]", "tests/test_protocol.py::test_mail_error[455]", "tests/test_protocol.py::test_mail_error[503]", "tests/test_protocol.py::test_mail_error[550]", "tests/test_protocol.py::test_mail_error[553]", "tests/test_protocol.py::test_mail_error[552]", "tests/test_protocol.py::test_mail_error[555]", "tests/test_protocol.py::test_rcpt_error[450]", "tests/test_protocol.py::test_rcpt_error[451]", "tests/test_protocol.py::test_rcpt_error[452]", "tests/test_protocol.py::test_rcpt_error[455]", "tests/test_protocol.py::test_rcpt_error[503]", "tests/test_protocol.py::test_rcpt_error[550]", "tests/test_protocol.py::test_rcpt_error[551]", "tests/test_protocol.py::test_rcpt_error[552]", "tests/test_protocol.py::test_rcpt_error[553]", "tests/test_protocol.py::test_rcpt_error[555]", "tests/test_protocol.py::test_start_data_error[450]", "tests/test_protocol.py::test_start_data_error[451]", "tests/test_protocol.py::test_start_data_error[452]", "tests/test_protocol.py::test_start_data_error[503]", "tests/test_protocol.py::test_start_data_error[550]", "tests/test_protocol.py::test_start_data_error[552]", "tests/test_protocol.py::test_start_data_error[554]" ]
[ "tests/test_protocol.py::test_send_mail_utf8_content[7bit]", "tests/test_protocol.py::test_bad_greeting", "tests/test_protocol.py::test_premature_greeting", "tests/test_protocol.py::test_double_command", "tests/test_protocol.py::test_noop", "tests/test_protocol.py::test_start_tls", "tests/test_protocol.py::test_start_tls_missing_extension", "tests/test_protocol.py::test_quit", "tests/test_protocol.py::test_auth_with_unsupported_mechanism", "tests/test_protocol.py::test_auth_plain", "tests/test_protocol.py::test_auth_plain_failure[432]", "tests/test_protocol.py::test_auth_plain_failure[454]", "tests/test_protocol.py::test_auth_plain_failure[500]", "tests/test_protocol.py::test_auth_plain_failure[534]", "tests/test_protocol.py::test_auth_plain_failure[535]", "tests/test_protocol.py::test_auth_plain_failure[538]", "tests/test_protocol.py::test_auth_login", "tests/test_protocol.py::test_auth_login_failure[432]", "tests/test_protocol.py::test_auth_login_failure[454]", "tests/test_protocol.py::test_auth_login_failure[500]", "tests/test_protocol.py::test_auth_login_failure[534]", "tests/test_protocol.py::test_auth_login_failure[535]", "tests/test_protocol.py::test_auth_login_failure[538]", "tests/test_protocol.py::test_server_invalid_input", "tests/test_protocol.py::test_server_invalid_continuation", "tests/test_protocol.py::test_server_invalid_status_code", "tests/test_protocol.py::test_ehlo_error[504]", "tests/test_protocol.py::test_ehlo_error[550]", "tests/test_protocol.py::test_helo_error[502]", "tests/test_protocol.py::test_helo_error[504]", "tests/test_protocol.py::test_helo_error[550]" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2021-01-01 14:54:31+00:00
mit
936
agronholm__sphinx-autodoc-typehints-64
diff --git a/sphinx_autodoc_typehints.py b/sphinx_autodoc_typehints.py index e7f8f4a..3eafe5b 100644 --- a/sphinx_autodoc_typehints.py +++ b/sphinx_autodoc_typehints.py @@ -117,6 +117,10 @@ def format_annotation(annotation): return '{}`~{}.{}`{}'.format(prefix, module, class_name, extra) elif annotation is Ellipsis: return '...' + elif (inspect.isfunction(annotation) and annotation.__module__ == 'typing' and + hasattr(annotation, '__name__') and hasattr(annotation, '__supertype__')): + return ':py:func:`~typing.NewType`\\(:py:data:`~{}`, {})'.format( + annotation.__name__, format_annotation(annotation.__supertype__)) elif inspect.isclass(annotation) or inspect.isclass(getattr(annotation, '__origin__', None)): if not inspect.isclass(annotation): annotation_cls = annotation.__origin__
agronholm/sphinx-autodoc-typehints
c6895fa568c7ad7fd8ade90eab5fce14c612902b
diff --git a/tests/test_sphinx_autodoc_typehints.py b/tests/test_sphinx_autodoc_typehints.py index cba630f..6c4df94 100644 --- a/tests/test_sphinx_autodoc_typehints.py +++ b/tests/test_sphinx_autodoc_typehints.py @@ -3,7 +3,8 @@ import pytest import sys import textwrap from typing import ( - Any, AnyStr, Callable, Dict, Generic, Mapping, Optional, Pattern, Tuple, TypeVar, Union, Type) + Any, AnyStr, Callable, Dict, Generic, Mapping, NewType, Optional, Pattern, + Tuple, TypeVar, Union, Type) from typing_extensions import Protocol @@ -12,6 +13,7 @@ from sphinx_autodoc_typehints import format_annotation, process_docstring T = TypeVar('T') U = TypeVar('U', covariant=True) V = TypeVar('V', contravariant=True) +W = NewType('W', str) class A: @@ -89,7 +91,8 @@ class Slotted: (C, ':py:class:`~%s.C`' % __name__), (D, ':py:class:`~%s.D`' % __name__), (E, ':py:class:`~%s.E`\\[\\~T]' % __name__), - (E[int], ':py:class:`~%s.E`\\[:py:class:`int`]' % __name__) + (E[int], ':py:class:`~%s.E`\\[:py:class:`int`]' % __name__), + (W, ':py:func:`~typing.NewType`\\(:py:data:`~W`, :py:class:`str`)') ]) def test_format_annotation(annotation, expected_result): result = format_annotation(annotation)
Types created with NewType are rendered poorly. If I have code like: ``` Foo = typing.NewType('Foo', str) def bar(x: Foo): pass ``` then its parameter gets documented as: ``` x (<function NewType.<locals>.new_type at 0x7f644b4c6488>) ``` I was expecting something like one of the following: ``` x (Foo) x (Foo alias for str) x (str) ```
0.0
c6895fa568c7ad7fd8ade90eab5fce14c612902b
[ "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[W-:py:func:`~typing.NewType`\\\\(:py:data:`~W`," ]
[ "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[str-:py:class:`str`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[int-:py:class:`int`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[NoneType-``None``]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation3-:py:data:`~typing.Any`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[AnyStr-:py:data:`~typing.AnyStr`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation5-:py:class:`~typing.Generic`\\\\[\\\\~T]]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation7-:py:class:`~typing.Mapping`\\\\[\\\\~T,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation8-:py:class:`~typing.Mapping`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation9-:py:class:`~typing.Mapping`\\\\[\\\\~T,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation10-:py:class:`~typing.Mapping`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation12-:py:class:`~typing.Dict`\\\\[\\\\~T,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation13-:py:class:`~typing.Dict`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation14-:py:class:`~typing.Dict`\\\\[\\\\~T,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation15-:py:class:`~typing.Dict`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation16-:py:class:`~typing.Tuple`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation17-:py:class:`~typing.Tuple`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation18-:py:class:`~typing.Tuple`\\\\[:py:class:`int`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation19-:py:class:`~typing.Tuple`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation20-:py:data:`~typing.Union`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation21-:py:data:`~typing.Union`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation22-:py:data:`~typing.Union`\\\\[:py:class:`str`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation23-:py:data:`~typing.Optional`\\\\[:py:class:`str`]]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation24-:py:data:`~typing.Callable`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation25-:py:data:`~typing.Callable`\\\\[...,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation26-:py:data:`~typing.Callable`\\\\[\\\\[:py:class:`int`],", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation27-:py:data:`~typing.Callable`\\\\[\\\\[:py:class:`int`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation28-:py:data:`~typing.Callable`\\\\[\\\\[:py:class:`int`,", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation29-:py:data:`~typing.Callable`\\\\[\\\\[\\\\~T],", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation31-:py:class:`~typing.Pattern`\\\\[:py:class:`str`]]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[A-:py:class:`~test_sphinx_autodoc_typehints.A`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[B-:py:class:`~test_sphinx_autodoc_typehints.B`\\\\[\\\\~T]]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation34-:py:class:`~test_sphinx_autodoc_typehints.B`\\\\[:py:class:`int`]]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[C-:py:class:`~test_sphinx_autodoc_typehints.C`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[D-:py:class:`~test_sphinx_autodoc_typehints.D`]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[E-:py:class:`~test_sphinx_autodoc_typehints.E`\\\\[\\\\~T]]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation[annotation38-:py:class:`~test_sphinx_autodoc_typehints.E`\\\\[:py:class:`int`]]", "tests/test_sphinx_autodoc_typehints.py::test_format_annotation_type[A-:py:class:`~typing.Type`\\\\[:py:class:`~test_sphinx_autodoc_typehints.A`]]", "tests/test_sphinx_autodoc_typehints.py::test_process_docstring_slot_wrapper" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2018-11-21 20:26:37+00:00
mit
937
ahawker__ulid-471
diff --git a/ulid/base32.py b/ulid/base32.py index 82f450e..83d734d 100644 --- a/ulid/base32.py +++ b/ulid/base32.py @@ -366,4 +366,10 @@ def str_to_bytes(value: str, expected_length: int) -> bytes: if decoding[byte] > 31: raise ValueError('Non-base32 character found: "{}"'.format(chr(byte))) + # Confirm most significant bit on timestamp value is limited so it can be stored in 128-bits. + if length in (10, 26): + msb = decoding[encoded[0]] + if msb > 7: + raise ValueError('Timestamp value too large and will overflow 128-bits. Must be between b"0" and b"7"') + return encoded
ahawker/ulid
359b8c889218a144053d2fa3bea3d04581421f1c
diff --git a/tests/conftest.py b/tests/conftest.py index 846861f..5bb6f87 100644 --- a/tests/conftest.py +++ b/tests/conftest.py @@ -16,6 +16,8 @@ from ulid import base32 ASCII_ALPHABET = ''.join(chr(d) for d in range(0, 128)) EXTENDED_ASCII_ALPHABET = ''.join(chr(d) for d in range(128, 256)) ASCII_NON_BASE_32_ALPHABET = ''.join(set(ASCII_ALPHABET).difference(set(base32.ENCODING))) +MSB_ASCII_ALPHABET = ''.join(chr(d) for d in range(48, 56)) +MSB_ASCII_INVALID_ALPHABET = ''.join(set(base32.ENCODING).difference(set(MSB_ASCII_ALPHABET))) MIN_EPOCH = 0 MAX_EPOCH = 281474976710655 @@ -195,6 +197,15 @@ def invalid_str_10(request): return random_str(request.param, not_in=[10]) [email protected](scope='function') +def invalid_str_10_msb_invalid(): + """ + Fixture that yields :class:`~str` instances that are 10 characters long and use an invalid + MSB. + """ + return random_str(10, msb_alphabet=MSB_ASCII_INVALID_ALPHABET) + + @pytest.fixture(scope='function', params=range(0, 32)) def invalid_str_10_16_26(request): """ @@ -289,7 +300,7 @@ def random_timestamp_bytes(): Helper function that returns a number of random bytes that represent a timestamp that are within the valid range. """ - value = random.randint(MIN_EPOCH, MAX_EPOCH + 1) + value = random.randint(MIN_EPOCH, MAX_EPOCH - 1) return value.to_bytes(6, byteorder='big') @@ -309,13 +320,13 @@ def random_bytes(num_bytes, not_in=(-1,)): return os.urandom(num_bytes) -def random_str(num_chars, alphabet=base32.ENCODING, not_in=(-1,)): +def random_str(num_chars, alphabet=base32.ENCODING, msb_alphabet=MSB_ASCII_ALPHABET, not_in=(-1,)): """ Helper function that returns a string with the specified number of random characters, optionally excluding those of a specific length. """ num_chars = num_chars + 1 if num_chars in not_in else num_chars - return ''.join(random.choice(alphabet) for _ in range(num_chars)) + return random.choice(msb_alphabet) + ''.join(random.choice(alphabet) for _ in range(num_chars - 1)) def fixed_year_timestamp_bytes(*args, **kwargs): diff --git a/tests/test_base32.py b/tests/test_base32.py index 7c069e6..2a4e4a5 100644 --- a/tests/test_base32.py +++ b/tests/test_base32.py @@ -18,6 +18,7 @@ DECODE_STR_LEN_EXC_REGEX = r'^Expects string in lengths of' DECODE_ULID_STR_LEN_EXC_REGEX = r'^Expects 26 characters for decoding' DECODE_TIMESTAMP_STR_LEN_EXC_REGEX = r'^Expects 10 characters for decoding' DECODE_RANDOMNESS_STR_LEN_EXC_REGEX = r'^Expects 16 characters for decoding' +TIMESTAMP_OVERFLOW_EXC_REGEX = r'Timestamp value too large and will overflow 128-bits. Must be between b"0" and b"7"' @pytest.fixture(scope='session') @@ -355,3 +356,13 @@ def test_str_to_bytes_raises_on_non_base32_decode_char(ascii_non_base32_str_vali with pytest.raises(ValueError) as ex: base32.str_to_bytes(ascii_non_base32_str_valid_length, len(ascii_non_base32_str_valid_length)) ex.match(NON_BASE_32_EXC_REGEX) + + +def test_str_to_bytes_raises_on_timestamp_msb_overflow(invalid_str_10_msb_invalid): + """ + Assert that :func:`~ulid.base32.str_to_bytes` raises a :class:`~ValueError` when given a :class:`~str` + instance that includes a valid length timestamp but MSB too large causing an overflow. + """ + with pytest.raises(ValueError) as ex: + base32.str_to_bytes(invalid_str_10_msb_invalid, len(invalid_str_10_msb_invalid)) + ex.match(TIMESTAMP_OVERFLOW_EXC_REGEX)
Add bounds checking for max timestamp overflow case We need to add validation for handling the max timestamp value, 2 ^ 48 - 1, 281474976710655. Spec notes are at https://github.com/ulid/spec#overflow-errors-when-parsing-base32-strings Parsing of the `t` value in the following example should raise an exception. ```python >>> import ulid >>> s = '7ZZZZZZZZZZZZZZZZZZZZZZZZZ' >>> t = '8ZZZZZZZZZZZZZZZZZZZZZZZZZ' >>> ulid.parse(s) <ULID('7ZZZZZZZZZZZZZZZZZZZZZZZZZ')> >>> ulid.parse(t) <ULID('0ZZZZZZZZZZZZZZZZZZZZZZZZZ')> ``` <blockquote><img src="https://avatars1.githubusercontent.com/u/33265518?s=400&v=4" width="48" align="right"><div><img src="https://github.githubassets.com/favicons/favicon.svg" height="14"> GitHub</div><div><strong><a href="https://github.com/ulid/spec">ulid/spec</a></strong></div><div>The canonical spec for ulid. Contribute to ulid/spec development by creating an account on GitHub.</div></blockquote>
0.0
359b8c889218a144053d2fa3bea3d04581421f1c
[ "tests/test_base32.py::test_str_to_bytes_raises_on_timestamp_msb_overflow" ]
[ "tests/test_base32.py::test_encode_handles_ulid_and_returns_26_char_string", "tests/test_base32.py::test_encode_handles_timestamp_and_returns_10_char_string", "tests/test_base32.py::test_encode_handles_randomness_and_returns_16_char_string", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_ulid_returns_26_char_string", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_timestamp_returns_10_char_string", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_randomness_returns_16_char_string", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_decode_handles_ulid_and_returns_16_bytes", "tests/test_base32.py::test_decode_handles_timestamp_and_returns_6_bytes", "tests/test_base32.py::test_decode_handles_randomness_and_returns_10_bytes", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_raises_on_extended_ascii_str[10]", "tests/test_base32.py::test_decode_raises_on_extended_ascii_str[16]", "tests/test_base32.py::test_decode_raises_on_extended_ascii_str[26]", "tests/test_base32.py::test_decode_raises_on_non_base32_decode_char[10]", "tests/test_base32.py::test_decode_raises_on_non_base32_decode_char[16]", "tests/test_base32.py::test_decode_raises_on_non_base32_decode_char[26]", "tests/test_base32.py::test_decode_ulid_returns_16_bytes", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str", "tests/test_base32.py::test_decode_ulid_raises_on_non_base32_decode_char", "tests/test_base32.py::test_decode_timestamp_returns_6_bytes", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str", "tests/test_base32.py::test_decode_timestamp_raises_on_non_base32_decode_char", "tests/test_base32.py::test_decode_randomness_returns_10_bytes", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str", "tests/test_base32.py::test_decode_randomness_raises_on_non_base32_decode_char", "tests/test_base32.py::test_decode_table_has_value_for_entire_decoding_alphabet", "tests/test_base32.py::test_str_to_bytes_returns_expected_bytes[10]", "tests/test_base32.py::test_str_to_bytes_returns_expected_bytes[16]", "tests/test_base32.py::test_str_to_bytes_returns_expected_bytes[26]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[0]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[1]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[2]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[3]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[4]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[5]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[6]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[7]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[8]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[9]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[10]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[11]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[12]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[13]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[14]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[15]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[16]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[17]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[18]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[19]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[20]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[21]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[22]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[23]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[24]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[25]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[26]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[27]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[28]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[29]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[30]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[31]", "tests/test_base32.py::test_str_to_bytes_raises_on_extended_ascii_str[10]", "tests/test_base32.py::test_str_to_bytes_raises_on_extended_ascii_str[16]", "tests/test_base32.py::test_str_to_bytes_raises_on_extended_ascii_str[26]", "tests/test_base32.py::test_str_to_bytes_raises_on_non_base32_decode_char[10]", "tests/test_base32.py::test_str_to_bytes_raises_on_non_base32_decode_char[16]", "tests/test_base32.py::test_str_to_bytes_raises_on_non_base32_decode_char[26]" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_media", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2020-08-10 22:12:12+00:00
apache-2.0
938
ahawker__ulid-59
diff --git a/ulid/base32.py b/ulid/base32.py index 83f8a8a..f7377b6 100644 --- a/ulid/base32.py +++ b/ulid/base32.py @@ -31,11 +31,11 @@ DECODING = array.array( 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0x00, 0x01, 0x02, 0x03, 0x04, 0x05, 0x06, 0x07, 0x08, 0x09, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0x0A, 0x0B, 0x0C, 0x0D, 0x0E, - 0x0F, 0x10, 0x11, 0xFF, 0x12, 0x13, 0xFF, 0x14, 0x15, 0xFF, + 0x0F, 0x10, 0x11, 0x01, 0x12, 0x13, 0x01, 0x14, 0x15, 0x00, 0x16, 0x17, 0x18, 0x19, 0x1A, 0xFF, 0x1B, 0x1C, 0x1D, 0x1E, 0x1F, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0x0A, 0x0B, 0x0C, - 0x0D, 0x0E, 0x0F, 0x10, 0x11, 0xFF, 0x12, 0x13, 0xFF, 0x14, - 0x15, 0xFF, 0x16, 0x17, 0x18, 0x19, 0x1A, 0xFF, 0x1B, 0x1C, + 0x0D, 0x0E, 0x0F, 0x10, 0x11, 0x01, 0x12, 0x13, 0x01, 0x14, + 0x15, 0x00, 0x16, 0x17, 0x18, 0x19, 0x1A, 0xFF, 0x1B, 0x1C, 0x1D, 0x1E, 0x1F, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF, 0xFF,
ahawker/ulid
efdac942d7f969c802903f574965ca860882a891
diff --git a/tests/test_base32.py b/tests/test_base32.py index ab2df67..cac8214 100644 --- a/tests/test_base32.py +++ b/tests/test_base32.py @@ -9,6 +9,14 @@ import pytest from ulid import base32 [email protected](scope='session') +def decoding_alphabet(): + """ + Fixture that yields the entire alphabet that is valid for base32 decoding. + """ + return base32.ENCODING + 'lLiIoO' + + def test_encode_handles_ulid_and_returns_26_char_string(valid_bytes_128): """ Assert that :func:`~ulid.base32.encode` encodes a valid 128 bit bytes object into a :class:`~str` @@ -235,3 +243,12 @@ def test_decode_randomness_raises_on_non_ascii_str(invalid_str_encoding): """ with pytest.raises(ValueError): base32.decode_randomness(invalid_str_encoding) + + +def test_decode_table_has_value_for_entire_decoding_alphabet(decoding_alphabet): + """ + Assert that :attr:`~ulid.base32.DECODING` stores a valid value mapping for all characters that + can be base32 decoded. + """ + for char in decoding_alphabet: + assert base32.DECODING[ord(char)] != 0xFF, 'Character "{}" decoded improperly'.format(char) diff --git a/tests/test_bugs.py b/tests/test_bugs.py new file mode 100644 index 0000000..6ab8fcb --- /dev/null +++ b/tests/test_bugs.py @@ -0,0 +1,21 @@ +""" + test_bugs + ~~~~~~~~~ + + Tests for validating reported bugs have been fixed. +""" +from ulid import api + + +def test_github_issue_58(): + """ + Assert that :func:`~ulid.api.from_str` can properly decode strings that + contain Base32 "translate" characters. + + Base32 "translate" characters are: "iI, lL, oO". + + Issue: https://github.com/ahawker/ulid/issues/58 + """ + value = '01BX73KC0TNH409RTFD1JXKmO0' + instance = api.from_str(value) + assert instance.str == '01BX73KC0TNH409RTFD1JXKM00'
Non-Crockford's Base32 letters converted differently in Java or Python implementations Hi Andrew, first of all, thanks for the amazing library, we've been using a lot! I have a doubt regarding how we fix the conversion of ULIDs which are not following Crockford's Base32 standard. We are using Lua to generate some guids (https://github.com/Tieske/ulid.lua) and for some reason, we get from time to time letters outside the Crockford's Base32. While trying to fix this on our side (we're not sure how this is happening to be honest), we realised that Java and Python implementations silently corrects this issue in different ways: ### Java ```java ULID.Value ulidValueFromString = ULID.parseULID("01BX73KC0TNH409RTFD1JXKmO0") --> "01BX73KC0TNH409RTFD1JXKM00" ``` `mO` is silently converted into `M0` ### Python ```python In [1]: import ulid In [2]: u = ulid.from_str('01BX73KC0TNH409RTFD1JXKmO0') In [3]: u Out[3]: <ULID('01BX73KC0TNH409RTFD1JXKQZ0')> In [4]: u.str Out[4]: '01BX73KC0TNH409RTFD1JXKQZ0' ``` `mO` is silently converted into `QZ` Shouldn't the python library behave as the Java one as per the [Crockford's Base32](http://crockford.com/wrmg/base32.html) spec, converting `L` and `I` to `1` and `O` to `0` and only upper casing lower case letters instead of changing them? Thanks a lot in advance! Eddie
0.0
efdac942d7f969c802903f574965ca860882a891
[ "tests/test_base32.py::test_decode_table_has_value_for_entire_decoding_alphabet", "tests/test_bugs.py::test_github_issue_58" ]
[ "tests/test_base32.py::test_encode_handles_ulid_and_returns_26_char_string", "tests/test_base32.py::test_encode_handles_timestamp_and_returns_10_char_string", "tests/test_base32.py::test_encode_handles_randomness_and_returns_16_char_string", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_ulid_returns_26_char_string", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_timestamp_returns_10_char_string", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_randomness_returns_16_char_string", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_decode_handles_ulid_and_returns_16_bytes", "tests/test_base32.py::test_decode_handles_timestamp_and_returns_6_bytes", "tests/test_base32.py::test_decode_handles_randomness_and_returns_10_bytes", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[0]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[1]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[2]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[3]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[4]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[5]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[6]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[7]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[8]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[9]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[10]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[11]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[12]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[13]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[14]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[15]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[16]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[17]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[18]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[19]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[20]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[21]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[22]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[23]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[24]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[25]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[26]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[27]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[28]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[29]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[30]", "tests/test_base32.py::test_decode_raises_on_non_ascii_str[31]", "tests/test_base32.py::test_decode_ulid_returns_16_bytes", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[0]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[1]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[2]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[3]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[4]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[5]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[6]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[7]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[8]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[9]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[10]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[11]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[12]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[13]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[14]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[15]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[16]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[17]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[18]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[19]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[20]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[21]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[22]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[23]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[24]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[25]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[26]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[27]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[28]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[29]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[30]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str[31]", "tests/test_base32.py::test_decode_timestamp_returns_6_bytes", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[0]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[1]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[2]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[3]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[4]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[5]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[6]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[7]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[8]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[9]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[10]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[11]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[12]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[13]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[14]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[15]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[16]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[17]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[18]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[19]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[20]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[21]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[22]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[23]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[24]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[25]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[26]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[27]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[28]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[29]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[30]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str[31]", "tests/test_base32.py::test_decode_randomness_returns_10_bytes", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[0]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[1]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[2]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[3]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[4]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[5]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[6]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[7]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[8]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[9]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[10]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[11]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[12]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[13]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[14]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[15]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[16]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[17]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[18]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[19]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[20]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[21]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[22]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[23]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[24]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[25]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[26]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[27]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[28]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[29]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[30]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str[31]" ]
{ "failed_lite_validators": [ "has_hyperlinks" ], "has_test_patch": true, "is_lite": false }
2017-10-26 02:56:21+00:00
apache-2.0
939
ahawker__ulid-63
diff --git a/ulid/base32.py b/ulid/base32.py index f7377b6..b63ba7a 100644 --- a/ulid/base32.py +++ b/ulid/base32.py @@ -248,14 +248,7 @@ def decode_ulid(value: str) -> bytes: :raises ValueError: when value is not 26 characters :raises ValueError: when value cannot be encoded in ASCII """ - length = len(value) - if length != 26: - raise ValueError('Expects 26 characters for timestamp + randomness; got {}'.format(length)) - - try: - encoded = value.encode('ascii') - except UnicodeEncodeError as ex: - raise ValueError('Expects value that can be encoded in ASCII charset: {}'.format(ex)) + encoded = str_to_bytes(value, 26) decoding = DECODING @@ -296,14 +289,7 @@ def decode_timestamp(timestamp: str) -> bytes: :raises ValueError: when value is not 10 characters :raises ValueError: when value cannot be encoded in ASCII """ - length = len(timestamp) - if length != 10: - raise ValueError('Expects 10 characters for timestamp; got {}'.format(length)) - - try: - encoded = timestamp.encode('ascii') - except UnicodeEncodeError as ex: - raise ValueError('Expects timestamp that can be encoded in ASCII charset: {}'.format(ex)) + encoded = str_to_bytes(timestamp, 10) decoding = DECODING @@ -334,14 +320,7 @@ def decode_randomness(randomness: str) -> bytes: :raises ValueError: when value is not 16 characters :raises ValueError: when value cannot be encoded in ASCII """ - length = len(randomness) - if length != 16: - raise ValueError('Expects 16 characters for randomness; got {}'.format(length)) - - try: - encoded = randomness.encode('ascii') - except UnicodeEncodeError as ex: - raise ValueError('Expects randomness that can be encoded in ASCII charset: {}'.format(ex)) + encoded = str_to_bytes(randomness, 16) decoding = DECODING @@ -357,3 +336,34 @@ def decode_randomness(randomness: str) -> bytes: ((decoding[encoded[12]] << 7) | (decoding[encoded[13]] << 2) | (decoding[encoded[14]] >> 3)) & 0xFF, ((decoding[encoded[14]] << 5) | (decoding[encoded[15]])) & 0xFF )) + + +def str_to_bytes(value: str, expected_length: int) -> bytes: + """ + Convert the given string to bytes and validate it is within the Base32 character set. + + :param value: String to convert to bytes + :type value: :class:`~str` + :param expected_length: Expected length of the input string + :type expected_length: :class:`~int` + :return: Value converted to bytes. + :rtype: :class:`~bytes` + """ + length = len(value) + if length != expected_length: + raise ValueError('Expects {} characters for decoding; got {}'.format(expected_length, length)) + + try: + encoded = value.encode('ascii') + except UnicodeEncodeError as ex: + raise ValueError('Expects value that can be encoded in ASCII charset: {}'.format(ex)) + + decoding = DECODING + + # Confirm all bytes are valid Base32 decode characters. + # Note: ASCII encoding handles the out of range checking for us. + for byte in encoded: + if decoding[byte] > 31: + raise ValueError('Non-base32 character found: "{}"'.format(chr(byte))) + + return encoded
ahawker/ulid
ee7977eef6df2c85dda59f7be117722e0718ff05
diff --git a/tests/conftest.py b/tests/conftest.py index 5e78e67..48e4ec1 100644 --- a/tests/conftest.py +++ b/tests/conftest.py @@ -13,7 +13,9 @@ import random from ulid import base32 +ASCII_ALPHABET = ''.join(chr(d) for d in range(0, 128)) EXTENDED_ASCII_ALPHABET = ''.join(chr(d) for d in range(128, 256)) +ASCII_NON_BASE_32_ALPHABET = ''.join(set(ASCII_ALPHABET).difference(set(base32.ENCODING))) @pytest.fixture(scope='session') @@ -126,6 +128,14 @@ def invalid_bytes_48_80_128(request): return random_bytes(request.param, not_in=[6, 10, 16]) [email protected](scope='function', params=[10, 16, 26]) +def valid_str_valid_length(request): + """ + Fixture that yields :class:`~str` instances that are 10, 16, and 26 characters. + """ + return random_str(request.param) + + @pytest.fixture(scope='function') def valid_str_26(): """ @@ -182,6 +192,42 @@ def invalid_str_10_16_26(request): return random_str(request.param, not_in=[10, 16, 26]) [email protected](scope='function', params=[10, 16, 26]) +def ascii_non_base32_str_valid_length(request): + """ + Fixture that yields a :class:`~str` instance that is valid length for a ULID part but contains + any standard ASCII characters that are not in the Base 32 alphabet. + """ + return random_str(request.param, alphabet=ASCII_NON_BASE_32_ALPHABET) + + [email protected](scope='function') +def ascii_non_base32_str_26(): + """ + Fixture that yields a :class:`~str` instance that is 26 characters, the length of an entire ULID but + contains extended ASCII characters. + """ + return random_str(26, alphabet=ASCII_NON_BASE_32_ALPHABET) + + [email protected](scope='function') +def ascii_non_base32_str_10(): + """ + Fixture that yields a :class:`~str` instance that is 10 characters, the length of a ULID timestamp value but + contains extended ASCII characters. + """ + return random_str(10, alphabet=ASCII_NON_BASE_32_ALPHABET) + + [email protected](scope='function') +def ascii_non_base32_str_16(): + """ + Fixture that yields a :class:`~str` instance that is 16 characters, the length of a ULID randomness value but + contains extended ASCII characters. + """ + return random_str(16, alphabet=ASCII_NON_BASE_32_ALPHABET) + + @pytest.fixture(scope='function', params=[10, 16, 26]) def extended_ascii_str_valid_length(request): """ diff --git a/tests/test_base32.py b/tests/test_base32.py index a922802..42cdf1f 100644 --- a/tests/test_base32.py +++ b/tests/test_base32.py @@ -9,6 +9,9 @@ import pytest from ulid import base32 +NON_BASE_32_EXP = r'^Non-base32 character found' + + @pytest.fixture(scope='session') def decoding_alphabet(): """ @@ -115,7 +118,7 @@ def test_encode_randomness_raises_on_bytes_length_mismatch(invalid_bytes_80): def test_decode_handles_ulid_and_returns_16_bytes(valid_str_26): """ - Assert that :func:`~ulid.base32.decode` decodes a valid 26 character string into a :class:`~bytes` + Assert that :func:`~ulid.base32.decode` decodes a valid 26 character string into a :class:`~bytes` instance that is 128 bit. """ decoded = base32.decode(valid_str_26) @@ -125,7 +128,7 @@ def test_decode_handles_ulid_and_returns_16_bytes(valid_str_26): def test_decode_handles_timestamp_and_returns_6_bytes(valid_str_10): """ - Assert that :func:`~ulid.base32.decode` decodes a valid 10 character string into a :class:`~bytes` + Assert that :func:`~ulid.base32.decode` decodes a valid 10 character string into a :class:`~bytes` instance that is 48 bit. """ decoded = base32.decode(valid_str_10) @@ -135,7 +138,7 @@ def test_decode_handles_timestamp_and_returns_6_bytes(valid_str_10): def test_decode_handles_randomness_and_returns_10_bytes(valid_str_16): """ - Assert that :func:`~ulid.base32.decode` decodes a valid 16 character string into a :class:`~bytes` + Assert that :func:`~ulid.base32.decode` decodes a valid 16 character string into a :class:`~bytes` instance that is 80 bit. """ decoded = base32.decode(valid_str_16) @@ -161,9 +164,19 @@ def test_decode_raises_on_extended_ascii_str(extended_ascii_str_valid_length): base32.decode(extended_ascii_str_valid_length) +def test_decode_raises_on_non_base32_decode_char(ascii_non_base32_str_valid_length): + """ + Assert that :func:`~ulid.base32.decode_ulid` raises a :class:`~ValueError` when given a :class:`~str` + instance that includes ASCII characters not part of the Base 32 decoding character set. + """ + with pytest.raises(ValueError) as ex: + base32.decode(ascii_non_base32_str_valid_length) + ex.match(NON_BASE_32_EXP) + + def test_decode_ulid_returns_16_bytes(valid_str_26): """ - Assert that :func:`~ulid.base32.decode_ulid` decodes a valid 26 character string into a :class:`~bytes` + Assert that :func:`~ulid.base32.decode_ulid` decodes a valid 26 character string into a :class:`~bytes` instance that is 128 bit. """ decoded = base32.decode_ulid(valid_str_26) @@ -189,9 +202,19 @@ def test_decode_ulid_raises_on_non_ascii_str(extended_ascii_str_26): base32.decode_ulid(extended_ascii_str_26) +def test_decode_ulid_raises_on_non_base32_decode_char(ascii_non_base32_str_26): + """ + Assert that :func:`~ulid.base32.decode_ulid` raises a :class:`~ValueError` when given a :class:`~str` + instance that includes ASCII characters not part of the Base 32 decoding character set. + """ + with pytest.raises(ValueError) as ex: + base32.decode_ulid(ascii_non_base32_str_26) + ex.match(NON_BASE_32_EXP) + + def test_decode_timestamp_returns_6_bytes(valid_str_10): """ - Assert that :func:`~ulid.base32.decode_timestamp` decodes a valid 10 character string into a :class:`~bytes` + Assert that :func:`~ulid.base32.decode_timestamp` decodes a valid 10 character string into a :class:`~bytes` instance that is 48 bit. """ decoded = base32.decode_timestamp(valid_str_10) @@ -217,9 +240,19 @@ def test_decode_timestamp_raises_on_non_ascii_str(extended_ascii_str_10): base32.decode_timestamp(extended_ascii_str_10) +def test_decode_timestamp_raises_on_non_base32_decode_char(ascii_non_base32_str_10): + """ + Assert that :func:`~ulid.base32.decode_timestamp` raises a :class:`~ValueError` when given a :class:`~str` + instance that includes ASCII characters not part of the Base 32 decoding character set. + """ + with pytest.raises(ValueError) as ex: + base32.decode_timestamp(ascii_non_base32_str_10) + ex.match(NON_BASE_32_EXP) + + def test_decode_randomness_returns_10_bytes(valid_str_16): """ - Assert that :func:`~ulid.base32.decode_randomness` decodes a valid 16 character string into a :class:`~bytes` + Assert that :func:`~ulid.base32.decode_randomness` decodes a valid 16 character string into a :class:`~bytes` instance that is 80 bit. """ decoded = base32.decode_randomness(valid_str_16) @@ -245,6 +278,16 @@ def test_decode_randomness_raises_on_non_ascii_str(extended_ascii_str_16): base32.decode_randomness(extended_ascii_str_16) +def test_decode_randomness_raises_on_non_base32_decode_char(ascii_non_base32_str_16): + """ + Assert that :func:`~ulid.base32.decode_randomness` raises a :class:`~ValueError` when given a :class:`~str` + instance that includes ASCII characters not part of the Base 32 decoding character set. + """ + with pytest.raises(ValueError) as ex: + base32.decode_randomness(ascii_non_base32_str_16) + ex.match(NON_BASE_32_EXP) + + def test_decode_table_has_value_for_entire_decoding_alphabet(decoding_alphabet): """ Assert that :attr:`~ulid.base32.DECODING` stores a valid value mapping for all characters that @@ -252,3 +295,41 @@ def test_decode_table_has_value_for_entire_decoding_alphabet(decoding_alphabet): """ for char in decoding_alphabet: assert base32.DECODING[ord(char)] != 0xFF, 'Character "{}" decoded improperly'.format(char) + + +def test_str_to_bytes_returns_expected_bytes(valid_str_valid_length): + """ + Assert that :func:`~ulid.base32.str_to_bytes` decodes a valid string that is 10, 16, or 26 characters long + into a :class:`~bytes` instance. + """ + decoded = base32.str_to_bytes(valid_str_valid_length, len(valid_str_valid_length)) + assert isinstance(decoded, bytes) + assert len(decoded) == len(valid_str_valid_length) + + +def test_str_to_bytes_raises_on_unexpected_length(invalid_str_26): + """ + Assert that :func:`~ulid.base32.str_to_bytes` raises a :class:`~ValueError` when given a :class:`~str` + instance that does not match the expected length. + """ + with pytest.raises(ValueError): + base32.str_to_bytes(invalid_str_26, 26) + + +def test_str_to_bytes_raises_on_extended_ascii_str(extended_ascii_str_valid_length): + """ + Assert that :func:`~ulid.base32.str_to_bytes` raises a :class:`~ValueError` when given a :class:`~str` + instance that includes extended ascii characters. + """ + with pytest.raises(ValueError): + base32.str_to_bytes(extended_ascii_str_valid_length, len(extended_ascii_str_valid_length)) + + +def test_str_to_bytes_raises_on_non_base32_decode_char(ascii_non_base32_str_valid_length): + """ + Assert that :func:`~ulid.base32.str_to_bytes` raises a :class:`~ValueError` when given a :class:`~str` + instance that includes ASCII characters not part of the Base 32 decoding character set. + """ + with pytest.raises(ValueError) as ex: + base32.str_to_bytes(ascii_non_base32_str_valid_length, len(ascii_non_base32_str_valid_length)) + ex.match(NON_BASE_32_EXP)
Properly handle invalid base32 characters As of today, it is possible to input non-base32 characters, `uU` for example, into any of the `api` calls. Doing this will cause the library to fail silently and perform an incorrect `base32` decode on the string. The API should provide a feedback mechanism that informs the caller of the bad input. The implementation of that feedback is still TBD (separate API call vs. exception vs. ??). **Considerations:** * Performance of this computation for every decode call? * Double-penality for callers that have already made this guarantee? * Separate API call to validate? Is there use-cases for this outside of normal hot path?
0.0
ee7977eef6df2c85dda59f7be117722e0718ff05
[ "tests/test_base32.py::test_decode_raises_on_non_base32_decode_char[10]", "tests/test_base32.py::test_decode_raises_on_non_base32_decode_char[16]", "tests/test_base32.py::test_decode_raises_on_non_base32_decode_char[26]", "tests/test_base32.py::test_decode_ulid_raises_on_non_base32_decode_char", "tests/test_base32.py::test_decode_timestamp_raises_on_non_base32_decode_char", "tests/test_base32.py::test_decode_randomness_raises_on_non_base32_decode_char", "tests/test_base32.py::test_str_to_bytes_returns_expected_bytes[10]", "tests/test_base32.py::test_str_to_bytes_returns_expected_bytes[16]", "tests/test_base32.py::test_str_to_bytes_returns_expected_bytes[26]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[0]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[1]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[2]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[3]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[4]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[5]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[6]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[7]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[8]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[9]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[10]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[11]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[12]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[13]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[14]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[15]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[16]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[17]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[18]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[19]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[20]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[21]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[22]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[23]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[24]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[25]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[26]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[27]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[28]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[29]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[30]", "tests/test_base32.py::test_str_to_bytes_raises_on_unexpected_length[31]", "tests/test_base32.py::test_str_to_bytes_raises_on_extended_ascii_str[10]", "tests/test_base32.py::test_str_to_bytes_raises_on_extended_ascii_str[16]", "tests/test_base32.py::test_str_to_bytes_raises_on_extended_ascii_str[26]", "tests/test_base32.py::test_str_to_bytes_raises_on_non_base32_decode_char[10]", "tests/test_base32.py::test_str_to_bytes_raises_on_non_base32_decode_char[16]", "tests/test_base32.py::test_str_to_bytes_raises_on_non_base32_decode_char[26]" ]
[ "tests/test_base32.py::test_encode_handles_ulid_and_returns_26_char_string", "tests/test_base32.py::test_encode_handles_timestamp_and_returns_10_char_string", "tests/test_base32.py::test_encode_handles_randomness_and_returns_16_char_string", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_ulid_returns_26_char_string", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_ulid_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_timestamp_returns_10_char_string", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_timestamp_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_encode_randomness_returns_16_char_string", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[0]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[1]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[2]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[3]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[4]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[5]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[6]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[7]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[8]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[9]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[10]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[11]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[12]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[13]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[14]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[15]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[16]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[17]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[18]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[19]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[20]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[21]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[22]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[23]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[24]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[25]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[26]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[27]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[28]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[29]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[30]", "tests/test_base32.py::test_encode_randomness_raises_on_bytes_length_mismatch[31]", "tests/test_base32.py::test_decode_handles_ulid_and_returns_16_bytes", "tests/test_base32.py::test_decode_handles_timestamp_and_returns_6_bytes", "tests/test_base32.py::test_decode_handles_randomness_and_returns_10_bytes", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_raises_on_extended_ascii_str[10]", "tests/test_base32.py::test_decode_raises_on_extended_ascii_str[16]", "tests/test_base32.py::test_decode_raises_on_extended_ascii_str[26]", "tests/test_base32.py::test_decode_ulid_returns_16_bytes", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_ulid_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_ulid_raises_on_non_ascii_str", "tests/test_base32.py::test_decode_timestamp_returns_6_bytes", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_timestamp_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_timestamp_raises_on_non_ascii_str", "tests/test_base32.py::test_decode_randomness_returns_10_bytes", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[0]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[1]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[2]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[3]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[4]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[5]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[6]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[7]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[8]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[9]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[10]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[11]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[12]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[13]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[14]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[15]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[16]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[17]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[18]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[19]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[20]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[21]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[22]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[23]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[24]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[25]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[26]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[27]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[28]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[29]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[30]", "tests/test_base32.py::test_decode_randomness_raises_on_str_length_mismatch[31]", "tests/test_base32.py::test_decode_randomness_raises_on_non_ascii_str", "tests/test_base32.py::test_decode_table_has_value_for_entire_decoding_alphabet" ]
{ "failed_lite_validators": [ "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2017-10-28 22:19:31+00:00
apache-2.0
940
aio-libs__aiocache-635
diff --git a/CHANGELOG.md b/CHANGELOG.md index c584b9c..0e66ae1 100644 --- a/CHANGELOG.md +++ b/CHANGELOG.md @@ -6,7 +6,8 @@ * Add ``async with`` support to ``BaseCache``. * Remove deprecated ``loop`` parameters. * Remove deprecated ``cache`` parameter from ``create()``. -* Use ``str()`` in ``_build_key()`` to ensure consistency of enum keys between different Python versions (if using enum keys, upgrading to 0.12 may invalidate existing caches due to key values changing). +* Use ``base._ensure_key()`` in ``_build_key()`` to ensure consistency of enum +keys between different Python versions. [#633](https://github.com/aio-libs/aiocache/issues/633) -- Padraic Shafer * Improved support for ``build_key(key, namespace)`` [#569](https://github.com/aio-libs/aiocache/issues/569) - Padraic Shafer * `BaseCache.build_key` uses `namespace` argument if provided, otherwise it uses `self.namespace`. diff --git a/aiocache/backends/redis.py b/aiocache/backends/redis.py index d569ec2..407efec 100644 --- a/aiocache/backends/redis.py +++ b/aiocache/backends/redis.py @@ -4,7 +4,7 @@ import warnings import redis.asyncio as redis from redis.exceptions import ResponseError as IncrbyException -from aiocache.base import BaseCache +from aiocache.base import BaseCache, _ensure_key from aiocache.serializers import JsonSerializer @@ -219,11 +219,12 @@ class RedisCache(RedisBackend): return options def _build_key(self, key, namespace=None): - # TODO(PY311): Remove str() if namespace is not None: - return "{}{}{}".format(namespace, ":" if namespace else "", str(key)) + return "{}{}{}".format( + namespace, ":" if namespace else "", _ensure_key(key)) if self.namespace is not None: - return "{}{}{}".format(self.namespace, ":" if self.namespace else "", str(key)) + return "{}{}{}".format( + self.namespace, ":" if self.namespace else "", _ensure_key(key)) return key def __repr__(self): # pragma: no cover diff --git a/aiocache/base.py b/aiocache/base.py index bc4df81..54e9d18 100644 --- a/aiocache/base.py +++ b/aiocache/base.py @@ -3,6 +3,7 @@ import functools import logging import os import time +from enum import Enum from types import TracebackType from typing import Callable, Optional, Set, Type @@ -498,14 +499,10 @@ class BaseCache: pass def _build_key(self, key, namespace=None): - # TODO(PY311): Remove str() calls. - # str() is needed to ensure consistent results when using enums between - # Python 3.11+ and older releases due to changed __format__() method: - # https://docs.python.org/3/whatsnew/3.11.html#enum if namespace is not None: - return "{}{}".format(namespace, str(key)) + return "{}{}".format(namespace, _ensure_key(key)) if self.namespace is not None: - return "{}{}".format(self.namespace, str(key)) + return "{}{}".format(self.namespace, _ensure_key(key)) return key def _get_ttl(self, ttl): @@ -553,5 +550,12 @@ class _Conn: return _do_inject_conn +def _ensure_key(key): + if isinstance(key, Enum): + return key.value + else: + return key + + for cmd in API.CMDS: setattr(_Conn, cmd.__name__, _Conn._inject_conn(cmd.__name__))
aio-libs/aiocache
2cc74f78267a073ec7cb9289e35c9a1a55b0e82c
diff --git a/tests/acceptance/test_decorators.py b/tests/acceptance/test_decorators.py index 13783db..2f755a1 100644 --- a/tests/acceptance/test_decorators.py +++ b/tests/acceptance/test_decorators.py @@ -5,6 +5,7 @@ from unittest import mock import pytest from aiocache import cached, cached_stampede, multi_cached +from aiocache.base import _ensure_key from ..utils import Keys @@ -137,17 +138,16 @@ class TestMultiCachedDecorator: assert await cache.exists(Keys.KEY) is True async def test_multi_cached_key_builder(self, cache): - # TODO(PY311): Remove str() calls def build_key(key, f, self, keys, market="ES"): - return "{}_{}_{}".format(f.__name__, str(key), market) + return "{}_{}_{}".format(f.__name__, _ensure_key(key), market) @multi_cached(keys_from_attr="keys", key_builder=build_key) async def fn(self, keys, market="ES"): return {Keys.KEY: 1, Keys.KEY_1: 2} await fn("self", keys=[Keys.KEY, Keys.KEY_1]) - assert await cache.exists("fn_" + str(Keys.KEY) + "_ES") is True - assert await cache.exists("fn_" + str(Keys.KEY_1) + "_ES") is True + assert await cache.exists("fn_" + _ensure_key(Keys.KEY) + "_ES") is True + assert await cache.exists("fn_" + _ensure_key(Keys.KEY_1) + "_ES") is True async def test_fn_with_args(self, cache): @multi_cached("keys") diff --git a/tests/ut/backends/test_memcached.py b/tests/ut/backends/test_memcached.py index 5f856b4..7e01161 100644 --- a/tests/ut/backends/test_memcached.py +++ b/tests/ut/backends/test_memcached.py @@ -4,7 +4,7 @@ import aiomcache import pytest from aiocache.backends.memcached import MemcachedBackend, MemcachedCache -from aiocache.base import BaseCache +from aiocache.base import BaseCache, _ensure_key from aiocache.serializers import JsonSerializer from ...utils import Keys @@ -249,8 +249,7 @@ class TestMemcachedCache: @pytest.mark.parametrize( "namespace, expected", - # TODO(PY311): Remove str() - ([None, "test" + str(Keys.KEY)], ["", str(Keys.KEY)], ["my_ns", "my_ns" + str(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 + ([None, "test" + _ensure_key(Keys.KEY)], ["", _ensure_key(Keys.KEY)], ["my_ns", "my_ns" + _ensure_key(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 ) def test_build_key_bytes(self, set_test_namespace, memcached_cache, namespace, expected): assert memcached_cache.build_key(Keys.KEY, namespace=namespace) == expected.encode() diff --git a/tests/ut/backends/test_redis.py b/tests/ut/backends/test_redis.py index dd41522..2470584 100644 --- a/tests/ut/backends/test_redis.py +++ b/tests/ut/backends/test_redis.py @@ -5,7 +5,7 @@ from redis.asyncio.client import Pipeline from redis.exceptions import ResponseError from aiocache.backends.redis import RedisBackend, RedisCache -from aiocache.base import BaseCache +from aiocache.base import BaseCache, _ensure_key from aiocache.serializers import JsonSerializer from ...utils import Keys @@ -253,8 +253,7 @@ class TestRedisCache: @pytest.mark.parametrize( "namespace, expected", - # TODO(PY311): Remove str() - ([None, "test:" + str(Keys.KEY)], ["", str(Keys.KEY)], ["my_ns", "my_ns:" + str(Keys.KEY)]), # noqa: B950 + ([None, "test:" + _ensure_key(Keys.KEY)], ["", _ensure_key(Keys.KEY)], ["my_ns", "my_ns:" + _ensure_key(Keys.KEY)]), # noqa: B950 ) def test_build_key_double_dot(self, set_test_namespace, redis_cache, namespace, expected): assert redis_cache.build_key(Keys.KEY, namespace=namespace) == expected diff --git a/tests/ut/test_base.py b/tests/ut/test_base.py index 09b36dd..569b524 100644 --- a/tests/ut/test_base.py +++ b/tests/ut/test_base.py @@ -4,7 +4,7 @@ from unittest.mock import ANY, AsyncMock, MagicMock, patch import pytest -from aiocache.base import API, BaseCache, _Conn +from aiocache.base import API, BaseCache, _Conn, _ensure_key from ..utils import Keys @@ -205,8 +205,7 @@ class TestBaseCache: @pytest.mark.parametrize( "namespace, expected", - # TODO(PY311): Remove str() - ([None, "test" + str(Keys.KEY)], ["", str(Keys.KEY)], ["my_ns", "my_ns" + str(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 + ([None, "test" + _ensure_key(Keys.KEY)], ["", _ensure_key(Keys.KEY)], ["my_ns", "my_ns" + _ensure_key(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 ) def test_build_key(self, set_test_namespace, base_cache, namespace, expected): assert base_cache.build_key(Keys.KEY, namespace=namespace) == expected @@ -219,18 +218,16 @@ class TestBaseCache: def alt_base_cache(self, init_namespace="test"): """Custom key_builder for cache""" def build_key(key, namespace=None): - # TODO(PY311): Remove str() ns = namespace if namespace is not None else "" sep = ":" if namespace else "" - return f"{ns}{sep}{str(key)}" + return f"{ns}{sep}{_ensure_key(key)}" cache = BaseCache(key_builder=build_key, namespace=init_namespace) return cache @pytest.mark.parametrize( "namespace, expected", - # TODO(PY311): Remove str() - ([None, str(Keys.KEY)], ["", str(Keys.KEY)], ["my_ns", "my_ns:" + str(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 + ([None, _ensure_key(Keys.KEY)], ["", _ensure_key(Keys.KEY)], ["my_ns", "my_ns:" + _ensure_key(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 ) def test_alt_build_key_override_namespace(self, alt_base_cache, namespace, expected): """Custom key_builder overrides namespace of cache""" @@ -239,8 +236,7 @@ class TestBaseCache: @pytest.mark.parametrize( "init_namespace, expected", - # TODO(PY311): Remove str() - ([None, str(Keys.KEY)], ["", str(Keys.KEY)], ["test", "test:" + str(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 + ([None, _ensure_key(Keys.KEY)], ["", _ensure_key(Keys.KEY)], ["test", "test:" + _ensure_key(Keys.KEY)]), # type: ignore[attr-defined] # noqa: B950 ) async def test_alt_build_key_default_namespace( self, init_namespace, alt_base_cache, expected):
Ensure that underlying value of enum key is used by BaseCache._build_key() across Python versions Key builders and tests currently cast key values (notably `Enum` values) to `str` to maintain compatibility with Python 3.11 and older versions. ~~This requirement can be eliminated by using f-strings rather than `str.__format__`.~~ EDIT: Whoops, that erroneous statement was based on testing in the wrong python environment. Instead of using `str()`, perhaps we should use a simple guard that check for an enum key. Something like: ``` def ensure_key(key): if isinstance(key, Enum): return key.value else: return key ```
0.0
2cc74f78267a073ec7cb9289e35c9a1a55b0e82c
[ "tests/acceptance/test_decorators.py::TestCached::test_cached_ttl[memory_cache]", "tests/acceptance/test_decorators.py::TestCached::test_cached_key_builder[memory_cache]", "tests/acceptance/test_decorators.py::TestCached::test_cached_without_namespace[memory_cache]", "tests/acceptance/test_decorators.py::TestCached::test_cached_with_namespace[memory_cache]", "tests/acceptance/test_decorators.py::TestCachedStampede::test_cached_stampede[memory_cache]", "tests/acceptance/test_decorators.py::TestCachedStampede::test_locking_dogpile_lease_expiration[memory_cache]", "tests/acceptance/test_decorators.py::TestCachedStampede::test_locking_dogpile_task_cancellation[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_multi_cached[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_keys_without_kwarg[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_multi_cached_key_builder[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_fn_with_args[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_double_decorator[memory_cache]", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_setup", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_setup_override", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_setup_casts", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_get", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_gets", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_get_none", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_get_no_encoding", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_set", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_set_float_ttl", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_set_cas_token", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_cas", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_cas_fail", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_multi_get", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_multi_get_none", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_multi_get_no_encoding", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_multi_set", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_multi_set_float_ttl", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_add", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_add_existing", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_add_float_ttl", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_exists", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_increment", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_increment_negative", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_increment_missing", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_increment_missing_negative", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_increment_typerror", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_expire", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_delete", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_delete_missing", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_clear", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_clear_with_namespace", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_raw", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_raw_bytes", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_redlock_release", "tests/ut/backends/test_memcached.py::TestMemcachedBackend::test_close", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_name", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_inheritance", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_default_serializer", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_parse_uri_path", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_build_key_bytes[None-testkey]", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_build_key_bytes[-key]", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_build_key_bytes[my_ns-my_nskey]", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_build_key_no_namespace", "tests/ut/backends/test_memcached.py::TestMemcachedCache::test_build_key_no_spaces", "tests/ut/backends/test_redis.py::TestRedisBackend::test_setup", "tests/ut/backends/test_redis.py::TestRedisBackend::test_setup_override", "tests/ut/backends/test_redis.py::TestRedisBackend::test_setup_casts", "tests/ut/backends/test_redis.py::TestRedisBackend::test_get", "tests/ut/backends/test_redis.py::TestRedisBackend::test_gets", "tests/ut/backends/test_redis.py::TestRedisBackend::test_set", "tests/ut/backends/test_redis.py::TestRedisBackend::test_set_cas_token", "tests/ut/backends/test_redis.py::TestRedisBackend::test_cas", "tests/ut/backends/test_redis.py::TestRedisBackend::test_cas_float_ttl", "tests/ut/backends/test_redis.py::TestRedisBackend::test_multi_get", "tests/ut/backends/test_redis.py::TestRedisBackend::test_multi_set", "tests/ut/backends/test_redis.py::TestRedisBackend::test_multi_set_with_ttl", "tests/ut/backends/test_redis.py::TestRedisBackend::test_add", "tests/ut/backends/test_redis.py::TestRedisBackend::test_add_existing", "tests/ut/backends/test_redis.py::TestRedisBackend::test_add_float_ttl", "tests/ut/backends/test_redis.py::TestRedisBackend::test_exists", "tests/ut/backends/test_redis.py::TestRedisBackend::test_increment", "tests/ut/backends/test_redis.py::TestRedisBackend::test_increment_typerror", "tests/ut/backends/test_redis.py::TestRedisBackend::test_expire", "tests/ut/backends/test_redis.py::TestRedisBackend::test_expire_0_ttl", "tests/ut/backends/test_redis.py::TestRedisBackend::test_delete", "tests/ut/backends/test_redis.py::TestRedisBackend::test_clear", "tests/ut/backends/test_redis.py::TestRedisBackend::test_clear_no_keys", "tests/ut/backends/test_redis.py::TestRedisBackend::test_clear_no_namespace", "tests/ut/backends/test_redis.py::TestRedisBackend::test_raw", "tests/ut/backends/test_redis.py::TestRedisBackend::test_redlock_release", "tests/ut/backends/test_redis.py::TestRedisBackend::test_close", "tests/ut/backends/test_redis.py::TestRedisCache::test_name", "tests/ut/backends/test_redis.py::TestRedisCache::test_inheritance", "tests/ut/backends/test_redis.py::TestRedisCache::test_default_serializer", "tests/ut/backends/test_redis.py::TestRedisCache::test_parse_uri_path[-expected0]", "tests/ut/backends/test_redis.py::TestRedisCache::test_parse_uri_path[/-expected1]", "tests/ut/backends/test_redis.py::TestRedisCache::test_parse_uri_path[/1-expected2]", "tests/ut/backends/test_redis.py::TestRedisCache::test_parse_uri_path[/1/2/3-expected3]", "tests/ut/backends/test_redis.py::TestRedisCache::test_build_key_double_dot[None-test:key]", "tests/ut/backends/test_redis.py::TestRedisCache::test_build_key_double_dot[-key]", "tests/ut/backends/test_redis.py::TestRedisCache::test_build_key_double_dot[my_ns-my_ns:key]", "tests/ut/backends/test_redis.py::TestRedisCache::test_build_key_no_namespace", "tests/ut/test_base.py::TestAPI::test_register", "tests/ut/test_base.py::TestAPI::test_unregister", "tests/ut/test_base.py::TestAPI::test_unregister_unexisting", "tests/ut/test_base.py::TestAPI::test_aiocache_enabled", "tests/ut/test_base.py::TestAPI::test_aiocache_enabled_disabled", "tests/ut/test_base.py::TestAPI::test_timeout_no_timeout", "tests/ut/test_base.py::TestAPI::test_timeout_self", "tests/ut/test_base.py::TestAPI::test_timeout_kwarg_0", "tests/ut/test_base.py::TestAPI::test_timeout_kwarg_None", "tests/ut/test_base.py::TestAPI::test_timeout_kwarg", "tests/ut/test_base.py::TestAPI::test_timeout_self_kwarg", "tests/ut/test_base.py::TestAPI::test_plugins", "tests/ut/test_base.py::TestBaseCache::test_str_ttl", "tests/ut/test_base.py::TestBaseCache::test_str_timeout", "tests/ut/test_base.py::TestBaseCache::test_add", "tests/ut/test_base.py::TestBaseCache::test_get", "tests/ut/test_base.py::TestBaseCache::test_set", "tests/ut/test_base.py::TestBaseCache::test_multi_get", "tests/ut/test_base.py::TestBaseCache::test_multi_set", "tests/ut/test_base.py::TestBaseCache::test_delete", "tests/ut/test_base.py::TestBaseCache::test_exists", "tests/ut/test_base.py::TestBaseCache::test_increment", "tests/ut/test_base.py::TestBaseCache::test_expire", "tests/ut/test_base.py::TestBaseCache::test_clear", "tests/ut/test_base.py::TestBaseCache::test_raw", "tests/ut/test_base.py::TestBaseCache::test_close", "tests/ut/test_base.py::TestBaseCache::test_acquire_conn", "tests/ut/test_base.py::TestBaseCache::test_release_conn", "tests/ut/test_base.py::TestBaseCache::test_build_key[None-testkey]", "tests/ut/test_base.py::TestBaseCache::test_build_key[-key]", "tests/ut/test_base.py::TestBaseCache::test_build_key[my_ns-my_nskey]", "tests/ut/test_base.py::TestBaseCache::test_alt_build_key", "tests/ut/test_base.py::TestBaseCache::test_alt_build_key_override_namespace[None-key]", "tests/ut/test_base.py::TestBaseCache::test_alt_build_key_override_namespace[-key]", "tests/ut/test_base.py::TestBaseCache::test_alt_build_key_override_namespace[my_ns-my_ns:key]", "tests/ut/test_base.py::TestBaseCache::test_alt_build_key_default_namespace[None-key]", "tests/ut/test_base.py::TestBaseCache::test_alt_build_key_default_namespace[-key]", "tests/ut/test_base.py::TestBaseCache::test_alt_build_key_default_namespace[test-test:key]", "tests/ut/test_base.py::TestBaseCache::test_add_ttl_cache_default", "tests/ut/test_base.py::TestBaseCache::test_add_ttl_default", "tests/ut/test_base.py::TestBaseCache::test_add_ttl_overriden", "tests/ut/test_base.py::TestBaseCache::test_add_ttl_none", "tests/ut/test_base.py::TestBaseCache::test_set_ttl_cache_default", "tests/ut/test_base.py::TestBaseCache::test_set_ttl_default", "tests/ut/test_base.py::TestBaseCache::test_set_ttl_overriden", "tests/ut/test_base.py::TestBaseCache::test_set_ttl_none", "tests/ut/test_base.py::TestBaseCache::test_multi_set_ttl_cache_default", "tests/ut/test_base.py::TestBaseCache::test_multi_set_ttl_default", "tests/ut/test_base.py::TestBaseCache::test_multi_set_ttl_overriden", "tests/ut/test_base.py::TestBaseCache::test_multi_set_ttl_none", "tests/ut/test_base.py::TestCache::test_get", "tests/ut/test_base.py::TestCache::test_get_timeouts", "tests/ut/test_base.py::TestCache::test_get_default", "tests/ut/test_base.py::TestCache::test_get_negative_default", "tests/ut/test_base.py::TestCache::test_set", "tests/ut/test_base.py::TestCache::test_set_timeouts", "tests/ut/test_base.py::TestCache::test_add", "tests/ut/test_base.py::TestCache::test_add_timeouts", "tests/ut/test_base.py::TestCache::test_mget", "tests/ut/test_base.py::TestCache::test_mget_timeouts", "tests/ut/test_base.py::TestCache::test_mset", "tests/ut/test_base.py::TestCache::test_mset_timeouts", "tests/ut/test_base.py::TestCache::test_exists", "tests/ut/test_base.py::TestCache::test_exists_timeouts", "tests/ut/test_base.py::TestCache::test_increment", "tests/ut/test_base.py::TestCache::test_increment_timeouts", "tests/ut/test_base.py::TestCache::test_delete", "tests/ut/test_base.py::TestCache::test_delete_timeouts", "tests/ut/test_base.py::TestCache::test_expire", "tests/ut/test_base.py::TestCache::test_expire_timeouts", "tests/ut/test_base.py::TestCache::test_clear", "tests/ut/test_base.py::TestCache::test_clear_timeouts", "tests/ut/test_base.py::TestCache::test_raw", "tests/ut/test_base.py::TestCache::test_raw_timeouts", "tests/ut/test_base.py::TestCache::test_close", "tests/ut/test_base.py::TestCache::test_get_connection", "tests/ut/test_base.py::TestConn::test_conn", "tests/ut/test_base.py::TestConn::test_conn_getattr", "tests/ut/test_base.py::TestConn::test_conn_context_manager", "tests/ut/test_base.py::TestConn::test_inject_conn" ]
[]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2023-01-10 13:47:18+00:00
bsd-3-clause
941
aio-libs__aiocache-652
diff --git a/.codecov.yml b/.codecov.yml index 225b492..219845f 100644 --- a/.codecov.yml +++ b/.codecov.yml @@ -1,6 +1,5 @@ codecov: notify: - require_ci_to_pass: yes after_n_builds: 4 coverage: diff --git a/.github/workflows/auto-merge.yml b/.github/workflows/auto-merge.yml index 6957de7..0fc389a 100644 --- a/.github/workflows/auto-merge.yml +++ b/.github/workflows/auto-merge.yml @@ -12,7 +12,7 @@ jobs: steps: - name: Dependabot metadata id: metadata - uses: dependabot/[email protected] + uses: dependabot/[email protected] with: github-token: "${{ secrets.GITHUB_TOKEN }}" - name: Enable auto-merge for Dependabot PRs diff --git a/.github/workflows/ci.yml b/.github/workflows/ci.yml index 4859583..5e3a3b1 100644 --- a/.github/workflows/ci.yml +++ b/.github/workflows/ci.yml @@ -140,7 +140,7 @@ jobs: run: | python -m build - name: Make Release - uses: aio-libs/[email protected] + uses: aio-libs/[email protected] with: changes_file: CHANGES.rst name: aiocache diff --git a/aiocache/decorators.py b/aiocache/decorators.py index 92e4fe9..1892cf2 100644 --- a/aiocache/decorators.py +++ b/aiocache/decorators.py @@ -39,6 +39,10 @@ class cached: :param key_builder: Callable that allows to build the function dynamically. It receives the function plus same args and kwargs passed to the function. This behavior is necessarily different than ``BaseCache.build_key()`` + :param skip_cache_func: Callable that receives the result after calling the + wrapped function and should return `True` if the value should skip the + cache (or `False` to store in the cache). + e.g. to avoid caching `None` results: `lambda r: r is None` :param cache: cache class to use when calling the ``set``/``get`` operations. Default is :class:`aiocache.SimpleMemoryCache`. :param serializer: serializer instance to use when calling the ``dumps``/``loads``. @@ -58,6 +62,7 @@ class cached: ttl=SENTINEL, namespace=None, key_builder=None, + skip_cache_func=lambda x: False, cache=Cache.MEMORY, serializer=None, plugins=None, @@ -67,6 +72,7 @@ class cached: ): self.ttl = ttl self.key_builder = key_builder + self.skip_cache_func = skip_cache_func self.noself = noself self.alias = alias self.cache = None @@ -111,6 +117,9 @@ class cached: result = await f(*args, **kwargs) + if self.skip_cache_func(result): + return result + if cache_write: if aiocache_wait_for_write: await self.set_in_cache(key, result) @@ -171,6 +180,10 @@ class cached_stampede(cached): :param key_builder: Callable that allows to build the function dynamically. It receives the function plus same args and kwargs passed to the function. This behavior is necessarily different than ``BaseCache.build_key()`` + :param skip_cache_func: Callable that receives the result after calling the + wrapped function and should return `True` if the value should skip the + cache (or `False` to store in the cache). + e.g. to avoid caching `None` results: `lambda r: r is None` :param cache: cache class to use when calling the ``set``/``get`` operations. Default is :class:`aiocache.SimpleMemoryCache`. :param serializer: serializer instance to use when calling the ``dumps``/``loads``. @@ -202,6 +215,9 @@ class cached_stampede(cached): result = await f(*args, **kwargs) + if self.skip_cache_func(result): + return result + await self.set_in_cache(key, result) return result @@ -268,6 +284,9 @@ class multi_cached: ``keys_from_attr``, the decorated callable, and the positional and keyword arguments that were passed to the decorated callable. This behavior is necessarily different than ``BaseCache.build_key()`` and the call signature differs from ``cached.key_builder``. + :param skip_cache_keys: Callable that receives both key and value and returns True + if that key-value pair should not be cached (or False to store in cache). + The keys and values to be passed are taken from the wrapped function result. :param ttl: int seconds to store the keys. Default is 0 which means no expiration. :param cache: cache class to use when calling the ``multi_set``/``multi_get`` operations. Default is :class:`aiocache.SimpleMemoryCache`. @@ -286,6 +305,7 @@ class multi_cached: keys_from_attr, namespace=None, key_builder=None, + skip_cache_func=lambda k, v: False, ttl=SENTINEL, cache=Cache.MEMORY, serializer=None, @@ -295,6 +315,7 @@ class multi_cached: ): self.keys_from_attr = keys_from_attr self.key_builder = key_builder or (lambda key, f, *args, **kwargs: key) + self.skip_cache_func = skip_cache_func self.ttl = ttl self.alias = alias self.cache = None @@ -354,12 +375,17 @@ class multi_cached: result = await f(*new_args, **kwargs) result.update(partial) + to_cache = {k: v for k, v in result.items() if not self.skip_cache_func(k, v)} + + if not to_cache: + return result + if cache_write: if aiocache_wait_for_write: - await self.set_in_cache(result, f, args, kwargs) + await self.set_in_cache(to_cache, f, args, kwargs) else: # TODO: Use aiojobs to avoid warnings. - asyncio.create_task(self.set_in_cache(result, f, args, kwargs)) + asyncio.create_task(self.set_in_cache(to_cache, f, args, kwargs)) return result diff --git a/requirements-dev.txt b/requirements-dev.txt index 1a9e2df..04b8c87 100644 --- a/requirements-dev.txt +++ b/requirements-dev.txt @@ -4,7 +4,7 @@ flake8==6.0.0 flake8-bandit==4.1.1 flake8-bugbear==22.12.6 flake8-import-order==0.18.2 -flake8-requirements==1.7.6 -mypy==0.991; implementation_name=="cpython" -types-redis==4.4.0.3 +flake8-requirements==1.7.7 +mypy==1.0.0; implementation_name=="cpython" +types-redis==4.4.0.6 types-ujson==5.7.0.0 diff --git a/requirements.txt b/requirements.txt index 18cc050..17deb39 100644 --- a/requirements.txt +++ b/requirements.txt @@ -8,4 +8,4 @@ pytest==7.2.1 pytest-asyncio==0.20.3 pytest-cov==4.0.0 pytest-mock==3.10.0 -redis==4.4.2 +redis==4.5.1
aio-libs/aiocache
c916bab0742b8944a268845695f8a659d11681b9
diff --git a/tests/acceptance/test_decorators.py b/tests/acceptance/test_decorators.py index f5be29b..f9608e5 100644 --- a/tests/acceptance/test_decorators.py +++ b/tests/acceptance/test_decorators.py @@ -49,6 +49,31 @@ class TestCached: await fn("self", 1, 3) assert await cache.exists(build_key(fn, "self", 1, 3)) is True + @pytest.mark.parametrize("decorator", (cached, cached_stampede)) + async def test_cached_skip_cache_func(self, cache, decorator): + @decorator(skip_cache_func=lambda r: r is None) + async def sk_func(x): + return x if x > 0 else None + + arg = 1 + res = await sk_func(arg) + assert res + + key = decorator().get_cache_key(sk_func, args=(1,), kwargs={}) + + assert key + assert await cache.exists(key) + assert await cache.get(key) == res + + arg = -1 + + await sk_func(arg) + + key = decorator().get_cache_key(sk_func, args=(-1,), kwargs={}) + + assert key + assert not await cache.exists(key) + async def test_cached_without_namespace(self, cache): """Default cache key is created when no namespace is provided""" @cached(namespace=None) @@ -149,6 +174,19 @@ class TestMultiCachedDecorator: assert await cache.exists("fn_" + _ensure_key(Keys.KEY) + "_ES") is True assert await cache.exists("fn_" + _ensure_key(Keys.KEY_1) + "_ES") is True + async def test_multi_cached_skip_keys(self, cache): + @multi_cached(keys_from_attr="keys", skip_cache_func=lambda _, v: v is None) + async def multi_sk_fn(keys, values): + return {k: v for k, v in zip(keys, values)} + + res = await multi_sk_fn(keys=[Keys.KEY, Keys.KEY_1], values=[42, None]) + assert res + assert Keys.KEY in res and Keys.KEY_1 in res + + assert await cache.exists(Keys.KEY) + assert await cache.get(Keys.KEY) == res[Keys.KEY] + assert not await cache.exists(Keys.KEY_1) + async def test_fn_with_args(self, cache): @multi_cached("keys") async def fn(keys, *args):
Block writing cache in `cached` decorator if custom condition is not satisfied I m using the  `aiocache.cached` decorator with wraps the certain processing function. The setup is as following: ```python import aiocache aiocache.caches.add( "cache-alias", { "cache": "aiocache.RedisCache", { <cache-config-data> } }, ) @aiocache.cached( alias="cache-alias", key_builder=some_key_builder, ttl=ttl, ) async def processing(...) -> int: ... ``` The problem is -- can i pass any argument to cached decorator in order to avoid cache writing for `processing(...)` return? It seems like the only way to perform it is to throw exception inside the `processing(...)` function if the result is not appropriate one. I m looking for more generic way to do the same stuff. For example, pass some `Callable` object to `cached.__call__()` returning the bool var meaning caching the results. Something similar to: ```python def checker(value: Any) -> bool: ... @aiocache.cached( alias="cache-alias", key_builder=some_key_builder, value_checker=checker, ttl=ttl, ) async def processing(...) -> int: ... ```
0.0
c916bab0742b8944a268845695f8a659d11681b9
[ "tests/acceptance/test_decorators.py::TestCached::test_cached_skip_cache_func[memory_cache-cached]", "tests/acceptance/test_decorators.py::TestCached::test_cached_skip_cache_func[memory_cache-cached_stampede]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_multi_cached_skip_keys[memory_cache]" ]
[ "tests/acceptance/test_decorators.py::TestCached::test_cached_ttl[memory_cache]", "tests/acceptance/test_decorators.py::TestCached::test_cached_key_builder[memory_cache]", "tests/acceptance/test_decorators.py::TestCached::test_cached_without_namespace[memory_cache]", "tests/acceptance/test_decorators.py::TestCached::test_cached_with_namespace[memory_cache]", "tests/acceptance/test_decorators.py::TestCachedStampede::test_cached_stampede[memory_cache]", "tests/acceptance/test_decorators.py::TestCachedStampede::test_locking_dogpile_lease_expiration[memory_cache]", "tests/acceptance/test_decorators.py::TestCachedStampede::test_locking_dogpile_task_cancellation[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_multi_cached[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_keys_without_kwarg[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_multi_cached_key_builder[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_fn_with_args[memory_cache]", "tests/acceptance/test_decorators.py::TestMultiCachedDecorator::test_double_decorator[memory_cache]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2023-01-20 17:31:23+00:00
bsd-3-clause
942
aio-libs__aiocache-795
diff --git a/aiocache/factory.py b/aiocache/factory.py index 9ad2f98..ec674fd 100644 --- a/aiocache/factory.py +++ b/aiocache/factory.py @@ -60,7 +60,7 @@ class Cache: MEMCACHED = AIOCACHE_CACHES.get("memcached") def __new__(cls, cache_class=MEMORY, **kwargs): - if not issubclass(cache_class, BaseCache): + if not (cache_class and issubclass(cache_class, BaseCache)): raise InvalidCacheType( "Invalid cache type, you can only use {}".format(list(AIOCACHE_CACHES.keys())) )
aio-libs/aiocache
a6a131ecd33862a3406d03514e9e1031612301ef
diff --git a/tests/ut/test_factory.py b/tests/ut/test_factory.py index 56de47e..54120e9 100644 --- a/tests/ut/test_factory.py +++ b/tests/ut/test_factory.py @@ -74,9 +74,10 @@ class TestCache: def test_new_defaults_to_memory(self): assert isinstance(Cache(), Cache.MEMORY) - def test_new_invalid_cache_raises(self): + @pytest.mark.parametrize("cache_type", (None, object)) + def test_new_invalid_cache_raises(self, cache_type): with pytest.raises(InvalidCacheType) as e: - Cache(object) + Cache(cache_type) assert str(e.value) == "Invalid cache type, you can only use {}".format( list(AIOCACHE_CACHES.keys()) )
Cache.REDIS: issubclass() arg 1 must be a class In trying https://stackoverflow.com/questions/65686318/sharing-python-objects-across-multiple-workers I've encountered this exception. Seems hit same issue here: https://github.com/samuelcolvin/pydantic/issues/545#issuecomment-595983173 From docker stderr: ``` app_1 | File "/app/./main.py", line 8, in <module> app_1 | cache = Cache(Cache.REDIS, endpoint="localhost", port=6379, namespace="main") app_1 | File "/usr/local/lib/python3.8/site-packages/aiocache/factory.py", line 65, in __new__ app_1 | assert issubclass(cache_class, BaseCache) app_1 | TypeError: issubclass() arg 1 must be a class ``` REPL: ``` >>> from aiocache import Cache ujson module not found, using json msgpack not installed, MsgPackSerializer unavailable >>> Cache() <aiocache.backends.memory.SimpleMemoryCache object at 0x1085fd820> >>> Cache(Cache.REDIS) Traceback (most recent call last): File "<stdin>", line 1, in <module> File "/Users/variant23/repos/mintad-validator/venv/lib/python3.8/site-packages/aiocache/factory.py", line 65, in __new__ assert issubclass(cache_class, BaseCache) TypeError: issubclass() arg 1 must be a class >>> type(Cache.REDIS) <class 'NoneType'> >>> print(Cache.REDIS) None >>> print(Cache.MEMORY) <class 'aiocache.backends.memory.SimpleMemoryCache'> ``` Packages: ``` aiocache==0.11.1 fastapi==0.65.1 pydantic==1.8.2 ```
0.0
a6a131ecd33862a3406d03514e9e1031612301ef
[ "tests/ut/test_factory.py::TestCache::test_new_invalid_cache_raises[None]" ]
[ "tests/ut/test_factory.py::test_class_from_string", "tests/ut/test_factory.py::test_create_simple_cache", "tests/ut/test_factory.py::test_create_cache_with_everything", "tests/ut/test_factory.py::TestCache::test_cache_types", "tests/ut/test_factory.py::TestCache::test_new[memory]", "tests/ut/test_factory.py::TestCache::test_new[memcached]", "tests/ut/test_factory.py::TestCache::test_new[redis]", "tests/ut/test_factory.py::TestCache::test_new_defaults_to_memory", "tests/ut/test_factory.py::TestCache::test_new_invalid_cache_raises[object]", "tests/ut/test_factory.py::TestCache::test_get_scheme_class[memory]", "tests/ut/test_factory.py::TestCache::test_get_scheme_class[memcached]", "tests/ut/test_factory.py::TestCache::test_get_scheme_class[redis]", "tests/ut/test_factory.py::TestCache::test_get_scheme_class_invalid", "tests/ut/test_factory.py::TestCache::test_from_url_returns_cache_from_scheme[memory]", "tests/ut/test_factory.py::TestCache::test_from_url_returns_cache_from_scheme[memcached]", "tests/ut/test_factory.py::TestCache::test_from_url_returns_cache_from_scheme[redis]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://-expected_args0]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://localhost-expected_args1]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://localhost/-expected_args2]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://localhost:6379-expected_args3]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://localhost/?arg1=arg1&arg2=arg2-expected_args4]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://localhost:6379/?arg1=arg1&arg2=arg2-expected_args5]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis:///?arg1=arg1-expected_args6]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis:///?arg2=arg2-expected_args7]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://:password@localhost:6379-expected_args8]", "tests/ut/test_factory.py::TestCache::test_from_url_calls_cache_with_args[redis://:password@localhost:6379?password=pass-expected_args9]", "tests/ut/test_factory.py::TestCache::test_calls_parse_uri_path_from_cache", "tests/ut/test_factory.py::TestCache::test_from_url_invalid_protocol", "tests/ut/test_factory.py::TestCacheHandler::test_add_new_entry", "tests/ut/test_factory.py::TestCacheHandler::test_add_updates_existing_entry", "tests/ut/test_factory.py::TestCacheHandler::test_get_wrong_alias", "tests/ut/test_factory.py::TestCacheHandler::test_reuse_instance", "tests/ut/test_factory.py::TestCacheHandler::test_create_not_reuse", "tests/ut/test_factory.py::TestCacheHandler::test_create_extra_args", "tests/ut/test_factory.py::TestCacheHandler::test_retrieve_cache", "tests/ut/test_factory.py::TestCacheHandler::test_retrieve_cache_new_instance", "tests/ut/test_factory.py::TestCacheHandler::test_multiple_caches", "tests/ut/test_factory.py::TestCacheHandler::test_default_caches", "tests/ut/test_factory.py::TestCacheHandler::test_get_alias_config", "tests/ut/test_factory.py::TestCacheHandler::test_set_empty_config", "tests/ut/test_factory.py::TestCacheHandler::test_set_config_updates_existing_values", "tests/ut/test_factory.py::TestCacheHandler::test_set_config_removes_existing_caches", "tests/ut/test_factory.py::TestCacheHandler::test_set_config_no_default", "tests/ut/test_factory.py::TestCacheHandler::test_ensure_plugins_order" ]
{ "failed_lite_validators": [ "has_hyperlinks" ], "has_test_patch": true, "is_lite": false }
2023-12-22 17:18:41+00:00
bsd-3-clause
943
aio-libs__aiodocker-607
diff --git a/CHANGES/536.bugfix b/CHANGES/536.bugfix new file mode 100644 index 0000000..b11338a --- /dev/null +++ b/CHANGES/536.bugfix @@ -0,0 +1,1 @@ +Use ssl_context passsed to Docker constructor for creating underlying connection to docker engine. diff --git a/CHANGES/608.bugfix b/CHANGES/608.bugfix new file mode 100644 index 0000000..0020f4f --- /dev/null +++ b/CHANGES/608.bugfix @@ -0,0 +1,1 @@ +Fix an error when attach/exec when container stops before close connection to it. diff --git a/aiodocker/docker.py b/aiodocker/docker.py index 99c3040..7c5c2ef 100644 --- a/aiodocker/docker.py +++ b/aiodocker/docker.py @@ -109,8 +109,9 @@ class Docker: WIN_PRE_LEN = len(WIN_PRE) if _rx_tcp_schemes.search(docker_host): if os.environ.get("DOCKER_TLS_VERIFY", "0") == "1": - ssl_context = self._docker_machine_ssl_context() - docker_host = _rx_tcp_schemes.sub("https://", docker_host) + if ssl_context is None: + ssl_context = self._docker_machine_ssl_context() + docker_host = _rx_tcp_schemes.sub("https://", docker_host) else: ssl_context = None connector = aiohttp.TCPConnector(ssl=ssl_context) diff --git a/aiodocker/stream.py b/aiodocker/stream.py index d1365dd..0ee8da3 100644 --- a/aiodocker/stream.py +++ b/aiodocker/stream.py @@ -115,7 +115,7 @@ class Stream: return self._closed = True transport = self._resp.connection.transport - if transport.can_write_eof(): + if transport and transport.can_write_eof(): transport.write_eof() self._resp.close()
aio-libs/aiodocker
e35e9698c93d5e9df59e81267a65ff355109af5c
diff --git a/tests/test_integration.py b/tests/test_integration.py index c2e264a..998237b 100644 --- a/tests/test_integration.py +++ b/tests/test_integration.py @@ -3,6 +3,7 @@ import datetime import io import os import pathlib +import ssl import sys import tarfile import time @@ -70,6 +71,17 @@ async def test_ssl_context(monkeypatch): docker = Docker() assert docker.connector._ssl await docker.close() + with pytest.raises(TypeError): + docker = Docker(ssl_context="bad ssl context") + ssl_ctx = ssl.SSLContext(ssl.PROTOCOL_TLS) + ssl_ctx.set_ciphers(ssl._RESTRICTED_SERVER_CIPHERS) + ssl_ctx.load_verify_locations(cafile=str(cert_dir / "ca.pem")) + ssl_ctx.load_cert_chain( + certfile=str(cert_dir / "cert.pem"), keyfile=str(cert_dir / "key.pem") + ) + docker = Docker(ssl_context=ssl_ctx) + assert docker.connector._ssl + await docker.close() @pytest.mark.skipif( @@ -228,6 +240,30 @@ async def test_attach_nontty(docker, image_name, make_container, stderr): assert data.strip() == b"Hello" [email protected] +async def test_attach_nontty_wait_for_exit(docker, image_name, make_container): + cmd = ["python", "-c", "import time; time.sleep(3); print('Hello')"] + + config = { + "Cmd": cmd, + "Image": image_name, + "AttachStdin": False, + "AttachStdout": False, + "AttachStderr": False, + "Tty": False, + "OpenStdin": False, + "StdinOnce": False, + } + + container = await make_container( + config, + name="aiodocker-testing-attach-nontty-wait-for-exit", + ) + + async with container.attach(stdin=False, stdout=True, stderr=True): + await asyncio.sleep(10) + + @pytest.mark.asyncio async def test_attach_tty(docker, image_name, make_container): skip_windows()
ssl_context not used ## Long story short The `ssl_context` given as parameter to the [Docker class](https://github.com/aio-libs/aiodocker/blob/c8746face698e0045142e06a14173de10f2995a8/aiodocker/docker.py#L59) is never used so you need to give a aiohttp Connector object instead of `ssl_context`. ### Expected behaviour: Don't have the way to give a `ssl_context` in Docker constructor (and be forced to use the [`connector`](https://github.com/aio-libs/aiodocker/blob/c8746face698e0045142e06a14173de10f2995a8/aiodocker/docker.py#L63) parameter to pass SSL config) **OR** Use the `ssl_context` parameter to internaly create the [`connector`](https://github.com/aio-libs/aiodocker/blob/c8746face698e0045142e06a14173de10f2995a8/aiodocker/docker.py#L101) ### Actual behaviour: `ssl_context` parameter is useless and we need to pass through the `connector` parameter to pass SSL config. ## How to reproduce ```python3 import aiodocker aiodocker.Docker(ssl_context="will work because not used") ``` Please explain the expected behavior so I can make a PR to fix this.
0.0
e35e9698c93d5e9df59e81267a65ff355109af5c
[ "tests/test_integration.py::test_ssl_context" ]
[]
{ "failed_lite_validators": [ "has_added_files", "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2021-07-22 08:35:18+00:00
apache-2.0
944
aio-libs__aioftp-110
diff --git a/aioftp/client.py b/aioftp/client.py index bcb854f..a1072b6 100644 --- a/aioftp/client.py +++ b/aioftp/client.py @@ -1,4 +1,5 @@ import re +import calendar import collections import pathlib import logging @@ -26,6 +27,7 @@ from .common import ( async_enterable, setlocale, HALF_OF_YEAR_IN_SECONDS, + TWO_YEARS_IN_SECONDS, ) __all__ = ( @@ -354,7 +356,8 @@ class BaseClient: """ return d.strftime("%Y%m%d%H%M00") - def parse_ls_date(self, s, *, now=None): + @classmethod + def parse_ls_date(cls, s, *, now=None): """ Parsing dates from the ls unix utility. For example, "Nov 18 1958" and "Nov 18 12:29". @@ -368,16 +371,29 @@ class BaseClient: try: if now is None: now = datetime.datetime.now() - d = datetime.datetime.strptime(s, "%b %d %H:%M") - d = d.replace(year=now.year) - diff = (now - d).total_seconds() - if diff > HALF_OF_YEAR_IN_SECONDS: - d = d.replace(year=now.year + 1) - elif diff < -HALF_OF_YEAR_IN_SECONDS: - d = d.replace(year=now.year - 1) + if s.startswith('Feb 29'): + # Need to find the nearest previous leap year + prev_leap_year = now.year + while not calendar.isleap(prev_leap_year): + prev_leap_year -= 1 + d = datetime.datetime.strptime( + f"{prev_leap_year} {s}", "%Y %b %d %H:%M" + ) + # Check if it's next leap year + diff = (now - d).total_seconds() + if diff > TWO_YEARS_IN_SECONDS: + d = d.replace(year=prev_leap_year + 4) + else: + d = datetime.datetime.strptime(s, "%b %d %H:%M") + d = d.replace(year=now.year) + diff = (now - d).total_seconds() + if diff > HALF_OF_YEAR_IN_SECONDS: + d = d.replace(year=now.year + 1) + elif diff < -HALF_OF_YEAR_IN_SECONDS: + d = d.replace(year=now.year - 1) except ValueError: d = datetime.datetime.strptime(s, "%b %d %Y") - return self.format_date_time(d) + return cls.format_date_time(d) def parse_list_line_unix(self, b): """ diff --git a/aioftp/common.py b/aioftp/common.py index d94ea6a..50f766f 100644 --- a/aioftp/common.py +++ b/aioftp/common.py @@ -36,6 +36,7 @@ DEFAULT_USER = "anonymous" DEFAULT_PASSWORD = "anon@" DEFAULT_ACCOUNT = "" HALF_OF_YEAR_IN_SECONDS = 15778476 +TWO_YEARS_IN_SECONDS = ((365 * 3 + 366) * 24 * 60 * 60) / 2 def _now(): diff --git a/aioftp/errors.py b/aioftp/errors.py index fac144a..2955cc4 100644 --- a/aioftp/errors.py +++ b/aioftp/errors.py @@ -2,13 +2,21 @@ from . import common __all__ = ( + "AIOFTPException", "StatusCodeError", "PathIsNotAbsolute", "PathIOError", + "NoAvailablePort", ) -class StatusCodeError(Exception): +class AIOFTPException(Exception): + """ + Base exception class. + """ + + +class StatusCodeError(AIOFTPException): """ Raised for unexpected or "bad" status codes. @@ -41,13 +49,13 @@ class StatusCodeError(Exception): self.info = info -class PathIsNotAbsolute(Exception): +class PathIsNotAbsolute(AIOFTPException): """ Raised when "path" is not absolute. """ -class PathIOError(Exception): +class PathIOError(AIOFTPException): """ Universal exception for any path io errors. @@ -67,7 +75,7 @@ class PathIOError(Exception): self.reason = reason -class NoAvailablePort(OSError): +class NoAvailablePort(AIOFTPException, OSError): """ Raised when there is no available data port """ diff --git a/history.rst b/history.rst index aa132a0..995b54b 100644 --- a/history.rst +++ b/history.rst @@ -4,6 +4,10 @@ x.x.x (xx-xx-xxxx) - server: remove obsolete `pass` to `pass_` command renaming Thanks to `Puddly <https://github.com/puddly>`_ +- client: fix leap year bug at `parse_ls_date` method +- all: add base exception class +Thanks to `decaz <https://github.com/decaz>`_ + 0.15.0 (07-01-2019) -------------------
aio-libs/aioftp
9fa19b106d6be2d38eeb885c5ad8f81338869da1
diff --git a/tests/test_simple_functions.py b/tests/test_simple_functions.py index 1ecca61..cada55a 100644 --- a/tests/test_simple_functions.py +++ b/tests/test_simple_functions.py @@ -61,7 +61,56 @@ def _c_locale_time(d, format="%b %d %H:%M"): return d.strftime(format) -def test_parse_list_datetime_not_older_than_6_month_format(): +def test_parse_ls_date_of_leap_year(): + def date_to_p(d): + return d.strftime("%Y%m%d%H%M00") + p = aioftp.Client.parse_ls_date + # Leap year date to test + d = datetime.datetime(year=2000, month=2, day=29) + current_and_expected_dates = ( + # 2016 (leap) + ( + datetime.datetime(year=2016, month=2, day=29), + datetime.datetime(year=2016, month=2, day=29) + ), + # 2017 + ( + datetime.datetime(year=2017, month=2, day=28), + datetime.datetime(year=2016, month=2, day=29) + ), + ( + datetime.datetime(year=2017, month=3, day=1), + datetime.datetime(year=2016, month=2, day=29) + ), + # 2018 + ( + datetime.datetime(year=2018, month=2, day=28), + datetime.datetime(year=2016, month=2, day=29) + ), + ( + datetime.datetime(year=2018, month=3, day=1), + datetime.datetime(year=2020, month=2, day=29) + ), + # 2019 + ( + datetime.datetime(year=2019, month=2, day=28), + datetime.datetime(year=2020, month=2, day=29) + ), + ( + datetime.datetime(year=2019, month=3, day=1), + datetime.datetime(year=2020, month=2, day=29) + ), + # 2020 (leap) + ( + datetime.datetime(year=2020, month=2, day=29), + datetime.datetime(year=2020, month=2, day=29) + ), + ) + for now, expected in current_and_expected_dates: + assert p(_c_locale_time(d), now=now) == date_to_p(expected) + + +def test_parse_ls_date_not_older_than_6_month_format(): def date_to_p(d): return d.strftime("%Y%m%d%H%M00") p = aioftp.Client.parse_ls_date @@ -73,10 +122,10 @@ def test_parse_list_datetime_not_older_than_6_month_format(): deltas = (datetime.timedelta(), dt, -dt) for now, delta in itertools.product(dates, deltas): d = now + delta - assert p(aioftp.Client, _c_locale_time(d), now=now) == date_to_p(d) + assert p(_c_locale_time(d), now=now) == date_to_p(d) -def test_parse_list_datetime_older_than_6_month_format(): +def test_parse_ls_date_older_than_6_month_format(): def date_to_p(d): return d.strftime("%Y%m%d%H%M00") p = aioftp.Client.parse_ls_date @@ -92,10 +141,10 @@ def test_parse_list_datetime_older_than_6_month_format(): expect = date_to_p(d.replace(year=d.year - 1)) else: expect = date_to_p(d.replace(year=d.year + 1)) - assert p(aioftp.Client, _c_locale_time(d), now=now) == expect + assert p(_c_locale_time(d), now=now) == expect -def test_parse_list_datetime_short(): +def test_parse_ls_date_short(): def date_to_p(d): return d.strftime("%Y%m%d%H%M00") p = aioftp.Client.parse_ls_date @@ -105,7 +154,7 @@ def test_parse_list_datetime_short(): ) for d in dates: s = _c_locale_time(d, format="%b %d %Y") - assert p(aioftp.Client, s) == date_to_p(d) + assert p(s) == date_to_p(d) def test_parse_list_line_unix():
Leap Year Issue Hi, ``` import asyncio import aioftp async def get_files_path(host, port, login, password): async with aioftp.ClientSession(host, port, login, password) as client: for path, info in (await client.list(PATH)): print(path) asyncio.run(get_files_path(HOST, port, USERNAME, PASSWORD)) ``` It seems that aioftp fails to list up the files created after 02/29/2020 00:00. When I used Python ftplib, I could get the correct number of files totally the same with I was checking on FileZilla. Can you check this issue? Thanks.
0.0
9fa19b106d6be2d38eeb885c5ad8f81338869da1
[ "tests/test_simple_functions.py::test_parse_ls_date_of_leap_year", "tests/test_simple_functions.py::test_parse_ls_date_not_older_than_6_month_format", "tests/test_simple_functions.py::test_parse_ls_date_older_than_6_month_format", "tests/test_simple_functions.py::test_parse_ls_date_short", "tests/test_simple_functions.py::test_parse_list_line_unix", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r------]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------x]", "tests/test_simple_functions.py::test_parse_unix_mode[w--------]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r------]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t----]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x----]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------s--]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------x--]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--------s]", "tests/test_simple_functions.py::test_parse_unix_mode[--------x]", "tests/test_simple_functions.py::test_parse_unix_mode[---------]", "tests/test_simple_functions.py::test_parse_unix_mode[--------E]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------E--]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E----]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-E]", "tests/test_simple_functions.py::test_parse_list_line_failed", "tests/test_simple_functions.py::test_reprs_works", "tests/test_simple_functions.py::test_throttle_reset", "tests/test_simple_functions.py::test_permission_is_parent", "tests/test_simple_functions.py::test_server_mtime_build" ]
[ "tests/test_simple_functions.py::test_parse_directory_response", "tests/test_simple_functions.py::test_connection_del_future", "tests/test_simple_functions.py::test_connection_not_in_storage", "tests/test_simple_functions.py::test_available_connections_too_much_acquires", "tests/test_simple_functions.py::test_available_connections_too_much_releases", "tests/test_simple_functions.py::test_parse_pasv_response", "tests/test_simple_functions.py::test_parse_epsv_response" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2020-03-05 16:49:38+00:00
apache-2.0
945
aio-libs__aioftp-113
diff --git a/aioftp/client.py b/aioftp/client.py index a1072b6..566a397 100644 --- a/aioftp/client.py +++ b/aioftp/client.py @@ -360,7 +360,7 @@ class BaseClient: def parse_ls_date(cls, s, *, now=None): """ Parsing dates from the ls unix utility. For example, - "Nov 18 1958" and "Nov 18 12:29". + "Nov 18 1958", "Jan 03 2018", and "Nov 18 12:29". :param s: ls date :type s: :py:class:`str` @@ -439,7 +439,7 @@ class BaseClient: raise ValueError s = s[i:].lstrip() - info["modify"] = self.parse_ls_date(s[:12]) + info["modify"] = self.parse_ls_date(s[:12].strip()) s = s[12:].strip() if info["type"] == "link": i = s.rindex(" -> ") diff --git a/history.rst b/history.rst index 20ea7de..a78574f 100644 --- a/history.rst +++ b/history.rst @@ -1,6 +1,9 @@ x.x.x (xx-xx-xxxx) ------------------ +- client: strip date before parsing (#113) +Thanks to `ndhansen <https://github.com/ndhansen>`_ + 0.16.0 (11-03-2020) ------------------
aio-libs/aioftp
531b63eface3500b82cb2bf596da63876c1d5417
diff --git a/tests/test_simple_functions.py b/tests/test_simple_functions.py index cada55a..e46448b 100644 --- a/tests/test_simple_functions.py +++ b/tests/test_simple_functions.py @@ -165,6 +165,8 @@ def test_parse_list_line_unix(): ], "dir": [ "drw-rw-r-- 1 poh poh 6595 Feb 27 04:14 history.rst", + "drw-rw-r-- 1 poh poh 6595 Jan 03 2016 changes.rst", + "drw-rw-r-- 1 poh poh 6595 Mar 10 1996 README.rst", ], "unknown": [ "Erw-rw-r-- 1 poh poh 6595 Feb 27 04:14 history.rst",
`parse_ls_date` doesn't handle singe-spaced servers. I'm using aioftp across a multitude of FTP servers, and just discovered that one of them uses a timestamp of `%b %d %Y` instead of `%b %d %Y`. Because the parser assumes the date is exactly 12 characters long, it will catch `Jan 03 2018` as `Jan 03 2018 `. This in turn leads to a datetime parsing error.
0.0
531b63eface3500b82cb2bf596da63876c1d5417
[ "tests/test_simple_functions.py::test_parse_list_line_unix", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r------]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------x]", "tests/test_simple_functions.py::test_parse_unix_mode[w--------]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r------]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t----]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x----]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------s--]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------x--]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--------s]", "tests/test_simple_functions.py::test_parse_unix_mode[--------x]", "tests/test_simple_functions.py::test_parse_unix_mode[---------]", "tests/test_simple_functions.py::test_parse_unix_mode[--------E]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------E--]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E----]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-E]", "tests/test_simple_functions.py::test_parse_list_line_failed", "tests/test_simple_functions.py::test_reprs_works", "tests/test_simple_functions.py::test_throttle_reset", "tests/test_simple_functions.py::test_permission_is_parent", "tests/test_simple_functions.py::test_server_mtime_build" ]
[ "tests/test_simple_functions.py::test_parse_directory_response", "tests/test_simple_functions.py::test_connection_del_future", "tests/test_simple_functions.py::test_connection_not_in_storage", "tests/test_simple_functions.py::test_available_connections_too_much_acquires", "tests/test_simple_functions.py::test_available_connections_too_much_releases", "tests/test_simple_functions.py::test_parse_pasv_response", "tests/test_simple_functions.py::test_parse_epsv_response", "tests/test_simple_functions.py::test_parse_ls_date_of_leap_year", "tests/test_simple_functions.py::test_parse_ls_date_not_older_than_6_month_format", "tests/test_simple_functions.py::test_parse_ls_date_older_than_6_month_format", "tests/test_simple_functions.py::test_parse_ls_date_short" ]
{ "failed_lite_validators": [ "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2020-06-17 17:11:16+00:00
apache-2.0
946
aio-libs__aioftp-148
diff --git a/aioftp/server.py b/aioftp/server.py index 4af6399..f0a92c3 100644 --- a/aioftp/server.py +++ b/aioftp/server.py @@ -988,7 +988,8 @@ class Server: if tasks_to_wait: await asyncio.wait(tasks_to_wait) - def get_paths(self, connection, path): + @staticmethod + def get_paths(connection, path): """ Return *real* and *virtual* paths, resolves ".." with "up" action. *Real* path is path for path_io, when *virtual* deals with @@ -1014,6 +1015,12 @@ class Server: resolved_virtual_path /= part base_path = connection.user.base_path real_path = base_path / resolved_virtual_path.relative_to("/") + # replace with `is_relative_to` check after 3.9+ requirements lands + try: + real_path.relative_to(base_path) + except ValueError: + real_path = base_path + resolved_virtual_path = pathlib.PurePosixPath("/") return real_path, resolved_virtual_path async def greeting(self, connection, rest):
aio-libs/aioftp
81d4bc018261268bf2ea88f42e05f130ab4c9229
diff --git a/tests/test_simple_functions.py b/tests/test_simple_functions.py index e46448b..5fbc312 100644 --- a/tests/test_simple_functions.py +++ b/tests/test_simple_functions.py @@ -230,3 +230,17 @@ def test_server_mtime_build(): b = aioftp.Server.build_list_mtime assert b(now, now) == "Jan 1 00:00" assert b(past, now) == "Jan 1 2001" + + +def test_get_paths_windows_traverse(): + base_path = pathlib.PureWindowsPath("C:\\ftp") + user = aioftp.User() + user.base_path = base_path + connection = aioftp.Connection(current_directory=base_path, user=user) + virtual_path = pathlib.PurePosixPath("/foo/C:\\windows") + real_path, resolved_virtual_path = aioftp.Server.get_paths( + connection, + virtual_path, + ) + assert real_path == base_path + assert resolved_virtual_path == pathlib.PurePosixPath("/")
Directory traversal / base path escape possible on Windows The server allows escaping the user `base_path` on Windows using absolute path (segments). This is due to [`get_paths`](https://github.com/aio-libs/aioftp/blob/81d4bc018261268bf2ea88f42e05f130ab4c9229/aioftp/server.py#L991): While the virtual path handling is perfectly fine in itself (it represents a POSIX path, so all is good there), the joining between `base_path` and `resolved_virtual_path` is not and quickly falls apart when Windows absolute paths are involved. In my opinion this presets a serious security issue when developers naively rely on the `base_path` setting to not allow users to traverse outside of it. Consider the following: ```python base_path = pathlib.Path("C:\\locked_path") # base_path is of the type Path (so platform dependent path) ``` Now see what happens when the input virtual path contains Windows absolute path segments: ```python resolved_virtual_path = pathlib.PurePosixPath("/foo/C:\\Windows/bla") real_path = base_path / resolved_virtual_path.relative_to("/") >>> PureWindowsPath('C:/Windows/bla') ``` You have now broken out. This is due to two reasons: 1. While joining, `pathlib` joins each path segment to the list of first path object with the following rule: > When several absolute paths are given, the last is taken as an anchor (mimicking os.path.join()’s behaviour) This is also the reason the `relative_to("/")` does not help here. 2. When joining, `pathlib` joins according to the rules of the first path object, so in this case it pulls out all path `parts` from the `PurePosixPath` and joins them to the `PureWindowsPath` by the rules of `PureWindowsPath`, meaning the Windows absolute anchor in the `PurePosixPath` is interpreted as on Windows. There are a myriad of ways to _almost_ fix it inside the virtual path, but they always have special cases that break them and I do not consider them safe. In my opinion, the best way to prevent any directory traversal using `pathlib` is by going by the resulting absolute path. 1. Join the `resolved_virtual_path` to the `base_path` as is already done, but using the anchor given in the path to be relative to since users can pass Windows anchors too: ``` real_path = base_path / resolved_virtual_path.relative_to(resolved_virtual_path.anchor) ``` 2. Use `relative_to` to make sure the joined `real_path` is still relative to / inside the `base_path` and give us the fully resolved (all absolute anchors removed) subdirectory/virtual path at the same time: ``` resolved_virtual_path = pathlib.PurePosixPath("/") / real_path.relative_to(base_path) ``` 3. If the previous call raises (with our example from above: `ValueError: 'C:\\Windows\\bla' is not in the subpath of 'C:\\locked_path' OR one path is relative and the other is absolute.`) we know that a traversal was attempted and can either return 1. An access denied error (not very fitting in the current design, would need to either convert to using exceptions or add lots of boilerplate) 2. Just return something like `base_path, pathlib.PurePosixPath("/")` to throw the user back to the home directory. I will submit a pull request shortly.
0.0
81d4bc018261268bf2ea88f42e05f130ab4c9229
[ "tests/test_simple_functions.py::test_get_paths_windows_traverse" ]
[ "tests/test_simple_functions.py::test_parse_directory_response", "tests/test_simple_functions.py::test_connection_del_future", "tests/test_simple_functions.py::test_connection_not_in_storage", "tests/test_simple_functions.py::test_available_connections_too_much_acquires", "tests/test_simple_functions.py::test_available_connections_too_much_releases", "tests/test_simple_functions.py::test_parse_pasv_response", "tests/test_simple_functions.py::test_parse_epsv_response", "tests/test_simple_functions.py::test_parse_ls_date_of_leap_year", "tests/test_simple_functions.py::test_parse_ls_date_not_older_than_6_month_format", "tests/test_simple_functions.py::test_parse_ls_date_older_than_6_month_format", "tests/test_simple_functions.py::test_parse_ls_date_short", "tests/test_simple_functions.py::test_parse_list_line_unix", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r------]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-----E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r---E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E----]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-r-E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------x]", "tests/test_simple_functions.py::test_parse_unix_mode[w--------]", "tests/test_simple_functions.py::test_parse_unix_mode[w-------E]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w-----E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E----]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[w---E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r------]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-----E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r---E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E----]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[--r-E-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t----]", "tests/test_simple_functions.py::test_parse_unix_mode[----t---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----t-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x----]", "tests/test_simple_functions.py::test_parse_unix_mode[----x---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----x-E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------s--]", "tests/test_simple_functions.py::test_parse_unix_mode[------s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------x--]", "tests/test_simple_functions.py::test_parse_unix_mode[------x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[--------s]", "tests/test_simple_functions.py::test_parse_unix_mode[--------x]", "tests/test_simple_functions.py::test_parse_unix_mode[---------]", "tests/test_simple_functions.py::test_parse_unix_mode[--------E]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[------E--]", "tests/test_simple_functions.py::test_parse_unix_mode[------E-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-s-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-x-E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E----]", "tests/test_simple_functions.py::test_parse_unix_mode[----E---E]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-s]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-x]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E--]", "tests/test_simple_functions.py::test_parse_unix_mode[----E-E-E]", "tests/test_simple_functions.py::test_parse_list_line_failed", "tests/test_simple_functions.py::test_reprs_works", "tests/test_simple_functions.py::test_throttle_reset", "tests/test_simple_functions.py::test_permission_is_parent", "tests/test_simple_functions.py::test_server_mtime_build" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2022-01-27 22:56:19+00:00
apache-2.0
947
aio-libs__aioftp-97
diff --git a/aioftp/client.py b/aioftp/client.py index 007eba7..61c7b85 100644 --- a/aioftp/client.py +++ b/aioftp/client.py @@ -106,7 +106,8 @@ class BaseClient: def __init__(self, *, socket_timeout=None, read_speed_limit=None, write_speed_limit=None, path_timeout=None, path_io_factory=pathio.PathIO, - encoding="utf-8", ssl=None, **siosocks_asyncio_kwargs): + encoding="utf-8", ssl=None, parse_list_line_custom=None, + **siosocks_asyncio_kwargs): self.socket_timeout = socket_timeout self.throttle = StreamThrottle.from_limits( read_speed_limit, @@ -117,6 +118,7 @@ class BaseClient: self.encoding = encoding self.stream = None self.ssl = ssl + self.parse_list_line_custom = parse_list_line_custom self._open_connection = partial(open_connection, ssl=self.ssl, **siosocks_asyncio_kwargs) @@ -480,8 +482,14 @@ class BaseClient: :rtype: (:py:class:`pathlib.PurePosixPath`, :py:class:`dict`) """ ex = [] - parsers = (self.parse_list_line_unix, self.parse_list_line_windows) + parsers = ( + self.parse_list_line_custom, + self.parse_list_line_unix, + self.parse_list_line_windows, + ) for parser in parsers: + if parser is None: + continue try: return parser(b) except (ValueError, KeyError, IndexError) as e: @@ -543,6 +551,11 @@ class Client(BaseClient): Please look :py:meth:`asyncio.loop.create_connection` docs. :type ssl: :py:class:`bool` or :py:class:`ssl.SSLContext` + :param parse_list_line_custom: callable, which receive exactly one + argument: line of type bytes. Should return tuple of Path object and + dictionary with fields "modify", "type", "type", "size". For more + information see sources. + :type parse_list_line_custom: callable :param **siosocks_asyncio_kwargs: siosocks key-word only arguments """ async def connect(self, host, port=DEFAULT_PORT): diff --git a/history.rst b/history.rst index f64c8c4..9128de3 100644 --- a/history.rst +++ b/history.rst @@ -2,6 +2,9 @@ ------------------- - client: add socks proxy support via `siosocks <https://github.com/pohmelie/siosocks>`_ (#94) +- client: add custom `list` parser (#95) + +Thanks to `purpleskyfall https://github.com/purpleskyfall`_, `VyachAp <https://github.com/VyachAp>`_ 0.13.0 (24-03-2019) -------------------
aio-libs/aioftp
1298d1a468cedd178191770ab8e0870fe5640135
diff --git a/tests/test_list_fallback.py b/tests/test_list_fallback.py index f48a89a..6aeb03a 100644 --- a/tests/test_list_fallback.py +++ b/tests/test_list_fallback.py @@ -90,3 +90,26 @@ def test_client_list_windows(): assert entities[p]["type"] == "file" with pytest.raises(ValueError): parse(b" 10/3/2018 2:58 PM 34,35xxx38,368 win10.img") + + [email protected] +async def test_client_list_override_with_custom(pair_factory, Client): + meta = {"type": "file", "works": True} + + def parser(b): + import pickle + return pickle.loads(bytes.fromhex(b.decode().rstrip("\r\n"))) + + async def builder(_, path): + import pickle + return pickle.dumps((path, meta)).hex() + + async with pair_factory(Client(parse_list_line_custom=parser)) as pair: + pair.server.mlst = not_implemented + pair.server.mlsd = not_implemented + pair.server.build_list_string = builder + await pair.client.make_directory("bar") + (path, stat), *_ = files = await pair.client.list() + assert len(files) == 1 + assert path == pathlib.PurePosixPath("bar") + assert stat == meta
Windows_list parser fails on date_time format Based on this [issue](https://github.com/aio-libs/aioftp/issues/82): Hello everyone, seems we've got some problem with `parse_list_line_windows` function. ```python3 with setlocale("C"): strptime = datetime.datetime.strptime date_time = strptime(date_time_str, "%m/%d/%Y %I:%M %p") ``` In this case date cannot be parsed properly, so we've got an empty result of `client.list()` function. We've made some changes to the date format to make it works: ```python3 with setlocale("C"): strptime = datetime.datetime.strptime date_time = strptime(date_time_str, "%m-%d-%y %I:%M%p") ``` Actually we couldn't understand the role of `setlocale` context, at this time we already have a date as string and setlocale seems doing nothing to this. Probably we should add optional argument for date-time format.
0.0
1298d1a468cedd178191770ab8e0870fe5640135
[ "tests/test_list_fallback.py::test_client_list_override_with_custom[127.0.0.1]", "tests/test_list_fallback.py::test_client_list_override_with_custom[::1]" ]
[ "tests/test_list_fallback.py::test_client_fallback_to_list_at_list[127.0.0.1]", "tests/test_list_fallback.py::test_client_fallback_to_list_at_list[::1]", "tests/test_list_fallback.py::test_client_list_override[127.0.0.1]", "tests/test_list_fallback.py::test_client_list_override[::1]", "tests/test_list_fallback.py::test_client_list_override_invalid_raw_command[127.0.0.1]", "tests/test_list_fallback.py::test_client_list_override_invalid_raw_command[::1]", "tests/test_list_fallback.py::test_client_list_windows" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2019-08-10 15:47:39+00:00
apache-2.0
948
aio-libs__aiohttp-sse-431
diff --git a/aiohttp_sse/__init__.py b/aiohttp_sse/__init__.py index 1b04105..7a18da2 100644 --- a/aiohttp_sse/__init__.py +++ b/aiohttp_sse/__init__.py @@ -2,6 +2,7 @@ import asyncio import contextlib import io import re +from typing import Optional from aiohttp.web import HTTPMethodNotAllowed, StreamResponse @@ -26,6 +27,7 @@ class EventSourceResponse(StreamResponse): DEFAULT_PING_INTERVAL = 15 DEFAULT_SEPARATOR = "\r\n" + DEFAULT_LAST_EVENT_HEADER = "Last-Event-Id" LINE_SEP_EXPR = re.compile(r"\r\n|\r|\n") def __init__(self, *, status=200, reason=None, headers=None, sep=None): @@ -134,6 +136,15 @@ class EventSourceResponse(StreamResponse): """Time interval between two ping massages""" return self._ping_interval + @property + def last_event_id(self) -> Optional[str]: + """Last event ID, requested by client.""" + if self._req is None: + msg = "EventSource request must be prepared first" + raise RuntimeError(msg) + + return self._req.headers.get(self.DEFAULT_LAST_EVENT_HEADER) + @ping_interval.setter def ping_interval(self, value): """Setter for ping_interval property. diff --git a/examples/graceful_shutdown.py b/examples/graceful_shutdown.py index b884ead..065c883 100644 --- a/examples/graceful_shutdown.py +++ b/examples/graceful_shutdown.py @@ -14,10 +14,6 @@ worker = web.AppKey("worker", asyncio.Task[None]) class SSEResponse(EventSourceResponse): - @property - def last_event_id(self): - return self._req.headers.get("Last-Event-Id") - async def send_json( self, data,
aio-libs/aiohttp-sse
989774db2d41066c4d2e2cb31b211b12aa40e324
diff --git a/tests/test_sse.py b/tests/test_sse.py index 7805b1a..696cba5 100644 --- a/tests/test_sse.py +++ b/tests/test_sse.py @@ -388,3 +388,34 @@ async def test_multiline_data(loop, unused_tcp_port, session, stream_sep, line_s ) assert streamed_data == expected.format(stream_sep) await runner.cleanup() + + [email protected] +class TestLastEventId: + async def test_success(self, unused_tcp_port, session): + async def func(request): + async with sse_response(request) as sse: + await sse.send(sse.last_event_id) + return sse + + app = web.Application() + app.router.add_route("GET", "/", func) + + host = "127.0.0.1" + runner = await make_runner(app, host, unused_tcp_port) + url = f"http://{host}:{unused_tcp_port}/" + + last_event_id = "42" + headers = {EventSourceResponse.DEFAULT_LAST_EVENT_HEADER: last_event_id} + resp = await session.request("GET", url, headers=headers) + assert resp.status == 200 + + # check streamed data + streamed_data = await resp.text() + assert streamed_data == f"data: {last_event_id}\r\n\r\n" + await runner.cleanup() + + async def test_get_before_prepare(self): + sse = EventSourceResponse() + with pytest.raises(RuntimeError): + _ = sse.last_event_id
Add EventSourceResponse.last_event_id I think it would be useful to add `last_event_id` property to the `EventSourceResponse` class from the example: https://github.com/aio-libs/aiohttp-sse/blob/aca7808960635ff7511ff46002b7f83168f6952c/examples/graceful_shutdown.py#L14-L16 Also there is a bug at that example (`sse_response` doesn't accept `response_cls` parameter): https://github.com/aio-libs/aiohttp-sse/blob/aca7808960635ff7511ff46002b7f83168f6952c/examples/graceful_shutdown.py#L63
0.0
989774db2d41066c4d2e2cb31b211b12aa40e324
[ "tests/test_sse.py::TestLastEventId::test_success[debug:true]", "tests/test_sse.py::test_func[debug:false-with_sse_response]", "tests/test_sse.py::TestLastEventId::test_success[debug:false]", "tests/test_sse.py::test_custom_response_cls[without_subclass]", "tests/test_sse.py::TestLastEventId::test_get_before_prepare" ]
[ "tests/test_sse.py::test_func[debug:true-without_sse_response]", "tests/test_sse.py::test_func[debug:true-with_sse_response]", "tests/test_sse.py::test_wait_stop_streaming[debug:true]", "tests/test_sse.py::test_retry[debug:true]", "tests/test_sse.py::test_ping_property[debug:true]", "tests/test_sse.py::test_ping[debug:true]", "tests/test_sse.py::test_context_manager[debug:true]", "tests/test_sse.py::test_custom_sep[debug:true-LF]", "tests/test_sse.py::test_custom_sep[debug:true-CR]", "tests/test_sse.py::test_custom_sep[debug:true-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:true-steam-LF:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR:line-LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR:line-CR]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR+LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR+LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR+LF:line-CR+LF]", "tests/test_sse.py::test_func[debug:false-without_sse_response]", "tests/test_sse.py::test_wait_stop_streaming[debug:false]", "tests/test_sse.py::test_retry[debug:false]", "tests/test_sse.py::test_ping_property[debug:false]", "tests/test_sse.py::test_ping[debug:false]", "tests/test_sse.py::test_context_manager[debug:false]", "tests/test_sse.py::test_custom_sep[debug:false-LF]", "tests/test_sse.py::test_custom_sep[debug:false-CR]", "tests/test_sse.py::test_custom_sep[debug:false-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:false-steam-LF:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR:line-LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR:line-CR]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR+LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR+LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR+LF:line-CR+LF]", "tests/test_sse.py::test_wait_stop_streaming_errors", "tests/test_sse.py::test_compression_not_implemented", "tests/test_sse.py::test_custom_response_cls[with_subclass]" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2024-01-26 09:31:08+00:00
apache-2.0
949
aio-libs__aiohttp-sse-451
diff --git a/.coveragerc b/.coveragerc index e1ba26a..0e3ab35 100644 --- a/.coveragerc +++ b/.coveragerc @@ -5,4 +5,5 @@ branch = True [report] exclude_also = ^\s*if TYPE_CHECKING: + : \.\.\.(\s*#.*)?$ ^ +\.\.\.$ diff --git a/.pre-commit-config.yaml b/.pre-commit-config.yaml index 6cc2b3f..96536e0 100644 --- a/.pre-commit-config.yaml +++ b/.pre-commit-config.yaml @@ -12,7 +12,7 @@ repos: hooks: - id: isort - repo: https://github.com/psf/black - rev: '23.12.1' + rev: '24.1.1' hooks: - id: black language_version: python3 # Should be a command that runs python3.6+ diff --git a/aiohttp_sse/__init__.py b/aiohttp_sse/__init__.py index 8367e1f..43e6d50 100644 --- a/aiohttp_sse/__init__.py +++ b/aiohttp_sse/__init__.py @@ -51,7 +51,7 @@ class EventSourceResponse(StreamResponse): self.headers["Connection"] = "keep-alive" self.headers["X-Accel-Buffering"] = "no" - self._ping_interval: int = self.DEFAULT_PING_INTERVAL + self._ping_interval: float = self.DEFAULT_PING_INTERVAL self._ping_task: Optional[asyncio.Task[None]] = None self._sep = sep if sep is not None else self.DEFAULT_SEPARATOR @@ -129,7 +129,11 @@ class EventSourceResponse(StreamResponse): buffer.write(self._sep) buffer.write(self._sep) - await self.write(buffer.getvalue().encode("utf-8")) + try: + await self.write(buffer.getvalue().encode("utf-8")) + except ConnectionResetError: + self.stop_streaming() + raise async def wait(self) -> None: """EventSourceResponse object is used for streaming data to the client, @@ -164,19 +168,19 @@ class EventSourceResponse(StreamResponse): return self._req.headers.get(self.DEFAULT_LAST_EVENT_HEADER) @property - def ping_interval(self) -> int: + def ping_interval(self) -> float: """Time interval between two ping massages""" return self._ping_interval @ping_interval.setter - def ping_interval(self, value: int) -> None: + def ping_interval(self, value: float) -> None: """Setter for ping_interval property. - :param int value: interval in sec between two ping values. + :param value: interval in sec between two ping values. """ - if not isinstance(value, int): - raise TypeError("ping interval must be int") + if not isinstance(value, (int, float)): + raise TypeError("ping interval must be int or float") if value < 0: raise ValueError("ping interval must be greater then 0") @@ -221,8 +225,7 @@ def sse_response( reason: Optional[str] = None, headers: Optional[Mapping[str, str]] = None, sep: Optional[str] = None, -) -> _ContextManager[EventSourceResponse]: - ... +) -> _ContextManager[EventSourceResponse]: ... @overload @@ -234,8 +237,7 @@ def sse_response( headers: Optional[Mapping[str, str]] = None, sep: Optional[str] = None, response_cls: Type[ESR], -) -> _ContextManager[ESR]: - ... +) -> _ContextManager[ESR]: ... def sse_response(
aio-libs/aiohttp-sse
87854324c447f2a594888768b5b06bfb33cdd7d5
diff --git a/tests/test_sse.py b/tests/test_sse.py index 0163c6a..6aae5d6 100644 --- a/tests/test_sse.py +++ b/tests/test_sse.py @@ -133,19 +133,19 @@ def test_compression_not_implemented() -> None: class TestPingProperty: - @pytest.mark.parametrize("value", [25, 0], ids=("int", "zero int")) - def test_success(self, value: int) -> None: + @pytest.mark.parametrize("value", (25, 25.0, 0), ids=("int", "float", "zero int")) + def test_success(self, value: float) -> None: response = EventSourceResponse() response.ping_interval = value assert response.ping_interval == value @pytest.mark.parametrize("value", [None, "foo"], ids=("None", "str")) - def test_wrong_type(self, value: int) -> None: + def test_wrong_type(self, value: float) -> None: response = EventSourceResponse() with pytest.raises(TypeError) as ctx: response.ping_interval = value - assert ctx.match("ping interval must be int") + assert ctx.match("ping interval must be int or float") def test_negative_int(self) -> None: response = EventSourceResponse() @@ -230,6 +230,31 @@ async def test_ping_reset( assert streamed_data == expected +async def test_ping_auto_close(aiohttp_client: ClientFixture) -> None: + """Test ping task automatically closed on send failure.""" + + async def handler(request: web.Request) -> EventSourceResponse: + async with sse_response(request) as sse: + sse.ping_interval = 999 + + request.protocol.force_close() + with pytest.raises(ConnectionResetError): + await sse.send("never-should-be-delivered") + + assert sse._ping_task is not None + assert sse._ping_task.cancelled() + + return sse # pragma: no cover + + app = web.Application() + app.router.add_route("GET", "/", handler) + + client = await aiohttp_client(app) + + async with client.get("/") as response: + assert 200 == response.status + + async def test_context_manager(aiohttp_client: ClientFixture) -> None: async def func(request: web.Request) -> web.StreamResponse: h = {"X-SSE": "aiohttp_sse"}
Cancel ping_task on connection failure while sending event When attempting to execute `EventSourceResponse.send()`, the connection may be interrupted, resulting in a `ConnectionResetError` (for example, if the client closed the browser). Already at this moment we know that the connection is closed and cannot be restored. But `EventSourceResponse._ping_task` is still working... When the EventLoop pays attention to the Task, the `_ping_task` will try to send a `: ping` to the closed connection. Because the actions performed by the Task are doomed to failure in advance, we can free him from useless work and cancel the Task on `send()` failure
0.0
87854324c447f2a594888768b5b06bfb33cdd7d5
[ "tests/test_sse.py::TestPingProperty::test_success[debug:true-float]", "tests/test_sse.py::TestPingProperty::test_wrong_type[debug:true-None]", "tests/test_sse.py::TestPingProperty::test_wrong_type[debug:true-str]", "tests/test_sse.py::TestPingProperty::test_success[debug:false-float]", "tests/test_sse.py::TestPingProperty::test_wrong_type[debug:false-None]", "tests/test_sse.py::TestPingProperty::test_wrong_type[debug:false-str]" ]
[ "tests/test_sse.py::test_func[debug:true-without_sse_response]", "tests/test_sse.py::test_func[debug:true-with_sse_response]", "tests/test_sse.py::test_wait_stop_streaming[debug:true]", "tests/test_sse.py::test_retry[debug:true]", "tests/test_sse.py::test_wait_stop_streaming_errors[debug:true]", "tests/test_sse.py::test_compression_not_implemented[debug:true]", "tests/test_sse.py::TestPingProperty::test_success[debug:true-int]", "tests/test_sse.py::TestPingProperty::test_success[debug:true-zero", "tests/test_sse.py::TestPingProperty::test_negative_int[debug:true]", "tests/test_sse.py::TestPingProperty::test_default_value[debug:true]", "tests/test_sse.py::test_ping[debug:true]", "tests/test_sse.py::test_ping_reset[debug:true]", "tests/test_sse.py::test_ping_auto_close[debug:true]", "tests/test_sse.py::test_context_manager[debug:true]", "tests/test_sse.py::TestCustomResponseClass::test_subclass[debug:true]", "tests/test_sse.py::TestCustomResponseClass::test_not_related_class[debug:true]", "tests/test_sse.py::test_custom_sep[debug:true-LF]", "tests/test_sse.py::test_custom_sep[debug:true-CR]", "tests/test_sse.py::test_custom_sep[debug:true-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:true-steam-LF:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR:line-LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR:line-CR]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR+LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR+LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:true-steam-CR+LF:line-CR+LF]", "tests/test_sse.py::TestSSEState::test_context_states[debug:true]", "tests/test_sse.py::TestSSEState::test_not_prepared[debug:true]", "tests/test_sse.py::test_connection_is_not_alive[debug:true]", "tests/test_sse.py::TestLastEventId::test_success[debug:true]", "tests/test_sse.py::TestLastEventId::test_get_before_prepare[debug:true]", "tests/test_sse.py::test_http_methods[debug:true-GET]", "tests/test_sse.py::test_http_methods[debug:true-POST]", "tests/test_sse.py::test_http_methods[debug:true-PUT]", "tests/test_sse.py::test_http_methods[debug:true-DELETE]", "tests/test_sse.py::test_http_methods[debug:true-PATCH]", "tests/test_sse.py::test_func[debug:false-without_sse_response]", "tests/test_sse.py::test_func[debug:false-with_sse_response]", "tests/test_sse.py::test_wait_stop_streaming[debug:false]", "tests/test_sse.py::test_retry[debug:false]", "tests/test_sse.py::test_wait_stop_streaming_errors[debug:false]", "tests/test_sse.py::test_compression_not_implemented[debug:false]", "tests/test_sse.py::TestPingProperty::test_success[debug:false-int]", "tests/test_sse.py::TestPingProperty::test_success[debug:false-zero", "tests/test_sse.py::TestPingProperty::test_negative_int[debug:false]", "tests/test_sse.py::TestPingProperty::test_default_value[debug:false]", "tests/test_sse.py::test_ping[debug:false]", "tests/test_sse.py::test_ping_reset[debug:false]", "tests/test_sse.py::test_ping_auto_close[debug:false]", "tests/test_sse.py::test_context_manager[debug:false]", "tests/test_sse.py::TestCustomResponseClass::test_subclass[debug:false]", "tests/test_sse.py::TestCustomResponseClass::test_not_related_class[debug:false]", "tests/test_sse.py::test_custom_sep[debug:false-LF]", "tests/test_sse.py::test_custom_sep[debug:false-CR]", "tests/test_sse.py::test_custom_sep[debug:false-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:false-steam-LF:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR:line-LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR:line-CR]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR:line-CR+LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR+LF:line-LF]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR+LF:line-CR]", "tests/test_sse.py::test_multiline_data[debug:false-steam-CR+LF:line-CR+LF]", "tests/test_sse.py::TestSSEState::test_context_states[debug:false]", "tests/test_sse.py::TestSSEState::test_not_prepared[debug:false]", "tests/test_sse.py::test_connection_is_not_alive[debug:false]", "tests/test_sse.py::TestLastEventId::test_success[debug:false]", "tests/test_sse.py::TestLastEventId::test_get_before_prepare[debug:false]", "tests/test_sse.py::test_http_methods[debug:false-GET]", "tests/test_sse.py::test_http_methods[debug:false-POST]", "tests/test_sse.py::test_http_methods[debug:false-PUT]", "tests/test_sse.py::test_http_methods[debug:false-DELETE]", "tests/test_sse.py::test_http_methods[debug:false-PATCH]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2024-02-02 10:24:34+00:00
apache-2.0
950
aio-libs__aiohttp-sse-74
diff --git a/.travis.yml b/.travis.yml index 49b063f..10058c7 100644 --- a/.travis.yml +++ b/.travis.yml @@ -3,11 +3,11 @@ language: python matrix: include: - python: 3.5 - env: TOXENV=py35-aiohttp-2 + env: TOXENV=py35-aiohttp-3 - python: 3.5 env: TOXENV=py35-aiohttp-master - python: 3.6 - env: TOXENV=py36-aiohttp-2 + env: TOXENV=py36-aiohttp-3 - python: 3.6 env: TOXENV=py36-aiohttp-master allow_failures: diff --git a/CHANGES.txt b/CHANGES.txt index a7ffcb4..ca1f384 100644 --- a/CHANGES.txt +++ b/CHANGES.txt @@ -1,6 +1,11 @@ CHANGES ======= +2.0 (Undefined) +--------------- +* Drop aiohttp < 3 support +* ``EventSourceResponse.send`` is now a coroutine. + 1.1.0 (2017-08-21) ------------------ diff --git a/README.rst b/README.rst index c67dd49..71bdb1f 100644 --- a/README.rst +++ b/README.rst @@ -50,7 +50,7 @@ Example for i in range(0, 100): print('foo') await asyncio.sleep(1, loop=loop) - resp.send('foo {}'.format(i)) + await resp.send('foo {}'.format(i)) return resp @@ -94,7 +94,7 @@ Requirements ------------ * Python_ 3.5+ -* aiohttp_ +* aiohttp_ 3+ License diff --git a/aiohttp_sse/__init__.py b/aiohttp_sse/__init__.py index df11645..4beab3a 100644 --- a/aiohttp_sse/__init__.py +++ b/aiohttp_sse/__init__.py @@ -63,7 +63,7 @@ class EventSourceResponse(StreamResponse): self.enable_chunked_encoding() return writer - def send(self, data, id=None, event=None, retry=None): + async def send(self, data, id=None, event=None, retry=None): """Send data using EventSource protocol :param str data: The data field for the message. @@ -94,7 +94,7 @@ class EventSourceResponse(StreamResponse): buffer.write('retry: {0}\r\n'.format(retry).encode('utf-8')) buffer.write(b'\r\n') - self.write(buffer.getvalue()) + await self.write(buffer.getvalue()) async def wait(self): """EventSourceResponse object is used for streaming data to the client, @@ -142,7 +142,7 @@ class EventSourceResponse(StreamResponse): # as ping message. while True: await asyncio.sleep(self._ping_interval, loop=self._loop) - self.write(b': ping\r\n\r\n') + await self.write(b': ping\r\n\r\n') async def __aenter__(self): return self diff --git a/requirements-dev.txt b/requirements-dev.txt index 3e57ae0..79bb795 100644 --- a/requirements-dev.txt +++ b/requirements-dev.txt @@ -1,6 +1,6 @@ -e . flake8==3.5.0 -ipdb==0.10.3 +ipdb==0.11 pytest==3.4.0 pytest-asyncio==0.8.0 pytest-cov==2.5.1 diff --git a/setup.py b/setup.py index d257a03..de8d2fb 100644 --- a/setup.py +++ b/setup.py @@ -38,7 +38,7 @@ def read_version(): return finder.version -install_requires = ['aiohttp>=2.0'] +install_requires = ['aiohttp>=3.0'] setup(name='aiohttp-sse', diff --git a/tox.ini b/tox.ini index a8c0eae..0c271a7 100644 --- a/tox.ini +++ b/tox.ini @@ -1,10 +1,10 @@ [tox] -envlist = py{35,36}-aiohttp-{2,master} +envlist = py{35,36}-aiohttp-{3,master} [testenv] deps = -rrequirements-dev.txt - aiohttp-2: aiohttp>=2,<3 + aiohttp-3: aiohttp>=3,<4 aiohttp-master: https://github.com/aio-libs/aiohttp/archive/master.zip commands = pytest -sv tests/ --cov=aiohttp_sse --cov-report=html {posargs}
aio-libs/aiohttp-sse
a8b148af07e252540ca4d42b888574fc9082e7af
diff --git a/tests/test_sse.py b/tests/test_sse.py index 03b4716..b1a6faf 100644 --- a/tests/test_sse.py +++ b/tests/test_sse.py @@ -18,10 +18,10 @@ async def test_func(loop, unused_tcp_port, with_sse_response, session): else: resp = EventSourceResponse(headers={'X-SSE': 'aiohttp_sse'}) await resp.prepare(request) - resp.send('foo') - resp.send('foo', event='bar') - resp.send('foo', event='bar', id='xyz') - resp.send('foo', event='bar', id='xyz', retry=1) + await resp.send('foo') + await resp.send('foo', event='bar') + await resp.send('foo', event='bar', id='xyz') + await resp.send('foo', event='bar', id='xyz', retry=1) resp.stop_streaming() await resp.wait() return resp @@ -67,7 +67,7 @@ async def test_wait_stop_streaming(loop, unused_tcp_port, session): app = request.app resp = EventSourceResponse() await resp.prepare(request) - resp.send('foo', event='bar', id='xyz', retry=1) + await resp.send('foo', event='bar', id='xyz', retry=1) app['socket'].append(resp) await resp.wait() return resp @@ -107,8 +107,8 @@ async def test_retry(loop, unused_tcp_port, session): resp = EventSourceResponse() await resp.prepare(request) with pytest.raises(TypeError): - resp.send('foo', retry='one') - resp.send('foo', retry=1) + await resp.send('foo', retry='one') + await resp.send('foo', retry=1) resp.stop_streaming() await resp.wait() return resp @@ -175,7 +175,7 @@ async def test_ping(loop, unused_tcp_port, session): resp = EventSourceResponse() resp.ping_interval = 1 await resp.prepare(request) - resp.send('foo') + await resp.send('foo') app['socket'].append(resp) await resp.wait() return resp @@ -213,10 +213,10 @@ async def test_context_manager(loop, unused_tcp_port, session): async def func(request): h = {'X-SSE': 'aiohttp_sse'} async with sse_response(request, headers=h) as sse: - sse.send('foo') - sse.send('foo', event='bar') - sse.send('foo', event='bar', id='xyz') - sse.send('foo', event='bar', id='xyz', retry=1) + await sse.send('foo') + await sse.send('foo', event='bar') + await sse.send('foo', event='bar', id='xyz') + await sse.send('foo', event='bar', id='xyz', retry=1) return sse app = web.Application()
Fix compatibility with aiohttp master Library is not compatible with aiohttp master (https://travis-ci.org/aio-libs/aiohttp-sse/jobs/331709276), next major release will break everything. I think we need to fix compatibility before aiohttp release.
0.0
a8b148af07e252540ca4d42b888574fc9082e7af
[ "tests/test_sse.py::test_func[debug:true-without_sse_response]", "tests/test_sse.py::test_func[debug:true-with_sse_response]", "tests/test_sse.py::test_wait_stop_streaming[debug:true]", "tests/test_sse.py::test_retry[debug:true]", "tests/test_sse.py::test_ping[debug:true]", "tests/test_sse.py::test_context_manager[debug:true]", "tests/test_sse.py::test_func[debug:false-without_sse_response]", "tests/test_sse.py::test_func[debug:false-with_sse_response]", "tests/test_sse.py::test_wait_stop_streaming[debug:false]", "tests/test_sse.py::test_retry[debug:false]", "tests/test_sse.py::test_ping[debug:false]", "tests/test_sse.py::test_context_manager[debug:false]" ]
[ "tests/test_sse.py::test_ping_property[debug:true]", "tests/test_sse.py::test_ping_property[debug:false]", "tests/test_sse.py::test_wait_stop_streaming_errors", "tests/test_sse.py::test_compression_not_implemented" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2018-01-31 10:42:29+00:00
apache-2.0
951
aio-libs__aiosmtpd-106
diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index f123514..287875b 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -284,10 +284,6 @@ class SMTP(asyncio.StreamReaderProtocol): if not hostname: await self.push('501 Syntax: HELO hostname') return - # See issue #21783 for a discussion of this behavior. - if self.session.host_name: - await self.push('503 Duplicate HELO/EHLO') - return self._set_rset_state() self.session.extended_smtp = False status = await self._call_handler_hook('HELO', hostname) @@ -300,11 +296,6 @@ class SMTP(asyncio.StreamReaderProtocol): if not hostname: await self.push('501 Syntax: EHLO hostname') return - # See https://bugs.python.org/issue21783 for a discussion of this - # behavior. - if self.session.host_name: - await self.push('503 Duplicate HELO/EHLO') - return self._set_rset_state() self.session.extended_smtp = True await self.push('250-%s' % self.hostname)
aio-libs/aiosmtpd
2ec2b40aab6288baf2153672aae51800d3e73765
diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index 8e61021..9f78c16 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -38,6 +38,15 @@ class ReceivingHandler: return '250 OK' +class StoreEnvelopeOnVRFYHandler: + """Saves envelope for later inspection when handling VRFY.""" + envelope = None + + async def handle_VRFY(self, server, session, envelope, addr): + self.envelope = envelope + return '250 OK' + + class SizedController(Controller): def __init__(self, handler, size): self.size = size @@ -201,8 +210,7 @@ class TestSMTP(unittest.TestCase): code, response = client.helo('example.com') self.assertEqual(code, 250) code, response = client.helo('example.org') - self.assertEqual(code, 503) - self.assertEqual(response, b'Duplicate HELO/EHLO') + self.assertEqual(code, 250) def test_ehlo(self): with SMTP(*self.address) as client: @@ -219,8 +227,7 @@ class TestSMTP(unittest.TestCase): code, response = client.ehlo('example.com') self.assertEqual(code, 250) code, response = client.ehlo('example.org') - self.assertEqual(code, 503) - self.assertEqual(response, b'Duplicate HELO/EHLO') + self.assertEqual(code, 250) def test_ehlo_no_hostname(self): with SMTP(*self.address) as client: @@ -235,16 +242,14 @@ class TestSMTP(unittest.TestCase): code, response = client.helo('example.com') self.assertEqual(code, 250) code, response = client.ehlo('example.org') - self.assertEqual(code, 503) - self.assertEqual(response, b'Duplicate HELO/EHLO') + self.assertEqual(code, 250) def test_ehlo_then_helo(self): with SMTP(*self.address) as client: code, response = client.ehlo('example.com') self.assertEqual(code, 250) code, response = client.helo('example.org') - self.assertEqual(code, 503) - self.assertEqual(response, b'Duplicate HELO/EHLO') + self.assertEqual(code, 250) def test_noop(self): with SMTP(*self.address) as client: @@ -665,6 +670,80 @@ class TestSMTP(unittest.TestCase): b'Error: command "FOOBAR" not recognized') +class TestResetCommands(unittest.TestCase): + """Test that sender and recipients are reset on RSET, HELO, and EHLO. + + The tests below issue each command twice with different addresses and + verify that mail_from and rcpt_tos have been replacecd. + """ + + expected_envelope_data = [{ + 'mail_from': '[email protected]', + 'rcpt_tos': ['[email protected]', + '[email protected]']}, { + 'mail_from': '[email protected]', + 'rcpt_tos': ['[email protected]', + '[email protected]']}] + + def send_envolope_data(self, client, mail_from, rcpt_tos): + client.mail(mail_from) + for rcpt in rcpt_tos: + client.rcpt(rcpt) + + def test_helo(self): + handler = StoreEnvelopeOnVRFYHandler() + controller = DecodingController(handler) + controller.start() + self.addCleanup(controller.stop) + + with SMTP(controller.hostname, controller.port) as client: + for data in self.expected_envelope_data: + client.helo('example.com') + client.vrfy('[email protected]') # Save envelope in handler + self.assertIsNone(handler.envelope.mail_from) + self.assertEqual(len(handler.envelope.rcpt_tos), 0) + self.send_envolope_data(client, **data) + client.vrfy('[email protected]') # Save envelope in handler + self.assertEqual(handler.envelope.mail_from, data['mail_from']) + self.assertEqual(handler.envelope.rcpt_tos, data['rcpt_tos']) + + def test_ehlo(self): + handler = StoreEnvelopeOnVRFYHandler() + controller = DecodingController(handler) + controller.start() + self.addCleanup(controller.stop) + + with SMTP(controller.hostname, controller.port) as client: + for data in self.expected_envelope_data: + client.ehlo('example.com') + client.vrfy('[email protected]') # Save envelope in handler + self.assertIsNone(handler.envelope.mail_from) + self.assertEqual(len(handler.envelope.rcpt_tos), 0) + self.send_envolope_data(client, **data) + client.vrfy('[email protected]') # Save envelope in handler + self.assertEqual(handler.envelope.mail_from, data['mail_from']) + self.assertEqual(handler.envelope.rcpt_tos, data['rcpt_tos']) + + def test_rset(self): + handler = StoreEnvelopeOnVRFYHandler() + controller = DecodingController(handler) + controller.start() + self.addCleanup(controller.stop) + + with SMTP(controller.hostname, controller.port) as client: + client.helo('example.com') + + for data in self.expected_envelope_data: + self.send_envolope_data(client, **data) + client.vrfy('[email protected]') # Save envelope in handler + self.assertEqual(handler.envelope.mail_from, data['mail_from']) + self.assertEqual(handler.envelope.rcpt_tos, data['rcpt_tos']) + client.rset() + client.vrfy('[email protected]') # Save envelope in handler + self.assertIsNone(handler.envelope.mail_from) + self.assertEqual(len(handler.envelope.rcpt_tos), 0) + + class TestSMTPWithController(unittest.TestCase): def test_mail_with_size_too_large(self): controller = SizedController(Sink(), 9999)
Duplicated HELO/EHLO As already mentioned in source code (https://github.com/aio-libs/aiosmtpd/blob/c25b878473b086150d32fcd21c35c58099947e5f/aiosmtpd/smtp.py#L264, also in original smtpd's code) a second HELO/EHLO is rejected but the standart says it should be handled as a RSET command. Is there any special reason to not allow duplicated HELO/EHLO? I think the best way is to do the same other SMTP servers do: Allowing a duplicated HELO/EHLO. Another option is to have a configuration option.
0.0
2ec2b40aab6288baf2153672aae51800d3e73765
[ "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo" ]
[ "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimeters", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_data", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_malformed", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_malformed_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_missing_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_from", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_bad_syntax_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_unrecognized_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_to", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_bad_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_an_address", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2017-06-02 08:59:24+00:00
apache-2.0
952
aio-libs__aiosmtpd-143
diff --git a/.travis.yml b/.travis.yml index 6f1e947..cdecf91 100644 --- a/.travis.yml +++ b/.travis.yml @@ -9,6 +9,11 @@ matrix: env: INTERP=py35 PYTHONASYNCIODEBUG=1 - python: "3.6" env: INTERP=py36 PYTHONASYNCIODEBUG=1 +before_script: + # Disable IPv6. Ref travis-ci/travis-ci#8711 + - echo 0 | sudo tee /proc/sys/net/ipv6/conf/all/disable_ipv6 script: - tox -e $INTERP-nocov,$INTERP-cov,qa,docs - 'if [ "$TRAVIS_PULL_REQUEST" != "false" ]; then tox -e $INTERP-diffcov; fi' +before_script: + - echo 0 | sudo tee /proc/sys/net/ipv6/conf/all/disable_ipv6 diff --git a/aiosmtpd/controller.py b/aiosmtpd/controller.py index c529ff9..1df9c2c 100644 --- a/aiosmtpd/controller.py +++ b/aiosmtpd/controller.py @@ -10,6 +10,11 @@ from public import public class Controller: def __init__(self, handler, loop=None, hostname=None, port=8025, *, ready_timeout=1.0, enable_SMTPUTF8=True, ssl_context=None): + """ + `Documentation can be found here + <http://aiosmtpd.readthedocs.io/en/latest/aiosmtpd\ +/docs/controller.html#controller-api>`_. + """ self.handler = handler self.hostname = '::1' if hostname is None else hostname self.port = port diff --git a/aiosmtpd/docs/controller.rst b/aiosmtpd/docs/controller.rst index ca134b6..ab0a81a 100644 --- a/aiosmtpd/docs/controller.rst +++ b/aiosmtpd/docs/controller.rst @@ -168,7 +168,15 @@ Controller API *loop* is the asyncio event loop to use. If not given, :meth:`asyncio.new_event_loop()` is called to create the event loop. - *hostname* and *port* are passed directly to your loop's + *hostname* is passed to your loop's + :meth:`AbstractEventLoop.create_server` method as the + ``host`` parameter, + except None (default) is translated to '::1'. To bind + dual-stack locally, use 'localhost'. To bind `dual-stack + <https://en.wikipedia.org/wiki/IPv6#Dual-stack_IP_implementation>`_ + on all interfaces, use ''. + + *port* is passed directly to your loop's :meth:`AbstractEventLoop.create_server` method. *ready_timeout* is float number of seconds that the controller will wait in diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index 681732a..24661a6 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -234,10 +234,20 @@ class SMTP(asyncio.StreamReaderProtocol): # re-encoded back to the original bytes when the SMTP command # is handled. if i < 0: - command = line.upper().decode(encoding='ascii') + try: + command = line.upper().decode(encoding='ascii') + except UnicodeDecodeError: + await self.push('500 Error: bad syntax') + continue + arg = None else: - command = line[:i].upper().decode(encoding='ascii') + try: + command = line[:i].upper().decode(encoding='ascii') + except UnicodeDecodeError: + await self.push('500 Error: bad syntax') + continue + arg = line[i+1:].strip() # Remote SMTP servers can send us UTF-8 content despite # whether they've declared to do so or not. Some old diff --git a/examples/server.py b/examples/server.py index 792be44..db8b78b 100644 --- a/examples/server.py +++ b/examples/server.py @@ -6,7 +6,7 @@ from aiosmtpd.handlers import Sink async def amain(loop): - cont = Controller(Sink(), hostname='::0', port=8025) + cont = Controller(Sink(), hostname='', port=8025) cont.start()
aio-libs/aiosmtpd
23b743be942ffd37f9c051c1f6efe0108ffd456d
diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index be1da96..975f252 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -197,6 +197,20 @@ class TestSMTP(unittest.TestCase): self.addCleanup(controller.stop) self.address = (controller.hostname, controller.port) + def test_binary(self): + with SMTP(*self.address) as client: + client.sock.send(b"\x80FAIL\r\n") + code, response = client.getreply() + self.assertEqual(code, 500) + self.assertEqual(response, b'Error: bad syntax') + + def test_binary_space(self): + with SMTP(*self.address) as client: + client.sock.send(b"\x80 FAIL\r\n") + code, response = client.getreply() + self.assertEqual(code, 500) + self.assertEqual(response, b'Error: bad syntax') + def test_helo(self): with SMTP(*self.address) as client: code, response = client.helo('example.com')
Exception when parsing binary data aiosmtpd will try to ASCII decode binary data as SMTP commands, raising a `UnicodeDecodeError`. A simple test case that triggers this is shown at the end of this report. This can be caught by a generic exception handler, however it would be better to do this inside the library. This can be trivially fixed with a `try`/`except` handler. PR incoming. ``` python from base64 import b64decode import socket TCP_IP = '127.0.0.1' TCP_PORT = 8025 BUFFER_SIZE = 1024 RAW = "gUMBAwMBGgAAACAAwDAAwCwAwCgAwCQAwBQAwAoAwCIAwCEAAKMAAJ8AAGsAAGoAADkAADgAAIgAAIcAwBkAwCAAwDIAwC4AwCoAwCYAwA8AwAUAAJ0AAD0AADUAAIQAwBIAwAgAwBwAwBsAABYAABMAwBcAwBoAwA0AwAMAAAoHAMAAwC8AwCsAwCcAwCMAwBMAwAkAwB8AwB4AAKIAAJ4AAGcAAEAAADMAADIAAJoAAJkAAEUAAEQAwBgAwB0AwDEAwC0AwCkAwCUAwA4AwAQAAJwAADwAAC8AAJYAAEEAAAcAwBEAwAcAwBYAwAwAwAIAAAUAAAQFAIADAIABAIAAABUAABIAAAkGAEAAABQAABEAAAgAAAYAAAMEAIACAIAAAP8cXF6WB1DBTAUUZfksmYhwy/mtOvciiLZb+ZNMaF/tYg==" MESSAGE = b64decode(RAW) s = socket.socket(socket.AF_INET, socket.SOCK_STREAM) s.connect((TCP_IP, TCP_PORT)) data = s.recv(BUFFER_SIZE) print("Received: {}".format(data)) s.send(MESSAGE) data = s.recv(BUFFER_SIZE) print("Received: {}".format(data)) s.close() ```
0.0
23b743be942ffd37f9c051c1f6efe0108ffd456d
[ "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary_space" ]
[ "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimeters", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_data", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_malformed", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_malformed_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_missing_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_from", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_bad_syntax_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_unrecognized_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_to", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_bad_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_an_address", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2018-04-04 20:24:59+00:00
apache-2.0
953
aio-libs__aiosmtpd-157
diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index bf31b61..0962d67 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -26,6 +26,15 @@ Fixed/Improved This is the correct, strict interpretation of :rfc:`4954` mentions about ``=`` +1.2.4 (aiosmtpd-next) +===================== + +Added +----- +* New :meth:`handle_EHLO` interaction where said method can now modify list of responses + to the EHLO command (Closes #155) + + 1.2.3 (2021-01-14) ================== diff --git a/aiosmtpd/docs/handlers.rst b/aiosmtpd/docs/handlers.rst index 7f45007..10d2331 100644 --- a/aiosmtpd/docs/handlers.rst +++ b/aiosmtpd/docs/handlers.rst @@ -34,16 +34,19 @@ Handler hooks ============= Handlers can implement hooks that get called during the SMTP dialog, or in -exceptional cases. These *handler hooks* are all called asynchronously +exceptional cases. These *handler hooks* are all called **asynchronously** (i.e. they are coroutines) and they *must* return a status string, such as ``'250 OK'``. All handler hooks are optional and default behaviors are carried out by the ``SMTP`` class when a hook is omitted, so you only need to implement the ones you care about. When a handler hook is defined, it may have additional responsibilities as described below. -All handler hooks take at least three arguments, the ``SMTP`` server instance, -:ref:`a session instance, and an envelope instance <sessions_and_envelopes>`. -Some methods take additional arguments. +All handler hooks will be called with at least three arguments: +(1) the ``SMTP`` server instance, +(2) :ref:`a session instance <sessions_and_envelopes>`, and +(3) :ref:`an envelope instance <sessions_and_envelopes>`. + +Some handler hooks will receive additional arguments. The following hooks are currently defined: @@ -54,14 +57,40 @@ The following hooks are currently defined: also set the ``session.host_name`` attribute before returning ``'250 {}'.format(server.hostname)`` as the status. + .. important:: + + If the handler sets the ``session.host_name`` attribute to a false-y value + (or leave it as the default ``None`` value) + it will signal later steps that ``HELO`` failed + and need to be performed again. + + This also applies to the :meth:`handle_EHLO` hook below. + .. py:method:: handle_EHLO(server, session, envelope, hostname) + handle_EHLO(server, session, envelope, hostname, responses) Called during ``EHLO``. The ``hostname`` argument is the host name given - by the client in the ``EHLO`` command. If implemented, this hook must - also set the ``session.host_name`` attribute. This hook may push - additional ``250-<command>`` responses to the client by yielding from - ``server.push(status)`` before returning ``250 HELP`` as the final - response. + by the client in the ``EHLO`` command. + + There are two implementation forms. + + The first form accepts only 4 (four) arguments. + This hook may push *additional* ``250-<command>`` responses to the client by doing + ``await server.push(status)`` before returning ``"250 HELP"`` as the final response. + + **The 4-argument form will be deprecated in version 2.0** + + The second form accept 5 (five) arguments. + ``responses`` is a list strings representing the 'planned' responses to the ``EHLO`` command, + *including* the last ``250 HELP`` response. + The hook must return a list containing the desired responses. + *This is the only exception to the requirement of returning a status string.* + + .. important:: + + It is strongly recommended to not change element ``[0]`` of the list + (containing the hostname of the SMTP server), + and to end the list with ``"250 HELP"`` .. py:method:: handle_NOOP(server, session, envelope, arg) @@ -89,7 +118,7 @@ The following hooks are currently defined: Called during ``RCPT TO``. The ``address`` argument is the parsed email address given by the client in the ``RCPT TO`` command, and - ``rcpt_options`` are any additional ESMTP recipient options providing by + ``rcpt_options`` are any additional ESMTP recipient options provided by the client. If implemented, this hook should append the address to ``envelope.rcpt_tos`` and may extend ``envelope.rcpt_options`` (both of which are always Python lists). @@ -126,7 +155,7 @@ The following hooks are currently defined: In addition to the SMTP command hooks, the following hooks can also be implemented by handlers. These have different APIs, and are called -synchronously (i.e. they are **not** coroutines). +**synchronously** (i.e. they are **not** coroutines). .. py:method:: handle_STARTTLS(server, session, envelope) @@ -142,7 +171,10 @@ synchronously (i.e. they are **not** coroutines). a status string, such as ``'542 Internal server error'``. If the method returns ``None`` or raises an exception, an exception will be logged, and a ``451`` code will be returned to the client. - **Note:** If client connection losted function will not be called. + + .. important:: + + If client connection is lost, this handler will NOT be called. .. _auth_hooks: diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index ab8a866..3e3f8c7 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -65,7 +65,7 @@ __all__ = [ "AuthMechanismType", "MISSING", ] # Will be added to by @public -__version__ = '1.3.0.a1' +__version__ = '1.3.0a2' __ident__ = 'Python SMTP {}'.format(__version__) log = logging.getLogger('mail.log') @@ -270,6 +270,7 @@ class SMTP(asyncio.StreamReaderProtocol): self._auth_require_tls = auth_require_tls self._auth_callback = auth_callback or login_always_fail self._auth_required = auth_required + # Get hooks & methods to significantly speedup getattr's self._auth_methods: Dict[str, _AuthMechAttr] = { getattr( @@ -294,6 +295,26 @@ class SMTP(asyncio.StreamReaderProtocol): for m in dir(handler) if m.startswith("handle_") } + + # When we've deprecated the 4-arg form of handle_EHLO, + # we can -- and should -- remove this whole code block + ehlo_hook = self._handle_hooks.get("EHLO", None) + if ehlo_hook is None: + self._ehlo_hook_ver = None + else: + ehlo_hook_params = inspect.signature(ehlo_hook).parameters + if len(ehlo_hook_params) == 4: + self._ehlo_hook_ver = "old" + warn("Use the 5-argument handle_EHLO() hook instead of " + "the 4-argument handle_EHLO() hook; " + "support for the 4-argument handle_EHLO() hook will be " + "removed in version 2.0", + DeprecationWarning) + elif len(ehlo_hook_params) == 5: + self._ehlo_hook_ver = "new" + else: + raise RuntimeError("Unsupported EHLO Hook") + self._smtp_methods: Dict[str, Any] = { m.replace("smtp_", ""): getattr(self, m) for m in dir(self) @@ -636,32 +657,50 @@ class SMTP(asyncio.StreamReaderProtocol): if not hostname: await self.push('501 Syntax: EHLO hostname') return + + response = [] self._set_rset_state() self.session.extended_smtp = True - await self.push('250-%s' % self.hostname) + response.append('250-%s' % self.hostname) if self.data_size_limit: - await self.push('250-SIZE %s' % self.data_size_limit) + response.append('250-SIZE %s' % self.data_size_limit) self.command_size_limits['MAIL'] += 26 if not self._decode_data: - await self.push('250-8BITMIME') + response.append('250-8BITMIME') if self.enable_SMTPUTF8: - await self.push('250-SMTPUTF8') + response.append('250-SMTPUTF8') self.command_size_limits['MAIL'] += 10 if self.tls_context and not self._tls_protocol: - await self.push('250-STARTTLS') + response.append('250-STARTTLS') + if not self._auth_require_tls or self._tls_protocol: + response.append( + "250-AUTH " + " ".join(sorted(self._auth_methods.keys())) + ) + if hasattr(self, 'ehlo_hook'): warn('Use handler.handle_EHLO() instead of .ehlo_hook()', DeprecationWarning) await self.ehlo_hook() - if not self._auth_require_tls or self._tls_protocol: - await self.push( - "250-AUTH " + " ".join(sorted(self._auth_methods.keys())) - ) - status = await self._call_handler_hook('EHLO', hostname) - if status is MISSING: + + if self._ehlo_hook_ver is None: self.session.host_name = hostname - status = '250 HELP' - await self.push(status) + response.append('250 HELP') + elif self._ehlo_hook_ver == "old": + # Old behavior: Send all responses first... + for r in response: + await self.push(r) + # ... then send the response from the hook. + response = [await self._call_handler_hook("EHLO", hostname)] + # (The hook might internally send its own responses.) + elif self._ehlo_hook_ver == "new": # pragma: nobranch + # New behavior: hand over list of responses so far to the hook, and + # REPLACE existing list of responses with what the hook returns. + # We will handle the push()ing + response.append('250 HELP') + response = await self._call_handler_hook("EHLO", hostname, response) + + for r in response: + await self.push(r) @syntax('NOOP [ignored]') async def smtp_NOOP(self, arg): diff --git a/conf.py b/conf.py index 3968c70..b4a888c 100644 --- a/conf.py +++ b/conf.py @@ -13,23 +13,41 @@ # serve to show the default. import sys -import os import re import datetime from pathlib import Path -RE__VERSION = re.compile(r"""__version__ = (['"])(?P<ver>[^'"]+)(\1)""") +try: + # noinspection PyPackageRequirements + from colorama import ( + Fore, + Style, + init as colorama_init, + ) + colorama_init() +except ImportError: + class Fore: + CYAN = "\x1b[1;96m" + GREEN = "\x1b[1;92m" + YELLOW = "\x1b[1;93m" + + class Style: + BRIGHT = "\x1b[1m" + RESET_ALL = "\x1b[0m" -YELLOW = "\x1b[1;93m" -NORM = "\x1b[0m" + colorama_init = None + + +RE__VERSION = re.compile(r"""__version__ = (['"])(?P<ver>[^'"]+)(\1)""") # If extensions (or modules to document with autodoc) are in another directory, # add these directories to sys.path here. If the directory is relative to the # documentation root, use os.path.abspath to make it absolute, like shown here. -sys.path.insert(0, os.path.abspath('.')) -sys.path.append(str(Path("aiosmtpd/docs/_exts").expanduser().absolute())) +_curdir = Path(".").expanduser().absolute() +sys.path.insert(0, str(_curdir)) +sys.path.append(str(_curdir / "aiosmtpd" / "docs" / "_exts")) # -- General configuration ------------------------------------------------ @@ -300,17 +318,16 @@ def setup(app): def index_html(): import errno - cwd = os.getcwd() + cwd = Path(".").expanduser().absolute() + htmldir = cwd / "build" / "sphinx" / "html" try: try: - os.makedirs('build/sphinx/html') - except OSError as error: - if error.errno != errno.EEXIST: - raise - os.chdir('build/sphinx/html') + htmldir.mkdir() + except FileExistsError: + pass try: - os.symlink('README.html', 'index.html') - print('index.html -> README.html') + (htmldir / "index.html").symlink_to("README.html") + print(f'{Fore.CYAN}index.html -> README.html') except OSError as error: # On Windows>= 7, only users with 'SeCreateSymbolicLinkPrivilege' token # can create symlinks. @@ -318,14 +335,14 @@ def index_html(): or str(error) == "symbolic link privilege not held"): # I don't like matching against string, but sometimes this particular # OSError does not have any errno nor winerror. - print(f"{YELLOW}WARNING: No privilege to create symlinks. " - f"You have to make one manually{NORM}") + print(f"{Fore.YELLOW}WARNING: No privilege to create symlinks. " + f"You have to make one manually") elif error.errno == errno.EEXIST: pass else: raise finally: - os.chdir(cwd) + print(Style.RESET_ALL) import atexit diff --git a/tox.ini b/tox.ini index 8e46bd9..e481a11 100644 --- a/tox.ini +++ b/tox.ini @@ -1,4 +1,5 @@ [tox] +minversion = 3.9.0 envlist = qa, docs, py{36,37,38,39}-{nocov,cov,diffcov} skip_missing_interpreters = True @@ -25,7 +26,7 @@ deps = colorama coverage[toml] packaging - pytest + pytest >= 6.0 # Require >= 6.0 for pyproject.toml support (PEP 517) pytest-cov pytest-mock pytest-profiling @@ -45,7 +46,7 @@ setenv = !py36: PY_36=gt py39: PY_39=ge !py39: PY_39=lt - PLATFORM={env:PLATFORM:linux} + PLATFORM={env:PLATFORM:posix} passenv = PYTHON* TRAVIS @@ -78,8 +79,10 @@ commands = deps: {[qadocs]deps} +# I'd love to fold flake8 into pyproject.toml, because the flake8 settings +# should be "project-wide" settings (enforced not only during tox). +# But the flake8 maintainers seem to harbor a severe dislike of pyproject.toml. [flake8] -exclude = conf.py jobs = 1 max-line-length = 88 ignore = E123, E133, W503, W504
aio-libs/aiosmtpd
46540ff70e4c83a7ee977f638748ff700bb59e3b
diff --git a/.github/workflows/unit-testing-and-coverage.yml b/.github/workflows/unit-testing-and-coverage.yml index d3de80b..252af1e 100644 --- a/.github/workflows/unit-testing-and-coverage.yml +++ b/.github/workflows/unit-testing-and-coverage.yml @@ -4,9 +4,15 @@ on: # This is for direct commit to master push: branches: [ "master" ] + paths: + - "aiosmtpd/*" + - "setup.cfg" # To monitor changes in dependencies # This is for PRs pull_request: branches: [ "master" ] + paths: + - "aiosmtpd/*" + - "setup.cfg" # To monitor changes in dependencies # Manual/on-demand workflow_dispatch: # When doing "releases" @@ -14,20 +20,37 @@ on: types: [ "created", "edited", "published", "prereleased", "released" ] jobs: - test: + qa_docs: + runs-on: ubuntu-20.04 + steps: + - name: "Checkout latest commit" + uses: actions/checkout@v2 + - name: "Set up Python 3.8" + uses: actions/setup-python@v2 + with: + python-version: 3.8 + - name: "Install dependencies" + run: | + python -m pip install --upgrade pip + pip install tox + - name: "Execute tox -e qa,docs" + run: | + tox -e qa,docs + testing: + needs: qa_docs strategy: # If a matrix fail, do NOT stop other matrix, let them run to completion fail-fast: false matrix: - os: [ "ubuntu-latest" ] - platform: [ "linux" ] + os: [ "ubuntu-18.04", "ubuntu-20.04", "macos-10.15" ] + platform: [ "posix" ] python-version: [ "3.6", "3.7", "3.8", "3.9", "pypy3" ] include: - os: "windows-latest" platform: "mswin" - # Only the latest stable branch as indicated on + # Only the latest frozen branch as indicated on # https://devguide.python.org/#branchstatus - # ('stable' means Status == "security") + # ('frozen' means Status == "security") # Reason being that Windows users can change their Python anytime, # so there is no benefit in testing all released Python versions. # Plus pypy3 implementation in Windows is ... complicated. We @@ -53,7 +76,7 @@ jobs: # "py" testenv means we'll use whatever Python provided by GA, # as specified in 'matrix' above. No need to specify exact version. run: | - tox -e "qa,docs,py-cov" + tox -e py-cov - name: "Report to codecov" # Ubuntu 18.04 came out of the box with 3.6, and LOTS of system are still running # 18.04 happily, so we choose this as the 'canonical' code coverage testing. diff --git a/aiosmtpd/tests/test_handlers.py b/aiosmtpd/tests/test_handlers.py index 3463d35..f20028d 100644 --- a/aiosmtpd/tests/test_handlers.py +++ b/aiosmtpd/tests/test_handlers.py @@ -14,7 +14,7 @@ from mailbox import Maildir from operator import itemgetter from smtplib import SMTP, SMTPDataError, SMTPRecipientsRefused from tempfile import TemporaryDirectory -from unittest.mock import call, patch +from unittest.mock import call, patch, Mock CRLF = '\r\n' @@ -534,11 +534,40 @@ class HELOHandler: return '250 geddy.example.com' -class EHLOHandler: +class EHLOHandlerDeprecated: + hostname = None + async def handle_EHLO(self, server, session, envelope, hostname): + self.hostname = hostname return '250 alex.example.com' +class EHLOHandlerNew: + hostname = None + orig_responses = [] + + def __init__(self, *features): + self.features = features + + async def handle_EHLO(self, server, session, envelope, hostname, responses): + self.hostname = hostname + self.orig_responses.extend(responses) + my_resp = [responses[0]] + my_resp.extend(f"250-{f}" for f in self.features) + my_resp.append("250 HELP") + return my_resp + + +class EHLOHandlerIncompatibleShort: + async def handle_EHLO(self, server, session, envelope): + return + + +class EHLOHandlerIncompatibleLong: + async def handle_EHLO(self, server, session, envelope, hostname, responses, xtra): + return + + class MAILHandler: async def handle_MAIL(self, server, session, envelope, address, options): envelope.mail_options.extend(options) @@ -595,16 +624,56 @@ Subject: Test self.assertEqual(code, 250) self.assertEqual(response, b'geddy.example.com') - def test_ehlo_hook(self): - controller = Controller(EHLOHandler()) + def test_ehlo_hook_oldsystem(self): + declare_myself = "me" + handler = EHLOHandlerDeprecated() + controller = Controller(handler) controller.start() self.addCleanup(controller.stop) with SMTP(controller.hostname, controller.port) as client: - code, response = client.ehlo('me') + code, response = client.ehlo(declare_myself) self.assertEqual(code, 250) + self.assertEqual(declare_myself, handler.hostname) lines = response.decode('utf-8').splitlines() self.assertEqual(lines[-1], 'alex.example.com') + def test_ehlo_hook_newsystem(self): + declare_myself = "me" + handler = EHLOHandlerNew("FEATURE1", "FEATURE2 OPTION", "FEAT3 OPTA OPTB") + controller = Controller(handler) + controller.start() + self.addCleanup(controller.stop) + with SMTP(controller.hostname, controller.port) as client: + code, response = client.ehlo(declare_myself) + self.assertEqual(code, 250) + self.assertEqual(declare_myself, handler.hostname) + + self.assertIn("250-8BITMIME", handler.orig_responses) + self.assertIn("250-SMTPUTF8", handler.orig_responses) + self.assertNotIn("8bitmime", client.esmtp_features) + self.assertNotIn("smtputf8", client.esmtp_features) + + self.assertIn("feature1", client.esmtp_features) + self.assertIn("feature2", client.esmtp_features) + self.assertEqual("OPTION", client.esmtp_features["feature2"]) + self.assertIn("feat3", client.esmtp_features) + self.assertEqual("OPTA OPTB", client.esmtp_features["feat3"]) + self.assertIn("help", client.esmtp_features) + + def test_ehlo_hook_incompat_short(self): + handler = EHLOHandlerIncompatibleShort() + controller = Controller(handler) + self.addCleanup(controller.stop) + with self.assertRaises(RuntimeError): + controller.start() + + def test_ehlo_hook_incompat_long(self): + handler = EHLOHandlerIncompatibleLong() + controller = Controller(handler) + self.addCleanup(controller.stop) + with self.assertRaises(RuntimeError): + controller.start() + def test_mail_hook(self): controller = Controller(MAILHandler()) controller.start() @@ -782,3 +851,15 @@ Testing controller.smtpd.warnings[0], call('Use handler.handle_RSET() instead of .rset_hook()', DeprecationWarning)) + + @patch("aiosmtpd.smtp.warn") + def test_handle_ehlo_4arg_deprecation(self, mock_warn: Mock): + handler = EHLOHandlerDeprecated() + _ = Server(handler) + mock_warn.assert_called_with( + "Use the 5-argument handle_EHLO() hook instead of " + "the 4-argument handle_EHLO() hook; " + "support for the 4-argument handle_EHLO() hook will be " + "removed in version 2.0", + DeprecationWarning + ) diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index d682dc1..966c5fa 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -435,16 +435,17 @@ class TestSMTP(unittest.TestCase): with SMTP(*self.address) as client: code, response = client.ehlo('example.com') self.assertEqual(code, 250) - lines = response.splitlines() - expecteds = ( + actuals = response.splitlines() + expecteds = [ bytes(socket.getfqdn(), 'utf-8'), b'SIZE 33554432', b'SMTPUTF8', b'AUTH LOGIN PLAIN', b'HELP', - ) - for actual, expected in zip(lines, expecteds): - self.assertEqual(actual, expected) + ] + # for actual, expected in zip(lines, expecteds): + # self.assertEqual(actual, expected) + self.assertEqual(expecteds, actuals) def test_ehlo_duplicate(self): with SMTP(*self.address) as client:
EHLO command returns all bunch of 250- data, even when the hooks returns otherwise [In the current state of the code](https://github.com/aio-libs/aiosmtpd/blob/master/aiosmtpd/smtp.py#L351), some data are pushed BEFORE calling the hook, including ``` 250-{hostname} 250-SIZE ... 250-8BITMIME 250-SMTPUTF8 250-STARTTLS ``` And AFTER that, the hook is called. The issue is that if the hook doesn't return a 2xx response, the server sends a mixed response and makes the clients fails. The `EHLO` command should call the hook, and depending on the response, send all the push commands afterward.
0.0
46540ff70e4c83a7ee977f638748ff700bb59e3b
[ "aiosmtpd/tests/test_handlers.py::TestHooks::test_ehlo_hook_incompat_long", "aiosmtpd/tests/test_handlers.py::TestHooks::test_ehlo_hook_incompat_short", "aiosmtpd/tests/test_handlers.py::TestHooks::test_ehlo_hook_newsystem", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_handle_ehlo_4arg_deprecation" ]
[ "aiosmtpd/tests/test_handlers.py::TestDebugging::test_debugging", "aiosmtpd/tests/test_handlers.py::TestDebuggingBytes::test_debugging", "aiosmtpd/tests/test_handlers.py::TestDebuggingOptions::test_debugging_with_options", "aiosmtpd/tests/test_handlers.py::TestDebuggingOptions::test_debugging_without_options", "aiosmtpd/tests/test_handlers.py::TestMessage::test_message", "aiosmtpd/tests/test_handlers.py::TestMessage::test_message_decoded", "aiosmtpd/tests/test_handlers.py::TestAsyncMessage::test_message", "aiosmtpd/tests/test_handlers.py::TestAsyncMessage::test_message_decoded", "aiosmtpd/tests/test_handlers.py::TestMailbox::test_mailbox", "aiosmtpd/tests/test_handlers.py::TestMailbox::test_mailbox_reset", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_cli_bad_argument", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_cli_no_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_cli_stderr", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_cli_stdout", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_cli_two_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_mailbox_cli", "aiosmtpd/tests/test_handlers.py::TestCLI::test_mailbox_cli_no_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_mailbox_cli_too_many_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_sink_cli_any_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_sink_cli_no_args", "aiosmtpd/tests/test_handlers.py::TestProxy::test_deliver_bytes", "aiosmtpd/tests/test_handlers.py::TestProxy::test_deliver_str", "aiosmtpd/tests/test_handlers.py::TestProxyMocked::test_oserror", "aiosmtpd/tests/test_handlers.py::TestProxyMocked::test_recipients_refused", "aiosmtpd/tests/test_handlers.py::TestHooks::test_auth_hook", "aiosmtpd/tests/test_handlers.py::TestHooks::test_data_hook", "aiosmtpd/tests/test_handlers.py::TestHooks::test_ehlo_hook_oldsystem", "aiosmtpd/tests/test_handlers.py::TestHooks::test_helo_hook", "aiosmtpd/tests/test_handlers.py::TestHooks::test_mail_hook", "aiosmtpd/tests/test_handlers.py::TestHooks::test_no_hooks", "aiosmtpd/tests/test_handlers.py::TestHooks::test_rcpt_hook", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_deprecation", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_deprecation_async", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_ehlo_hook_deprecation", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_rset_hook_deprecation", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimeters", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_already_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_length", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_login_multisteps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_no_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_enough_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_supported_methods", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_plain_null", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_too_many_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_abort", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_authplain_goodcreds_sanitized_log", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary_space", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_bpo27931fix_smtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_auth", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_data", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_empty", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_invalid", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_malformed", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_malformed_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_missing_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_from", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_bad_syntax_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_unrecognized_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_address_invalid", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_address_valid", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_to", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_bad_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_an_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_way_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_custom_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_disabled_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_individually", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_login", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_password", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_loginteract_warning", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_plain_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_rset_maintain_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_data_line_too_long", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_multiple_connections_lost", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_double_count", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_leak", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_then_too_long_lines", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_line_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_lines_then_too_long_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_in_long_command", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo", "aiosmtpd/tests/test_smtp.py::TestTimeout::test_timeout", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_log_authmechanisms", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls", "aiosmtpd/tests/test_smtp.py::TestLimits::test_all_limit_15", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits_custom_default", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_bogus", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_value_type" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2018-12-10 13:13:46+00:00
apache-2.0
954
aio-libs__aiosmtpd-207
diff --git a/MANIFEST.in b/MANIFEST.in index 41d11f0..5a8020d 100644 --- a/MANIFEST.in +++ b/MANIFEST.in @@ -1,3 +1,3 @@ graft aiosmtpd -include .coveragerc LICENSE *.cfg *.ini *.py *.rst *.yml +include LICENSE *.cfg *.ini *.py *.rst *.yml global-exclude *.py[oc] diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 05628e0..4b0cab1 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -2,6 +2,7 @@ NEWS for aiosmtpd =================== + 1.2.3 (aiosmtpd-next) ===================== @@ -15,12 +16,14 @@ Fixed/Improved * Implement & enforce line-length-limit, thus becoming Compliant with RFC 5321 § 4.5.3.1.6 * Delay all SMTP Status Code replies during ``DATA`` phase until the phase termination (Closes #9) * Now catches ``Controller.factory()`` failure during ``Controller.start()`` (Closes #212) -* :class:`SMTP` no longer edits user-supplied SSL Context (closes #191) -* Implement waiting for SSL setup/handshake within STARTTLS handler to be able to catch and handle +* :class:`SMTP` no longer edits user-supplied SSL Context (Closes #191) +* Implement waiting for SSL setup/handshake within ``STARTTLS`` handler to be able to catch and handle (log) errors and to avoid session hanging around until timeout in such cases * Add session peer information to some logging output where it was missing * Support AUTH mechanisms with dash(es) in their names (Closes #224) * Remove some double-logging of commands sent by clients +* LMTP servers now correctly advertise extensions in reply to ``LHLO`` (Closes #123, #124) +* ``NOOP`` now accepted before ``STARTTLS`` even if ``require_starttls=True`` (Closes #124) 1.2.2 (2020-11-08) diff --git a/aiosmtpd/lmtp.py b/aiosmtpd/lmtp.py index 8d763fd..5a7ba40 100644 --- a/aiosmtpd/lmtp.py +++ b/aiosmtpd/lmtp.py @@ -9,7 +9,7 @@ class LMTP(SMTP): @syntax('LHLO hostname') async def smtp_LHLO(self, arg): """The LMTP greeting, used instead of HELO/EHLO.""" - await super().smtp_HELO(arg) + await super().smtp_EHLO(arg) async def smtp_HELO(self, arg): """HELO is not a valid LMTP command.""" diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index 1564d9b..5447640 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -59,7 +59,7 @@ __all__ = [ "AuthMechanismType", "MISSING", ] # Will be added to by @public -__version__ = '1.2.3a4' +__version__ = '1.2.3a5' __ident__ = 'Python SMTP {}'.format(__version__) log = logging.getLogger('mail.log') @@ -71,6 +71,9 @@ MISSING = _Missing() NEWLINE = '\n' VALID_AUTHMECH = re.compile(r"[A-Z0-9_-]+\Z") +# https://tools.ietf.org/html/rfc3207.html#page-3 +ALLOWED_BEFORE_STARTTLS = {"NOOP", "EHLO", "STARTTLS", "QUIT"} + # endregion @@ -447,7 +450,7 @@ class SMTP(asyncio.StreamReaderProtocol): continue if (self.require_starttls and not self._tls_protocol - and command not in ['EHLO', 'STARTTLS', 'QUIT']): + and command not in ALLOWED_BEFORE_STARTTLS): # RFC3207 part 4 await self.push('530 Must issue a STARTTLS command first') continue diff --git a/.coveragerc b/coverage.cfg similarity index 100% rename from .coveragerc rename to coverage.cfg diff --git a/housekeep.py b/housekeep.py index f1e6acf..cf35a3f 100644 --- a/housekeep.py +++ b/housekeep.py @@ -31,6 +31,8 @@ except ImportError: TOX_ENV_NAME = os.environ.get("TOX_ENV_NAME", None) WORKDIRS = ( + ".mypy_cache", + ".pytype", ".pytest-cache", ".pytest_cache", ".tox", @@ -41,6 +43,14 @@ WORKDIRS = ( "prof", ) +WORKFILES = ( + ".coverage", + "coverage.xml", + "diffcov.html", + "coverage-*.xml", + "diffcov-*.html", +) + # region #### Helper funcs ############################################################ @@ -79,11 +89,13 @@ def dump_env(): def move_prof(): """Move profiling files to per-testenv dirs""" profpath = Path("prof") + # fmt: off prof_files = [ - f - for p in ("*.prof", "*.svg") - for f in profpath.glob(p) + filepath + for fileglob in ("*.prof", "*.svg") + for filepath in profpath.glob(fileglob) ] + # fmt: on if not prof_files: return targpath = profpath / TOX_ENV_NAME @@ -119,17 +131,10 @@ def rm_work(): deldir(Path(dd)) print(" ", end="", flush=True) print(f"\n{Style.BRIGHT}Removing work files ...", end="") - for fn in (".coverage", "coverage.xml", "diffcov.html"): - print(".", end="", flush=True) - fp = Path(fn) - if fp.exists(): - fp.unlink() - for fp in Path(".").glob("coverage-*.xml"): - print(".", end="", flush=True) - fp.unlink() - for fp in Path(".").glob("diffcov-*.html"): - print(".", end="", flush=True) - fp.unlink() + for fnglob in WORKFILES: + for fp in Path(".").glob(fnglob): + print(".", end="", flush=True) + fp.exists() and fp.unlink() print() @@ -197,10 +202,11 @@ def get_opts(argv): parser.add_argument( "--force", "-F", action="store_true", help="Force action even if in CI" ) + + # From: https://stackoverflow.com/a/49999185/149900 parser.add_argument( "cmd", metavar="COMMAND", choices=sorted(dispers.keys()), help="(See below)" ) - cgrp = parser.add_argument_group(title="COMMAND is one of") for name, doc in sorted(dispers.items()): cgrp.add_argument(name, help=doc, action="no_action") diff --git a/tox.ini b/tox.ini index 4bee309..bb8fe53 100644 --- a/tox.ini +++ b/tox.ini @@ -30,7 +30,8 @@ deps = coverage diff_cover setenv = - cov: COVERAGE_PROCESS_START=.coveragerc + cov: COVERAGE_RCFILE=coverage.cfg + cov: COVERAGE_PROCESS_START=coverage.cfg cov: COVERAGE_OPTIONS="-p" cov: COVERAGE_FILE={toxinidir}/.coverage py36: INTERP=py36
aio-libs/aiosmtpd
17541ae0faf06053c1687427d2d95bbcf9e858e8
diff --git a/aiosmtpd/tests/test_lmtp.py b/aiosmtpd/tests/test_lmtp.py index 66fe8f3..f7cfac8 100644 --- a/aiosmtpd/tests/test_lmtp.py +++ b/aiosmtpd/tests/test_lmtp.py @@ -40,7 +40,15 @@ class TestLMTP(unittest.TestCase): with SMTP(*self.address) as client: code, response = client.docmd('LHLO', 'example.com') self.assertEqual(code, 250) - self.assertEqual(response, bytes(socket.getfqdn(), 'utf-8')) + lines = response.splitlines() + expecteds = ( + bytes(socket.getfqdn(), 'utf-8'), + b'SIZE 33554432', + b'8BITMIME', + b'HELP', + ) + for actual, expected in zip(lines, expecteds): + self.assertEqual(actual, expected) def test_helo(self): # HELO and EHLO are not valid LMTP commands. diff --git a/aiosmtpd/tests/test_starttls.py b/aiosmtpd/tests/test_starttls.py index d658b9a..e38e887 100644 --- a/aiosmtpd/tests/test_starttls.py +++ b/aiosmtpd/tests/test_starttls.py @@ -292,6 +292,18 @@ class TestRequireTLS(unittest.TestCase): code, response = client.docmd('DATA') self.assertEqual(code, 530) + def test_noop_okay(self): + with SMTP(*self.address) as client: + client.ehlo('example.com') + code, response = client.docmd('NOOP') + self.assertEqual(code, 250) + + def test_quit_okay(self): + with SMTP(*self.address) as client: + client.ehlo('example.com') + code, response = client.docmd('QUIT') + self.assertEqual(code, 221) + class TestRequireTLSAUTH(unittest.TestCase): def setUp(self):
LMTP server fails to list any extended services The LHLO service awaits smtp_HELO instead of smtp_EHLO, preventing the greeting from displaying the service menu. This is a violation of the LMTP spec, RFC 2033. Patch attached. This affects https://gitlab.com/mailman/mailman/issues/365 [lmtp_lhlo.zip](https://github.com/aio-libs/aiosmtpd/files/1132381/lmtp_lhlo.zip)
0.0
17541ae0faf06053c1687427d2d95bbcf9e858e8
[ "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_noop_okay" ]
[ "aiosmtpd/tests/test_lmtp.py::TestLMTP::test_ehlo", "aiosmtpd/tests/test_lmtp.py::TestLMTP::test_helo", "aiosmtpd/tests/test_lmtp.py::TestLMTP::test_help", "aiosmtpd/tests/test_lmtp.py::TestLMTP::test_lhlo", "aiosmtpd/tests/test_starttls.py::TestTLSEnding::test_eof_received", "aiosmtpd/tests/test_starttls.py::TestStartTLS::test_disabled_tls", "aiosmtpd/tests/test_starttls.py::TestStartTLS::test_failed_handshake", "aiosmtpd/tests/test_starttls.py::TestStartTLS::test_help_after_starttls", "aiosmtpd/tests/test_starttls.py::TestStartTLS::test_starttls", "aiosmtpd/tests/test_starttls.py::TestStartTLS::test_tls_bad_syntax", "aiosmtpd/tests/test_starttls.py::TestStartTLS::test_tls_handshake_failing", "aiosmtpd/tests/test_starttls.py::TestStartTLS::test_tls_handshake_stopcontroller", "aiosmtpd/tests/test_starttls.py::TestTLSForgetsSessionData::test_forget_ehlo", "aiosmtpd/tests/test_starttls.py::TestTLSForgetsSessionData::test_forget_mail", "aiosmtpd/tests/test_starttls.py::TestTLSForgetsSessionData::test_forget_rcpt", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_data_fails", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_ehlo", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_hello_fails", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_help_fails", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_mail_fails", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_quit_okay", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_rcpt_fails", "aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_vrfy_fails", "aiosmtpd/tests/test_starttls.py::TestRequireTLSAUTH::test_auth_notls", "aiosmtpd/tests/test_starttls.py::TestRequireTLSAUTH::test_auth_tls", "aiosmtpd/tests/test_starttls.py::TestTLSContext::test_certreq_warn", "aiosmtpd/tests/test_starttls.py::TestTLSContext::test_nocertreq_chkhost_warn", "aiosmtpd/tests/test_starttls.py::TestTLSContext::test_verify_mode_nochange" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2020-11-16 13:27:23+00:00
apache-2.0
955
aio-libs__aiosmtpd-222
diff --git a/README.rst b/README.rst index da032ab..a5514fc 100644 --- a/README.rst +++ b/README.rst @@ -184,6 +184,24 @@ versions on your system by using ``pyenv``. General steps: documentation about this option) +``housekeep.py`` +------------------- + +If you ever need to 'reset' your repo, you can use the ``housekeep.py`` utility +like so:: + + $ python housekeep.py superclean + +It is `strongly` recommended to NOT do superclean too often, though. +Every time you invoke ``superclean``, +tox will have to recreate all its testenvs, +and this will make testing `much` longer to finish. + +``superclean`` is typically only needed when you switch branches, +or if you want to really ensure that artifacts from previous testing sessions +won't interfere with your next testing sessions. + + Contents ======== diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 4b0cab1..49abd45 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -9,6 +9,7 @@ Added ----- * Test for ``SMTP.__init__`` behavior after taking out code that edits TLS Context +* Implement mechanism to limit the number of commands sent (Closes #145) Fixed/Improved -------------- diff --git a/aiosmtpd/docs/smtp.rst b/aiosmtpd/docs/smtp.rst index 84694c5..2d3a3eb 100644 --- a/aiosmtpd/docs/smtp.rst +++ b/aiosmtpd/docs/smtp.rst @@ -107,7 +107,9 @@ SMTP API decode_data=False, hostname=None, ident=None, tls_context=None, \ require_starttls=False, timeout=300, auth_required=False, \ auth_require_tls=True, auth_exclude_mechanism=None, auth_callback=None, \ - loop=None) + command_call_limit=None, loop=None) + + **Parameters** :boldital:`handler` is an instance of a :ref:`handler <handlers>` class. @@ -158,9 +160,51 @@ SMTP API must return a ``bool`` that indicates whether the client's authentication attempt is accepted/successful or not. + :boldital:`command_call_limit` if not ``None`` sets the maximum time a certain SMTP + command can be invoked. + This is to prevent DoS due to malicious client connecting and never disconnecting, + due to continual sending of SMTP commands to prevent timeout. + + The handling differs based on the type: + + .. highlights:: + + If :attr:`command_call_limit` is of type ``int``, + then the value is the call limit for ALL SMTP commands. + + If :attr:`command_call_limit` is of type ``dict``, + it must be a ``Dict[str, int]`` + (the type of the values will be enforced). + The keys will be the SMTP Command to set the limit for, + the values will be the call limit per SMTP Command. + + .. highlights:: + + A special key of ``"*"`` is used to set the 'default' call limit for commands not + explicitly declared in :attr:`command_call_limit`. + If ``"*"`` is not given, + then the 'default' call limit will be set to ``aiosmtpd.smtp.CALL_LIMIT_DEFAULT`` + + Other types -- or a ``Dict`` whose any value is not an ``int`` -- will raise a + ``TypeError`` exception. + + Examples:: + + # All commands have a limit of 10 calls + SMTP(..., command_call_limit=10) + + # Commands RCPT and NOOP have their own limits; others have an implicit limit + # of 20 (CALL_LIMIT_DEFAULT) + SMTP(..., command_call_limit={"RCPT": 30, "NOOP": 5}) + + # Commands RCPT and NOOP have their own limits; others set to 3 + SMTP(..., command_call_limit={"RCPT": 20, "NOOP": 10, "*": 3}) + :boldital:`loop` is the asyncio event loop to use. If not given, :meth:`asyncio.new_event_loop()` is called to create the event loop. + **Attributes** + .. py:attribute:: line_length_limit The maximum line length, in octets (not characters; one UTF-8 character diff --git a/aiosmtpd/lmtp.py b/aiosmtpd/lmtp.py index 5a7ba40..a9ba9d7 100644 --- a/aiosmtpd/lmtp.py +++ b/aiosmtpd/lmtp.py @@ -4,7 +4,7 @@ from public import public @public class LMTP(SMTP): - show_smtp_greeting = False + show_smtp_greeting: bool = False @syntax('LHLO hostname') async def smtp_LHLO(self, arg): diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index 5447640..0381184 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -59,11 +59,13 @@ __all__ = [ "AuthMechanismType", "MISSING", ] # Will be added to by @public -__version__ = '1.2.3a5' +__version__ = '1.2.3a6' __ident__ = 'Python SMTP {}'.format(__version__) log = logging.getLogger('mail.log') +BOGUS_LIMIT = 5 +CALL_LIMIT_DEFAULT = 20 DATA_SIZE_DEFAULT = 2**25 # Where does this number come from, I wonder... EMPTY_BARR = bytearray() EMPTYBYTES = b'' @@ -151,6 +153,11 @@ def login_always_fail(mechanism, login, password): return False +def is_int(o): + return isinstance(o, int) + + +@public class TLSSetupException(Exception): pass @@ -181,6 +188,7 @@ class SMTP(asyncio.StreamReaderProtocol): auth_require_tls=True, auth_exclude_mechanism: Optional[Iterable[str]] = None, auth_callback: AuthCallbackType = None, + command_call_limit: Union[int, Dict[str, int], None] = None, loop=None, ): self.__ident__ = ident or __ident__ @@ -256,6 +264,23 @@ class SMTP(asyncio.StreamReaderProtocol): if m.startswith("smtp_") } + if command_call_limit is None: + self._enforce_call_limit = False + else: + self._enforce_call_limit = True + if isinstance(command_call_limit, int): + self._call_limit_base = {} + self._call_limit_default: int = command_call_limit + elif isinstance(command_call_limit, dict): + if not all(map(is_int, command_call_limit.values())): + raise TypeError("All command_call_limit values must be int") + self._call_limit_base = command_call_limit + self._call_limit_default: int = command_call_limit.get( + "*", CALL_LIMIT_DEFAULT + ) + else: + raise TypeError("command_call_limit must be int or Dict[str, int]") + def _create_session(self): return Session(self.loop) @@ -378,6 +403,15 @@ class SMTP(asyncio.StreamReaderProtocol): async def _handle_client(self): log.info('%r handling connection', self.session.peer) await self.push('220 {} {}'.format(self.hostname, self.__ident__)) + if self._enforce_call_limit: + call_limit = collections.defaultdict( + lambda x=self._call_limit_default: x, + self._call_limit_base + ) + else: + # Not used, but this silences code inspection tools + call_limit = {} + bogus_budget = BOGUS_LIMIT while self.transport is not None: # pragma: nobranch try: try: @@ -454,8 +488,31 @@ class SMTP(asyncio.StreamReaderProtocol): # RFC3207 part 4 await self.push('530 Must issue a STARTTLS command first') continue + + if self._enforce_call_limit: + budget = call_limit[command] + if budget < 1: + log.warning( + "%r over limit for %s", self.session.peer, command + ) + await self.push( + f"421 4.7.0 {command} sent too many times" + ) + self.transport.close() + continue + call_limit[command] = budget - 1 + method = self._smtp_methods.get(command) if method is None: + log.warning("%r unrecognised: %s", self.session.peer, command) + bogus_budget -= 1 + if bogus_budget < 1: + log.warning("%r too many bogus commands", self.session.peer) + await self.push( + "502 5.5.1 Too many unrecognized commands, goodbye." + ) + self.transport.close() + continue await self.push( '500 Error: command "%s" not recognized' % command) continue
aio-libs/aiosmtpd
20bd3376bf702491997e6697941946622f9c2874
diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index 04f541a..6c18c58 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -9,7 +9,11 @@ import warnings from aiosmtpd.controller import Controller from aiosmtpd.handlers import Sink from aiosmtpd.smtp import ( - MISSING, Session as SMTPSess, SMTP as Server, __ident__ as GREETING, auth_mechanism + CALL_LIMIT_DEFAULT, + MISSING, + Session as SMTPSess, + SMTP as Server, + __ident__ as GREETING, auth_mechanism ) from aiosmtpd.testing.helpers import ( ReceivingHandler, @@ -803,7 +807,8 @@ class TestSMTP(unittest.TestCase): self.assertEqual(code, 250) self.assertEqual(response, b'OK') - def test_unknown_command(self): + @patch("logging.Logger.warning") + def test_unknown_command(self, mock_warning): with SMTP(*self.address) as client: code, response = client.docmd('FOOBAR') self.assertEqual(code, 500) @@ -1888,3 +1893,158 @@ class TestAuthArgs(unittest.TestCase): self.assertRaises(ValueError, auth_mechanism, "has space") self.assertRaises(ValueError, auth_mechanism, "has.dot") self.assertRaises(ValueError, auth_mechanism, "has/slash") + + +class TestLimits(unittest.TestCase): + @patch("logging.Logger.warning") + def test_all_limit_15(self, mock_warning): + kwargs = dict( + command_call_limit=15, + ) + controller = Controller(Sink(), server_kwargs=kwargs) + self.addCleanup(controller.stop) + controller.start() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for _ in range(0, 15): + code, mesg = client.noop() + self.assertEqual(250, code) + code, mesg = client.noop() + self.assertEqual(421, code) + self.assertEqual(b"4.7.0 NOOP sent too many times", mesg) + with self.assertRaises(SMTPServerDisconnected): + client.noop() + + @patch("logging.Logger.warning") + def test_different_limits(self, mock_warning): + noop_max, expn_max = 15, 5 + kwargs = dict( + command_call_limit={"NOOP": noop_max, "EXPN": expn_max}, + ) + controller = Controller(Sink(), server_kwargs=kwargs) + self.addCleanup(controller.stop) + controller.start() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for _ in range(0, noop_max): + code, mesg = client.noop() + self.assertEqual(250, code) + code, mesg = client.noop() + self.assertEqual(421, code) + self.assertEqual(b"4.7.0 NOOP sent too many times", mesg) + with self.assertRaises(SMTPServerDisconnected): + client.noop() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for _ in range(0, expn_max): + code, mesg = client.expn("[email protected]") + self.assertEqual(502, code) + code, mesg = client.expn("[email protected]") + self.assertEqual(421, code) + self.assertEqual(b"4.7.0 EXPN sent too many times", mesg) + with self.assertRaises(SMTPServerDisconnected): + client.noop() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for _ in range(0, CALL_LIMIT_DEFAULT): + code, mesg = client.vrfy("[email protected]") + self.assertEqual(252, code) + code, mesg = client.vrfy("[email protected]") + self.assertEqual(421, code) + self.assertEqual(b"4.7.0 VRFY sent too many times", mesg) + with self.assertRaises(SMTPServerDisconnected): + client.noop() + + @patch("logging.Logger.warning") + def test_different_limits_custom_default(self, mock_warning): + # Important: make sure default_max > CALL_LIMIT_DEFAULT + # Others can be set small to cut down on testing time, but must be different + noop_max, expn_max, default_max = 7, 5, 25 + self.assertGreater(default_max, CALL_LIMIT_DEFAULT) + self.assertNotEqual(noop_max, expn_max) + kwargs = dict( + command_call_limit={"NOOP": noop_max, "EXPN": expn_max, "*": default_max}, + ) + controller = Controller(Sink(), server_kwargs=kwargs) + self.addCleanup(controller.stop) + controller.start() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for _ in range(0, noop_max): + code, mesg = client.noop() + self.assertEqual(250, code) + code, mesg = client.noop() + self.assertEqual(421, code) + self.assertEqual(b"4.7.0 NOOP sent too many times", mesg) + with self.assertRaises(SMTPServerDisconnected): + client.noop() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for _ in range(0, expn_max): + code, mesg = client.expn("[email protected]") + self.assertEqual(502, code) + code, mesg = client.expn("[email protected]") + self.assertEqual(421, code) + self.assertEqual(b"4.7.0 EXPN sent too many times", mesg) + with self.assertRaises(SMTPServerDisconnected): + client.noop() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for _ in range(0, default_max): + code, mesg = client.vrfy("[email protected]") + self.assertEqual(252, code) + code, mesg = client.vrfy("[email protected]") + self.assertEqual(421, code) + self.assertEqual(b"4.7.0 VRFY sent too many times", mesg) + with self.assertRaises(SMTPServerDisconnected): + client.noop() + + def test_limit_wrong_type(self): + kwargs = dict( + command_call_limit="invalid", + ) + controller = Controller(Sink(), server_kwargs=kwargs) + self.addCleanup(controller.stop) + with self.assertRaises(TypeError): + controller.start() + + def test_limit_wrong_value_type(self): + kwargs = dict( + command_call_limit={"NOOP": "invalid"}, + ) + controller = Controller(Sink(), server_kwargs=kwargs) + self.addCleanup(controller.stop) + with self.assertRaises(TypeError): + controller.start() + + @patch("logging.Logger.warning") + def test_limit_bogus(self, mock_warning): + # Extreme limit. + kwargs = dict( + command_call_limit=1, + ) + controller = Controller(Sink(), server_kwargs=kwargs) + self.addCleanup(controller.stop) + controller.start() + with SMTP(controller.hostname, controller.port) as client: + code, mesg = client.ehlo('example.com') + self.assertEqual(250, code) + for i in range(0, 4): + code, mesg = client.docmd(f"BOGUS{i}") + self.assertEqual(500, code) + expected = f"Error: command \"BOGUS{i}\" not recognized" + self.assertEqual(expected, mesg.decode("ascii")) + code, mesg = client.docmd("LASTBOGUS") + self.assertEqual(502, code) + self.assertEqual( + b"5.5.1 Too many unrecognized commands, goodbye.", mesg + ) + with self.assertRaises(SMTPServerDisconnected): + client.noop()
Misbehaving clients are never disconnected It's possible to exhaust resources on the server in a number of ways: * Connect and never send a valid command * Connect and repeatedly send NOOP * Connect and waste time in the SMTP transaction, e.g. send multiple HELO, reset, Eventually Python will run out of file handles and exceptions will occur in code that tries to open any file, socket, etc.
0.0
20bd3376bf702491997e6697941946622f9c2874
[ "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimeters", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_already_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_length", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_login_multisteps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_no_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_enough_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_supported_methods", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_too_many_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_abort", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary_space", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_auth", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_data", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_malformed", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_malformed_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_missing_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_from", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_bad_syntax_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_unrecognized_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_to", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_bad_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_an_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_way_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_custom_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_disabled_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_individually", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_login", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_password", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_plain_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_rset_maintain_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_data_line_too_long", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_multiple_connections_lost", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_double_count", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_leak", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_then_too_long_lines", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_line_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_lines_then_too_long_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_in_long_command", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo", "aiosmtpd/tests/test_smtp.py::TestTimeout::test_timeout", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_log_authmechanisms", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls", "aiosmtpd/tests/test_smtp.py::TestLimits::test_all_limit_15", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits_custom_default", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_bogus", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_value_type" ]
[]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2020-12-23 14:05:31+00:00
apache-2.0
956
aio-libs__aiosmtpd-225
diff --git a/.gitignore b/.gitignore index 34d0ea4..5a24133 100644 --- a/.gitignore +++ b/.gitignore @@ -30,3 +30,4 @@ _dynamic/ coverage.xml diffcov.html .python-version +.pytype/ diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 167e830..05628e0 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -19,6 +19,9 @@ Fixed/Improved * Implement waiting for SSL setup/handshake within STARTTLS handler to be able to catch and handle (log) errors and to avoid session hanging around until timeout in such cases * Add session peer information to some logging output where it was missing +* Support AUTH mechanisms with dash(es) in their names (Closes #224) +* Remove some double-logging of commands sent by clients + 1.2.2 (2020-11-08) ================== diff --git a/aiosmtpd/docs/handlers.rst b/aiosmtpd/docs/handlers.rst index d98af40..f661c93 100644 --- a/aiosmtpd/docs/handlers.rst +++ b/aiosmtpd/docs/handlers.rst @@ -156,6 +156,24 @@ Every AUTH hook is named ``auth_MECHANISM`` where ``MECHANISM`` is the all-upper mechanism that the hook will implement. AUTH hooks will be called with the SMTP server instance and a list of str following the ``AUTH`` command. +.. important:: + + If ``MECHANISM`` has a dash within its name, + use **double-underscore** to represent the dash. + For example, to implement a ``MECH-WITH-DASHES`` mechanism, + name the AUTH hook as ``auth_MECH__WITH__DASHES``. + + Single underscores will not be modified. + So a hook named ``auth_MECH_WITH_UNDERSCORE`` + will implement the ``MECH_WITH_UNDERSCORE`` mechanism. + + (If in the future a SASL mechanism with double underscores in its name gets defined, + this name-mangling mechanism will be revisited. + That is very unlikely to happen, though.) + + Alternatively, you can also use the ``@auth_mechanism(actual_name)`` decorator, + which you can import from the :mod:`aiosmtpd.smtp` module. + The SMTP class provides built-in AUTH hooks for the ``LOGIN`` and ``PLAIN`` mechanisms, named ``auth_LOGIN`` and ``auth_PLAIN``, respectively. If the handler class implements ``auth_LOGIN`` and/or ``auth_PLAIN``, then diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index 2f5f8dd..1564d9b 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -1,7 +1,9 @@ +import re import ssl import enum import socket import asyncio +import inspect import logging import binascii import collections @@ -42,6 +44,7 @@ class _DataState(enum.Enum): TOO_MUCH = enum.auto() +AuthCallbackType = Callable[[str, Optional[bytes], Optional[bytes]], bool] AuthMechanismType = Callable[["SMTP", List[str]], Awaitable[Any]] _TriStateType = Union[None, _Missing, bytes] @@ -51,7 +54,12 @@ _TriStateType = Union[None, _Missing, bytes] # region #### Constant & Constant-likes ############################################### -__version__ = '1.2.3a3' +__all__ = [ + "AuthCallbackType", + "AuthMechanismType", + "MISSING", +] # Will be added to by @public +__version__ = '1.2.3a4' __ident__ = 'Python SMTP {}'.format(__version__) log = logging.getLogger('mail.log') @@ -61,6 +69,7 @@ EMPTY_BARR = bytearray() EMPTYBYTES = b'' MISSING = _Missing() NEWLINE = '\n' +VALID_AUTHMECH = re.compile(r"[A-Z0-9_-]+\Z") # endregion @@ -75,6 +84,10 @@ class Session: self.loop = loop self.login_data = None + @property + def authenticated(self): + return self.login_data is not None + @public class Envelope: @@ -95,7 +108,16 @@ def make_loop(): return asyncio.get_event_loop() -def syntax(text, extended=None, when=None): +@public +def syntax(text, extended=None, when: Optional[str] = None): + """ + Provides helptext for (E)SMTP HELP. Applies for smtp_* methods only! + + :param text: Help text for (E)SMTP HELP + :param extended: Additional text for ESMTP HELP (appended to text) + :param when: The name of the attribute of SMTP class to check; if the value + of the attribute is false-y then HELP will not be available for the command + """ def decorator(f): f.__smtp_syntax__ = text f.__smtp_syntax_extended__ = extended @@ -104,6 +126,24 @@ def syntax(text, extended=None, when=None): return decorator +@public +def auth_mechanism(actual_name: str): + """ + Explicitly specifies the name of the AUTH mechanism implemented by + the function/method this decorates + + :param actual_name: Name of AUTH mechanism. Must consists of [A-Z0-9_-] only. + Will be converted to uppercase + """ + def decorator(f): + f.__auth_mechanism_name__ = actual_name + return f + actual_name = actual_name.upper() + if not VALID_AUTHMECH.match(actual_name): + raise ValueError(f"Invalid AUTH mechanism name: {actual_name}") + return decorator + + def login_always_fail(mechanism, login, password): return False @@ -137,7 +177,7 @@ class SMTP(asyncio.StreamReaderProtocol): auth_required=False, auth_require_tls=True, auth_exclude_mechanism: Optional[Iterable[str]] = None, - auth_callback: Callable[[str, bytes, bytes], bool] = None, + auth_callback: AuthCallbackType = None, loop=None, ): self.__ident__ = ident or __ident__ @@ -183,21 +223,25 @@ class SMTP(asyncio.StreamReaderProtocol): self._auth_require_tls = auth_require_tls self._auth_callback = auth_callback or login_always_fail self._auth_required = auth_required - self.authenticated = False # Get hooks & methods to significantly speedup getattr's self._auth_methods: Dict[str, _AuthMechAttr] = { - m.replace("auth_", ""): _AuthMechAttr(getattr(h, m), h is self) - for h in (self, handler) - for m in dir(h) - if m.startswith("auth_") + getattr( + mfunc, "__auth_mechanism_name__", + mname.replace("auth_", "").replace("__", "-") + ): _AuthMechAttr(mfunc, obj is self) + for obj in (self, handler) + for mname, mfunc in inspect.getmembers(obj) + if mname.startswith("auth_") } for m in (auth_exclude_mechanism or []): self._auth_methods.pop(m, None) - msg = "Available AUTH mechanisms:" - for m, impl in sorted( - self._auth_methods.items()): # type: str, _AuthMechAttr - msg += f" {m}{'(builtin)' if impl.is_builtin else ''}" - log.info(msg) + log.info( + "Available AUTH mechanisms: " + + " ".join( + m + "(builtin)" if impl.is_builtin else m + for m, impl in sorted(self._auth_methods.items()) + ) + ) self._handle_hooks: Dict[str, Callable] = { m.replace("handle_", ""): getattr(handler, m) for m in dir(handler) @@ -315,7 +359,7 @@ class SMTP(asyncio.StreamReaderProtocol): response = bytes( status + '\r\n', 'utf-8' if self.enable_SMTPUTF8 else 'ascii') self._writer.write(response) - log.debug(response) + log.debug("%r << %r", self.session.peer, response) await self._writer.drain() async def handle_exception(self, error): @@ -350,10 +394,10 @@ class SMTP(asyncio.StreamReaderProtocol): # send error response and read the next command line. await self.push('500 Command line too long') continue - log.debug('_handle_client readline: %s', line) + log.debug('_handle_client readline: %r', line) # XXX this rstrip may not completely preserve old behavior. line = line.rstrip(b'\r\n') - log.info('%r Data: %s', self.session.peer, line) + log.info('%r >> %r', self.session.peer, line) if not line: await self.push('500 Error: bad syntax') continue @@ -467,7 +511,7 @@ class SMTP(asyncio.StreamReaderProtocol): :param caller_method: The SMTP method needing a check (for logging) :return: True if AUTH is needed """ - if self._auth_required and not self.authenticated: + if self._auth_required and not self.session.authenticated: log.info(f'{caller_method}: Authentication required') await self.push('530 5.7.0 Authentication required') return True @@ -536,7 +580,6 @@ class SMTP(asyncio.StreamReaderProtocol): @syntax('STARTTLS', when='tls_context') async def smtp_STARTTLS(self, arg): - log.info('%r STARTTLS', self.session.peer) if arg: await self.push('501 Syntax: STARTTLS') return @@ -580,7 +623,7 @@ class SMTP(asyncio.StreamReaderProtocol): elif self._auth_require_tls and not self._tls_protocol: await self.push("538 5.7.11 Encryption required for requested " "authentication mechanism") - elif self.authenticated: + elif self.session.authenticated: await self.push('503 Already authenticated') elif not arg: await self.push('501 Not enough value') @@ -615,7 +658,6 @@ class SMTP(asyncio.StreamReaderProtocol): # is rejected / not valid status = '535 5.7.8 Authentication credentials invalid' else: - self.authenticated = True self.session.login_data = login_data status = '235 2.7.0 Authentication successful' if status is not None: # pragma: no branch @@ -628,15 +670,16 @@ class SMTP(asyncio.StreamReaderProtocol): blob = line.strip() # '=' and '*' handling are in accordance with RFC4954 if blob == b"=": - log.debug("User responded with '='") + log.debug("%r responded with '='", self.session.peer) return None if blob == b"*": - log.warning("User requested abort with '*'") + log.warning("%r aborted with '*'", self.session.peer) await self.push("501 Auth aborted") return MISSING try: decoded_blob = b64decode(blob, validate=True) except binascii.Error: + log.debug("%r can't decode base64: %s", self.session.peer, blob) await self.push("501 5.5.2 Can't decode base64") return MISSING return decoded_blob @@ -656,37 +699,40 @@ class SMTP(asyncio.StreamReaderProtocol): # nism. Might be a session key, a one-time user ID, or any kind of # object, actually. # - If the client provides "=" for username during interaction, the - # method MUST return b"" (empty bytes) + # method MUST return b"" (empty bytes) NOT None, because None has been + # used to indicate error/login failure. # 3. Auth credentials checking is performed in the auth_* methods because # more advanced auth mechanism might not return login+password pair # (see #2 above) async def auth_PLAIN(self, _, args: List[str]): - loginpassword: _TriStateType + login_and_password: _TriStateType if len(args) == 1: # Trailing space is MANDATORY - # See https://tools.ietf.org/html/rfc4954#page-4 - loginpassword = await self._auth_interact("334 ") - if loginpassword is MISSING: + # See https://tools.ietf.org/html/rfc4954#page-4 ¶ 5 + login_and_password = await self._auth_interact("334 ") + if login_and_password is MISSING: return else: - blob = args[1].encode() - if blob == b"=": - loginpassword = None + blob = args[1] + if blob == "=": + login_and_password = None else: try: - loginpassword = b64decode(blob, validate=True) + login_and_password = b64decode(blob, validate=True) except Exception: await self.push("501 5.5.2 Can't decode base64") return - if loginpassword is None: + # Decode login data + if login_and_password is None: login = password = None else: try: - _, login, password = loginpassword.split(b"\x00") + _, login, password = login_and_password.split(b"\x00") except ValueError: # not enough args await self.push("501 5.5.2 Can't split auth value") return + # Verify login data if self._auth_callback("PLAIN", login, password): if login is None: login = EMPTYBYTES @@ -801,7 +847,6 @@ class SMTP(asyncio.StreamReaderProtocol): return if await self.check_auth_needed("MAIL"): return - log.debug('===> MAIL %s', arg) syntaxerr = '501 Syntax: MAIL FROM: <address>' if self.session.extended_smtp: syntaxerr += ' [SP <mail-parameters>]' @@ -869,7 +914,6 @@ class SMTP(asyncio.StreamReaderProtocol): return if await self.check_auth_needed("RCPT"): return - log.debug('===> RCPT %s', arg) if not self.envelope.mail_from: await self.push('503 Error: need MAIL command') return
aio-libs/aiosmtpd
6c8fdbc7aecabb66272bd906c123808048308885
diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index 2730c0d..04f541a 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -9,7 +9,7 @@ import warnings from aiosmtpd.controller import Controller from aiosmtpd.handlers import Sink from aiosmtpd.smtp import ( - MISSING, Session as SMTPSess, SMTP as Server, __ident__ as GREETING + MISSING, Session as SMTPSess, SMTP as Server, __ident__ as GREETING, auth_mechanism ) from aiosmtpd.testing.helpers import ( ReceivingHandler, @@ -76,6 +76,16 @@ class PeekerHandler: ): return MISSING + async def auth_WITH_UNDERSCORE(self, server, args): + return "250 OK" + + @auth_mechanism("with-dash") + async def auth_WITH_DASH(self, server, args): + return "250 OK" + + async def auth_WITH__MULTI__DASH(self, server, args): + return "250 OK" + class PeekerAuth: def __init__(self): @@ -972,7 +982,7 @@ class TestSMTPAuth(unittest.TestCase): bytes(socket.getfqdn(), 'utf-8'), b'SIZE 33554432', b'SMTPUTF8', - b'AUTH LOGIN NULL PLAIN', + b'AUTH LOGIN NULL PLAIN WITH-DASH WITH-MULTI-DASH WITH_UNDERSCORE', b'HELP', ) for actual, expected in zip(lines, expecteds): @@ -1052,6 +1062,37 @@ class TestSMTPAuth(unittest.TestCase): self.assertEqual(response, b"5.5.4 Unrecognized authentication type") + def test_rset_maintain_authenticated(self): + """RSET resets only Envelope not Session""" + with SMTP(*self.address) as client: + client.ehlo("example.com") + code, mesg = client.docmd("AUTH PLAIN") + self.assertEqual(code, 334) + self.assertEqual(mesg, b"") + code, mesg = client.docmd('=') + assert_auth_success(self, code, mesg) + self.assertEqual(auth_peeker.login, None) + self.assertEqual(auth_peeker.password, None) + code, mesg = client.mail("[email protected]") + sess: SMTPSess = self.handler.session + self.assertEqual(sess.login_data, b"") + code, mesg = client.rset() + self.assertEqual(code, 250) + code, mesg = client.docmd("AUTH PLAIN") + self.assertEqual(503, code) + self.assertEqual(b'Already authenticated', mesg) + + def test_auth_individually(self): + """AUTH state of different clients must be independent""" + with SMTP(*self.address) as client1, SMTP(*self.address) as client2: + for client in client1, client2: + client.ehlo("example.com") + code, mesg = client.docmd("AUTH PLAIN") + self.assertEqual(code, 334) + self.assertEqual(mesg, b"") + code, mesg = client.docmd('=') + assert_auth_success(self, code, mesg) + class TestRequiredAuthentication(unittest.TestCase): def setUp(self): @@ -1842,3 +1883,8 @@ class TestAuthArgs(unittest.TestCase): mock_info.assert_any_call( f"Available AUTH mechanisms: {' '.join(auth_mechs)}" ) + + def test_authmechname_decorator_badname(self): + self.assertRaises(ValueError, auth_mechanism, "has space") + self.assertRaises(ValueError, auth_mechanism, "has.dot") + self.assertRaises(ValueError, auth_mechanism, "has/slash")
Current AUTH hook implementation cannot support mechanisms with dash "-" in the name The current implementation simply searches for `auth_*` methods in the handler, chop off the `auth_` part, and present the chopped name as is to the list of supported authentications. This means that AUTH mechanisms such as "CRAM-MD5" and "DIGEST-MD5" are not representable. Fixing this is a bit tricky; the simple trick of replacing "_" with "-" will result in SASL mechanisms that _does_ contain underscore in their names (see [SASL mechanisms registry on IANA](https://www.iana.org/assignments/sasl-mechanisms/sasl-mechanisms.xhtml)) to be not representable. My suggestion would be to add another decorator (similar to the existing `@syntax` decorator) that will add an attribute, say `__auth_mechanism_name__` ; if the attribute exists, use that. If the attribute does not exist, use the existing name-mangling strategy.
0.0
6c8fdbc7aecabb66272bd906c123808048308885
[ "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimeters", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_already_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_length", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_login_multisteps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_no_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_enough_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_supported_methods", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_too_many_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_abort", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary_space", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_auth", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_data", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_malformed", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_malformed_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_missing_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_from", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_bad_syntax_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_unrecognized_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_to", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_bad_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_an_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_way_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_custom_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_disabled_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_individually", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_login", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_password", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_plain_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_rset_maintain_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_data_line_too_long", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_multiple_connections_lost", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_double_count", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_leak", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_then_too_long_lines", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_line_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_lines_then_too_long_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_in_long_command", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo", "aiosmtpd/tests/test_smtp.py::TestTimeout::test_timeout", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_log_authmechanisms", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls" ]
[]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2020-12-27 16:15:04+00:00
apache-2.0
957
aio-libs__aiosmtpd-234
diff --git a/.gitignore b/.gitignore index 995ec61..5295a9f 100644 --- a/.gitignore +++ b/.gitignore @@ -33,3 +33,4 @@ diffcov.html diffcov-*.html .python-version .pytype/ +~temp* diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 260d382..eb47070 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -2,6 +2,17 @@ NEWS for aiosmtpd =================== +1.2.4 (aiosmtpd-next) +===================== + +Added +----- +* Optional (default-disabled) logging of ``AUTH`` interaction -- with severe warnings + +Fixed/Improved +-------------- +* ``AUTH`` command line now sanitized before logging (Closes #233) + 1.2.4 (aiosmtpd-next) ===================== diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index da9c7a9..a5c5d39 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -31,7 +31,8 @@ from warnings import warn # region #### Custom Data Types ####################################################### class _Missing: - pass + def __repr__(self): + return "MISSING" class _AuthMechAttr(NamedTuple): @@ -60,7 +61,7 @@ __all__ = [ "AuthMechanismType", "MISSING", ] # Will be added to by @public -__version__ = '1.2.4a1' +__version__ = '1.2.4a2' __ident__ = 'Python SMTP {}'.format(__version__) log = logging.getLogger('mail.log') @@ -77,6 +78,19 @@ VALID_AUTHMECH = re.compile(r"[A-Z0-9_-]+\Z") # https://tools.ietf.org/html/rfc3207.html#page-3 ALLOWED_BEFORE_STARTTLS = {"NOOP", "EHLO", "STARTTLS", "QUIT"} +# Auth hiding regexes +CLIENT_AUTH_B = re.compile( + # Matches "AUTH" <mechanism> <whitespace_but_not_\r_nor_\n> + br"(?P<authm>\s*AUTH\s+\S+[^\S\r\n]+)" + # Param to AUTH <mechanism>. We only need to sanitize if param is given, which + # for some mechanisms contain sensitive info. If no param is given, then we + # can skip (match fails) + br"(\S+)" + # Optional bCRLF at end. Why optional? Because we also want to sanitize the + # stripped line. If no bCRLF, then this group will be b"" + br"(?P<crlf>(?:\r\n)?)", re.IGNORECASE +) + # endregion @@ -163,6 +177,23 @@ class TLSSetupException(Exception): pass +@public +def sanitize(text: bytes) -> bytes: + m = CLIENT_AUTH_B.match(text) + if m: + return m.group("authm") + b"********" + m.group("crlf") + return text + + +@public +def sanitized_log(func: Callable, msg: AnyStr, *args, **kwargs): + sanitized_args = [ + sanitize(a) if isinstance(a, bytes) else a + for a in args + ] + func(msg, *sanitized_args, **kwargs) + + @public class SMTP(asyncio.StreamReaderProtocol): command_size_limit = 512 @@ -436,10 +467,10 @@ class SMTP(asyncio.StreamReaderProtocol): # send error response and read the next command line. await self.push('500 Command line too long') continue - log.debug('_handle_client readline: %r', line) + sanitized_log(log.debug, '_handle_client readline: %r', line) # XXX this rstrip may not completely preserve old behavior. line = line.rstrip(b'\r\n') - log.info('%r >> %r', self.session.peer, line) + sanitized_log(log.info, '%r >> %r', self.session.peer, line) if not line: await self.push('500 Error: bad syntax') continue @@ -732,6 +763,7 @@ class SMTP(asyncio.StreamReaderProtocol): self, challenge: AnyStr, encode_to_b64: bool = True, + log_client_response: bool = False, ) -> Union[_Missing, bytes]: """ Send challenge during authentication. "334 " will be prefixed, so do NOT @@ -739,6 +771,9 @@ class SMTP(asyncio.StreamReaderProtocol): :param challenge: Challenge to send to client. If str, will be utf8-encoded. :param encode_to_b64: If true, then perform Base64 encoding on challenge + :param log_client_response: Perform logging of client's response. + WARNING: Might cause leak of sensitive information! Do not turn on + unless _absolutely_ necessary! :return: Response from client, or MISSING """ challenge = ( @@ -750,9 +785,13 @@ class SMTP(asyncio.StreamReaderProtocol): # - https://tools.ietf.org/html/rfc4954#page-4 ¶ 5 # - https://tools.ietf.org/html/rfc4954#page-13 "continue-req" challenge = b"334 " + (b64encode(challenge) if encode_to_b64 else challenge) - log.debug("Send challenge to %r: %r", self.session.peer, challenge) + log.debug("%r << challenge: %r", self.session.peer, challenge) await self.push(challenge) line = await self._reader.readline() + if log_client_response: + warn("AUTH interaction logging is enabled!") + warn("Sensitive information might be leaked!") + log.debug("%r >> %r", self.session.peer, line) blob: bytes = line.strip() # '*' handling in accordance with RFC4954 if blob == b"*":
aio-libs/aiosmtpd
1ac77bcba5c41568eefce9f19a4751881e63d188
diff --git a/aiosmtpd/testing/helpers.py b/aiosmtpd/testing/helpers.py index a02568e..614760b 100644 --- a/aiosmtpd/testing/helpers.py +++ b/aiosmtpd/testing/helpers.py @@ -66,24 +66,15 @@ def start(plugin): def assert_auth_success(testcase: TestCase, *response): - testcase.assertEqual( - (235, b"2.7.0 Authentication successful"), - response - ) + assert response == (235, b"2.7.0 Authentication successful") def assert_auth_invalid(testcase: TestCase, *response): - testcase.assertEqual( - (535, b"5.7.8 Authentication credentials invalid"), - response - ) + assert response == (535, b"5.7.8 Authentication credentials invalid") def assert_auth_required(testcase: TestCase, *response): - testcase.assertEqual( - (530, b"5.7.0 Authentication required"), - response - ) + assert response == (530, b"5.7.0 Authentication required") SUPPORTED_COMMANDS_TLS: bytes = ( diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index c2eed49..d225303 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -1,8 +1,10 @@ """Test the SMTP protocol.""" +import os import time import socket import asyncio +import logging import unittest import warnings @@ -36,6 +38,7 @@ BCRLF = b'\r\n' ModuleResources = ExitStack() +mail_logger = logging.getLogger('mail.log') def setUpModule(): @@ -43,6 +46,24 @@ def setUpModule(): # and oftentimes (not always, though) leads to Error ModuleResources.enter_context(patch("socket.getfqdn", return_value="localhost")) + loglevel = int(os.environ.get("AIOSMTPD_TESTLOGLEVEL", logging.INFO)) + mail_logger.setLevel(loglevel) + + if "AIOSMTPD_TESTLOGFILE" in os.environ: + fhandler = logging.FileHandler( + os.environ["AIOSMTPD_TESTLOGFILE"], + mode="a", + encoding="latin1", + ) + fhandler.setLevel(1) + fhandler.setFormatter( + logging.Formatter( + u"{asctime} - {name} - {levelname} - {message}", + style="{", + ) + ) + mail_logger.addHandler(fhandler) + def tearDownModule(): ModuleResources.close() @@ -80,7 +101,14 @@ class PeekerHandler: ): return MISSING - async def auth_WITH_UNDERSCORE(self, server, args): + async def auth_WITH_UNDERSCORE(self, server: Server, args): + """ + Be careful when using this AUTH mechanism; log_client_response is set to + True, and this will raise some severe warnings. + """ + await server.challenge_auth( + "challenge", encode_to_b64=False, log_client_response=True + ) return "250 OK" @auth_mechanism("with-dash") @@ -241,6 +269,7 @@ class TestProtocol(unittest.TestCase): def setUp(self): self.transport = Mock() self.transport.write = self._write + self.transport.get_extra_info.return_value = "MockedPeer" self.responses = [] self._old_loop = asyncio.get_event_loop() self.loop = asyncio.new_event_loop() @@ -941,6 +970,26 @@ class TestSMTP(unittest.TestCase): ) assert_auth_success(self, code, response) + def test_authplain_goodcreds_sanitized_log(self): + oldlevel = mail_logger.getEffectiveLevel() + mail_logger.setLevel(logging.DEBUG) + with SMTP(*self.address) as client: + client.ehlo('example.com') + with self.assertLogs(mail_logger, level="DEBUG") as cm: + code, response = client.docmd( + 'AUTH PLAIN ' + + b64encode(b'\0goodlogin\0goodpasswd').decode() + ) + mail_logger.setLevel(oldlevel) + interestings = [ + msg for msg in cm.output if "AUTH PLAIN" in msg + ] + assert len(interestings) == 2 + assert interestings[0].startswith("DEBUG:") + assert interestings[0].endswith("b'AUTH PLAIN ********\\r\\n'") + assert interestings[1].startswith("INFO:") + assert interestings[1].endswith("b'AUTH PLAIN ********'") + def test_auth_plain_null(self): with SMTP(*self.address) as client: client.ehlo('example.com') @@ -1110,6 +1159,19 @@ class TestSMTPAuth(unittest.TestCase): code, mesg = client.docmd("AAA=") assert_auth_success(self, code, mesg) + def test_auth_loginteract_warning(self): + """AUTH state of different clients must be independent""" + with SMTP(*self.address) as client: + client.ehlo("example.com") + resp = client.docmd("AUTH WITH_UNDERSCORE") + assert resp == (334, b"challenge") + with warnings.catch_warnings(record=True) as w: + code, mesg = client.docmd('=') + assert_auth_success(self, code, mesg) + assert len(w) > 0 + assert str(w[0].message) == "AUTH interaction logging is enabled!" + assert str(w[1].message) == "Sensitive information might be leaked!" + class TestRequiredAuthentication(unittest.TestCase): def setUp(self):
Possible Security Issue: AUTH credentials visible in log I was fooling around with a branch, and decided to activate logging. Found out that all `AUTH` commands are logged as-is, without sanitizing. Even if logging level set to `INFO`. Not a problem if using multistep authentication (i.e., `AUTH mech` then wait for `334 ` then respond; the `_auth_interact` method does not log client response), but a problem if using one-step authentication (e.g., `AUTH PLAIN <encoded_username_and_password>`) I fear this might cause to inadvertent leak of sensitive information. For example, if log is being forwarded to an external log collector (e.g., CloudWatch Log on AWS, DataDog, etc.) I will submit an URGENT PR to fix this.
0.0
1ac77bcba5c41568eefce9f19a4751881e63d188
[ "aiosmtpd/tests/test_smtp.py::TestSMTP::test_authplain_goodcreds_sanitized_log", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_loginteract_warning" ]
[ "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimeters", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_already_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_base64_length", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_login_multisteps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_no_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_enough_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_not_supported_methods", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_plain_null", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_too_many_values", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_abort", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_good_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_auth_two_steps_no_credentials", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary_space", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_auth", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_data", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_malformed", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_malformed_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_missing_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_from", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_bad_syntax_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_unrecognized_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_fail_parse_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_to", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_bad_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_an_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_way_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_custom_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_disabled_mechanism", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_individually", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_login", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_abort_password", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_login_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_plain_null_credential", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_rset_maintain_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_data_line_too_long", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_multiple_connections_lost", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_double_count", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_leak", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_then_too_long_lines", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_line_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_lines_then_too_long_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_in_long_command", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo", "aiosmtpd/tests/test_smtp.py::TestTimeout::test_timeout", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_log_authmechanisms", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls", "aiosmtpd/tests/test_smtp.py::TestLimits::test_all_limit_15", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits_custom_default", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_bogus", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_value_type" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-01-17 17:37:05+00:00
apache-2.0
958
aio-libs__aiosmtpd-242
diff --git a/aiosmtpd/__init__.py b/aiosmtpd/__init__.py index e69de29..05c9e9e 100644 --- a/aiosmtpd/__init__.py +++ b/aiosmtpd/__init__.py @@ -0,0 +1,4 @@ +# Copyright 2014-2021 The aiosmtpd Developers +# SPDX-License-Identifier: Apache-2.0 + +__version__ = "1.3.0a4" diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 73eef8c..26a5697 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -19,6 +19,11 @@ Fixed/Improved * ``authenticator`` system improves on ``auth_callback`` by enabling the called function to see the SMTP Session and other info. (``auth_callback`` will be deprecated in 2.0) +* ``__version__`` is now an attribute in ``__init__.py``, + and can be imported from the 'plain' ``aiosmtpd`` module. + (It gets reimported to ``aiosmtpd.smtp``, + so programs relying on ``aiosmtpd.smtp.__version__`` should still work.) + (Closes #241) 1.2.4 (2021-01-24) diff --git a/aiosmtpd/docs/conf.py b/aiosmtpd/docs/conf.py index 4969686..1ce252b 100644 --- a/aiosmtpd/docs/conf.py +++ b/aiosmtpd/docs/conf.py @@ -12,17 +12,16 @@ # All configuration values have a default; values that are commented out # serve to show the default. -import sys -import re import datetime - +import re +import sys from pathlib import Path +from aiosmtpd import __version__ + try: # noinspection PyPackageRequirements - from colorama import ( # pytype: disable=import-error - init as colorama_init, - ) + from colorama import init as colorama_init # pytype: disable=import-error colorama_init() except ImportError: @@ -77,15 +76,6 @@ copyright = f"2015-{datetime.datetime.now().year}, {author}" # |version| and |release|, also used in various other places throughout the # built documents. # -__version__ = None -with open("../smtp.py") as fp: - for line in fp: - m = RE__VERSION.match(line.strip()) - if m: - __version__ = m.group("ver") - break -if __version__ is None: - raise RuntimeError("No __version__ found in aiosmtpd/smtp.py!") release = __version__ version = __version__ diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index f86abdc..cf263f6 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -13,6 +13,7 @@ import binascii import collections import asyncio.sslproto as sslproto +from aiosmtpd import __version__ from base64 import b64decode, b64encode from email._header_value_parser import get_addr_spec, get_angle_addr from email.errors import HeaderParseError @@ -66,8 +67,8 @@ __all__ = [ "AuthCallbackType", "AuthMechanismType", "MISSING", + "__version__", ] # Will be added to by @public -__version__ = '1.3.0a3' __ident__ = 'Python SMTP {}'.format(__version__) log = logging.getLogger('mail.log') diff --git a/setup.cfg b/setup.cfg index 0707662..ab14d23 100644 --- a/setup.cfg +++ b/setup.cfg @@ -1,6 +1,6 @@ [metadata] name = aiosmtpd -version = attr: aiosmtpd.smtp.__version__ +version = attr: aiosmtpd.__version__ description = aiosmtpd - asyncio based SMTP server long_description = This is a server for SMTP and related protocols, similar in utility to the
aio-libs/aiosmtpd
784950296ad5a12431c6e2411de28fcb3c605720
diff --git a/aiosmtpd/tests/test_server.py b/aiosmtpd/tests/test_server.py index 94ea6ab..1262bfe 100644 --- a/aiosmtpd/tests/test_server.py +++ b/aiosmtpd/tests/test_server.py @@ -8,9 +8,10 @@ import os import socket import unittest +from aiosmtpd import __version__ as init_version from aiosmtpd.controller import asyncio, Controller, _FakeServer from aiosmtpd.handlers import Sink -from aiosmtpd.smtp import SMTP as Server +from aiosmtpd.smtp import SMTP as Server, __version__ as smtp_version from contextlib import ExitStack from functools import wraps from smtplib import SMTP @@ -203,3 +204,9 @@ class TestFactory(unittest.TestCase): self.assertIsNone(cont._thread_exception) excm = str(cm.exception) self.assertEqual("Unknown Error, failed to init SMTP server", excm) + + +class TestCompat(unittest.TestCase): + + def test_version(self): + assert smtp_version is init_version
Can't install Version 1.2.4 - No module named 'public' **System:** CentOS 7 **Python Version:** 3.6 (from Software Collection) **PIP Version:** 21.0.1 **Virtualenv:** yes **Description:** When I try to install version 1.2.4 from pypi, the install will be discarded and version 1.2.2 is insalled instead. The reason is, that the module atpuplic is not installed. So the error "ModuleNotFoundError: No module named 'public'" is raised. **Stacktrace:** ``` (testenv) [root@78e76264529c /]# pip install -i https://pypi.org/simple aiosmtpd Collecting aiosmtpd Downloading aiosmtpd-1.2.4.tar.gz (83 kB) |################################| 83 kB 340 kB/s Installing build dependencies ... done Getting requirements to build wheel ... error ERROR: Command errored out with exit status 1: command: /testenv/bin/python /testenv/lib64/python3.6/site-packages/pip/_vendor/pep517/_in_process.py get_requires_for_build_wheel /tmp/tmpxbr7mohf cwd: /tmp/pip-install-s4res86q/aiosmtpd_1b7979a5651c4ef48a1f5c635ab706a8 Complete output (55 lines): Traceback (most recent call last): File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 387, in _parse_attr return getattr(StaticModule(module_name), attr_name) File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 26, in __init__ src = strm.read() File "/opt/rh/rh-python36/root/usr/lib64/python3.6/encodings/ascii.py", line 26, in decode return codecs.ascii_decode(input, self.errors)[0] UnicodeDecodeError: 'ascii' codec can't decode byte 0xc2 in position 30439: ordinal not in range(128) During handling of the above exception, another exception occurred: Traceback (most recent call last): File "/testenv/lib64/python3.6/site-packages/pip/_vendor/pep517/_in_process.py", line 280, in <module> main() File "/testenv/lib64/python3.6/site-packages/pip/_vendor/pep517/_in_process.py", line 263, in main json_out['return_val'] = hook(**hook_input['kwargs']) File "/testenv/lib64/python3.6/site-packages/pip/_vendor/pep517/_in_process.py", line 114, in get_requires_for_build_wheel return hook(config_settings) File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/build_meta.py", line 150, in get_requires_for_build_wheel config_settings, requirements=['wheel']) File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/build_meta.py", line 130, in _get_build_requires self.run_setup() File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/build_meta.py", line 145, in run_setup exec(compile(code, __file__, 'exec'), locals()) File "setup.py", line 4, in <module> setup() File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/__init__.py", line 153, in setup return distutils.core.setup(**attrs) File "/opt/rh/rh-python36/root/usr/lib64/python3.6/distutils/core.py", line 121, in setup dist.parse_config_files() File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/dist.py", line 681, in parse_config_files ignore_option_errors=ignore_option_errors) File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 157, in parse_configuration meta.parse() File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 463, in parse section_parser_method(section_options) File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 436, in parse_section self[name] = value File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 220, in __setitem__ value = parser(value) File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 552, in _parse_version version = self._parse_attr(value, self.package_dir) File "/tmp/pip-build-env-1ki9o5ff/overlay/lib/python3.6/site-packages/setuptools/config.py", line 390, in _parse_attr module = importlib.import_module(module_name) File "/opt/rh/rh-python36/root/usr/lib64/python3.6/importlib/__init__.py", line 126, in import_module return _bootstrap._gcd_import(name[level:], package, level) File "<frozen importlib._bootstrap>", line 994, in _gcd_import File "<frozen importlib._bootstrap>", line 971, in _find_and_load File "<frozen importlib._bootstrap>", line 955, in _find_and_load_unlocked File "<frozen importlib._bootstrap>", line 665, in _load_unlocked File "<frozen importlib._bootstrap_external>", line 678, in exec_module File "<frozen importlib._bootstrap>", line 219, in _call_with_frames_removed File "/tmp/pip-install-s4res86q/aiosmtpd_1b7979a5651c4ef48a1f5c635ab706a8/aiosmtpd/smtp.py", line 15, in <module> from public import public ModuleNotFoundError: No module named 'public' ---------------------------------------- WARNING: Discarding https://files.pythonhosted.org/packages/68/00/736583da7ce52b0ff3e8ce9045d2c1a183d1877a59a4362be50f49e49b03/aiosmtpd-1.2.4.tar.gz#sha256=34cea0ecd0495f752e1c4bfe5f541676d7aab29674390c007834a63fe7ba0bda (from https://pypi.org/simple/aiosmtpd/) (requires-python:~=3.6). Command errored out with exit status 1: /testenv/bin/python /testenv/lib64/python3.6/site-packages/pip/_vendor/pep517/_in_process.py get_requires_for_build_wheel /tmp/tmpxbr7mohf Check the logs for full command output. Downloading aiosmtpd-1.2.2.tar.gz (170 kB) |################################| 170 kB 12.4 MB/s Collecting atpublic Downloading atpublic-2.1.2.tar.gz (16 kB) Collecting typing_extensions Downloading typing_extensions-3.7.4.3-py3-none-any.whl (22 kB) Using legacy 'setup.py install' for aiosmtpd, since package 'wheel' is not installed. Using legacy 'setup.py install' for atpublic, since package 'wheel' is not installed. Installing collected packages: typing-extensions, atpublic, aiosmtpd Running setup.py install for atpublic ... done Running setup.py install for aiosmtpd ... done Successfully installed aiosmtpd-1.2.2 atpublic-2.1.2 typing-extensions-3.7.4.3 ```
0.0
784950296ad5a12431c6e2411de28fcb3c605720
[ "aiosmtpd/tests/test_server.py::TestServer::test_default_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_server_attribute", "aiosmtpd/tests/test_server.py::TestServer::test_smtp_utf8", "aiosmtpd/tests/test_server.py::TestServer::test_socket_error", "aiosmtpd/tests/test_server.py::TestServer::test_special_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestFactory::test_factory_none", "aiosmtpd/tests/test_server.py::TestFactory::test_noexc_smtpd_missing", "aiosmtpd/tests/test_server.py::TestFactory::test_normal_situation", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args", "aiosmtpd/tests/test_server.py::TestCompat::test_version" ]
[]
{ "failed_lite_validators": [ "has_hyperlinks", "has_added_files", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-02-05 09:51:19+00:00
apache-2.0
959
aio-libs__aiosmtpd-248
diff --git a/aiosmtpd/__init__.py b/aiosmtpd/__init__.py index 0689112..05ef765 100644 --- a/aiosmtpd/__init__.py +++ b/aiosmtpd/__init__.py @@ -1,4 +1,4 @@ # Copyright 2014-2021 The aiosmtpd Developers # SPDX-License-Identifier: Apache-2.0 -__version__ = "1.3.0" +__version__ = "1.3.1" diff --git a/aiosmtpd/controller.py b/aiosmtpd/controller.py index 27f1251..0a6d4e2 100644 --- a/aiosmtpd/controller.py +++ b/aiosmtpd/controller.py @@ -2,11 +2,15 @@ # SPDX-License-Identifier: Apache-2.0 import asyncio +import errno import os import ssl import threading +import time from contextlib import ExitStack -from socket import create_connection +from socket import AF_INET6, SOCK_STREAM, create_connection, has_ipv6 +from socket import socket as makesock +from socket import timeout as socket_timeout from typing import Any, Coroutine, Dict, Optional from warnings import warn @@ -17,6 +21,42 @@ from aiosmtpd.smtp import SMTP AsyncServer = asyncio.base_events.Server +def _has_ipv6(): + # Helper function to assist in mocking + return has_ipv6 + + +def get_localhost() -> str: + # Ref: + # - https://github.com/urllib3/urllib3/pull/611#issuecomment-100954017 + # - https://github.com/python/cpython/blob/ : + # - v3.6.13/Lib/test/support/__init__.py#L745-L758 + # - v3.9.1/Lib/test/support/socket_helper.py#L124-L137 + if not _has_ipv6(): + # socket.has_ipv6 only tells us of current Python's IPv6 support, not the + # system's. But if the current Python does not support IPv6, it's pointless to + # explore further. + return "127.0.0.1" + try: + with makesock(AF_INET6, SOCK_STREAM) as sock: + sock.bind(("::1", 0)) + # If we reach this point, that means we can successfully bind ::1 (on random + # unused port), so IPv6 is definitely supported + return "::1" + except OSError as e: + # Apparently errno.E* constants adapts to the OS, so on Windows they will + # automatically use the WSAE* constants + if e.errno == errno.EADDRNOTAVAIL: + # Getting (WSA)EADDRNOTAVAIL means IPv6 is not supported + return "127.0.0.1" + if e.errno == errno.EADDRINUSE: + # Getting (WSA)EADDRINUSE means IPv6 *is* supported, but already used. + # Shouldn't be possible, but just in case... + return "::1" + # Other kinds of errors MUST be raised so we can inspect + raise + + class _FakeServer(asyncio.StreamReaderProtocol): """ Returned by _factory_invoker() in lieu of an SMTP instance in case @@ -40,6 +80,7 @@ class Controller: server: Optional[AsyncServer] = None server_coro: Coroutine = None smtpd = None + _factory_invoked: Optional[threading.Event] = None _thread: Optional[threading.Thread] = None _thread_exception: Optional[Exception] = None @@ -63,18 +104,19 @@ class Controller: /docs/controller.html#controller-api>`_. """ self.handler = handler - self.hostname = "::1" if hostname is None else hostname + self.hostname = get_localhost() if hostname is None else hostname self.port = port self.ssl_context = ssl_context self.loop = asyncio.new_event_loop() if loop is None else loop - self.ready_timeout = os.getenv( - 'AIOSMTPD_CONTROLLER_TIMEOUT', ready_timeout) + self.ready_timeout = float( + os.getenv("AIOSMTPD_CONTROLLER_TIMEOUT", ready_timeout) + ) if server_kwargs: warn( "server_kwargs will be removed in version 2.0. " "Just specify the keyword arguments to forward to SMTP " "as kwargs to this __init__ method.", - DeprecationWarning + DeprecationWarning, ) self.SMTP_kwargs: Dict[str, Any] = server_kwargs or {} self.SMTP_kwargs.update(SMTP_parameters) @@ -87,9 +129,7 @@ class Controller: def factory(self): """Allow subclasses to customize the handler/server creation.""" - return SMTP( - self.handler, **self.SMTP_kwargs - ) + return SMTP(self.handler, **self.SMTP_kwargs) def _factory_invoker(self): """Wraps factory() to catch exceptions during instantiation""" @@ -101,6 +141,8 @@ class Controller: except Exception as err: self._thread_exception = err return _FakeServer(self.loop) + finally: + self._factory_invoked.set() def _run(self, ready_event): asyncio.set_event_loop(self.loop) @@ -116,9 +158,7 @@ class Controller: ssl=self.ssl_context, ) self.server_coro = srv_coro - srv: AsyncServer = self.loop.run_until_complete( - srv_coro - ) + srv: AsyncServer = self.loop.run_until_complete(srv_coro) self.server = srv except Exception as error: # pragma: on-wsl # Usually will enter this part only if create_server() cannot bind to the @@ -143,35 +183,55 @@ class Controller: Context if necessary, and read some data from it to ensure that factory() gets invoked. """ + # IMPORTANT: Windows does not need the next line; for some reasons, + # create_connection is happy with hostname="" on Windows, but screams murder + # in Linux. + # At this point, if self.hostname is Falsy, it most likely is "" (bind to all + # addresses). In such case, it should be safe to connect to localhost) + hostname = self.hostname or get_localhost() with ExitStack() as stk: - s = stk.enter_context(create_connection((self.hostname, self.port), 1.0)) + s = stk.enter_context(create_connection((hostname, self.port), 1.0)) if self.ssl_context: s = stk.enter_context(self.ssl_context.wrap_socket(s)) _ = s.recv(1024) def start(self): assert self._thread is None, "SMTP daemon already running" + self._factory_invoked = threading.Event() + ready_event = threading.Event() self._thread = threading.Thread(target=self._run, args=(ready_event,)) self._thread.daemon = True self._thread.start() # Wait a while until the server is responding. - ready_event.wait(self.ready_timeout) - if self._thread_exception is not None: # pragma: on-wsl - # See comment about WSL1.0 in the _run() method - assert self._thread is not None # Stupid LGTM.com; see github/codeql#4918 - raise self._thread_exception + start = time.monotonic() + if not ready_event.wait(self.ready_timeout): + # An exception within self._run will also result in ready_event not set + # So, we first test for that, before raising TimeoutError + if self._thread_exception is not None: # pragma: on-wsl + # See comment about WSL1.0 in the _run() method + raise self._thread_exception + else: + raise TimeoutError("SMTP server failed to start within allotted time") + respond_timeout = self.ready_timeout - (time.monotonic() - start) + # Apparently create_server invokes factory() "lazily", so exceptions in # factory() go undetected. To trigger factory() invocation we need to open # a connection to the server and 'exchange' some traffic. try: self._testconn() - except Exception: - # We totally don't care of exceptions experienced by _testconn, + except socket_timeout: + # We totally don't care of timeout experienced by _testconn, # which _will_ happen if factory() experienced problems. pass + except Exception: + # Raise other exceptions though + raise + if not self._factory_invoked.wait(respond_timeout): + raise TimeoutError("SMTP server not responding within allotted time") if self._thread_exception is not None: raise self._thread_exception + # Defensive if self.smtpd is None: raise RuntimeError("Unknown Error, failed to init SMTP server") @@ -179,7 +239,7 @@ class Controller: def _stop(self): self.loop.stop() try: - _all_tasks = asyncio.all_tasks + _all_tasks = asyncio.all_tasks # pytype: disable=module-attr except AttributeError: # pragma: py-gt-36 _all_tasks = asyncio.Task.all_tasks for task in _all_tasks(self.loop): diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 41c505f..835a9f6 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -3,6 +3,15 @@ =================== +1.3.1 (aiosmtpd-next) +===================== + +Fixed/Improved +============== +* ``ready_timeout`` now actually enforced, raising ``TimeoutError`` if breached +* No longer fail with opaque "Unknown Error" if ``hostname=""`` (Fixes #244) + + 1.3.0 (2021-02-09) ================== diff --git a/aiosmtpd/docs/controller.rst b/aiosmtpd/docs/controller.rst index 97aa875..1a58ec6 100644 --- a/aiosmtpd/docs/controller.rst +++ b/aiosmtpd/docs/controller.rst @@ -220,6 +220,8 @@ Controller API a float number of seconds, which takes precedence over the ``ready_timeout`` argument value. + If this timeout is breached, a :class:`TimeoutError` exception will be raised. + .. py:attribute:: ssl_context :type: ssl.SSLContext diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index bef3cb4..0d42f3d 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -160,17 +160,15 @@ class Session: @property def login_data(self): """Legacy login_data, usually containing the username""" - warn( + log.warning( "Session.login_data is deprecated and will be removed in version 2.0", - DeprecationWarning ) return self._login_data @login_data.setter def login_data(self, value): - warn( + log.warning( "Session.login_data is deprecated and will be removed in version 2.0", - DeprecationWarning ) self._login_data = value diff --git a/release.py b/release.py index 4f96b6d..e3fd646 100755 --- a/release.py +++ b/release.py @@ -4,6 +4,7 @@ # SPDX-License-Identifier: Apache-2.0 import os +import re import subprocess import sys from pathlib import Path @@ -45,6 +46,19 @@ GPG_SIGNING_ID = {GPG_SIGNING_ID or 'None'} choice = input(f"Release aiosmtpd {version} - correct? [y/N]: ") if choice.lower() not in ("y", "yes"): sys.exit("Release aborted") + +newsfile = Path(".") / "aiosmtpd" / "docs" / "NEWS.rst" +with newsfile.open("rt") as fin: + want = re.compile("^" + re.escape(version) + r"\s*\(\d{4}-\d\d-\d\d\)") + for ln in fin: + m = want.match(ln) + if not m: + continue + break + else: + print(f"ERROR: I found no datestamped entry for {version} in NEWS.rst!") + sys.exit(1) + if not GPG_SIGNING_ID: choice = input("You did not specify GPG signing ID! Continue? [y/N]: ") if choice.lower() not in ("y", "yes"):
aio-libs/aiosmtpd
f1c69432b12149cc5e822fe07b62327e23602925
diff --git a/.github/workflows/unit-testing-and-coverage.yml b/.github/workflows/unit-testing-and-coverage.yml index 6e850b2..6d77512 100644 --- a/.github/workflows/unit-testing-and-coverage.yml +++ b/.github/workflows/unit-testing-and-coverage.yml @@ -70,7 +70,7 @@ jobs: # If a matrix fail, do NOT stop other matrix, let them run to completion fail-fast: false matrix: - os: [ "ubuntu-18.04", "ubuntu-20.04", "macos-10.15", "windows-latest" ] + os: [ "macos-10.15", "ubuntu-18.04", "ubuntu-20.04", "windows-latest" ] python-version: [ "3.6", "3.7", "3.8", "3.9", "pypy3" ] runs-on: ${{ matrix.os }} steps: diff --git a/aiosmtpd/tests/test_server.py b/aiosmtpd/tests/test_server.py index 2572450..96ced4a 100644 --- a/aiosmtpd/tests/test_server.py +++ b/aiosmtpd/tests/test_server.py @@ -3,20 +3,53 @@ """Test other aspects of the server implementation.""" +import errno import platform import socket +import time from functools import partial import pytest from pytest_mock import MockFixture -from aiosmtpd.controller import Controller, _FakeServer +from aiosmtpd.controller import Controller, _FakeServer, get_localhost from aiosmtpd.handlers import Sink from aiosmtpd.smtp import SMTP as Server from .conftest import Global +class SlowStartController(Controller): + def __init__(self, *args, **kwargs): + kwargs.setdefault("ready_timeout", 0.5) + super().__init__(*args, **kwargs) + + def _run(self, ready_event): + time.sleep(self.ready_timeout * 1.5) + try: + super()._run(ready_event) + except Exception: + pass + + +class SlowFactoryController(Controller): + def __init__(self, *args, **kwargs): + kwargs.setdefault("ready_timeout", 0.5) + super().__init__(*args, **kwargs) + + def factory(self): + time.sleep(self.ready_timeout * 3) + return super().factory() + + def _factory_invoker(self): + time.sleep(self.ready_timeout * 3) + return super()._factory_invoker() + + +def in_win32(): + return platform.system().casefold() == "windows" + + def in_wsl(): # WSL 1.0 somehow allows more than one listener on one port. # So we have to detect when we're running on WSL so we can skip some tests. @@ -56,6 +89,35 @@ class TestServer: class TestController: """Tests for the aiosmtpd.controller.Controller class""" + @pytest.mark.filterwarnings("ignore") + def test_ready_timeout(self): + cont = SlowStartController(Sink()) + expectre = r"SMTP server failed to start within allotted time" + try: + with pytest.raises(TimeoutError, match=expectre): + cont.start() + finally: + cont.stop() + + @pytest.mark.filterwarnings("ignore") + def test_factory_timeout(self): + cont = SlowFactoryController(Sink()) + expectre = r"SMTP server not responding within allotted time" + try: + with pytest.raises(TimeoutError, match=expectre): + cont.start() + finally: + cont.stop() + + def test_reuse_loop(self, temp_event_loop): + cont = Controller(Sink(), loop=temp_event_loop) + assert cont.loop is temp_event_loop + try: + cont.start() + assert cont.smtpd.loop is temp_event_loop + finally: + cont.stop() + @pytest.mark.skipif(in_wsl(), reason="WSL prevents socket collision") def test_socket_error_dupe(self, plain_controller, client): contr2 = Controller( @@ -129,6 +191,72 @@ class TestController: controller = contsink(server_hostname="testhost3", server_kwargs=kwargs) assert controller.SMTP_kwargs["hostname"] == "testhost3" + def test_hostname_empty(self): + # WARNING: This test _always_ succeeds in Windows. + cont = Controller(Sink(), hostname="") + try: + cont.start() + finally: + cont.stop() + + def test_hostname_none(self): + cont = Controller(Sink()) + try: + cont.start() + finally: + cont.stop() + + def test_testconn_raises(self, mocker: MockFixture): + mocker.patch("socket.socket.recv", side_effect=RuntimeError("MockError")) + cont = Controller(Sink(), hostname="") + try: + with pytest.raises(RuntimeError, match="MockError"): + cont.start() + finally: + cont.stop() + + def test_getlocalhost(self): + assert get_localhost() in ("127.0.0.1", "::1") + + def test_getlocalhost_noipv6(self, mocker): + mock_hasip6 = mocker.patch("aiosmtpd.controller._has_ipv6", return_value=False) + assert get_localhost() == "127.0.0.1" + assert mock_hasip6.called + + def test_getlocalhost_6yes(self, mocker: MockFixture): + mock_sock = mocker.Mock() + mock_makesock: mocker.Mock = mocker.patch("aiosmtpd.controller.makesock") + mock_makesock.return_value.__enter__.return_value = mock_sock + assert get_localhost() == "::1" + mock_makesock.assert_called_with(socket.AF_INET6, socket.SOCK_STREAM) + assert mock_sock.bind.called + + def test_getlocalhost_6no(self, mocker): + mock_makesock: mocker.Mock = mocker.patch( + "aiosmtpd.controller.makesock", + side_effect=OSError(errno.EADDRNOTAVAIL, "Mock IP4-only"), + ) + assert get_localhost() == "127.0.0.1" + mock_makesock.assert_called_with(socket.AF_INET6, socket.SOCK_STREAM) + + def test_getlocalhost_6inuse(self, mocker): + mock_makesock: mocker.Mock = mocker.patch( + "aiosmtpd.controller.makesock", + side_effect=OSError(errno.EADDRINUSE, "Mock IP6 used"), + ) + assert get_localhost() == "::1" + mock_makesock.assert_called_with(socket.AF_INET6, socket.SOCK_STREAM) + + def test_getlocalhost_error(self, mocker): + mock_makesock: mocker.Mock = mocker.patch( + "aiosmtpd.controller.makesock", + side_effect=OSError(errno.EAFNOSUPPORT, "Mock Error"), + ) + with pytest.raises(OSError, match="Mock Error") as exc: + get_localhost() + assert exc.value.errno == errno.EAFNOSUPPORT + mock_makesock.assert_called_with(socket.AF_INET6, socket.SOCK_STREAM) + class TestFactory: def test_normal_situation(self): @@ -143,7 +271,7 @@ class TestFactory: @pytest.mark.filterwarnings("ignore::pytest.PytestUnraisableExceptionWarning") def test_unknown_args_direct(self, silence_event_loop_closed): unknown = "this_is_an_unknown_kwarg" - cont = Controller(Sink(), **{unknown: True}) + cont = Controller(Sink(), ready_timeout=0.3, **{unknown: True}) expectedre = r"__init__.. got an unexpected keyword argument '" + unknown + r"'" try: with pytest.raises(TypeError, match=expectedre): @@ -159,7 +287,7 @@ class TestFactory: @pytest.mark.filterwarnings("ignore::pytest.PytestUnraisableExceptionWarning") def test_unknown_args_inkwargs(self, silence_event_loop_closed): unknown = "this_is_an_unknown_kwarg" - cont = Controller(Sink(), server_kwargs={unknown: True}) + cont = Controller(Sink(), ready_timeout=0.3, server_kwargs={unknown: True}) expectedre = r"__init__.. got an unexpected keyword argument '" + unknown + r"'" try: with pytest.raises(TypeError, match=expectedre): @@ -173,7 +301,7 @@ class TestFactory: # Hypothetical situation where factory() did not raise an Exception # but returned None instead mocker.patch("aiosmtpd.controller.SMTP", return_value=None) - cont = Controller(Sink()) + cont = Controller(Sink(), ready_timeout=0.3) expectedre = r"factory\(\) returned None" try: with pytest.raises(RuntimeError, match=expectedre):
RuntimeError after upgrading from 1.2.2 After upgrading from version 1.2.2 to 1.2.4 we receive the following error when trying to start the controller: ``` Traceback (most recent call last): File "<stdin>", line 1, in <module> File "/usr/local/lib/python3.6/site-packages/aiosmtpd/controller.py", line 165, in start raise RuntimeError("Unknown Error, failed to init SMTP server") RuntimeError: Unknown Error, failed to init SMTP server ``` This error can even be triggered by running the sample code from the [documentation](https://aiosmtpd.readthedocs.io/en/latest/controller.html): ``` import asyncio class ExampleHandler: async def handle_RCPT(self, server, session, envelope, address, rcpt_options): return '250 OK' from aiosmtpd.controller import Controller controller = Controller(ExampleHandler()) controller.start() ``` After executing "controller.start()" the RuntimeError from above appears. Python version is 3.6.8 OS is Red Hat 7.9 aiosmtpd was installed with pip3. After downgrading via "sudo pip3 install aiosmtpd=1.2.2" everything works again and aiosmtpd receives and processes emails without problems.
0.0
f1c69432b12149cc5e822fe07b62327e23602925
[ "aiosmtpd/tests/test_server.py::TestServer::test_smtp_utf8", "aiosmtpd/tests/test_server.py::TestServer::test_default_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_special_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_warn_authreq_notls", "aiosmtpd/tests/test_server.py::TestController::test_ready_timeout", "aiosmtpd/tests/test_server.py::TestController::test_factory_timeout", "aiosmtpd/tests/test_server.py::TestController::test_reuse_loop", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_dupe", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_default", "aiosmtpd/tests/test_server.py::TestController::test_server_attribute", "aiosmtpd/tests/test_server.py::TestController::test_enablesmtputf8_flag", "aiosmtpd/tests/test_server.py::TestController::test_serverhostname_arg", "aiosmtpd/tests/test_server.py::TestController::test_hostname_empty", "aiosmtpd/tests/test_server.py::TestController::test_hostname_none", "aiosmtpd/tests/test_server.py::TestController::test_testconn_raises", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_noipv6", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6yes", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6no", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6inuse", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_error", "aiosmtpd/tests/test_server.py::TestFactory::test_normal_situation", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_direct", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_inkwargs", "aiosmtpd/tests/test_server.py::TestFactory::test_factory_none", "aiosmtpd/tests/test_server.py::TestFactory::test_noexc_smtpd_missing", "aiosmtpd/tests/test_server.py::TestCompat::test_version" ]
[]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2021-02-17 03:45:31+00:00
apache-2.0
960
aio-libs__aiosmtpd-25
diff --git a/.gitignore b/.gitignore index 4a71485..74def74 100644 --- a/.gitignore +++ b/.gitignore @@ -27,3 +27,5 @@ __pycache__/ py34-cov py35-cov htmlcov +coverage.xml +diffcov.html diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 433ed66..1ca0483 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -4,6 +4,8 @@ 1.0a4 (20XX-XX-XX) ================== +* The SMTP server connection identifier can be changed by setting the + `__ident__` attribute on the `SMTP` instance. (Closes #20) 1.0a3 (2016-11-24) ================== diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index 01349de..569a4a1 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -36,6 +36,7 @@ class SMTP(asyncio.StreamReaderProtocol): decode_data=False, hostname=None, loop=None): + self.__ident__ = __ident__ self.loop = loop if loop else asyncio.get_event_loop() super().__init__( asyncio.StreamReader(loop=self.loop), @@ -120,7 +121,7 @@ class SMTP(asyncio.StreamReaderProtocol): @asyncio.coroutine def _handle_client(self): log.info('handling connection') - yield from self.push('220 %s %s' % (self.hostname, __version__)) + yield from self.push('220 {} {}'.format(self.hostname, self.__ident__)) while not self.connection_closed: # XXX Put the line limit stuff into the StreamReader? line = yield from self._reader.readline() diff --git a/tox.ini b/tox.ini index 1bdd04a..0755ccc 100644 --- a/tox.ini +++ b/tox.ini @@ -1,20 +1,24 @@ [tox] -envlist = {py34,py35,py36}-{cov,nocov},qa +envlist = {py34,py35,py36}-{cov,nocov,diffcov},qa recreate = True skip_missing_interpreters=True [testenv] commands = nocov: python -m nose2 -v {posargs} - cov: python -m coverage run {[coverage]rc} -m nose2 -v - cov: python -m coverage combine {[coverage]rc} + {cov,diffcov}: python -m coverage run {[coverage]rc} -m nose2 -v + {cov,diffcov}: python -m coverage combine {[coverage]rc} cov: python -m coverage html {[coverage]rc} cov: python -m coverage report -m {[coverage]rc} --fail-under=96 + diffcov: python -m coverage xml {[coverage]rc} + diffcov: diff-cover coverage.xml --html-report diffcov.html + diffcov: diff-cover coverage.xml #sitepackages = True usedevelop = True deps = nose2 - cov: coverage + {cov,diffcov}: coverage + diffcov: diff_cover setenv = cov: COVERAGE_PROCESS_START={[coverage]rcfile} cov: COVERAGE_OPTIONS="-p"
aio-libs/aiosmtpd
0894d5f2660e995089974a11c264bab29e894cec
diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index cdb39f4..c0173ff 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -5,7 +5,7 @@ import unittest from aiosmtpd.controller import Controller from aiosmtpd.handlers import Sink -from aiosmtpd.smtp import SMTP as Server +from aiosmtpd.smtp import SMTP as Server, __ident__ as GREETING from smtplib import SMTP, SMTPDataError @@ -33,6 +33,13 @@ class CustomHostnameController(Controller): return Server(self.handler, hostname='custom.localhost') +class CustomIdentController(Controller): + def factory(self): + server = Server(self.handler) + server.__ident__ = 'Identifying SMTP v2112' + return server + + class ErroringHandler: def process_message(self, peer, mailfrom, rcpttos, data, **kws): return '499 Could not accept the message' @@ -534,15 +541,32 @@ Testing b'Could not accept the message') -class TestCustomHostname(unittest.TestCase): - def setUp(self): +class TestCustomizations(unittest.TestCase): + def test_custom_hostname(self): controller = CustomHostnameController(Sink) controller.start() self.addCleanup(controller.stop) - self.address = (controller.hostname, controller.port) - - def test_helo(self): - with SMTP(*self.address) as client: + with SMTP(controller.hostname, controller.port) as client: code, response = client.helo('example.com') self.assertEqual(code, 250) self.assertEqual(response, bytes('custom.localhost', 'utf-8')) + + def test_custom_greeting(self): + controller = CustomIdentController(Sink) + controller.start() + self.addCleanup(controller.stop) + with SMTP() as client: + code, msg = client.connect(controller.hostname, controller.port) + self.assertEqual(code, 220) + # The hostname prefix is unpredictable. + self.assertEqual(msg[-22:], b'Identifying SMTP v2112') + + def test_default_greeting(self): + controller = Controller(Sink) + controller.start() + self.addCleanup(controller.stop) + with SMTP() as client: + code, msg = client.connect(controller.hostname, controller.port) + self.assertEqual(code, 220) + # The hostname prefix is unpredictable. + self.assertEqual(msg[-len(GREETING):], bytes(GREETING, 'utf-8'))
Set the connection identifier without setting a module global Currently, there's an `__version__` module global in smtp.py that is used when the client connects to the SMTP instance. There's also an unused module global `__ident__`. It should be possible to set these as attributes or arguments to the `SMTP` class, or at least without having to modify the module global.
0.0
0894d5f2660e995089974a11c264bab29e894cec
[ "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_default_greeting" ]
[ "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_data", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_mail_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rcpt_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_malformed", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_malformed_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_missing_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_from", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_bad_syntax_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_unrecognized_params_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_arg_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_bad_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_with_params_no_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_an_address", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestCustomizations::test_custom_hostname" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2016-11-27 18:07:08+00:00
apache-2.0
961
aio-libs__aiosmtpd-258
diff --git a/aiosmtpd/__init__.py b/aiosmtpd/__init__.py index 778795f..d8a299d 100644 --- a/aiosmtpd/__init__.py +++ b/aiosmtpd/__init__.py @@ -1,4 +1,4 @@ # Copyright 2014-2021 The aiosmtpd Developers # SPDX-License-Identifier: Apache-2.0 -__version__ = "1.4.0" +__version__ = "1.4.1a1" diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index 5cd2841..ac079d4 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -3,6 +3,15 @@ ################### +1.4.1 (aiosmtpd-next) +===================== + +Fixed/Improved +-------------- +* Maximum length of email address local part is customizable, defaults to no limit. (Closes #257) + + + 1.4.0 (2021-02-26) ================== diff --git a/aiosmtpd/docs/smtp.rst b/aiosmtpd/docs/smtp.rst index a1246d8..f48b717 100644 --- a/aiosmtpd/docs/smtp.rst +++ b/aiosmtpd/docs/smtp.rst @@ -390,6 +390,16 @@ aiosmtpd.smtp :attr:`line_length_limit` to ``2**16`` *before* instantiating the :class:`SMTP` class. + .. py:attribute:: local_part_limit + + The maximum lengh (in octets) of the local part of email addresses. + + :rfc:`RFC 5321 § 4.5.3.1.1 <5321#section-4.5.3.1.1>` specifies a maximum length of 64 octets, + but this requirement is flexible and can be relaxed at the server's discretion + (see :rfc:`§ 4.5.3.1 <5321#section-4.5.3.1>`). + + Setting this to `0` (the default) disables this limit completely. + .. py:attribute:: AuthLoginUsernameChallenge A ``str`` containing the base64-encoded challenge to be sent as the first challenge diff --git a/aiosmtpd/smtp.py b/aiosmtpd/smtp.py index 702faad..667b4af 100644 --- a/aiosmtpd/smtp.py +++ b/aiosmtpd/smtp.py @@ -277,12 +277,19 @@ class SMTP(asyncio.StreamReaderProtocol): command_size_limit = 512 command_size_limits: Dict[str, int] = collections.defaultdict( lambda x=command_size_limit: x) + line_length_limit = 1001 """Maximum line length according to RFC 5321 s 4.5.3.1.6""" # The number comes from this calculation: # (RFC 5322 s 2.1.1 + RFC 6532 s 3.4) 998 octets + CRLF = 1000 octets # (RFC 5321 s 4.5.3.1.6) 1000 octets + "transparent dot" = 1001 octets + local_part_limit: int = 0 + """ + Maximum local part length. (RFC 5321 § 4.5.3.1.1 specifies 64, but lenient) + If 0 or Falsey, local part length is unlimited. + """ + AuthLoginUsernameChallenge = "User Name\x00" AuthLoginPasswordChallenge = "Password\x00" @@ -455,6 +462,18 @@ class SMTP(asyncio.StreamReaderProtocol): except ValueError: return self.command_size_limit + def __del__(self): # pragma: nocover + # This is nocover-ed because the contents *totally* does NOT affect function- + # ality, and in addition this comes directly from StreamReaderProtocol.__del__() + # but with a getattr()+check addition to stop the annoying (but harmless) + # "exception ignored" messages caused by AttributeError when self._closed is + # missing (which seems to happen randomly). + closed = getattr(self, "_closed", None) + if closed is None: + return + if closed.done() and not closed.cancelled(): + closed.exception() + def connection_made(self, transport): # Reset state due to rfc3207 part 4.2. self._set_rset_state() @@ -1112,10 +1131,9 @@ class SMTP(asyncio.StreamReaderProtocol): return None, None address = address.addr_spec localpart, atsign, domainpart = address.rpartition("@") - if len(localpart) > 64: # RFC 5321 § 4.5.3.1.1 + if self.local_part_limit and len(localpart) > self.local_part_limit: return None, None - else: - return address, rest + return address, rest def _getparams(self, params): # Return params as dictionary. Return None if not all parameters
aio-libs/aiosmtpd
c52d3b6eb514327cb8b4cc7757439870715e2c50
diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index ee2c614..b614bc1 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -489,16 +489,21 @@ class TestSMTP(_CommonMethods): "customer/[email protected]", "[email protected]", "!def!xyz%[email protected]", + "a" * 65 + "@example.com", # local-part > 64 chars -- see Issue#257 + "b" * 488 + "@example.com", # practical longest for MAIL FROM + "c" * 500, # practical longest domainless for MAIL FROM ] valid_rcptto_addresses = valid_mailfrom_addresses + [ # Postmaster -- RFC5321 § 4.1.1.3 "<Postmaster>", + "b" * 490 + "@example.com", # practical longest for RCPT TO + "c" * 502, # practical longest domainless for RCPT TO ] invalid_email_addresses = [ - "<@example.com>", # no local part - "a" * 65 + "@example.com", # local-part > 64 chars + "<@example.com>", # null local part + "<johnathon@>", # null domain part ] @pytest.mark.parametrize("data", [b"\x80FAIL\r\n", b"\x80 FAIL\r\n"]) @@ -1659,6 +1664,16 @@ class TestCustomization(_CommonMethods): resp = client.docmd("MAIL FROM: <[email protected]> BODY=FOOBAR") assert resp == S.S501_MAIL_BODY + def test_limitlocalpart(self, plain_controller, client): + plain_controller.smtpd.local_part_limit = 64 + client.ehlo("example.com") + locpart = "a" * 64 + resp = client.docmd(f"MAIL FROM: {locpart}@example.com") + assert resp == S.S250_OK + locpart = "b" * 65 + resp = client.docmd(f"RCPT TO: {locpart}@example.com") + assert resp == S.S553_MALFORMED + class TestClientCrash(_CommonMethods): def test_connection_reset_during_DATA(
SMTP doesn't accept RCPT with local part > 64 octets. smtp.py in the code in _getaddr() at lines 1097 - 1118 contains at lines 1115,1116 ``` if len(localpart) > 64: # RFC 5321 § 4.5.3.1.1 return None, None ``` While it is true that RFC 5321 § 4.5.3.1.1 specifies 64 octets as the maximum length of a local part, § 4.5.3.1 says in part `To the maximum extent possible, implementation techniques that impose no limits on the length of these objects should be used.` Also, the stdlib smtpd.py _getaddr() contains no such restriction. Thus, I think SMTP should be more forgiving since I see no reason to enforce this limit. This restriction results in issues for GNU Mailman which uses the LMTP class to receive messages and receives confirmation messages addressed to `LISTNAME-confirm+TOKEN@example .com. The length of the token is 40 bytes which means if the length of the list name is > 15 bytes, the local part will exceed 64 bytes and be rejected.
0.0
c52d3b6eb514327cb8b4cc7757439870715e2c50
[ "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[37]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[38]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[37]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[38]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[41]" ]
[ "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimiters", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary[\\x80FAIL\\r\\n]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary[\\x80", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_close_then_continue", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_args", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[HELO]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[EHLO]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[DATA]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[RSET]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[NOOP]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[QUIT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[VRFY]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[AUTH]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_esmtp[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_esmtp[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[DATA]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[2]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[3]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[4]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[5]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[6]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[7]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[8]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[9]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[10]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[11]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[12]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[13]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[14]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[15]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[16]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[17]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[18]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[19]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[20]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[21]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[22]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[23]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[24]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[25]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[26]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[27]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[28]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[29]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[30]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[31]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[32]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[33]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[34]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[35]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[36]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[39]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[nofrom]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[params_noesmtp]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[norm]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[extralead]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[extratail]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[missing]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[badsyntax]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[space]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_params_unrecognized", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_bpo27931fix_smtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noto]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[params]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noto]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[badparams]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[2]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[3]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[4]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[5]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[6]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[7]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[8]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[9]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[10]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[11]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[12]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[13]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[14]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[15]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[16]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[17]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[18]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[19]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[20]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[21]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[22]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[23]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[24]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[25]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[26]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[27]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[28]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[29]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[30]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[31]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[32]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[33]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[34]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[35]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[36]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[39]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[40]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[42]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_bpo27931fix_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_354", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_way_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTPNonDecoding::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_no_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_not_enough_values", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_already_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_individually", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_rset_maintain_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_loginteract_warning", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[GSSAPI]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[DIGEST-MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[CRAM-MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_custom_mechanism", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_disabled_mechanism", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[login-True]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[plain-True]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[plain-False]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_base64_length", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_too_many_values", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_empty", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_goodcreds_sanitized_log", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_no_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_abort", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login2_bad_base64", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login2_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_base64", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_empty_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_abort_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_abort_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_DENYFALSE", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_DENYMISSING", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_NONE", "aiosmtpd/tests/test_smtp.py::TestAuthenticator::test_success", "aiosmtpd/tests/test_smtp.py::TestAuthenticator::test_fail_withmesg", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_nomail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_norcpt_authenticated", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_multiple_connections_lost", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_data_line_too_long", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_double_count", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_leak", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_then_too_long_lines", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_line_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_lines_then_too_long_body", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_limitlocalpart", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command_2", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_sockclose_after_helo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo", "aiosmtpd/tests/test_smtp.py::TestTimeout::test_timeout", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_log_authmechanisms", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has.dot]", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has/slash]", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has\\\\backslash]", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_value_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_all_limit_15", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits_custom_default", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_bogus" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-03-01 09:45:21+00:00
apache-2.0
962
aio-libs__aiosmtpd-263
diff --git a/aiosmtpd/__init__.py b/aiosmtpd/__init__.py index 7403d8e..2124ae5 100644 --- a/aiosmtpd/__init__.py +++ b/aiosmtpd/__init__.py @@ -1,4 +1,4 @@ # Copyright 2014-2021 The aiosmtpd Developers # SPDX-License-Identifier: Apache-2.0 -__version__ = "1.4.1" +__version__ = "1.4.2a1" diff --git a/aiosmtpd/controller.py b/aiosmtpd/controller.py index 9dee79d..2258c54 100644 --- a/aiosmtpd/controller.py +++ b/aiosmtpd/controller.py @@ -27,6 +27,8 @@ from aiosmtpd.smtp import SMTP AsyncServer = asyncio.base_events.Server +DEFAULT_READY_TIMEOUT: float = 5.0 + @public class IP6_IS: @@ -106,7 +108,7 @@ class BaseThreadedController(metaclass=ABCMeta): handler, loop=None, *, - ready_timeout: float = 1.0, + ready_timeout: float, ssl_context: Optional[ssl.SSLContext] = None, # SMTP parameters server_hostname: Optional[str] = None, @@ -207,7 +209,11 @@ class BaseThreadedController(metaclass=ABCMeta): # See comment about WSL1.0 in the _run() method raise self._thread_exception else: - raise TimeoutError("SMTP server failed to start within allotted time") + raise TimeoutError( + "SMTP server failed to start within allotted time. " + "This might happen if the system is too busy. " + "Try increasing the `ready_timeout` parameter." + ) respond_timeout = self.ready_timeout - (time.monotonic() - start) # Apparently create_server invokes factory() "lazily", so exceptions in @@ -222,7 +228,11 @@ class BaseThreadedController(metaclass=ABCMeta): # Raise other exceptions though raise if not self._factory_invoked.wait(respond_timeout): - raise TimeoutError("SMTP server not responding within allotted time") + raise TimeoutError( + "SMTP server started, but not responding within allotted time. " + "This might happen if the system is too busy. " + "Try increasing the `ready_timeout` parameter." + ) if self._thread_exception is not None: raise self._thread_exception @@ -265,7 +275,7 @@ class Controller(BaseThreadedController): port: int = 8025, loop=None, *, - ready_timeout: float = 1.0, + ready_timeout: float = DEFAULT_READY_TIMEOUT, ssl_context: ssl.SSLContext = None, # SMTP parameters server_hostname: Optional[str] = None, @@ -317,8 +327,8 @@ class UnixSocketController(BaseThreadedController): # pragma: on-win32 on-cygwi unix_socket: Optional[Union[str, Path]], loop=None, *, - ready_timeout=1.0, - ssl_context=None, + ready_timeout: float = DEFAULT_READY_TIMEOUT, + ssl_context: ssl.SSLContext = None, # SMTP parameters server_hostname: str = None, **SMTP_parameters, diff --git a/aiosmtpd/docs/NEWS.rst b/aiosmtpd/docs/NEWS.rst index cb38f44..0e6aff2 100644 --- a/aiosmtpd/docs/NEWS.rst +++ b/aiosmtpd/docs/NEWS.rst @@ -3,6 +3,22 @@ ################### +1.4.2 (aiosmtpd-next) +===================== + +Fixed/Improved +-------------- +* Controller's ``ready_timeout`` parameter increased from ``1.0`` to ``5.0``. + This won't slow down Controller startup because it's just a timeout limit + (instead of a sleep delay), + but this should help prevent Controller from giving up too soon, + especially during situations where system/network is a bit busy causing slowdowns. + (See #262) +* Timeout messages in ``Controller.start()`` gets more details and a mention about the + ``ready_timeout`` parameter. (See #262) + + + 1.4.1 (2021-03-04) ================== diff --git a/aiosmtpd/docs/controller.rst b/aiosmtpd/docs/controller.rst index 06a0f3b..d3e08ed 100644 --- a/aiosmtpd/docs/controller.rst +++ b/aiosmtpd/docs/controller.rst @@ -283,7 +283,7 @@ Controller API handler, \ loop=None, \ *, \ - ready_timeout=1.0, \ + ready_timeout, \ ssl_context=None, \ server_hostname=None, server_kwargs=None, **SMTP_parameters) @@ -292,6 +292,7 @@ Controller API If not given, :func:`asyncio.new_event_loop` will be called to create the event loop. :param ready_timeout: How long to wait until server starts. The :envvar:`AIOSMTPD_CONTROLLER_TIMEOUT` takes precedence over this parameter. + See :attr:`ready_timeout` for more information. :type ready_timeout: float :param ssl_context: SSL Context to wrap the socket in. Will be passed-through to :meth:`~asyncio.loop.create_server` method @@ -330,7 +331,6 @@ Controller API .. attribute:: ready_timeout :type: float - :noindex: The timeout value used to wait for the server to start. @@ -338,6 +338,11 @@ Controller API the :envvar:`AIOSMTPD_CONTROLLER_TIMEOUT` environment variable (converted to float), or the :attr:`ready_timeout` parameter. + Setting this to a high value will NOT slow down controller startup, + because it's a timeout limit rather than a sleep delay. + However, you may want to reduce the default value to something 'just enough' + so you don't have to wait too long for an exception, if problem arises. + If this timeout is breached, a :class:`TimeoutError` exception will be raised. .. attribute:: server @@ -430,7 +435,7 @@ Controller API hostname=None, port=8025, \ loop=None, \ *, \ - ready_timeout=1.0, \ + ready_timeout=3.0, \ ssl_context=None, \ server_hostname=None, server_kwargs=None, **SMTP_parameters) @@ -488,7 +493,7 @@ Controller API unix_socket, \ loop=None, \ *, \ - ready_timeout=1.0, \ + ready_timeout=3.0, \ ssl_context=None, \ server_hostname=None,\ **SMTP_parameters)
aio-libs/aiosmtpd
9c2a13eac52c6c293335b45c7c644ebc794a6905
diff --git a/aiosmtpd/tests/test_proxyprotocol.py b/aiosmtpd/tests/test_proxyprotocol.py index 3e8fb9a..bf7f939 100644 --- a/aiosmtpd/tests/test_proxyprotocol.py +++ b/aiosmtpd/tests/test_proxyprotocol.py @@ -38,7 +38,7 @@ from aiosmtpd.smtp import Session as SMTPSession from aiosmtpd.tests.conftest import Global, controller_data, handler_data DEFAULT_AUTOCANCEL = 0.1 -TIMEOUT_MULTIPLIER = 1.5 +TIMEOUT_MULTIPLIER = 2.0 param = pytest.param parametrize = pytest.mark.parametrize diff --git a/aiosmtpd/tests/test_server.py b/aiosmtpd/tests/test_server.py index a271243..99c5630 100644 --- a/aiosmtpd/tests/test_server.py +++ b/aiosmtpd/tests/test_server.py @@ -123,7 +123,11 @@ class TestController: @pytest.mark.filterwarnings("ignore") def test_ready_timeout(self): cont = SlowStartController(Sink()) - expectre = r"SMTP server failed to start within allotted time" + expectre = ( + "SMTP server failed to start within allotted time. " + "This might happen if the system is too busy. " + "Try increasing the `ready_timeout` parameter." + ) try: with pytest.raises(TimeoutError, match=expectre): cont.start() @@ -133,7 +137,11 @@ class TestController: @pytest.mark.filterwarnings("ignore") def test_factory_timeout(self): cont = SlowFactoryController(Sink()) - expectre = r"SMTP server not responding within allotted time" + expectre = ( + r"SMTP server started, but not responding within allotted time. " + r"This might happen if the system is too busy. " + r"Try increasing the `ready_timeout` parameter." + ) try: with pytest.raises(TimeoutError, match=expectre): cont.start()
TimeoutError: SMTP server not responding within allotted time Hello, I have similar problem. My project [msztolcman/sendria](https://github.com/msztolcman/sendria) is using `aiosmtpd` to handle incoming smtp connections. It works fine with `aiosmtpd` 1.2.2, but after upgrade to 1.4.1 I have: ```bash % sendria --db db.sqlite -d -a 2021-03-05T12:36:02.487786Z no PID file specified; runnning in foreground 2021-03-05T12:36:02.487885Z starting Sendria db=/Users/mysz/Projects/sendria/db.sqlite debug=enabled foreground=true pidfile=None 2021-03-05T12:36:02.491769Z DB initialized 2021-03-05T12:36:02.492011Z webhooks disabled Traceback (most recent call last): File "/Users/mysz/Projects/sendria/.venv/bin/sendria", line 33, in <module> sys.exit(load_entry_point('sendria', 'console_scripts', 'sendria')()) File "/Users/mysz/Projects/sendria/sendria/cli.py", line 296, in main run_sendria_servers(loop, args) File "/Users/mysz/Projects/sendria/sendria/cli.py", line 176, in run_sendria_servers smtp.run(args.smtp_ip, args.smtp_port, args.smtp_auth, args.smtp_ident, args.debug) File "/Users/mysz/Projects/sendria/sendria/smtp.py", line 69, in run controller.start() File "/Users/mysz/Projects/sendria/.venv/lib/python3.9/site-packages/aiosmtpd/controller.py", line 225, in start raise TimeoutError("SMTP server not responding within allotted time") TimeoutError: SMTP server not responding within allotted time ``` Platform data: ```bash % python --version Python 3.9.1 % uname -s Darwin ```
0.0
9c2a13eac52c6c293335b45c7c644ebc794a6905
[ "aiosmtpd/tests/test_server.py::TestController::test_ready_timeout", "aiosmtpd/tests/test_server.py::TestController::test_factory_timeout" ]
[ "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_invalid_version", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_invalid_error", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_invalid_protocol", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_mismatch", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_mismatch_raises", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_unsetkey", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_unknownkey", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_unknownkey_raises", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_tlv_none", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_tlv_fake", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyData::test_tlv_1", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_1", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_1_ne", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_1_ne_raises", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_2", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[1-ALPN]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[2-AUTHORITY]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[3-CRC32C]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[4-NOOP]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[5-UNIQUE_ID]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[32-SSL]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[33-SSL_VERSION]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[34-SSL_CN]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[35-SSL_CIPHER]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[36-SSL_SIG_ALG]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[37-SSL_KEY_ALG]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[48-NETNS]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_backmap[None-wrongname]", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_parse_partial", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_unknowntype_notstrict", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_unknowntype_strict", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_malformed_ssl_partialok", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_malformed_ssl_notpartialok", "aiosmtpd/tests/test_proxyprotocol.py::TestProxyTLV::test_eq", "aiosmtpd/tests/test_proxyprotocol.py::TestModule::test_get[v1]", "aiosmtpd/tests/test_proxyprotocol.py::TestModule::test_get[v2]", "aiosmtpd/tests/test_proxyprotocol.py::TestModule::test_get_cut_v1", "aiosmtpd/tests/test_proxyprotocol.py::TestModule::test_get_cut_v2", "aiosmtpd/tests/test_proxyprotocol.py::TestModule::test_get_invalid_sig", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_value_error[-1]", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_value_error[-1.0]", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_value_error[0]", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_value_error[0.0]", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_lt_3", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_ge_3[3]", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_ge_3[3.0]", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_ge_3[4]", "aiosmtpd/tests/test_proxyprotocol.py::TestSMTPInit::test_ge_3[4.0]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_noproxy", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_valid_patterns[joaoreis81]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_valid_patterns[haproxydoc]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_valid_patterns[cloudflare4]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_valid_patterns[cloudflare6]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_valid_patterns[avinetworks]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_valid_patterns[googlecloud]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_tcp4", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_tcp4_random", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_tcp6_shortened", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_tcp6_random", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_unknown", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_unknown_short", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_invalid_sig", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_unsupported_family", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_unsupported_proto", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_too_long", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_nocr", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_notproxy", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_wrongtype_64", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_wrongtype_46", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_wrongtype_6mixed", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr[zeroleader]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr[space1]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr[space2]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr[space3]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr[space4]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr[addr6s]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr[addr6d]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_extra[space]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_extra[sptext]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_malformed_addr4", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_ports_oob", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV1::test_portd_oob", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_1", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_UNSPEC_empty", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_UNSPEC_notempty", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET4[PROTO.STREAM-]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET4[PROTO.STREAM-fake_tlv]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET4[PROTO.DGRAM-]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET4[PROTO.DGRAM-fake_tlv]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET6[PROTO.STREAM-]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET6[PROTO.STREAM-fake_tlv]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET6[PROTO.DGRAM-]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_INET6[PROTO.DGRAM-fake_tlv]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_UNIX[PROTO.STREAM-]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_UNIX[PROTO.STREAM-fake_tlv]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_UNIX[PROTO.DGRAM-]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_UNIX[PROTO.DGRAM-fake_tlv]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_fallback_UNSPEC[AF.UNSPEC-PROTO.STREAM]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_fallback_UNSPEC[AF.UNSPEC-PROTO.DGRAM]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_fallback_UNSPEC[AF.INET-PROTO.UNSPEC]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_fallback_UNSPEC[AF.INET6-PROTO.UNSPEC]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_fallback_UNSPEC[AF.UNIX-PROTO.UNSPEC]", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_invalid_sig", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_illegal_ver", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_unsupported_cmd", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_unsupported_fam", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_unsupported_proto", "aiosmtpd/tests/test_proxyprotocol.py::TestGetV2::test_wrong_proto_6shouldbe4", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_okay[v1]", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_okay[v2]", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_hiccup[v1]", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_hiccup[v2]", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_timeout[v1]", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_timeout[v2]", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_incomplete[v1]", "aiosmtpd/tests/test_proxyprotocol.py::TestWithController::test_incomplete[v2]", "aiosmtpd/tests/test_proxyprotocol.py::TestHandlerAcceptReject::test_simple[v1-True]", "aiosmtpd/tests/test_proxyprotocol.py::TestHandlerAcceptReject::test_simple[v1-False]", "aiosmtpd/tests/test_proxyprotocol.py::TestHandlerAcceptReject::test_simple[v2-True]", "aiosmtpd/tests/test_proxyprotocol.py::TestHandlerAcceptReject::test_simple[v2-False]", "aiosmtpd/tests/test_server.py::TestServer::test_smtp_utf8", "aiosmtpd/tests/test_server.py::TestServer::test_default_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_special_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_warn_authreq_notls", "aiosmtpd/tests/test_server.py::TestController::test_reuse_loop", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_dupe", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_default", "aiosmtpd/tests/test_server.py::TestController::test_server_attribute", "aiosmtpd/tests/test_server.py::TestController::test_enablesmtputf8_flag", "aiosmtpd/tests/test_server.py::TestController::test_serverhostname_arg", "aiosmtpd/tests/test_server.py::TestController::test_hostname_empty", "aiosmtpd/tests/test_server.py::TestController::test_hostname_none", "aiosmtpd/tests/test_server.py::TestController::test_testconn_raises", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_noipv6", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6yes", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6no[99]", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6no[97]", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6inuse", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_error", "aiosmtpd/tests/test_server.py::TestController::test_stop_default", "aiosmtpd/tests/test_server.py::TestController::test_stop_assert", "aiosmtpd/tests/test_server.py::TestController::test_stop_noassert", "aiosmtpd/tests/test_server.py::TestUnixSocketController::test_server_creation", "aiosmtpd/tests/test_server.py::TestUnixSocketController::test_server_creation_ssl", "aiosmtpd/tests/test_server.py::TestFactory::test_normal_situation", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_direct", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_inkwargs", "aiosmtpd/tests/test_server.py::TestFactory::test_factory_none", "aiosmtpd/tests/test_server.py::TestFactory::test_noexc_smtpd_missing", "aiosmtpd/tests/test_server.py::TestCompat::test_version" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2021-03-06 06:36:02+00:00
apache-2.0
963
aio-libs__aiosmtpd-309
diff --git a/aiosmtpd/controller.py b/aiosmtpd/controller.py index 075d74b..8a336d9 100644 --- a/aiosmtpd/controller.py +++ b/aiosmtpd/controller.py @@ -79,6 +79,24 @@ def get_localhost() -> Literal["::1", "127.0.0.1"]: raise +def _server_to_client_ssl_ctx(server_ctx: ssl.SSLContext) -> ssl.SSLContext: + """ + Given an SSLContext object with TLS_SERVER_PROTOCOL return a client + context that can connect to the server. + """ + client_ctx = ssl.create_default_context(purpose=ssl.Purpose.SERVER_AUTH) + client_ctx.options = server_ctx.options + client_ctx.check_hostname = False + # We do not verify the ssl cert for the server here simply because this + # is a local connection to poke at the server for it to do its lazy + # initialization sequence. The only purpose of this client context + # is to make a connection to the *local* server created using the same + # code. That is also the reason why we disable cert verification below + # and the flake8 check for the same. + client_ctx.verify_mode = ssl.CERT_NONE # noqa: DUO122 + return client_ctx + + class _FakeServer(asyncio.StreamReaderProtocol): """ Returned by _factory_invoker() in lieu of an SMTP instance in case @@ -425,7 +443,8 @@ class InetMixin(BaseController, metaclass=ABCMeta): with ExitStack() as stk: s = stk.enter_context(create_connection((hostname, self.port), 1.0)) if self.ssl_context: - s = stk.enter_context(self.ssl_context.wrap_socket(s)) + client_ctx = _server_to_client_ssl_ctx(self.ssl_context) + s = stk.enter_context(client_ctx.wrap_socket(s)) s.recv(1024) @@ -467,7 +486,8 @@ class UnixSocketMixin(BaseController, metaclass=ABCMeta): # pragma: no-unixsock s: makesock = stk.enter_context(makesock(AF_UNIX, SOCK_STREAM)) s.connect(self.unix_socket) if self.ssl_context: - s = stk.enter_context(self.ssl_context.wrap_socket(s)) + client_ctx = _server_to_client_ssl_ctx(self.ssl_context) + s = stk.enter_context(client_ctx.wrap_socket(s)) s.recv(1024) diff --git a/setup.cfg b/setup.cfg index 9f16d3a..63ae3a8 100644 --- a/setup.cfg +++ b/setup.cfg @@ -25,6 +25,7 @@ classifiers = Programming Language :: Python :: 3.7 Programming Language :: Python :: 3.8 Programming Language :: Python :: 3.9 + Programming Language :: Python :: 3.10 Programming Language :: Python :: Implementation :: CPython Programming Language :: Python :: Implementation :: PyPy Topic :: Communications :: Email :: Mail Transport Agents
aio-libs/aiosmtpd
73c3a0c46481bbe916885584fb1063bf609e7653
diff --git a/.github/workflows/unit-testing-and-coverage.yml b/.github/workflows/unit-testing-and-coverage.yml index e17be25..8d4d2ef 100644 --- a/.github/workflows/unit-testing-and-coverage.yml +++ b/.github/workflows/unit-testing-and-coverage.yml @@ -89,7 +89,7 @@ jobs: fail-fast: false matrix: os: [ "macos-10.15", "ubuntu-18.04", "ubuntu-20.04", "windows-latest" ] - python-version: [ "3.6", "3.7", "3.8", "3.9", "pypy3.6" ] + python-version: [ "3.6", "3.7", "3.8", "3.9", "3.10", "pypy3.6" ] runs-on: ${{ matrix.os }} timeout-minutes: 15 # Slowest so far is pypy3 on MacOS, taking almost 7m steps: diff --git a/aiosmtpd/tests/test_server.py b/aiosmtpd/tests/test_server.py index 0449310..bda6d3b 100644 --- a/aiosmtpd/tests/test_server.py +++ b/aiosmtpd/tests/test_server.py @@ -28,6 +28,7 @@ from aiosmtpd.controller import ( UnixSocketUnthreadedController, _FakeServer, get_localhost, + _server_to_client_ssl_ctx, ) from aiosmtpd.handlers import Sink from aiosmtpd.smtp import SMTP as Server @@ -101,7 +102,10 @@ def safe_socket_dir() -> Generator[Path, None, None]: def assert_smtp_socket(controller: UnixSocketMixin) -> bool: assert Path(controller.unix_socket).exists() sockfile = controller.unix_socket - ssl_context = controller.ssl_context + if controller.ssl_context: + ssl_context = _server_to_client_ssl_ctx(controller.ssl_context) + else: + ssl_context = None with ExitStack() as stk: sock: socket.socket = stk.enter_context( socket.socket(socket.AF_UNIX, socket.SOCK_STREAM) diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index 69a0871..0907d37 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -1946,12 +1946,16 @@ class TestAuthArgs: def test_warn_authreqnotls(self, caplog): with pytest.warns(UserWarning) as record: _ = Server(Sink(), auth_required=True, auth_require_tls=False) - assert len(record) == 1 - assert ( - record[0].message.args[0] - == "Requiring AUTH while not requiring TLS can lead to " - "security vulnerabilities!" - ) + for warning in record: + if warning.message.args and ( + warning.message.args[0] + == "Requiring AUTH while not requiring TLS can lead to " + "security vulnerabilities!" + ): + break + else: + pytest.xfail("Did not raise expected warning") + assert caplog.record_tuples[0] == ( "mail.log", logging.WARNING,
aiosmtpd test suite fails on Python 3.10 While trying to build aiosmtpd 1.4.2 on Fedora for Python 3.10 (as part of [upgrading to Python 3.10 for Fedora Linux 35](https://fedoraproject.org/wiki/Changes/Python3.10)), aiosmtpd failed to build because the test suite fails: ``` =========================== short test summary info ============================ FAILED aiosmtpd/tests/test_server.py::TestUnixSocketController::test_server_creation_ssl FAILED aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[login-False] FAILED aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls - as... ERROR aiosmtpd/tests/test_smtps.py::TestSMTPS::test_smtps - ssl.SSLError: Can... ERROR aiosmtpd/tests/test_starttls.py::TestNoTLS::test_disabled_tls - OSError... ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_help_starttls - OSE... ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_starttls_arg - OSEr... ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_starttls - OSError:... ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_starttls_quit - OSE... ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_failed_handshake - ... ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_tls_handshake_stopcontroller ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_tls_bad_syntax - OS... ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_help_after_starttls ERROR aiosmtpd/tests/test_starttls.py::TestStartTLS::test_helo_starttls - OSE... ERROR aiosmtpd/tests/test_starttls.py::TestTLSEnding::test_eof_received - OSE... ERROR aiosmtpd/tests/test_starttls.py::TestTLSEnding::test_tls_handshake_failing ERROR aiosmtpd/tests/test_starttls.py::TestTLSForgetsSessionData::test_forget_ehlo ERROR aiosmtpd/tests/test_starttls.py::TestTLSForgetsSessionData::test_forget_mail ERROR aiosmtpd/tests/test_starttls.py::TestTLSForgetsSessionData::test_forget_rcpt ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_helo_fails - OSEr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_help_fails - OSEr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_ehlo - OSError: [... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_mail_fails - OSEr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_rcpt_fails - OSEr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_vrfy_fails - OSEr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_data_fails - OSEr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_noop_okay - OSErr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLS::test_quit_okay - OSErr... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLSAUTH::test_auth_notls - ... ERROR aiosmtpd/tests/test_starttls.py::TestRequireTLSAUTH::test_auth_tls - OS... = 3 failed, 521 passed, 1 skipped, 113 warnings, 27 errors in 186.09s (0:03:06) = ``` Most of it is the test suite returning `OSError: [Errno 98] error while attempting to bind on address ('127.0.0.1', 8025): address already in use`, but there are other errors too... Full build log: [python-aiosmtpd-1.4.2-3.fc35-build.log.txt](https://github.com/aio-libs/aiosmtpd/files/6885253/python-aiosmtpd-1.4.2-3.fc35-build.log.txt) Reference Koji build task: https://koji.fedoraproject.org/koji/taskinfo?taskID=72467725 cc: @abompard, @hroncok
0.0
73c3a0c46481bbe916885584fb1063bf609e7653
[ "aiosmtpd/tests/test_server.py::TestServer::test_smtp_utf8", "aiosmtpd/tests/test_server.py::TestServer::test_default_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_special_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_warn_authreq_notls", "aiosmtpd/tests/test_server.py::TestController::test_ready_timeout", "aiosmtpd/tests/test_server.py::TestController::test_factory_timeout", "aiosmtpd/tests/test_server.py::TestController::test_reuse_loop", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_dupe", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_default", "aiosmtpd/tests/test_server.py::TestController::test_server_attribute", "aiosmtpd/tests/test_server.py::TestController::test_enablesmtputf8_flag", "aiosmtpd/tests/test_server.py::TestController::test_serverhostname_arg", "aiosmtpd/tests/test_server.py::TestController::test_hostname_empty", "aiosmtpd/tests/test_server.py::TestController::test_hostname_none", "aiosmtpd/tests/test_server.py::TestController::test_testconn_raises", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_noipv6", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6yes", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6no[99]", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6no[97]", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6inuse", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_error", "aiosmtpd/tests/test_server.py::TestController::test_stop_default", "aiosmtpd/tests/test_server.py::TestController::test_stop_assert", "aiosmtpd/tests/test_server.py::TestController::test_stop_noassert", "aiosmtpd/tests/test_server.py::TestUnixSocketController::test_server_creation", "aiosmtpd/tests/test_server.py::TestUnixSocketController::test_server_creation_ssl", "aiosmtpd/tests/test_server.py::TestUnthreaded::test_unixsocket", "aiosmtpd/tests/test_server.py::TestUnthreaded::test_inet_loopstop", "aiosmtpd/tests/test_server.py::TestUnthreaded::test_inet_contstop", "aiosmtpd/tests/test_server.py::TestFactory::test_normal_situation", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_direct", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_inkwargs", "aiosmtpd/tests/test_server.py::TestFactory::test_factory_none", "aiosmtpd/tests/test_server.py::TestFactory::test_noexc_smtpd_missing", "aiosmtpd/tests/test_server.py::TestCompat::test_version", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimiters", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary[\\x80FAIL\\r\\n]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary[\\x80", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_close_then_continue", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_args", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[HELO]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[EHLO]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[DATA]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[RSET]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[NOOP]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[QUIT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[VRFY]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[AUTH]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_esmtp[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_esmtp[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[DATA]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[2]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[3]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[4]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[5]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[6]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[7]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[8]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[9]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[10]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[11]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[12]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[13]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[14]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[15]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[16]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[17]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[18]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[19]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[20]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[21]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[22]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[23]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[24]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[25]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[26]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[27]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[28]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[29]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[30]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[31]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[32]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[33]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[34]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[35]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[36]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[37]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[38]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[39]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[nofrom]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[params_noesmtp]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[norm]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[extralead]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[extratail]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[missing]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[badsyntax]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[space]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_params_unrecognized", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_bpo27931fix_smtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noto]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[params]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noto]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[badparams]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[2]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[3]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[4]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[5]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[6]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[7]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[8]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[9]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[10]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[11]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[12]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[13]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[14]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[15]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[16]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[17]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[18]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[19]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[20]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[21]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[22]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[23]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[24]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[25]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[26]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[27]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[28]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[29]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[30]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[31]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[32]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[33]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[34]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[35]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[36]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[37]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[38]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[39]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[40]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[41]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[42]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_bpo27931fix_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_354", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_way_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTPNonDecoding::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_no_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_not_enough_values", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_already_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_individually", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_rset_maintain_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_loginteract_warning", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[GSSAPI]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[DIGEST-MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[CRAM-MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_custom_mechanism", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_disabled_mechanism", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[login-True]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[login-False]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[plain-True]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[plain-False]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_base64_length", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_too_many_values", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_empty", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_goodcreds_sanitized_log", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_no_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_abort", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login2_bad_base64", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login2_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_base64", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_empty_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_abort_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_abort_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_DENYFALSE", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_DENYMISSING", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_NONE", "aiosmtpd/tests/test_smtp.py::TestAuthenticator::test_success", "aiosmtpd/tests/test_smtp.py::TestAuthenticator::test_fail_withmesg", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_nomail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_norcpt_authenticated", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_multiple_connections_lost", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_data_line_too_long", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_double_count", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_leak", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_then_too_long_lines", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_line_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_lines_then_too_long_body", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_limitlocalpart", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command_2", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_sockclose_after_helo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo", "aiosmtpd/tests/test_smtp.py::TestTimeout::test_timeout", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_log_authmechanisms", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has.dot]", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has/slash]", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has\\\\backslash]", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_value_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_all_limit_15", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits_custom_default", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_bogus", "aiosmtpd/tests/test_smtp.py::TestSanitize::test_loginpassword", "aiosmtpd/tests/test_smtp.py::TestSanitize::test_authresult" ]
[]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2022-10-27 09:09:22+00:00
apache-2.0
964
aio-libs__aiosmtpd-311
diff --git a/aiosmtpd/controller.py b/aiosmtpd/controller.py index 075d74b..8a336d9 100644 --- a/aiosmtpd/controller.py +++ b/aiosmtpd/controller.py @@ -79,6 +79,24 @@ def get_localhost() -> Literal["::1", "127.0.0.1"]: raise +def _server_to_client_ssl_ctx(server_ctx: ssl.SSLContext) -> ssl.SSLContext: + """ + Given an SSLContext object with TLS_SERVER_PROTOCOL return a client + context that can connect to the server. + """ + client_ctx = ssl.create_default_context(purpose=ssl.Purpose.SERVER_AUTH) + client_ctx.options = server_ctx.options + client_ctx.check_hostname = False + # We do not verify the ssl cert for the server here simply because this + # is a local connection to poke at the server for it to do its lazy + # initialization sequence. The only purpose of this client context + # is to make a connection to the *local* server created using the same + # code. That is also the reason why we disable cert verification below + # and the flake8 check for the same. + client_ctx.verify_mode = ssl.CERT_NONE # noqa: DUO122 + return client_ctx + + class _FakeServer(asyncio.StreamReaderProtocol): """ Returned by _factory_invoker() in lieu of an SMTP instance in case @@ -425,7 +443,8 @@ class InetMixin(BaseController, metaclass=ABCMeta): with ExitStack() as stk: s = stk.enter_context(create_connection((hostname, self.port), 1.0)) if self.ssl_context: - s = stk.enter_context(self.ssl_context.wrap_socket(s)) + client_ctx = _server_to_client_ssl_ctx(self.ssl_context) + s = stk.enter_context(client_ctx.wrap_socket(s)) s.recv(1024) @@ -467,7 +486,8 @@ class UnixSocketMixin(BaseController, metaclass=ABCMeta): # pragma: no-unixsock s: makesock = stk.enter_context(makesock(AF_UNIX, SOCK_STREAM)) s.connect(self.unix_socket) if self.ssl_context: - s = stk.enter_context(self.ssl_context.wrap_socket(s)) + client_ctx = _server_to_client_ssl_ctx(self.ssl_context) + s = stk.enter_context(client_ctx.wrap_socket(s)) s.recv(1024) diff --git a/setup.cfg b/setup.cfg index 9f16d3a..63ae3a8 100644 --- a/setup.cfg +++ b/setup.cfg @@ -25,6 +25,7 @@ classifiers = Programming Language :: Python :: 3.7 Programming Language :: Python :: 3.8 Programming Language :: Python :: 3.9 + Programming Language :: Python :: 3.10 Programming Language :: Python :: Implementation :: CPython Programming Language :: Python :: Implementation :: PyPy Topic :: Communications :: Email :: Mail Transport Agents diff --git a/tox.ini b/tox.ini index e5ac6a3..678cd98 100644 --- a/tox.ini +++ b/tox.ini @@ -39,6 +39,7 @@ deps = pytest-print pytest-profiling pytest-sugar + py # needed for pytest-sugar as it doesn't declare dependency on it. diff_cover setenv = cov: COVERAGE_FILE={toxinidir}/_dump/.coverage @@ -108,12 +109,14 @@ commands = python -m flake8 aiosmtpd setup.py housekeep.py release.py check-manifest -v pytest -v --tb=short aiosmtpd/qa + pytype --keep-going --jobs auto . deps = colorama flake8 {[flake8_plugins]deps} pytest check-manifest + pytype [testenv:docs] basepython = python3
aio-libs/aiosmtpd
e0fb197e9a020a045f8d6d3ced2b28fa27e6df07
diff --git a/.github/workflows/unit-testing-and-coverage.yml b/.github/workflows/unit-testing-and-coverage.yml index eb8daa1..8d4d2ef 100644 --- a/.github/workflows/unit-testing-and-coverage.yml +++ b/.github/workflows/unit-testing-and-coverage.yml @@ -89,7 +89,7 @@ jobs: fail-fast: false matrix: os: [ "macos-10.15", "ubuntu-18.04", "ubuntu-20.04", "windows-latest" ] - python-version: [ "3.6", "3.7", "3.8", "3.9", "pypy3" ] + python-version: [ "3.6", "3.7", "3.8", "3.9", "3.10", "pypy3.6" ] runs-on: ${{ matrix.os }} timeout-minutes: 15 # Slowest so far is pypy3 on MacOS, taking almost 7m steps: @@ -98,7 +98,7 @@ jobs: with: fetch-depth: 0 # Required by codecov/codecov-action@v1 - name: "Set up Python ${{ matrix.python-version }}" - uses: actions/setup-python@v2 + uses: actions/setup-python@v4 with: python-version: ${{ matrix.python-version }} - name: "Install dependencies" diff --git a/aiosmtpd/tests/conftest.py b/aiosmtpd/tests/conftest.py index 859d5ef..6a8c3dd 100644 --- a/aiosmtpd/tests/conftest.py +++ b/aiosmtpd/tests/conftest.py @@ -71,7 +71,7 @@ class Global: # If less than 1.0, might cause intermittent error if test system # is too busy/overloaded. -AUTOSTOP_DELAY = 1.0 +AUTOSTOP_DELAY = 1.5 SERVER_CRT = resource_filename("aiosmtpd.tests.certs", "server.crt") SERVER_KEY = resource_filename("aiosmtpd.tests.certs", "server.key") diff --git a/aiosmtpd/tests/test_handlers.py b/aiosmtpd/tests/test_handlers.py index a20df9a..d48593c 100644 --- a/aiosmtpd/tests/test_handlers.py +++ b/aiosmtpd/tests/test_handlers.py @@ -821,7 +821,7 @@ class TestProxyMocked: if rt == ( logger_name, logging.INFO, - "we got some refusals: {'[email protected]': (-1, 'ignore')}", + "we got some refusals: {'[email protected]': (-1, b'ignore')}", ): break else: diff --git a/aiosmtpd/tests/test_server.py b/aiosmtpd/tests/test_server.py index 0449310..bda6d3b 100644 --- a/aiosmtpd/tests/test_server.py +++ b/aiosmtpd/tests/test_server.py @@ -28,6 +28,7 @@ from aiosmtpd.controller import ( UnixSocketUnthreadedController, _FakeServer, get_localhost, + _server_to_client_ssl_ctx, ) from aiosmtpd.handlers import Sink from aiosmtpd.smtp import SMTP as Server @@ -101,7 +102,10 @@ def safe_socket_dir() -> Generator[Path, None, None]: def assert_smtp_socket(controller: UnixSocketMixin) -> bool: assert Path(controller.unix_socket).exists() sockfile = controller.unix_socket - ssl_context = controller.ssl_context + if controller.ssl_context: + ssl_context = _server_to_client_ssl_ctx(controller.ssl_context) + else: + ssl_context = None with ExitStack() as stk: sock: socket.socket = stk.enter_context( socket.socket(socket.AF_UNIX, socket.SOCK_STREAM) diff --git a/aiosmtpd/tests/test_smtp.py b/aiosmtpd/tests/test_smtp.py index ce61af2..0907d37 100644 --- a/aiosmtpd/tests/test_smtp.py +++ b/aiosmtpd/tests/test_smtp.py @@ -7,6 +7,7 @@ import asyncio import itertools import logging import socket +import sys import time import warnings from asyncio.transports import Transport @@ -1060,7 +1061,12 @@ class TestAuthMechanisms(_CommonMethods): client.user = "goodlogin" client.password = PW auth_meth = getattr(client, "auth_" + mechanism) - if (mechanism, init_resp) == ("login", False): + if (mechanism, init_resp) == ("login", False) and ( + sys.version_info < (3, 8, 9) + or (3, 9, 0) < sys.version_info < (3, 9, 4)): + # The bug with SMTP.auth_login was fixed in Python 3.10 and backported + # to 3.9.4 and and 3.8.9. + # See https://github.com/python/cpython/pull/24118 for the fixes.: with pytest.raises(SMTPAuthenticationError): client.auth(mechanism, auth_meth, initial_response_ok=init_resp) client.docmd("*") @@ -1940,12 +1946,16 @@ class TestAuthArgs: def test_warn_authreqnotls(self, caplog): with pytest.warns(UserWarning) as record: _ = Server(Sink(), auth_required=True, auth_require_tls=False) - assert len(record) == 1 - assert ( - record[0].message.args[0] - == "Requiring AUTH while not requiring TLS can lead to " - "security vulnerabilities!" - ) + for warning in record: + if warning.message.args and ( + warning.message.args[0] + == "Requiring AUTH while not requiring TLS can lead to " + "security vulnerabilities!" + ): + break + else: + pytest.xfail("Did not raise expected warning") + assert caplog.record_tuples[0] == ( "mail.log", logging.WARNING,
testing: Allow running pytype using tox for local testing Currently, the qa job in Github Action used for CI doesn't match the 'qa' tox testenv and specifically skips the type checking using `pytype`. If there isn't a reason to _not_ run pytype locally, we should probably bridge that gap and add pytype for qa jobs and _maybe_ consider using tox as the source of truth and run tests using that even in CI?
0.0
e0fb197e9a020a045f8d6d3ced2b28fa27e6df07
[ "aiosmtpd/tests/test_handlers.py::TestDebugging::test_debugging", "aiosmtpd/tests/test_handlers.py::TestDebugging::test_debugging_bytes", "aiosmtpd/tests/test_handlers.py::TestDebugging::test_debugging_without_options", "aiosmtpd/tests/test_handlers.py::TestDebugging::test_debugging_with_options", "aiosmtpd/tests/test_handlers.py::TestMessage::test_prepare_message[bytes]", "aiosmtpd/tests/test_handlers.py::TestMessage::test_prepare_message[bytearray]", "aiosmtpd/tests/test_handlers.py::TestMessage::test_prepare_message[str]", "aiosmtpd/tests/test_handlers.py::TestMessage::test_prepare_message_err[None]", "aiosmtpd/tests/test_handlers.py::TestMessage::test_prepare_message_err[List]", "aiosmtpd/tests/test_handlers.py::TestMessage::test_prepare_message_err[Dict]", "aiosmtpd/tests/test_handlers.py::TestMessage::test_prepare_message_err[Tuple]", "aiosmtpd/tests/test_handlers.py::TestMessage::test_message", "aiosmtpd/tests/test_handlers.py::TestMessage::test_message_decoded", "aiosmtpd/tests/test_handlers.py::TestMessage::test_message_async", "aiosmtpd/tests/test_handlers.py::TestMessage::test_message_decoded_async", "aiosmtpd/tests/test_handlers.py::TestMailbox::test_mailbox", "aiosmtpd/tests/test_handlers.py::TestMailbox::test_mailbox_reset", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_no_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_two_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_stdout", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_stderr", "aiosmtpd/tests/test_handlers.py::TestCLI::test_debugging_bad_argument", "aiosmtpd/tests/test_handlers.py::TestCLI::test_sink_no_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_sink_any_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_mailbox_no_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_mailbox_too_many_args", "aiosmtpd/tests/test_handlers.py::TestCLI::test_mailbox", "aiosmtpd/tests/test_handlers.py::TestProxy::test_deliver_bytes", "aiosmtpd/tests/test_handlers.py::TestProxy::test_deliver_str", "aiosmtpd/tests/test_handlers.py::TestProxyMocked::test_recipients_refused", "aiosmtpd/tests/test_handlers.py::TestProxyMocked::test_oserror", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_HELO", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_EHLO_deprecated", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_EHLO_deprecated_warning", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_EHLO_new", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_EHLO_incompat[TooShort]", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_EHLO_incompat[TooLong]", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_MAIL", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_RCPT", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_DATA", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_AUTH", "aiosmtpd/tests/test_handlers.py::TestHooks::test_hook_NoHooks", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_process_message", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_process_message_async", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_ehlo_hook", "aiosmtpd/tests/test_handlers.py::TestDeprecation::test_rset_hook", "aiosmtpd/tests/test_server.py::TestServer::test_smtp_utf8", "aiosmtpd/tests/test_server.py::TestServer::test_default_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_special_max_command_size_limit", "aiosmtpd/tests/test_server.py::TestServer::test_warn_authreq_notls", "aiosmtpd/tests/test_server.py::TestController::test_ready_timeout", "aiosmtpd/tests/test_server.py::TestController::test_factory_timeout", "aiosmtpd/tests/test_server.py::TestController::test_reuse_loop", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_dupe", "aiosmtpd/tests/test_server.py::TestController::test_socket_error_default", "aiosmtpd/tests/test_server.py::TestController::test_server_attribute", "aiosmtpd/tests/test_server.py::TestController::test_enablesmtputf8_flag", "aiosmtpd/tests/test_server.py::TestController::test_serverhostname_arg", "aiosmtpd/tests/test_server.py::TestController::test_hostname_empty", "aiosmtpd/tests/test_server.py::TestController::test_hostname_none", "aiosmtpd/tests/test_server.py::TestController::test_testconn_raises", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_noipv6", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6yes", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6no[99]", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6no[97]", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_6inuse", "aiosmtpd/tests/test_server.py::TestController::test_getlocalhost_error", "aiosmtpd/tests/test_server.py::TestController::test_stop_default", "aiosmtpd/tests/test_server.py::TestController::test_stop_assert", "aiosmtpd/tests/test_server.py::TestController::test_stop_noassert", "aiosmtpd/tests/test_server.py::TestUnixSocketController::test_server_creation", "aiosmtpd/tests/test_server.py::TestUnixSocketController::test_server_creation_ssl", "aiosmtpd/tests/test_server.py::TestUnthreaded::test_unixsocket", "aiosmtpd/tests/test_server.py::TestUnthreaded::test_inet_loopstop", "aiosmtpd/tests/test_server.py::TestUnthreaded::test_inet_contstop", "aiosmtpd/tests/test_server.py::TestFactory::test_normal_situation", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_direct", "aiosmtpd/tests/test_server.py::TestFactory::test_unknown_args_inkwargs", "aiosmtpd/tests/test_server.py::TestFactory::test_factory_none", "aiosmtpd/tests/test_server.py::TestFactory::test_noexc_smtpd_missing", "aiosmtpd/tests/test_server.py::TestCompat::test_version", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_honors_mail_delimiters", "aiosmtpd/tests/test_smtp.py::TestProtocol::test_empty_email", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary[\\x80FAIL\\r\\n]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_binary[\\x80", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_close_then_continue", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_duplicate", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_no_hostname", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_helo_then_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_ehlo_then_helo", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_noop_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_quit_with_args", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[HELO]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[EHLO]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[DATA]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[RSET]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[NOOP]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[QUIT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[VRFY]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_[AUTH]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_esmtp[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_esmtp[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_help_bad_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_expn", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[MAIL]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[RCPT]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_no_helo[DATA]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[2]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[3]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[4]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[5]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[6]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[7]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[8]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[9]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[10]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[11]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[12]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[13]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[14]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[15]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[16]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[17]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[18]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[19]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[20]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[21]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[22]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[23]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[24]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[25]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[26]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[27]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[28]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[29]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[30]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[31]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[32]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[33]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[34]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[35]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[36]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[37]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[38]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_valid_address[39]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[nofrom]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[params_noesmtp]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_smtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[norm]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[extralead]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_params_esmtp[extratail]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_from_twice", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[missing]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[badsyntax]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_errsyntax[space]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_params_unrecognized", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_bpo27931fix_smtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_mail_esmtp_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_no_mail", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noto]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[params]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_smtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noarg]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noto]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[noaddr]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[badparams]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_esmtp_errsyntax[malformed]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_unknown_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[2]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[3]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[4]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[5]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[6]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[7]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[8]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[9]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[10]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[11]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[12]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[13]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[14]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[15]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[16]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[17]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[18]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[19]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[20]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[21]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[22]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[23]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[24]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[25]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[26]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[27]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[28]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[29]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[30]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[31]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[32]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[33]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[34]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[35]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[36]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[37]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[38]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[39]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[40]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[41]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_valid_address[42]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_invalid_address[0]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rcpt_invalid_address[1]", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_bpo27931fix_esmtp", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_rset_with_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_no_arg", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_vrfy_not_address", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_no_rcpt", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_354", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_data_invalid_params", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_empty_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_way_too_long_command", "aiosmtpd/tests/test_smtp.py::TestSMTP::test_unknown_command", "aiosmtpd/tests/test_smtp.py::TestSMTPNonDecoding::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_no_ehlo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_helo", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_not_enough_values", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_already_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_individually", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_rset_maintain_authenticated", "aiosmtpd/tests/test_smtp.py::TestSMTPAuth::test_auth_loginteract_warning", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[GSSAPI]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[DIGEST-MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_not_supported_mechanism[CRAM-MD5]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_custom_mechanism", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_disabled_mechanism", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[login-True]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[login-False]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[plain-True]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_byclient[plain-False]", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_base64_length", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_too_many_values", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_bad_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_empty", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain1_goodcreds_sanitized_log", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_bad_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_no_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_abort", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_plain2_bad_base64_encoding", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login2_bad_base64", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login2_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_good_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_base64", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_bad_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_empty_credentials", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_abort_username", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_login3_abort_password", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_DENYFALSE", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_DENYMISSING", "aiosmtpd/tests/test_smtp.py::TestAuthMechanisms::test_NONE", "aiosmtpd/tests/test_smtp.py::TestAuthenticator::test_success", "aiosmtpd/tests/test_smtp.py::TestAuthenticator::test_fail_withmesg", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_help_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_rcpt_nomail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_unauthenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_vrfy_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_mail_authenticated", "aiosmtpd/tests/test_smtp.py::TestRequiredAuthentication::test_data_norcpt_authenticated", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_helo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestResetCommands::test_rset", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_size_too_large", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_compatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_unrequited_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_with_incompatible_smtputf8", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_mail_invalid_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_esmtp_no_size_limit", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_process_message_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_message_body", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_dots_escaped", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_unhandled", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_unexpected_errors_custom_response", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_exception", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_undescribable", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_exception_handler_multiple_connections_lost", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_bad_encodings", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_data_line_too_long", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_double_count", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_long_line_leak", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_body_then_too_long_lines", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_line_delay_error", "aiosmtpd/tests/test_smtp.py::TestSMTPWithController::test_too_long_lines_then_too_long_body", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_custom_hostname", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_default_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_custom_greeting", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_mail_invalid_body_param", "aiosmtpd/tests/test_smtp.py::TestCustomization::test_limitlocalpart", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_DATA", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_during_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_connection_reset_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_command_2", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_long_command", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_close_in_data", "aiosmtpd/tests/test_smtp.py::TestClientCrash::test_sockclose_after_helo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_ehlo", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_bad_encoded_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_mail_param", "aiosmtpd/tests/test_smtp.py::TestStrictASCII::test_data", "aiosmtpd/tests/test_smtp.py::TestSleepingHandler::test_close_after_helo", "aiosmtpd/tests/test_smtp.py::TestTimeout::test_timeout", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_warn_authreqnotls", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_log_authmechanisms", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has.dot]", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has/slash]", "aiosmtpd/tests/test_smtp.py::TestAuthArgs::test_authmechname_decorator_badname[has\\\\backslash]", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_wrong_value_type", "aiosmtpd/tests/test_smtp.py::TestLimits::test_all_limit_15", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits", "aiosmtpd/tests/test_smtp.py::TestLimits::test_different_limits_custom_default", "aiosmtpd/tests/test_smtp.py::TestLimits::test_limit_bogus", "aiosmtpd/tests/test_smtp.py::TestSanitize::test_loginpassword", "aiosmtpd/tests/test_smtp.py::TestSanitize::test_authresult" ]
[]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2022-10-31 08:26:51+00:00
apache-2.0
965
aio-libs__multidict-100
diff --git a/CHANGES.rst b/CHANGES.rst index 322e475..f8edd45 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -1,3 +1,9 @@ +3.1.0 (2017-xx-xx) +------------------ + +* Fix #99: raise `RuntimeError` on dict iterations if the dict was changed + + 3.0.0 (2017-06-21) ------------------ diff --git a/multidict/_multidict.pyx b/multidict/_multidict.pyx index 64961d0..2c74af8 100644 --- a/multidict/_multidict.pyx +++ b/multidict/_multidict.pyx @@ -638,16 +638,20 @@ cdef class _ItemsIter: cdef _Impl _impl cdef int _current cdef int _len + cdef unsigned long long _version def __cinit__(self, _Impl impl): self._impl = impl self._current = 0 - self._len = len(self._impl._items) + self._version = impl._version + self._len = len(impl._items) def __iter__(self): return self def __next__(self): + if self._version != self._impl._version: + raise RuntimeError("Dictionary changed during iteration") if self._current == self._len: raise StopIteration item = <_Pair>self._impl._items[self._current] @@ -700,16 +704,20 @@ cdef class _ValuesIter: cdef _Impl _impl cdef int _current cdef int _len + cdef unsigned long long _version def __cinit__(self, _Impl impl): self._impl = impl self._current = 0 - self._len = len(self._impl._items) + self._len = len(impl._items) + self._version = impl._version def __iter__(self): return self def __next__(self): + if self._version != self._impl._version: + raise RuntimeError("Dictionary changed during iteration") if self._current == self._len: raise StopIteration item = <_Pair>self._impl._items[self._current] @@ -747,16 +755,20 @@ cdef class _KeysIter: cdef _Impl _impl cdef int _current cdef int _len + cdef unsigned long long _version def __cinit__(self, _Impl impl): self._impl = impl self._current = 0 self._len = len(self._impl._items) + self._version = impl._version def __iter__(self): return self def __next__(self): + if self._version != self._impl._version: + raise RuntimeError("Dictionary changed during iteration") if self._current == self._len: raise StopIteration item = <_Pair>self._impl._items[self._current] diff --git a/multidict/_multidict_py.py b/multidict/_multidict_py.py index 8249211..89382cf 100644 --- a/multidict/_multidict_py.py +++ b/multidict/_multidict_py.py @@ -375,6 +375,7 @@ class _ViewBase: def __init__(self, impl): self._impl = impl + self._version = impl._version def __len__(self): return len(self._impl._items) @@ -392,6 +393,8 @@ class _ItemsView(_ViewBase, abc.ItemsView): def __iter__(self): for i, k, v in self._impl._items: + if self._version != self._impl._version: + raise RuntimeError("Dictionary changed during iteration") yield k, v def __repr__(self): @@ -412,6 +415,8 @@ class _ValuesView(_ViewBase, abc.ValuesView): def __iter__(self): for item in self._impl._items: + if self._version != self._impl._version: + raise RuntimeError("Dictionary changed during iteration") yield item[2] def __repr__(self): @@ -432,6 +437,8 @@ class _KeysView(_ViewBase, abc.KeysView): def __iter__(self): for item in self._impl._items: + if self._version != self._impl._version: + raise RuntimeError("Dictionary changed during iteration") yield item[1] def __repr__(self):
aio-libs/multidict
e7f2044f87d1ba1b5275ad61297ad0e59cb9aa40
diff --git a/tests/test_guard.py b/tests/test_guard.py new file mode 100644 index 0000000..eb48064 --- /dev/null +++ b/tests/test_guard.py @@ -0,0 +1,34 @@ +import pytest + +from multidict._multidict import MultiDict +from multidict._multidict_py import MultiDict as PyMultiDict + + [email protected](params=[MultiDict, PyMultiDict], + ids=['MultiDict', 'PyMultiDict']) +def cls(request): + return request.param + + +def test_guard_items(cls): + md = cls({'a': 'b'}) + it = iter(md.items()) + md['a'] = 'c' + with pytest.raises(RuntimeError): + next(it) + + +def test_guard_keys(cls): + md = cls({'a': 'b'}) + it = iter(md.keys()) + md['a'] = 'c' + with pytest.raises(RuntimeError): + next(it) + + +def test_guard_values(cls): + md = cls({'a': 'b'}) + it = iter(md.values()) + md['a'] = 'c' + with pytest.raises(RuntimeError): + next(it)
Guard iterations Iteration over keys, items and values should raise `RuntimeError` if dict is changed.
0.0
e7f2044f87d1ba1b5275ad61297ad0e59cb9aa40
[ "tests/test_guard.py::test_guard_items[PyMultiDict]", "tests/test_guard.py::test_guard_keys[PyMultiDict]", "tests/test_guard.py::test_guard_values[PyMultiDict]" ]
[]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2017-06-24 16:08:23+00:00
apache-2.0
966
aio-libs__multidict-203
diff --git a/multidict/_multidict_py.py b/multidict/_multidict_py.py index b698e25..62eaca2 100644 --- a/multidict/_multidict_py.py +++ b/multidict/_multidict_py.py @@ -243,7 +243,7 @@ class MultiDict(_Base, MutableMultiMapping): method(items) - method([(self._title(key), key, value) + method([(self._title(key), self._key(key), value) for key, value in kwargs.items()]) def _extend_items(self, items): @@ -258,15 +258,14 @@ class MultiDict(_Base, MutableMultiMapping): # Mapping interface # def __setitem__(self, key, value): - key = self._title(key) self._replace(key, value) def __delitem__(self, key): - key = self._title(key) + identity = self._title(key) items = self._impl._items found = False for i in range(len(items) - 1, -1, -1): - if items[i][0] == key: + if items[i][0] == identity: del items[i] found = True if not found: @@ -276,9 +275,9 @@ class MultiDict(_Base, MutableMultiMapping): def setdefault(self, key, default=None): """Return value for key, set value to default if key is not present.""" - key = self._title(key) + identity = self._title(key) for i, k, v in self._impl._items: - if i == key: + if i == identity: return v self.add(key, default) return default @@ -290,9 +289,9 @@ class MultiDict(_Base, MutableMultiMapping): KeyError is raised. """ - key = self._title(key) + identity = self._title(key) for i in range(len(self._impl._items)): - if self._impl._items[i][0] == key: + if self._impl._items[i][0] == identity: value = self._impl._items[i][2] del self._impl._items[i] self._impl.incr_version()
aio-libs/multidict
4b799356a42ea80b44b2f63cb707cfbca145a02c
diff --git a/tests/test_multidict.py b/tests/test_multidict.py index b8a3391..85f4cc2 100644 --- a/tests/test_multidict.py +++ b/tests/test_multidict.py @@ -118,9 +118,9 @@ class BaseMultiDictTest: assert d.get('key') == 'value1' assert d['key'] == 'value1' - with pytest.raises(KeyError, matches='key2'): + with pytest.raises(KeyError, match='key2'): d['key2'] - with pytest.raises(KeyError, matches='key2'): + with pytest.raises(KeyError, match='key2'): d.getone('key2') assert d.getone('key2', 'default') == 'default' @@ -326,7 +326,7 @@ class TestMultiDict(BaseMultiDictTest): assert d.getall('key') == ['value1', 'value2'] - with pytest.raises(KeyError, matches='some_key'): + with pytest.raises(KeyError, match='some_key'): d.getall('some_key') default = object() @@ -374,9 +374,9 @@ class TestCIMultiDict(BaseMultiDictTest): assert d['key'] == 'value1' assert 'key' in d - with pytest.raises(KeyError): + with pytest.raises(KeyError, match='key2'): d['key2'] - with pytest.raises(KeyError): + with pytest.raises(KeyError, match='key2'): d.getone('key2') def test_getall(self, cls): @@ -387,9 +387,8 @@ class TestCIMultiDict(BaseMultiDictTest): assert d.getall('key') == ['value1', 'value2'] - with pytest.raises(KeyError) as excinfo: + with pytest.raises(KeyError, match='some_key'): d.getall('some_key') - assert "some_key" in str(excinfo.value) def test_get(self, cls): d = cls([('A', 1), ('a', 2)]) diff --git a/tests/test_mutable_multidict.py b/tests/test_mutable_multidict.py index bab9270..b6bf60d 100644 --- a/tests/test_mutable_multidict.py +++ b/tests/test_mutable_multidict.py @@ -37,9 +37,8 @@ class TestMutableMultiDict: assert d.getall('key') == ['value1', 'value2'] - with pytest.raises(KeyError) as excinfo: + with pytest.raises(KeyError, match='some_key'): d.getall('some_key') - assert 'some_key' in str(excinfo.value) default = object() assert d.getall('some_key', default) is default @@ -116,7 +115,7 @@ class TestMutableMultiDict: assert d == {'foo': 'bar'} assert list(d.items()) == [('foo', 'bar')] - with pytest.raises(KeyError): + with pytest.raises(KeyError, match='key'): del d['key'] def test_set_default(self, cls): @@ -166,7 +165,7 @@ class TestMutableMultiDict: def test_pop_raises(self, cls): d = cls(other='val') - with pytest.raises(KeyError): + with pytest.raises(KeyError, match='key'): d.pop('key') assert 'other' in d @@ -218,7 +217,7 @@ class TestMutableMultiDict: def test_popall_key_error(self, cls): d = cls() - with pytest.raises(KeyError): + with pytest.raises(KeyError, match='key'): d.popall('key') @@ -244,18 +243,19 @@ class TestCIMutableMultiDict: assert d.getall('key') == ['value1', 'value2'] - with pytest.raises(KeyError) as excinfo: + with pytest.raises(KeyError, match='some_key'): d.getall('some_key') - assert 'some_key' in str(excinfo.value) def test_ctor(self, cls): d = cls(k1='v1') assert 'v1' == d['K1'] + assert ('k1', 'v1') in d.items() def test_setitem(self, cls): d = cls() d['k1'] = 'v1' assert 'v1' == d['K1'] + assert ('k1', 'v1') in d.items() def test_delitem(self, cls): d = cls() @@ -269,6 +269,7 @@ class TestCIMutableMultiDict: d2 = d1.copy() assert d1 == d2 + assert d1.items() == d2.items() assert d1 is not d2 def test__repr__(self, cls): @@ -285,18 +286,22 @@ class TestCIMutableMultiDict: assert d == {} d['KEY'] = 'one' + assert ('KEY', 'one') in d.items() assert d == cls({'Key': 'one'}) assert d.getall('key') == ['one'] d['KEY'] = 'two' + assert ('KEY', 'two') in d.items() assert d == cls({'Key': 'two'}) assert d.getall('key') == ['two'] d.add('KEY', 'one') + assert ('KEY', 'one') in d.items() assert 2 == len(d) assert d.getall('key') == ['two', 'one'] d.add('FOO', 'bar') + assert ('FOO', 'bar') in d.items() assert 3 == len(d) assert d.getall('foo') == ['bar'] @@ -353,7 +358,7 @@ class TestCIMutableMultiDict: assert d == {'foo': 'bar'} assert list(d.items()) == [('foo', 'bar')] - with pytest.raises(KeyError): + with pytest.raises(KeyError, match='key'): del d['key'] def test_set_default(self, cls): @@ -361,6 +366,7 @@ class TestCIMutableMultiDict: assert 'one' == d.setdefault('key', 'three') assert 'three' == d.setdefault('otherkey', 'three') assert 'otherkey' in d + assert ('otherkey', 'three') in d.items() assert 'three' == d['OTHERKEY'] def test_popitem(self, cls): @@ -404,7 +410,7 @@ class TestCIMutableMultiDict: def test_pop_raises(self, cls): d = cls(OTHER='val') - with pytest.raises(KeyError): + with pytest.raises(KeyError, match="KEY"): d.pop('KEY') assert 'other' in d
Cython and Python versions of CIMultiDict treat key case differently First noticed this in 3.3.2 (probably existed before that), still exists in 4.0.0: As one would expect (IMO) the Cython version uses the title-ized key for matching and preserves the original key for output/serialization. The Python version throws away the original key completely and uses the title-ized key for both purposes, breaking output. Again, that's my opinion, but in any case, the behavior should be the same. ```python In [1]: from multidict._multidict import CIMultiDict # Cython In [2]: md = CIMultiDict() ...: md['some_key'] = 1 ...: list(md.items()) ...: Out[2]: [('some_key', 1)] # outputs original key In [3]: from multidict._multidict_py import CIMultiDict # Python In [4]: md = CIMultiDict() ...: md['some_key'] = 1 ...: list(md.items()) ...: Out[4]: [('Some_Key', 1)] # outputs title-ized key ```
0.0
4b799356a42ea80b44b2f63cb707cfbca145a02c
[ "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_setitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_del[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_set_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_raises[multidict._multidict_py]" ]
[ "tests/test_multidict.py::test_exposed_names[multidict._multidict-MultiDict]", "tests/test_multidict.py::test_exposed_names[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::test__iter__types[multidict._multidict-MultiDict-str]", "tests/test_multidict.py::test__iter__types[multidict._multidict-cls1-str]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict-MultiDict-MultiDictProxy]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict-CIMultiDict-CIMultiDictProxy]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-MultiDict-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-MultiDict-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-MultiDict-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-MultiDict-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-cls1-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-cls1-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-CIMultiDict-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-CIMultiDict-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-CIMultiDict-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-CIMultiDict-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-cls1-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-cls1-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict-cls1]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_copy[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test__repr__[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_getall[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend_from_proxy[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_clear[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_del[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_set_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem_empty_multidict[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop2[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_raises[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_replacement_order[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_nonstr_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_key_error[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_getall[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_ctor[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_setitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_delitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test__repr__[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_from_proxy[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_clear[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_del[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_set_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem_empty_multidict[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_lowercase[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_raises[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_with_istr[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy_istr[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_eq[multidict._multidict]", "tests/test_multidict.py::test_exposed_names[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::test_exposed_names[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::test__iter__types[multidict._multidict_py-MultiDict-str]", "tests/test_multidict.py::test__iter__types[multidict._multidict_py-cls1-str]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict_py-MultiDict-MultiDictProxy]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict_py-CIMultiDict-CIMultiDictProxy]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-MultiDict-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-MultiDict-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_and[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_and[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_and2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_and2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_or[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_or[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_or2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_or2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_sub[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_sub[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_sub2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_sub2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_xor[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_xor[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_xor2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_xor2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-MultiDict-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-MultiDict-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-or_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-and_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-sub]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-xor]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-or_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-and_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-sub]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-xor]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-CIMultiDict-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-CIMultiDict-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_and[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_and[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_and2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_and2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_or[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_or[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_or2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_or2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_sub[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_sub[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_sub2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_sub2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_xor[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_xor[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_xor2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_xor2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-CIMultiDict-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-CIMultiDict-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-or_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-and_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-sub]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-xor]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-or_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-and_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-sub]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-xor]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict_py-cls1]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_copy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test__repr__[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_getall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend_from_proxy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_clear[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_del[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_set_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem_empty_multidict[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop2[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_raises[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_replacement_order[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_nonstr_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_key_error[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_getall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_ctor[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_delitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test__repr__[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_from_proxy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_clear[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem_empty_multidict[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_lowercase[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_with_istr[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy_istr[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_eq[multidict._multidict_py]" ]
{ "failed_lite_validators": [ "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2018-01-28 06:12:44+00:00
apache-2.0
967
aio-libs__multidict-3
diff --git a/multidict/_multidict_py.py b/multidict/_multidict_py.py index f9c8f38..bff8276 100644 --- a/multidict/_multidict_py.py +++ b/multidict/_multidict_py.py @@ -185,12 +185,13 @@ class MultiDict(_Base, abc.MutableMapping): elif hasattr(arg, 'items'): items = arg.items() else: + items = [] for item in arg: if not len(item) == 2: raise TypeError( "{} takes either dict or list of (key, value) " "tuples".format(name)) - items = arg + items.append(item) for key, value in items: method(key, value)
aio-libs/multidict
ae23ed4adbfff861bd2621223a0e50bb0313cf32
diff --git a/tests/test_multidict.py b/tests/test_multidict.py index 8fa6e78..268a26e 100644 --- a/tests/test_multidict.py +++ b/tests/test_multidict.py @@ -73,6 +73,15 @@ class _BaseTest(_Root): self.assertEqual(sorted(d.items()), [('key', 'value1'), ('key2', 'value2')]) + def test_instantiate__from_generator(self): + d = self.make_dict((str(i), i) for i in range(2)) + + self.assertEqual(d, {'0': 0, '1': 1}) + self.assertEqual(len(d), 2) + self.assertEqual(sorted(d.keys()), ['0', '1']) + self.assertEqual(sorted(d.values()), [0, 1]) + self.assertEqual(sorted(d.items()), [('0', 0), ('1', 1)]) + def test_getone(self): d = self.make_dict([('key', 'value1')], key='value2') self.assertEqual(d.getone('key'), 'value1')
Python MultiDict constructor discards generator content When using the pure Python implementation, if a `MultiDict` is constructed with a generator argument: headers = CIMultiDict( ( k.decode('utf-8', 'surrogateescape'), v.decode('utf-8', 'surrogateescape'), ) for k, v in event.headers ) then the resulting `MultiDict` will be empty, instead of containing the key/value pairs as expected. This is because the generator is iterated over twice, and the first iteration discards all of the pairs.
0.0
ae23ed4adbfff861bd2621223a0e50bb0313cf32
[ "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__from_generator", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__from_generator" ]
[ "tests/test_multidict.py::TestPyMultiDictProxy::test__iter__", "tests/test_multidict.py::TestPyMultiDictProxy::test__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_and", "tests/test_multidict.py::TestPyMultiDictProxy::test_and_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_cannot_create_from_unaccepted", "tests/test_multidict.py::TestPyMultiDictProxy::test_copy", "tests/test_multidict.py::TestPyMultiDictProxy::test_eq", "tests/test_multidict.py::TestPyMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestPyMultiDictProxy::test_get", "tests/test_multidict.py::TestPyMultiDictProxy::test_getall", "tests/test_multidict.py::TestPyMultiDictProxy::test_getone", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__empty", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__from_arg0", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__from_arg0_dict", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__with_kwargs", "tests/test_multidict.py::TestPyMultiDictProxy::test_isdisjoint", "tests/test_multidict.py::TestPyMultiDictProxy::test_isdisjoint2", "tests/test_multidict.py::TestPyMultiDictProxy::test_items__contains", "tests/test_multidict.py::TestPyMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys__contains", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_greater", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_greater_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_less", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_less_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_not_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_ne", "tests/test_multidict.py::TestPyMultiDictProxy::test_or", "tests/test_multidict.py::TestPyMultiDictProxy::test_or_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_preserve_stable_ordering", "tests/test_multidict.py::TestPyMultiDictProxy::test_repr_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_sub", "tests/test_multidict.py::TestPyMultiDictProxy::test_sub_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_values__contains", "tests/test_multidict.py::TestPyMultiDictProxy::test_values__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_xor", "tests/test_multidict.py::TestPyMultiDictProxy::test_xor_issue_410", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_basics", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_copy", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_get", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_getall", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_values__repr__", "tests/test_multidict.py::PyMutableMultiDictTests::test__iter__", "tests/test_multidict.py::PyMutableMultiDictTests::test__repr__", "tests/test_multidict.py::PyMutableMultiDictTests::test_add", "tests/test_multidict.py::PyMutableMultiDictTests::test_and", "tests/test_multidict.py::PyMutableMultiDictTests::test_and_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_cannot_create_from_unaccepted", "tests/test_multidict.py::PyMutableMultiDictTests::test_clear", "tests/test_multidict.py::PyMutableMultiDictTests::test_copy", "tests/test_multidict.py::PyMutableMultiDictTests::test_del", "tests/test_multidict.py::PyMutableMultiDictTests::test_eq", "tests/test_multidict.py::PyMutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::PyMutableMultiDictTests::test_extend", "tests/test_multidict.py::PyMutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::PyMutableMultiDictTests::test_getall", "tests/test_multidict.py::PyMutableMultiDictTests::test_getone", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__empty", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__from_arg0", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__from_arg0_dict", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__with_kwargs", "tests/test_multidict.py::PyMutableMultiDictTests::test_isdisjoint", "tests/test_multidict.py::PyMutableMultiDictTests::test_isdisjoint2", "tests/test_multidict.py::PyMutableMultiDictTests::test_items__contains", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys__contains", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_greater", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_greater_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_less", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_less_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_not_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_ne", "tests/test_multidict.py::PyMutableMultiDictTests::test_or", "tests/test_multidict.py::PyMutableMultiDictTests::test_or_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_pop", "tests/test_multidict.py::PyMutableMultiDictTests::test_pop_default", "tests/test_multidict.py::PyMutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::PyMutableMultiDictTests::test_popitem", "tests/test_multidict.py::PyMutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::PyMutableMultiDictTests::test_repr_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_set_default", "tests/test_multidict.py::PyMutableMultiDictTests::test_sub", "tests/test_multidict.py::PyMutableMultiDictTests::test_sub_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_update", "tests/test_multidict.py::PyMutableMultiDictTests::test_values__contains", "tests/test_multidict.py::PyMutableMultiDictTests::test_xor", "tests/test_multidict.py::PyMutableMultiDictTests::test_xor_issue_410", "tests/test_multidict.py::PyCIMutableMultiDictTests::test__repr__", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_add", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_basics", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_clear", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_copy", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_ctor", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_del", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_delitem", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_extend", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_extend_with_upstr", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_get", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_getall", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_items__repr__", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_keys__repr__", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_pop", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_pop_default", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_popitem", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_set_default", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_setitem", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_update", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_values__repr__", "tests/test_multidict.py::TestMultiDictProxy::test__iter__", "tests/test_multidict.py::TestMultiDictProxy::test__repr__", "tests/test_multidict.py::TestMultiDictProxy::test_and", "tests/test_multidict.py::TestMultiDictProxy::test_and_issue_410", "tests/test_multidict.py::TestMultiDictProxy::test_cannot_create_from_unaccepted", "tests/test_multidict.py::TestMultiDictProxy::test_copy", "tests/test_multidict.py::TestMultiDictProxy::test_eq", "tests/test_multidict.py::TestMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestMultiDictProxy::test_get", "tests/test_multidict.py::TestMultiDictProxy::test_getall", "tests/test_multidict.py::TestMultiDictProxy::test_getone", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__empty", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__from_arg0", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__from_arg0_dict", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__from_generator", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__with_kwargs", "tests/test_multidict.py::TestMultiDictProxy::test_isdisjoint", "tests/test_multidict.py::TestMultiDictProxy::test_isdisjoint2", "tests/test_multidict.py::TestMultiDictProxy::test_items__contains", "tests/test_multidict.py::TestMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestMultiDictProxy::test_keys__contains", "tests/test_multidict.py::TestMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_equal", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_greater", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_greater_equal", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_less", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_less_equal", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_not_equal", "tests/test_multidict.py::TestMultiDictProxy::test_ne", "tests/test_multidict.py::TestMultiDictProxy::test_or", "tests/test_multidict.py::TestMultiDictProxy::test_or_issue_410", "tests/test_multidict.py::TestMultiDictProxy::test_preserve_stable_ordering", "tests/test_multidict.py::TestMultiDictProxy::test_repr_issue_410", "tests/test_multidict.py::TestMultiDictProxy::test_sub", "tests/test_multidict.py::TestMultiDictProxy::test_sub_issue_410", "tests/test_multidict.py::TestMultiDictProxy::test_values__contains", "tests/test_multidict.py::TestMultiDictProxy::test_values__repr__", "tests/test_multidict.py::TestMultiDictProxy::test_xor", "tests/test_multidict.py::TestMultiDictProxy::test_xor_issue_410", "tests/test_multidict.py::TestCIMultiDictProxy::test_basics", "tests/test_multidict.py::TestCIMultiDictProxy::test_copy", "tests/test_multidict.py::TestCIMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestCIMultiDictProxy::test_get", "tests/test_multidict.py::TestCIMultiDictProxy::test_getall", "tests/test_multidict.py::TestCIMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestCIMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestCIMultiDictProxy::test_values__repr__", "tests/test_multidict.py::MutableMultiDictTests::test__iter__", "tests/test_multidict.py::MutableMultiDictTests::test__repr__", "tests/test_multidict.py::MutableMultiDictTests::test_add", "tests/test_multidict.py::MutableMultiDictTests::test_and", "tests/test_multidict.py::MutableMultiDictTests::test_and_issue_410", "tests/test_multidict.py::MutableMultiDictTests::test_cannot_create_from_unaccepted", "tests/test_multidict.py::MutableMultiDictTests::test_clear", "tests/test_multidict.py::MutableMultiDictTests::test_copy", "tests/test_multidict.py::MutableMultiDictTests::test_del", "tests/test_multidict.py::MutableMultiDictTests::test_eq", "tests/test_multidict.py::MutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::MutableMultiDictTests::test_extend", "tests/test_multidict.py::MutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::MutableMultiDictTests::test_getall", "tests/test_multidict.py::MutableMultiDictTests::test_getone", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__empty", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__from_arg0", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__from_arg0_dict", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__from_generator", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__with_kwargs", "tests/test_multidict.py::MutableMultiDictTests::test_isdisjoint", "tests/test_multidict.py::MutableMultiDictTests::test_isdisjoint2", "tests/test_multidict.py::MutableMultiDictTests::test_items__contains", "tests/test_multidict.py::MutableMultiDictTests::test_keys__contains", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_equal", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_greater", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_greater_equal", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_less", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_less_equal", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_not_equal", "tests/test_multidict.py::MutableMultiDictTests::test_ne", "tests/test_multidict.py::MutableMultiDictTests::test_or", "tests/test_multidict.py::MutableMultiDictTests::test_or_issue_410", "tests/test_multidict.py::MutableMultiDictTests::test_pop", "tests/test_multidict.py::MutableMultiDictTests::test_pop_default", "tests/test_multidict.py::MutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::MutableMultiDictTests::test_popitem", "tests/test_multidict.py::MutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::MutableMultiDictTests::test_repr_issue_410", "tests/test_multidict.py::MutableMultiDictTests::test_set_default", "tests/test_multidict.py::MutableMultiDictTests::test_sub", "tests/test_multidict.py::MutableMultiDictTests::test_sub_issue_410", "tests/test_multidict.py::MutableMultiDictTests::test_update", "tests/test_multidict.py::MutableMultiDictTests::test_values__contains", "tests/test_multidict.py::MutableMultiDictTests::test_xor", "tests/test_multidict.py::MutableMultiDictTests::test_xor_issue_410", "tests/test_multidict.py::CIMutableMultiDictTests::test__repr__", "tests/test_multidict.py::CIMutableMultiDictTests::test_add", "tests/test_multidict.py::CIMutableMultiDictTests::test_basics", "tests/test_multidict.py::CIMutableMultiDictTests::test_clear", "tests/test_multidict.py::CIMutableMultiDictTests::test_copy", "tests/test_multidict.py::CIMutableMultiDictTests::test_ctor", "tests/test_multidict.py::CIMutableMultiDictTests::test_del", "tests/test_multidict.py::CIMutableMultiDictTests::test_delitem", "tests/test_multidict.py::CIMutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::CIMutableMultiDictTests::test_extend", "tests/test_multidict.py::CIMutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::CIMutableMultiDictTests::test_extend_with_upstr", "tests/test_multidict.py::CIMutableMultiDictTests::test_get", "tests/test_multidict.py::CIMutableMultiDictTests::test_getall", "tests/test_multidict.py::CIMutableMultiDictTests::test_items__repr__", "tests/test_multidict.py::CIMutableMultiDictTests::test_keys__repr__", "tests/test_multidict.py::CIMutableMultiDictTests::test_pop", "tests/test_multidict.py::CIMutableMultiDictTests::test_pop_default", "tests/test_multidict.py::CIMutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::CIMutableMultiDictTests::test_popitem", "tests/test_multidict.py::CIMutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::CIMutableMultiDictTests::test_set_default", "tests/test_multidict.py::CIMutableMultiDictTests::test_setitem", "tests/test_multidict.py::CIMutableMultiDictTests::test_update", "tests/test_multidict.py::CIMutableMultiDictTests::test_values__repr__", "tests/test_multidict.py::TestPyUpStr::test_ctor", "tests/test_multidict.py::TestPyUpStr::test_ctor_buffer", "tests/test_multidict.py::TestPyUpStr::test_ctor_repr", "tests/test_multidict.py::TestPyUpStr::test_ctor_str", "tests/test_multidict.py::TestPyUpStr::test_ctor_str_uppercase", "tests/test_multidict.py::TestPyUpStr::test_upper", "tests/test_multidict.py::TestUpStr::test_ctor", "tests/test_multidict.py::TestUpStr::test_ctor_buffer", "tests/test_multidict.py::TestUpStr::test_ctor_repr", "tests/test_multidict.py::TestUpStr::test_ctor_str", "tests/test_multidict.py::TestUpStr::test_ctor_str_uppercase", "tests/test_multidict.py::TestUpStr::test_upper", "tests/test_multidict.py::TestPyTypes::test_create_ci_multidict_proxy_from_multidict", "tests/test_multidict.py::TestPyTypes::test_create_cimultidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestPyTypes::test_create_multidict_proxy_from_cimultidict", "tests/test_multidict.py::TestPyTypes::test_create_multidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestPyTypes::test_dict_not_inherited_from_proxy", "tests/test_multidict.py::TestPyTypes::test_dicts", "tests/test_multidict.py::TestPyTypes::test_proxies", "tests/test_multidict.py::TestPyTypes::test_proxy_not_inherited_from_dict", "tests/test_multidict.py::TestTypes::test_create_ci_multidict_proxy_from_multidict", "tests/test_multidict.py::TestTypes::test_create_cimultidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestTypes::test_create_multidict_proxy_from_cimultidict", "tests/test_multidict.py::TestTypes::test_create_multidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestTypes::test_dict_not_inherited_from_proxy", "tests/test_multidict.py::TestTypes::test_dicts", "tests/test_multidict.py::TestTypes::test_proxies", "tests/test_multidict.py::TestTypes::test_proxy_not_inherited_from_dict" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2016-06-04 15:22:44+00:00
apache-2.0
968
aio-libs__multidict-408
diff --git a/CHANGES/310.feature b/CHANGES/310.feature new file mode 100644 index 0000000..9f0fb19 --- /dev/null +++ b/CHANGES/310.feature @@ -0,0 +1,1 @@ +Implement __length_hint__() for iterators \ No newline at end of file diff --git a/multidict/_multidict_iter.c b/multidict/_multidict_iter.c index 41aeb71..30bb46b 100644 --- a/multidict/_multidict_iter.c +++ b/multidict/_multidict_iter.c @@ -156,6 +156,28 @@ multidict_iter_clear(MultidictIter *self) return 0; } +static PyObject * +multidict_iter_len(MultidictIter *self) +{ + return PyLong_FromSize_t(pair_list_len(&self->md->pairs)); +} + +PyDoc_STRVAR(length_hint_doc, + "Private method returning an estimate of len(list(it))."); + +static PyMethodDef multidict_iter_methods[] = { + { + "__length_hint__", + (PyCFunction)(void(*)(void))multidict_iter_len, + METH_NOARGS, + length_hint_doc + }, + { + NULL, + NULL + } /* sentinel */ +}; + /***********************************************************************/ /* We link this module statically for convenience. If compiled as a shared @@ -177,6 +199,7 @@ static PyTypeObject multidict_items_iter_type = { .tp_clear = (inquiry)multidict_iter_clear, .tp_iter = PyObject_SelfIter, .tp_iternext = (iternextfunc)multidict_items_iter_iternext, + .tp_methods = multidict_iter_methods, }; static PyTypeObject multidict_values_iter_type = { @@ -189,6 +212,7 @@ static PyTypeObject multidict_values_iter_type = { .tp_clear = (inquiry)multidict_iter_clear, .tp_iter = PyObject_SelfIter, .tp_iternext = (iternextfunc)multidict_values_iter_iternext, + .tp_methods = multidict_iter_methods, }; static PyTypeObject multidict_keys_iter_type = { @@ -201,6 +225,7 @@ static PyTypeObject multidict_keys_iter_type = { .tp_clear = (inquiry)multidict_iter_clear, .tp_iter = PyObject_SelfIter, .tp_iternext = (iternextfunc)multidict_keys_iter_iternext, + .tp_methods = multidict_iter_methods, }; int diff --git a/multidict/_multidict_py.py b/multidict/_multidict_py.py index 1d5736d..04e96cd 100644 --- a/multidict/_multidict_py.py +++ b/multidict/_multidict_py.py @@ -404,6 +404,23 @@ class CIMultiDict(MultiDict): return key.title() +class _Iter: + __slots__ = ('_size', '_iter') + + def __init__(self, size, iterator): + self._size = size + self._iter = iterator + + def __iter__(self): + return self + + def __next__(self): + return next(self._iter) + + def __length_hint__(self): + return self._size + + class _ViewBase: def __init__(self, impl): self._impl = impl @@ -423,6 +440,9 @@ class _ItemsView(_ViewBase, abc.ItemsView): return False def __iter__(self): + return _Iter(len(self), self._iter()) + + def _iter(self): for i, k, v in self._impl._items: if self._version != self._impl._version: raise RuntimeError("Dictionary changed during iteration") @@ -444,6 +464,9 @@ class _ValuesView(_ViewBase, abc.ValuesView): return False def __iter__(self): + return _Iter(len(self), self._iter()) + + def _iter(self): for item in self._impl._items: if self._version != self._impl._version: raise RuntimeError("Dictionary changed during iteration") @@ -465,6 +488,9 @@ class _KeysView(_ViewBase, abc.KeysView): return False def __iter__(self): + return _Iter(len(self), self._iter()) + + def _iter(self): for item in self._impl._items: if self._version != self._impl._version: raise RuntimeError("Dictionary changed during iteration")
aio-libs/multidict
c638532226e94b27eeface0a0d434884361b3c21
diff --git a/tests/test_multidict.py b/tests/test_multidict.py index 92dc62b..6822eca 100644 --- a/tests/test_multidict.py +++ b/tests/test_multidict.py @@ -320,6 +320,21 @@ class BaseMultiDictTest: assert called del wr + def test_iter_length_hint_keys(self, cls): + md = cls(a=1, b=2) + it = iter(md.keys()) + assert it.__length_hint__() == 2 + + def test_iter_length_hint_items(self, cls): + md = cls(a=1, b=2) + it = iter(md.items()) + assert it.__length_hint__() == 2 + + def test_iter_length_hint_values(self, cls): + md = cls(a=1, b=2) + it = iter(md.values()) + assert it.__length_hint__() == 2 + class TestMultiDict(BaseMultiDictTest): @pytest.fixture(params=["MultiDict", ("MultiDict", "MultiDictProxy")])
Implement __length_hint__() for iterators It can help with optimizing calls like `[i for i in md.items()]` etc.
0.0
c638532226e94b27eeface0a0d434884361b3c21
[ "tests/test_multidict.py::TestMultiDict::test_iter_length_hint_keys[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_iter_length_hint_keys[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_iter_length_hint_items[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_iter_length_hint_items[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_iter_length_hint_values[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_iter_length_hint_values[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_iter_length_hint_keys[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_iter_length_hint_keys[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_iter_length_hint_items[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_iter_length_hint_items[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_iter_length_hint_values[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_iter_length_hint_values[multidict._multidict_py-cls1]" ]
[ "tests/test_multidict.py::test_exposed_names[multidict._multidict-MultiDict]", "tests/test_multidict.py::test_exposed_names[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::test__iter__types[multidict._multidict-MultiDict-str]", "tests/test_multidict.py::test__iter__types[multidict._multidict-cls1-str]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict-MultiDict-MultiDictProxy]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict-CIMultiDict-CIMultiDictProxy]", "tests/test_multidict.py::test_class_getitem[multidict._multidict-MultiDict]", "tests/test_multidict.py::test_class_getitem[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::test_class_getitem[multidict._multidict-MultiDictProxy]", "tests/test_multidict.py::test_class_getitem[multidict._multidict-CIMultiDictProxy]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-MultiDict-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-MultiDict-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_and[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_and[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_and2[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_and2[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_or[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_or[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_or2[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_or2[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_sub[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_sub[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_sub2[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_sub2[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_xor[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_xor[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_xor2[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_xor2[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-MultiDict-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-MultiDict-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-cls1-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict-cls1-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-MultiDict-other0-or_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-MultiDict-other0-and_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-MultiDict-other0-sub]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-MultiDict-other0-xor]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-or_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-and_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-sub]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-xor]", "tests/test_multidict.py::TestMultiDict::test_weakref[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_weakref[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-CIMultiDict-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-CIMultiDict-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict-cls1-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_and[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_and[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_and2[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_and2[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_or[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_or[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_or2[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_or2[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_sub[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_sub[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_sub2[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_sub2[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_xor[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_xor[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_xor2[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_xor2[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-CIMultiDict-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-CIMultiDict-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-cls1-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict-cls1-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-CIMultiDict-other0-or_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-CIMultiDict-other0-and_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-CIMultiDict-other0-sub]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-CIMultiDict-other0-xor]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-or_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-and_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-sub]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict-cls1-other0-xor]", "tests/test_multidict.py::TestCIMultiDict::test_weakref[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_weakref[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict-cls1]", "tests/test_multidict.py::test_exposed_names[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::test_exposed_names[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::test__iter__types[multidict._multidict_py-MultiDict-str]", "tests/test_multidict.py::test__iter__types[multidict._multidict_py-cls1-str]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict_py-MultiDict-MultiDictProxy]", "tests/test_multidict.py::test_proxy_copy[multidict._multidict_py-CIMultiDict-CIMultiDictProxy]", "tests/test_multidict.py::test_class_getitem[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::test_class_getitem[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::test_class_getitem[multidict._multidict_py-MultiDictProxy]", "tests/test_multidict.py::test_class_getitem[multidict._multidict_py-CIMultiDictProxy]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__empty[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-MultiDict-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-MultiDict-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg00]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg01]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_instantiate__from_generator[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getone[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__iter__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq3[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_ne[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_and[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_and[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_and2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_and2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_or[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_or[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_or2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_or2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_sub[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_sub[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_sub2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_sub2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_xor[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_xor[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_xor2[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_xor2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-MultiDict-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-MultiDict-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set0-True]", "tests/test_multidict.py::TestMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set1-False]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_repr_issue_410[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-or_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-and_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-sub]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-MultiDict-other0-xor]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-or_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-and_]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-sub]", "tests/test_multidict.py::TestMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-xor]", "tests/test_multidict.py::TestMultiDict::test_weakref[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_weakref[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_getall[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_preserve_stable_ordering[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_get[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_items__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_keys__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict_py-MultiDict]", "tests/test_multidict.py::TestMultiDict::test_values__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__empty[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-CIMultiDict-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-CIMultiDict-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg00]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_arg0[multidict._multidict_py-cls1-arg01]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__with_kwargs[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_instantiate__from_generator[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getone[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__iter__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__contains[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_cannot_create_from_unaccepted[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_less_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_greater_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys_is_set_not_equal[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq3[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_eq_other_mapping_contains_more_keys[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_ne[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_and[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_and[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_and2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_and2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_or[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_or[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_or2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_or2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_sub[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_sub[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_sub2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_sub2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_xor[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_xor[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_xor2[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_xor2[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-CIMultiDict-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-CIMultiDict-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set0-True]", "tests/test_multidict.py::TestCIMultiDict::test_isdisjoint[multidict._multidict_py-cls1-_set1-False]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_repr_issue_410[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-or_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-and_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-sub]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-CIMultiDict-other0-xor]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-or_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-and_]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-sub]", "tests/test_multidict.py::TestCIMultiDict::test_op_issue_410[multidict._multidict_py-cls1-other0-xor]", "tests/test_multidict.py::TestCIMultiDict::test_weakref[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_weakref[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_basics[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_getall[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_get[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_items__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_keys__repr__[multidict._multidict_py-cls1]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict_py-CIMultiDict]", "tests/test_multidict.py::TestCIMultiDict::test_values__repr__[multidict._multidict_py-cls1]" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_added_files", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2019-11-24 16:43:30+00:00
apache-2.0
969
aio-libs__multidict-449
diff --git a/CHANGES/444.feature b/CHANGES/444.feature new file mode 100644 index 0000000..009dc8a --- /dev/null +++ b/CHANGES/444.feature @@ -0,0 +1,1 @@ +Implement ``__sizeof__`` function to correctly calculate all internal structures size. \ No newline at end of file diff --git a/multidict/_multidict.c b/multidict/_multidict.c index 0e8fa5d..0f0bf3d 100644 --- a/multidict/_multidict.c +++ b/multidict/_multidict.c @@ -416,6 +416,7 @@ fail: return NULL; } + /******************** Base Methods ********************/ static inline PyObject * @@ -863,6 +864,21 @@ multidict_class_getitem(PyObject *self, PyObject *arg) return self; } + +PyDoc_STRVAR(sizeof__doc__, +"D.__sizeof__() -> size of D in memory, in bytes"); + +static inline PyObject * +_multidict_sizeof(MultiDictObject *self) +{ + Py_ssize_t size = sizeof(MultiDictObject); + if (self->pairs.pairs != self->pairs.buffer) { + size += (Py_ssize_t)sizeof(pair_t) * self->pairs.capacity; + } + return PyLong_FromSsize_t(size); +} + + static PySequenceMethods multidict_sequence = { .sq_contains = (objobjproc)multidict_sq_contains, }; @@ -978,10 +994,16 @@ static PyMethodDef multidict_methods[] = { }, { "__class_getitem__", - multidict_class_getitem, + (PyCFunction)multidict_class_getitem, METH_O | METH_CLASS, NULL }, + { + "__sizeof__", + (PyCFunction)_multidict_sizeof, + METH_NOARGS, + sizeof__doc__, + }, { NULL, NULL @@ -1290,7 +1312,7 @@ static PyMethodDef multidict_proxy_methods[] = { }, { "__class_getitem__", - multidict_class_getitem, + (PyCFunction)multidict_class_getitem, METH_O | METH_CLASS, NULL }, diff --git a/multidict/_multidict_py.py b/multidict/_multidict_py.py index 8ee1850..d96c3a7 100644 --- a/multidict/_multidict_py.py +++ b/multidict/_multidict_py.py @@ -1,3 +1,4 @@ +import sys from array import array from collections import abc @@ -38,6 +39,10 @@ class _Impl: v[0] += 1 self._version = v[0] + if sys.implementation.name != "pypy": + def __sizeof__(self): + return object.__sizeof__(self) + sys.getsizeof(self._items) + class _Base: def _title(self, key): @@ -173,6 +178,10 @@ class MultiDict(_Base, MutableMultiMapping): self._extend(args, kwargs, self.__class__.__name__, self._extend_items) + if sys.implementation.name != "pypy": + def __sizeof__(self): + return object.__sizeof__(self) + sys.getsizeof(self._impl) + def __reduce__(self): return (self.__class__, (list(self.items()),)) diff --git a/setup.py b/setup.py index 4e07115..79e6b20 100644 --- a/setup.py +++ b/setup.py @@ -27,11 +27,7 @@ if platform.system() != "Windows": extensions = [ Extension( - "multidict._multidict", - [ - "multidict/_multidict.c", - ], - extra_compile_args=CFLAGS, + "multidict._multidict", ["multidict/_multidict.c"], extra_compile_args=CFLAGS, ), ]
aio-libs/multidict
57087211d2d68a780f5c4a29aeae46da0b5d9895
diff --git a/tests/test_mutable_multidict.py b/tests/test_mutable_multidict.py index 57661b7..9b9f118 100644 --- a/tests/test_mutable_multidict.py +++ b/tests/test_mutable_multidict.py @@ -1,3 +1,6 @@ +import string +import sys + import pytest @@ -459,3 +462,21 @@ class TestCIMutableMultiDict: d2 = cls(KEY="val") assert d1 == d2 + + @pytest.mark.skipif(sys.implementation.name == "pypy", + reason="getsizeof() is not implemented on PyPy") + def test_sizeof(self, cls): + md = cls() + s1 = sys.getsizeof(md) + for i in string.ascii_lowercase: + for j in string.ascii_uppercase: + md[i + j] = i + j + # multidict should be resized + s2 = sys.getsizeof(md) + assert s2 > s1 + + @pytest.mark.skipif(sys.implementation.name == "pypy", + reason="getsizeof() is not implemented on PyPy") + def test_min_sizeof(self, cls): + md = cls() + assert sys.getsizeof(md) < 1024
Implement __sizeof__ function to correctly calculate all internal structures size. See also https://docs.python.org/3/library/sys.html#sys.getsizeof
0.0
57087211d2d68a780f5c4a29aeae46da0b5d9895
[ "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_sizeof[multidict._multidict_py]" ]
[ "tests/test_mutable_multidict.py::TestMutableMultiDict::test_copy[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test__repr__[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_getall[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend_from_proxy[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_clear[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_del[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_set_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem_empty_multidict[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop2[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_raises[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_replacement_order[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_nonstr_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_key_error[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_large_multidict_resizing[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_getall[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_ctor[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_setitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_delitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test__repr__[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_from_proxy[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_clear[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_del[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_set_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem_empty_multidict[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_lowercase[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_raises[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_with_istr[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy_istr[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_eq[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_min_sizeof[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_copy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test__repr__[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_getall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend_from_proxy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_clear[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_del[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_set_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem_empty_multidict[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop2[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_raises[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_replacement_order[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_nonstr_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_key_error[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_large_multidict_resizing[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_getall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_ctor[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_setitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_delitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test__repr__[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_from_proxy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_clear[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_del[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_set_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem_empty_multidict[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_lowercase[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_raises[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_with_istr[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy_istr[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_eq[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_min_sizeof[multidict._multidict_py]" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks", "has_added_files", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2019-12-24 17:38:17+00:00
apache-2.0
970
aio-libs__multidict-628
diff --git a/CHANGES/620.bugfix b/CHANGES/620.bugfix new file mode 100644 index 0000000..75ca32b --- /dev/null +++ b/CHANGES/620.bugfix @@ -0,0 +1,1 @@ +Fix pure-python implementation that used to raise "Dictionary changed during iteration" error when iterated view (``.keys()``, ``.values()`` or ``.items()``) was created before the dictionary's content change. \ No newline at end of file diff --git a/multidict/_multidict_py.py b/multidict/_multidict_py.py index 1ec63da..52002c0 100644 --- a/multidict/_multidict_py.py +++ b/multidict/_multidict_py.py @@ -435,7 +435,6 @@ class _Iter: class _ViewBase: def __init__(self, impl): self._impl = impl - self._version = impl._version def __len__(self): return len(self._impl._items) @@ -451,11 +450,11 @@ class _ItemsView(_ViewBase, abc.ItemsView): return False def __iter__(self): - return _Iter(len(self), self._iter()) + return _Iter(len(self), self._iter(self._impl._version)) - def _iter(self): + def _iter(self, version): for i, k, v in self._impl._items: - if self._version != self._impl._version: + if version != self._impl._version: raise RuntimeError("Dictionary changed during iteration") yield k, v @@ -475,11 +474,11 @@ class _ValuesView(_ViewBase, abc.ValuesView): return False def __iter__(self): - return _Iter(len(self), self._iter()) + return _Iter(len(self), self._iter(self._impl._version)) - def _iter(self): + def _iter(self, version): for item in self._impl._items: - if self._version != self._impl._version: + if version != self._impl._version: raise RuntimeError("Dictionary changed during iteration") yield item[2] @@ -499,11 +498,11 @@ class _KeysView(_ViewBase, abc.KeysView): return False def __iter__(self): - return _Iter(len(self), self._iter()) + return _Iter(len(self), self._iter(self._impl._version)) - def _iter(self): + def _iter(self, version): for item in self._impl._items: - if self._version != self._impl._version: + if version != self._impl._version: raise RuntimeError("Dictionary changed during iteration") yield item[1]
aio-libs/multidict
9dde0bd53dc238e585eb1c3b86bc89539782e29e
diff --git a/tests/test_mutable_multidict.py b/tests/test_mutable_multidict.py index 55664c5..3d4d16a 100644 --- a/tests/test_mutable_multidict.py +++ b/tests/test_mutable_multidict.py @@ -484,3 +484,27 @@ class TestCIMutableMultiDict: def test_min_sizeof(self, cls): md = cls() assert sys.getsizeof(md) < 1024 + + def test_issue_620_items(self, cls): + # https://github.com/aio-libs/multidict/issues/620 + d = cls({"a": "123, 456", "b": "789"}) + before_mutation_items = d.items() + d["c"] = "000" + # This causes an error on pypy. + list(before_mutation_items) + + def test_issue_620_keys(self, cls): + # https://github.com/aio-libs/multidict/issues/620 + d = cls({"a": "123, 456", "b": "789"}) + before_mutation_keys = d.keys() + d["c"] = "000" + # This causes an error on pypy. + list(before_mutation_keys) + + def test_issue_620_values(self, cls): + # https://github.com/aio-libs/multidict/issues/620 + d = cls({"a": "123, 456", "b": "789"}) + before_mutation_values = d.values() + d["c"] = "000" + # This causes an error on pypy. + list(before_mutation_values)
potential pypy mutability bug ### Describe the bug when using `pypy` and mutating a `CIMultiDict`, I get a `RuntimeError` of `"Dictionary changed during iteration"`. This doesn't happen using regular python, and I don't see this error when using `pypy` and other kinds of dictionaries. ### To Reproduce I've added the following tests to repro with `pypy` ```python @pytest.mark.asyncio async def test_headers_response_items_multidict_compare(): h = CIMultiDict({'a': '123, 456', 'b': '789'}) before_mutation_items = h.items() h['c'] = '000' with pytest.raises(RuntimeError): list(before_mutation_items) def test_headers_response_items_requests_compare(): from requests.structures import CaseInsensitiveDict h = CaseInsensitiveDict({'a': '123, 456', 'b': '789'}) before_mutation_items = h.items() h['c'] = '000' list(before_mutation_items) def test_headers_response_items_python_compare(): h = {'a': '123, 456', 'b': '789'} before_mutation_items = h.items() h['c'] = '000' list(before_mutation_items) ``` ### Expected behavior My thinking is that if mutating the dictionary doesn't raise for regular python is that it shouldn't raise for `pypy`. Is this expected behavior? ### Logs/tracebacks ```python-traceback self = _ItemsView('a': '123, 456', 'b': '789', 'c': '000') def _iter(self): for i, k, v in self._impl._items: if self._version != self._impl._version: > raise RuntimeError("Dictionary changed during iteration") E RuntimeError: Dictionary changed during iteration envs/corepypy3venv/site-packages/multidict/_multidict_py.py:459: RuntimeError ``` ### Python Version ```console $ python --version Python 3.7.10 (51efa818fd9b24f625078c65e8e2f6a5ac24d572, Apr 08 2021, 17:43:00) [PyPy 7.3.4 with GCC Apple LLVM 12.0.0 (clang-1200.0.32.29)] ``` ### aiohttp Version ```console $ python -m pip show aiohttp Version: 3.7.4.post0 ``` ### multidict Version ```console $ python -m pip show multidict Version: 5.1.0 ``` ### yarl Version ```console $ python -m pip show yarl Version: 1.6.3 ``` ### OS macOS ### Related component Client ### Additional context _No response_ ### Code of Conduct - [X] I agree to follow the aio-libs Code of Conduct
0.0
9dde0bd53dc238e585eb1c3b86bc89539782e29e
[ "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_issue_620_items[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_issue_620_keys[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_issue_620_values[multidict._multidict_py]" ]
[ "tests/test_mutable_multidict.py::TestMutableMultiDict::test_copy[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test__repr__[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_getall[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend_from_proxy[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_clear[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_del[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_set_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem_empty_multidict[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop2[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_raises[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_replacement_order[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_nonstr_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_key_error[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_large_multidict_resizing[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_getall[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_ctor[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_setitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_delitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test__repr__[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_add[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_from_proxy[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_clear[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_del[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_set_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem_empty_multidict[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_lowercase[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_default[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_raises[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_with_istr[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy_istr[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_eq[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_sizeof[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_min_sizeof[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_issue_620_items[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_issue_620_keys[multidict._multidict]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_issue_620_values[multidict._multidict]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_copy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test__repr__[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_getall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_extend_from_proxy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_clear[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_del[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_set_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popitem_empty_multidict[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop2[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_pop_raises[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_replacement_order[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_nonstr_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_istr_key_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_str_derived_key_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_popall_key_error[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestMutableMultiDict::test_large_multidict_resizing[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_getall[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_ctor[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_setitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_delitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test__repr__[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_add[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_from_proxy[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_clear[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_del[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_set_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_popitem_empty_multidict[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_lowercase[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_default[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_pop_raises[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_extend_with_istr[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_copy_istr[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_eq[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_sizeof[multidict._multidict_py]", "tests/test_mutable_multidict.py::TestCIMutableMultiDict::test_min_sizeof[multidict._multidict_py]" ]
{ "failed_lite_validators": [ "has_git_commit_hash", "has_added_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-09-30 11:45:10+00:00
apache-2.0
971
aio-libs__multidict-89
diff --git a/CHANGES.rst b/CHANGES.rst index e606232..60d2759 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -13,6 +13,8 @@ If key is not present in dictionary the pair is added to the end +* Force keys to `str` instances #88 + 2.1.7 (2017-05-29) ------------------ diff --git a/benchmark.py b/benchmark.py index 492e582..379b998 100644 --- a/benchmark.py +++ b/benchmark.py @@ -11,22 +11,22 @@ dct[key] """ cython_multidict = """\ -from multidict import MultiDict +from multidict import MultiDict, istr dct = MultiDict() """ python_multidict = """\ -from multidict._multidict_py import MultiDict +from multidict._multidict_py import MultiDict, istr dct = MultiDict() """ cython_cimultidict = """\ -from multidict import CIMultiDict, upstr +from multidict import CIMultiDict, istr dct = CIMultiDict() """ python_cimultidict = """\ -from multidict._multidict_py import CIMultiDict, upstr +from multidict._multidict_py import CIMultiDict, istr dct = CIMultiDict() """ @@ -37,20 +37,20 @@ for i in range(20): key = 'key10' """ -fill_upstr = """\ +fill_istr = """\ for i in range(20): - key = upstr('key'+str(i)) + key = istr('key'+str(i)) dct[key] = str(i) -key = upstr('key10') +key = istr('key10') """ -upstr_from_upstr = """\ -upstr(val) +istr_from_istr = """\ +istr(val) """ -make_upstr = """\ -val = upstr('VaLuE') +make_istr = """\ +val = istr('VaLuE') """ print("Cython / Python / x") @@ -60,7 +60,14 @@ gc.collect() t2 = timeit.timeit(setitem, python_multidict+fill) gc.collect() -print("MD.setitem str: {:.3f}s {:3f}s {:1f}x".format(t1, t2, t2/t1)) +print("MD.setitem str: {:.3f}s {:.3f}s {:.1f}x".format(t1, t2, t2/t1)) + +t1 = timeit.timeit(setitem, cython_multidict+fill_istr) +gc.collect() +t2 = timeit.timeit(setitem, python_multidict+fill_istr) +gc.collect() + +print("MD.setitem istr: {:.3f}s {:.3f}s {:.1f}x".format(t1, t2, t2/t1)) t1 = timeit.timeit(getitem, cython_multidict+fill) @@ -68,23 +75,23 @@ gc.collect() t2 = timeit.timeit(getitem, python_multidict+fill) gc.collect() -print("MD.getitem str: {:.3f}s {:3f}s {:1f}x".format(t1, t2, t2/t1)) +print("MD.getitem str: {:.3f}s {:.3f}s {:.1f}x".format(t1, t2, t2/t1)) t1 = timeit.timeit(getitem, cython_cimultidict+fill) gc.collect() t2 = timeit.timeit(getitem, python_cimultidict+fill) gc.collect() -print("CI.getitem str: {:.3f}s {:3f}s {:1f}x".format(t1, t2, t2/t1)) +print("CI.getitem str: {:.3f}s {:.3f}s {:.1f}x".format(t1, t2, t2/t1)) -t1 = timeit.timeit(getitem, cython_cimultidict+fill_upstr) +t1 = timeit.timeit(getitem, cython_cimultidict+fill_istr) gc.collect() -t2 = timeit.timeit(getitem, python_cimultidict+fill_upstr) +t2 = timeit.timeit(getitem, python_cimultidict+fill_istr) gc.collect() -print("CI.getitem istr: {:.3f}s {:3f}s {:1f}x".format(t1, t2, t2/t1)) +print("CI.getitem istr: {:.3f}s {:.3f}s {:.1f}x".format(t1, t2, t2/t1)) -t1 = timeit.timeit(upstr_from_upstr, cython_cimultidict+make_upstr) +t1 = timeit.timeit(istr_from_istr, cython_cimultidict+make_istr) gc.collect() -t2 = timeit.timeit(upstr_from_upstr, python_cimultidict+make_upstr) +t2 = timeit.timeit(istr_from_istr, python_cimultidict+make_istr) gc.collect() -print("istr from istr: {:.3f}s {:3f}s {:1f}x".format(t1, t2, t2/t1)) +print("istr from istr: {:.3f}s {:.3f}s {:.1f}x".format(t1, t2, t2/t1)) diff --git a/multidict/_multidict.pyx b/multidict/_multidict.pyx index 0aff712..36b6666 100644 --- a/multidict/_multidict.pyx +++ b/multidict/_multidict.pyx @@ -26,7 +26,9 @@ class istr(str): pass else: val = str(val) - ret = str.__new__(cls, val.title()) + val = val.title() + ret = str.__new__(cls, val) + ret._canonical = val return ret def title(self): @@ -74,19 +76,13 @@ cdef _eq(self, other): cdef class _Pair: cdef str _identity cdef Py_hash_t _hash - cdef object _key + cdef str _key cdef object _value def __cinit__(self, identity, key, value): self._hash = hash(identity) - typ = type(identity) - if typ is str: - self._identity = <str>identity - elif typ is _istr: - self._identity = <str>identity - else: - self._identity = identity - self._key = key + self._identity = <str>identity + self._key = <str>key self._value = value @@ -99,9 +95,9 @@ cdef class _Base: if typ is str: return <str>s elif typ is _istr: - return <str>s + return <str>(s._canonical) else: - return s + return str(s) def getall(self, key, default=_marker): """Return a list of all values matching the key.""" @@ -261,7 +257,7 @@ cdef class CIMultiDictProxy(MultiDictProxy): if typ is str: return <str>(s.title()) elif type(s) is _istr: - return <str>s + return <str>(s._canonical) return s.title() def copy(self): @@ -272,6 +268,19 @@ cdef class CIMultiDictProxy(MultiDictProxy): abc.Mapping.register(CIMultiDictProxy) +cdef str _str(key): + typ = type(key) + if typ is str: + return <str>key + if typ is _istr: + return <str>(key._canonical) + elif issubclass(typ, str): + return str(key) + else: + raise TypeError("MultiDict keys should be either str " + "or subclasses of str") + + cdef class MultiDict(_Base): """An ordered dictionary that can have multiple values for each key.""" @@ -340,10 +349,12 @@ cdef class MultiDict(_Base): self._replace(key, value) cdef _add(self, key, value): - self._items.append(_Pair.__new__(_Pair, self._title(key), key, value)) + self._items.append(_Pair.__new__( + _Pair, self._title(key), _str(key), value)) cdef _replace(self, key, value): cdef str identity = self._title(key) + cdef str k = _str(key) cdef Py_hash_t h = hash(identity) cdef Py_ssize_t i, rgt cdef _Pair item @@ -355,13 +366,13 @@ cdef class MultiDict(_Base): if h != item._hash: continue if item._identity == identity: - item._key = key + item._key = k item._value = value # i points to last found item rgt = i break else: - self._items.append(_Pair.__new__(_Pair, identity, key, value)) + self._items.append(_Pair.__new__(_Pair, identity, k, value)) return # remove all precending items @@ -489,7 +500,7 @@ cdef class CIMultiDict(MultiDict): if typ is str: return <str>(s.title()) elif type(s) is _istr: - return <str>s + return <str>(s._canonical) return s.title() def popitem(self): diff --git a/multidict/_multidict_py.py b/multidict/_multidict_py.py index 3428081..c8fb628 100644 --- a/multidict/_multidict_py.py +++ b/multidict/_multidict_py.py @@ -167,9 +167,16 @@ class MultiDict(_Base, abc.MutableMapping): def _title(self, key): return key + def _key(self, key): + if isinstance(key, str): + return str(key) + else: + raise TypeError("MultiDict keys should be either str " + "or subclasses of str") + def add(self, key, value): identity = self._title(key) - self._items.append((identity, key, value)) + self._items.append((identity, self._key(key), value)) def copy(self): """Return a copy of itself.""" @@ -272,6 +279,7 @@ class MultiDict(_Base, abc.MutableMapping): self._extend(args, kwargs, 'update', self._replace) def _replace(self, key, value): + key = self._key(key) identity = self._title(key) items = self._items
aio-libs/multidict
fc4eec03faad191a8f4f764181be953228944101
diff --git a/tests/test_multidict.py b/tests/test_multidict.py index 3e0a345..25b13d3 100644 --- a/tests/test_multidict.py +++ b/tests/test_multidict.py @@ -597,6 +597,23 @@ class _BaseMutableMultiDictTests(_BaseTest): ('key1', 'val'), ('key2', 'val4')], list(d.items())) + def test_nonstr_key(self): + d = self.make_dict() + with self.assertRaises(TypeError): + d[1] = 'val' + + def test_istr_key(self): + d = self.make_dict() + d[istr('1')] = 'val' + self.assertIs(type(list(d.keys())[0]), str) + + def test_str_derived_key(self): + class A(str): + pass + d = self.make_dict() + d[A('1')] = 'val' + self.assertIs(type(list(d.keys())[0]), str) + class _CIMutableMultiDictTests(_Root):
Force keys to str instances Right now a key type is dark corner: it could be str, istr or something other. For sake of further optimizations it should be `str` always. Passing `istr` as key to any miltidict API is still allowed and encouraged: it saves execution time by getting rid of `s.title()` conversion. But `istr` type is ambiguous by it nature: we can define equality for `str` and `istr` by comparing their *canonical* representations but ordering is cumbersome. Ordering by canonical reprs leads to very tricky errors, the same for *original* reprs. Also CPython is very optimized for `str` but not classes derived from it. I believe the change doesn't touch our users but aiohttp might get speedup on implementing the issue.
0.0
fc4eec03faad191a8f4f764181be953228944101
[ "tests/test_multidict.py::PyMutableMultiDictTests::test_istr_key", "tests/test_multidict.py::PyMutableMultiDictTests::test_nonstr_key", "tests/test_multidict.py::PyMutableMultiDictTests::test_str_derived_key" ]
[ "tests/test_multidict.py::TestPyMultiDictProxy::test__iter__", "tests/test_multidict.py::TestPyMultiDictProxy::test__iter__types", "tests/test_multidict.py::TestPyMultiDictProxy::test__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_and", "tests/test_multidict.py::TestPyMultiDictProxy::test_and2", "tests/test_multidict.py::TestPyMultiDictProxy::test_and_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_cannot_create_from_unaccepted", "tests/test_multidict.py::TestPyMultiDictProxy::test_copy", "tests/test_multidict.py::TestPyMultiDictProxy::test_eq", "tests/test_multidict.py::TestPyMultiDictProxy::test_eq2", "tests/test_multidict.py::TestPyMultiDictProxy::test_eq3", "tests/test_multidict.py::TestPyMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestPyMultiDictProxy::test_get", "tests/test_multidict.py::TestPyMultiDictProxy::test_getall", "tests/test_multidict.py::TestPyMultiDictProxy::test_getone", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__empty", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__from_arg0", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__from_arg0_dict", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__from_generator", "tests/test_multidict.py::TestPyMultiDictProxy::test_instantiate__with_kwargs", "tests/test_multidict.py::TestPyMultiDictProxy::test_isdisjoint", "tests/test_multidict.py::TestPyMultiDictProxy::test_isdisjoint2", "tests/test_multidict.py::TestPyMultiDictProxy::test_items__contains", "tests/test_multidict.py::TestPyMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys__contains", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_greater", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_greater_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_less", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_less_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_keys_is_set_not_equal", "tests/test_multidict.py::TestPyMultiDictProxy::test_ne", "tests/test_multidict.py::TestPyMultiDictProxy::test_or", "tests/test_multidict.py::TestPyMultiDictProxy::test_or2", "tests/test_multidict.py::TestPyMultiDictProxy::test_or_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_preserve_stable_ordering", "tests/test_multidict.py::TestPyMultiDictProxy::test_repr_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_sub", "tests/test_multidict.py::TestPyMultiDictProxy::test_sub2", "tests/test_multidict.py::TestPyMultiDictProxy::test_sub_issue_410", "tests/test_multidict.py::TestPyMultiDictProxy::test_values__contains", "tests/test_multidict.py::TestPyMultiDictProxy::test_values__repr__", "tests/test_multidict.py::TestPyMultiDictProxy::test_xor", "tests/test_multidict.py::TestPyMultiDictProxy::test_xor2", "tests/test_multidict.py::TestPyMultiDictProxy::test_xor_issue_410", "tests/test_multidict.py::TestPyCIMultiDictProxy::test__repr__", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_basics", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_copy", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_get", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_getall", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestPyCIMultiDictProxy::test_values__repr__", "tests/test_multidict.py::PyMutableMultiDictTests::test__iter__", "tests/test_multidict.py::PyMutableMultiDictTests::test__iter__types", "tests/test_multidict.py::PyMutableMultiDictTests::test__repr__", "tests/test_multidict.py::PyMutableMultiDictTests::test_add", "tests/test_multidict.py::PyMutableMultiDictTests::test_and", "tests/test_multidict.py::PyMutableMultiDictTests::test_and2", "tests/test_multidict.py::PyMutableMultiDictTests::test_and_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_cannot_create_from_unaccepted", "tests/test_multidict.py::PyMutableMultiDictTests::test_clear", "tests/test_multidict.py::PyMutableMultiDictTests::test_copy", "tests/test_multidict.py::PyMutableMultiDictTests::test_del", "tests/test_multidict.py::PyMutableMultiDictTests::test_eq", "tests/test_multidict.py::PyMutableMultiDictTests::test_eq2", "tests/test_multidict.py::PyMutableMultiDictTests::test_eq3", "tests/test_multidict.py::PyMutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::PyMutableMultiDictTests::test_extend", "tests/test_multidict.py::PyMutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::PyMutableMultiDictTests::test_getall", "tests/test_multidict.py::PyMutableMultiDictTests::test_getone", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__empty", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__from_arg0", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__from_arg0_dict", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__from_generator", "tests/test_multidict.py::PyMutableMultiDictTests::test_instantiate__with_kwargs", "tests/test_multidict.py::PyMutableMultiDictTests::test_isdisjoint", "tests/test_multidict.py::PyMutableMultiDictTests::test_isdisjoint2", "tests/test_multidict.py::PyMutableMultiDictTests::test_items__contains", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys__contains", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_greater", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_greater_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_less", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_less_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_keys_is_set_not_equal", "tests/test_multidict.py::PyMutableMultiDictTests::test_ne", "tests/test_multidict.py::PyMutableMultiDictTests::test_or", "tests/test_multidict.py::PyMutableMultiDictTests::test_or2", "tests/test_multidict.py::PyMutableMultiDictTests::test_or_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_pop", "tests/test_multidict.py::PyMutableMultiDictTests::test_pop_default", "tests/test_multidict.py::PyMutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::PyMutableMultiDictTests::test_popitem", "tests/test_multidict.py::PyMutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::PyMutableMultiDictTests::test_replacement_order", "tests/test_multidict.py::PyMutableMultiDictTests::test_repr_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_set_default", "tests/test_multidict.py::PyMutableMultiDictTests::test_sub", "tests/test_multidict.py::PyMutableMultiDictTests::test_sub2", "tests/test_multidict.py::PyMutableMultiDictTests::test_sub_issue_410", "tests/test_multidict.py::PyMutableMultiDictTests::test_update", "tests/test_multidict.py::PyMutableMultiDictTests::test_values__contains", "tests/test_multidict.py::PyMutableMultiDictTests::test_xor", "tests/test_multidict.py::PyMutableMultiDictTests::test_xor2", "tests/test_multidict.py::PyMutableMultiDictTests::test_xor_issue_410", "tests/test_multidict.py::PyCIMutableMultiDictTests::test__repr__", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_add", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_basics", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_clear", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_copy", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_copy_istr", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_ctor", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_del", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_delitem", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_eq", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_extend", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_extend_with_istr", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_get", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_getall", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_items__repr__", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_keys__repr__", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_pop", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_pop_default", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_pop_lowercase", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_popitem", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_set_default", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_setitem", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_update", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_update_istr", "tests/test_multidict.py::PyCIMutableMultiDictTests::test_values__repr__", "tests/test_multidict.py::TestMultiDictProxy::test__iter__", "tests/test_multidict.py::TestMultiDictProxy::test__iter__types", "tests/test_multidict.py::TestMultiDictProxy::test__repr__", "tests/test_multidict.py::TestMultiDictProxy::test_cannot_create_from_unaccepted", "tests/test_multidict.py::TestMultiDictProxy::test_copy", "tests/test_multidict.py::TestMultiDictProxy::test_eq", "tests/test_multidict.py::TestMultiDictProxy::test_eq2", "tests/test_multidict.py::TestMultiDictProxy::test_eq3", "tests/test_multidict.py::TestMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestMultiDictProxy::test_get", "tests/test_multidict.py::TestMultiDictProxy::test_getall", "tests/test_multidict.py::TestMultiDictProxy::test_getone", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__empty", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__from_arg0", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__from_arg0_dict", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__from_generator", "tests/test_multidict.py::TestMultiDictProxy::test_instantiate__with_kwargs", "tests/test_multidict.py::TestMultiDictProxy::test_isdisjoint", "tests/test_multidict.py::TestMultiDictProxy::test_isdisjoint2", "tests/test_multidict.py::TestMultiDictProxy::test_items__contains", "tests/test_multidict.py::TestMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestMultiDictProxy::test_keys__contains", "tests/test_multidict.py::TestMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_equal", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_greater", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_greater_equal", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_less", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_less_equal", "tests/test_multidict.py::TestMultiDictProxy::test_keys_is_set_not_equal", "tests/test_multidict.py::TestMultiDictProxy::test_ne", "tests/test_multidict.py::TestMultiDictProxy::test_preserve_stable_ordering", "tests/test_multidict.py::TestMultiDictProxy::test_repr_issue_410", "tests/test_multidict.py::TestMultiDictProxy::test_values__contains", "tests/test_multidict.py::TestMultiDictProxy::test_values__repr__", "tests/test_multidict.py::TestCIMultiDictProxy::test__repr__", "tests/test_multidict.py::TestCIMultiDictProxy::test_basics", "tests/test_multidict.py::TestCIMultiDictProxy::test_copy", "tests/test_multidict.py::TestCIMultiDictProxy::test_exposed_names", "tests/test_multidict.py::TestCIMultiDictProxy::test_get", "tests/test_multidict.py::TestCIMultiDictProxy::test_getall", "tests/test_multidict.py::TestCIMultiDictProxy::test_items__repr__", "tests/test_multidict.py::TestCIMultiDictProxy::test_keys__repr__", "tests/test_multidict.py::TestCIMultiDictProxy::test_values__repr__", "tests/test_multidict.py::MutableMultiDictTests::test__iter__", "tests/test_multidict.py::MutableMultiDictTests::test__iter__types", "tests/test_multidict.py::MutableMultiDictTests::test__repr__", "tests/test_multidict.py::MutableMultiDictTests::test_add", "tests/test_multidict.py::MutableMultiDictTests::test_cannot_create_from_unaccepted", "tests/test_multidict.py::MutableMultiDictTests::test_clear", "tests/test_multidict.py::MutableMultiDictTests::test_copy", "tests/test_multidict.py::MutableMultiDictTests::test_del", "tests/test_multidict.py::MutableMultiDictTests::test_eq", "tests/test_multidict.py::MutableMultiDictTests::test_eq2", "tests/test_multidict.py::MutableMultiDictTests::test_eq3", "tests/test_multidict.py::MutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::MutableMultiDictTests::test_extend", "tests/test_multidict.py::MutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::MutableMultiDictTests::test_getall", "tests/test_multidict.py::MutableMultiDictTests::test_getone", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__empty", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__from_arg0", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__from_arg0_dict", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__from_generator", "tests/test_multidict.py::MutableMultiDictTests::test_instantiate__with_kwargs", "tests/test_multidict.py::MutableMultiDictTests::test_isdisjoint", "tests/test_multidict.py::MutableMultiDictTests::test_isdisjoint2", "tests/test_multidict.py::MutableMultiDictTests::test_items__contains", "tests/test_multidict.py::MutableMultiDictTests::test_keys__contains", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_equal", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_greater", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_greater_equal", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_less", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_less_equal", "tests/test_multidict.py::MutableMultiDictTests::test_keys_is_set_not_equal", "tests/test_multidict.py::MutableMultiDictTests::test_ne", "tests/test_multidict.py::MutableMultiDictTests::test_nonstr_key", "tests/test_multidict.py::MutableMultiDictTests::test_pop", "tests/test_multidict.py::MutableMultiDictTests::test_pop_default", "tests/test_multidict.py::MutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::MutableMultiDictTests::test_popitem", "tests/test_multidict.py::MutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::MutableMultiDictTests::test_replacement_order", "tests/test_multidict.py::MutableMultiDictTests::test_repr_issue_410", "tests/test_multidict.py::MutableMultiDictTests::test_set_default", "tests/test_multidict.py::MutableMultiDictTests::test_update", "tests/test_multidict.py::MutableMultiDictTests::test_values__contains", "tests/test_multidict.py::CIMutableMultiDictTests::test__repr__", "tests/test_multidict.py::CIMutableMultiDictTests::test_add", "tests/test_multidict.py::CIMutableMultiDictTests::test_basics", "tests/test_multidict.py::CIMutableMultiDictTests::test_clear", "tests/test_multidict.py::CIMutableMultiDictTests::test_copy", "tests/test_multidict.py::CIMutableMultiDictTests::test_copy_istr", "tests/test_multidict.py::CIMutableMultiDictTests::test_ctor", "tests/test_multidict.py::CIMutableMultiDictTests::test_del", "tests/test_multidict.py::CIMutableMultiDictTests::test_delitem", "tests/test_multidict.py::CIMutableMultiDictTests::test_eq", "tests/test_multidict.py::CIMutableMultiDictTests::test_exposed_names", "tests/test_multidict.py::CIMutableMultiDictTests::test_extend", "tests/test_multidict.py::CIMutableMultiDictTests::test_extend_from_proxy", "tests/test_multidict.py::CIMutableMultiDictTests::test_extend_with_istr", "tests/test_multidict.py::CIMutableMultiDictTests::test_get", "tests/test_multidict.py::CIMutableMultiDictTests::test_getall", "tests/test_multidict.py::CIMutableMultiDictTests::test_items__repr__", "tests/test_multidict.py::CIMutableMultiDictTests::test_keys__repr__", "tests/test_multidict.py::CIMutableMultiDictTests::test_pop", "tests/test_multidict.py::CIMutableMultiDictTests::test_pop_default", "tests/test_multidict.py::CIMutableMultiDictTests::test_pop_lowercase", "tests/test_multidict.py::CIMutableMultiDictTests::test_pop_raises", "tests/test_multidict.py::CIMutableMultiDictTests::test_popitem", "tests/test_multidict.py::CIMutableMultiDictTests::test_popitem_empty_multidict", "tests/test_multidict.py::CIMutableMultiDictTests::test_set_default", "tests/test_multidict.py::CIMutableMultiDictTests::test_setitem", "tests/test_multidict.py::CIMutableMultiDictTests::test_update", "tests/test_multidict.py::CIMutableMultiDictTests::test_update_istr", "tests/test_multidict.py::CIMutableMultiDictTests::test_values__repr__", "tests/test_multidict.py::TestPyIStr::test_ctor", "tests/test_multidict.py::TestPyIStr::test_ctor_buffer", "tests/test_multidict.py::TestPyIStr::test_ctor_istr", "tests/test_multidict.py::TestPyIStr::test_ctor_repr", "tests/test_multidict.py::TestPyIStr::test_ctor_str", "tests/test_multidict.py::TestPyIStr::test_ctor_str_uppercase", "tests/test_multidict.py::TestPyIStr::test_title", "tests/test_multidict.py::TestIStr::test_ctor", "tests/test_multidict.py::TestIStr::test_ctor_buffer", "tests/test_multidict.py::TestIStr::test_ctor_istr", "tests/test_multidict.py::TestIStr::test_ctor_repr", "tests/test_multidict.py::TestIStr::test_ctor_str", "tests/test_multidict.py::TestIStr::test_ctor_str_uppercase", "tests/test_multidict.py::TestIStr::test_title", "tests/test_multidict.py::TestPyTypes::test_create_ci_multidict_proxy_from_multidict", "tests/test_multidict.py::TestPyTypes::test_create_cimultidict_proxy_from_cimultidict_proxy_from_ci", "tests/test_multidict.py::TestPyTypes::test_create_cimultidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestPyTypes::test_create_multidict_proxy_from_cimultidict", "tests/test_multidict.py::TestPyTypes::test_create_multidict_proxy_from_multidict_proxy_from_mdict", "tests/test_multidict.py::TestPyTypes::test_create_multidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestPyTypes::test_dict_not_inherited_from_proxy", "tests/test_multidict.py::TestPyTypes::test_dicts", "tests/test_multidict.py::TestPyTypes::test_proxies", "tests/test_multidict.py::TestPyTypes::test_proxy_not_inherited_from_dict", "tests/test_multidict.py::TestTypes::test_create_ci_multidict_proxy_from_multidict", "tests/test_multidict.py::TestTypes::test_create_cimultidict_proxy_from_cimultidict_proxy_from_ci", "tests/test_multidict.py::TestTypes::test_create_cimultidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestTypes::test_create_multidict_proxy_from_cimultidict", "tests/test_multidict.py::TestTypes::test_create_multidict_proxy_from_multidict_proxy_from_mdict", "tests/test_multidict.py::TestTypes::test_create_multidict_proxy_from_nonmultidict", "tests/test_multidict.py::TestTypes::test_dict_not_inherited_from_proxy", "tests/test_multidict.py::TestTypes::test_dicts", "tests/test_multidict.py::TestTypes::test_proxies", "tests/test_multidict.py::TestTypes::test_proxy_not_inherited_from_dict" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2017-06-08 19:07:25+00:00
apache-2.0
972
aio-libs__yarl-106
diff --git a/CHANGES.rst b/CHANGES.rst index 5b9a667..49b78a2 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -10,6 +10,8 @@ CHANGES * Unsafe encoding for QS fixed. Encode `;` char in value param (#104) +* Process passwords without user names (#95) + 0.12.0 (2017-06-26) ------------------- diff --git a/yarl/__init__.py b/yarl/__init__.py index 41a3089..e1151c0 100644 --- a/yarl/__init__.py +++ b/yarl/__init__.py @@ -176,8 +176,11 @@ class URL: netloc += ':{}'.format(val.port) if val.username: user = _quote(val.username) - if val.password: - user += ':' + _quote(val.password) + else: + user = '' + if val.password: + user += ':' + _quote(val.password) + if user: netloc = user + '@' + netloc path = _quote(val[2], safe='+@:', protected='/+', strict=strict) @@ -380,7 +383,10 @@ class URL: """ # not .username - return self._val.username + ret = self._val.username + if not ret: + return None + return ret @cached_property def user(self): @@ -590,7 +596,7 @@ class URL: ret = ret + ':' + str(port) if password: if not user: - raise ValueError("Non-empty password requires non-empty user") + user = '' user = user + ':' + password if user: ret = user + '@' + ret
aio-libs/yarl
6a091a171b0419dfa5ed67049d432d50d3301ce8
diff --git a/tests/test_url.py b/tests/test_url.py index b5d365e..d2582ff 100644 --- a/tests/test_url.py +++ b/tests/test_url.py @@ -77,6 +77,11 @@ def test_raw_user_non_ascii(): assert '%D0%B2%D0%B0%D1%81%D1%8F' == url.raw_user +def test_no_user(): + url = URL('http://example.com') + assert url.user is None + + def test_user_non_ascii(): url = URL('http://вася@example.com') assert 'вася' == url.user @@ -97,6 +102,11 @@ def test_password_non_ascii(): assert 'пароль' == url.password +def test_password_without_user(): + url = URL('http://:[email protected]') + assert 'password' == url.password + + def test_raw_host(): url = URL('http://example.com') assert "example.com" == url.raw_host diff --git a/tests/test_url_update_netloc.py b/tests/test_url_update_netloc.py index 9790dd4..46bdab0 100644 --- a/tests/test_url_update_netloc.py +++ b/tests/test_url_update_netloc.py @@ -90,8 +90,10 @@ def test_with_password_invalid_type(): def test_with_password_and_empty_user(): url = URL('http://example.com') - with pytest.raises(ValueError): - assert str(url.with_password('pass')) + url2 = url.with_password('pass') + assert url2.password == 'pass' + assert url2.user is None + assert str(url2) == 'http://:[email protected]' def test_from_str_with_host_ipv4():
Passwords without users Currently, yarl refuses to set an password if a user isn't set. That's a bit unfortunate because that’s exactly what you need if you’re building redis URLs: https://redis-py.readthedocs.io/en/latest/#redis.StrictRedis.from_url
0.0
6a091a171b0419dfa5ed67049d432d50d3301ce8
[ "tests/test_url.py::test_password_without_user", "tests/test_url_update_netloc.py::test_with_password_and_empty_user" ]
[ "tests/test_url.py::test_absolute_url_without_host", "tests/test_url.py::test_url_is_not_str", "tests/test_url.py::test_str", "tests/test_url.py::test_repr", "tests/test_url.py::test_origin", "tests/test_url.py::test_origin_not_absolute_url", "tests/test_url.py::test_origin_no_scheme", "tests/test_url.py::test_drop_dots", "tests/test_url.py::test_abs_cmp", "tests/test_url.py::test_abs_hash", "tests/test_url.py::test_scheme", "tests/test_url.py::test_raw_user", "tests/test_url.py::test_raw_user_non_ascii", "tests/test_url.py::test_no_user", "tests/test_url.py::test_user_non_ascii", "tests/test_url.py::test_raw_password", "tests/test_url.py::test_raw_password_non_ascii", "tests/test_url.py::test_password_non_ascii", "tests/test_url.py::test_raw_host", "tests/test_url.py::test_raw_host_non_ascii", "tests/test_url.py::test_host_non_ascii", "tests/test_url.py::test_raw_host_when_port_is_specified", "tests/test_url.py::test_raw_host_from_str_with_ipv4", "tests/test_url.py::test_raw_host_from_str_with_ipv6", "tests/test_url.py::test_explicit_port", "tests/test_url.py::test_implicit_port", "tests/test_url.py::test_port_for_relative_url", "tests/test_url.py::test_port_for_unknown_scheme", "tests/test_url.py::test_raw_path_string_empty", "tests/test_url.py::test_raw_path", "tests/test_url.py::test_raw_path_non_ascii", "tests/test_url.py::test_path_non_ascii", "tests/test_url.py::test_path_with_spaces", "tests/test_url.py::test_raw_path_for_empty_url", "tests/test_url.py::test_raw_path_for_colon_and_at", "tests/test_url.py::test_raw_query_string", "tests/test_url.py::test_raw_query_string_non_ascii", "tests/test_url.py::test_query_string_non_ascii", "tests/test_url.py::test_path_qs", "tests/test_url.py::test_query_string_spaces", "tests/test_url.py::test_raw_fragment_empty", "tests/test_url.py::test_raw_fragment", "tests/test_url.py::test_raw_fragment_non_ascii", "tests/test_url.py::test_raw_fragment_safe", "tests/test_url.py::test_fragment_non_ascii", "tests/test_url.py::test_raw_parts_empty", "tests/test_url.py::test_raw_parts", "tests/test_url.py::test_raw_parts_without_path", "tests/test_url.py::test_raw_path_parts_with_2F_in_path", "tests/test_url.py::test_raw_path_parts_with_2f_in_path", "tests/test_url.py::test_raw_parts_for_relative_path", "tests/test_url.py::test_raw_parts_for_relative_path_starting_from_slash", "tests/test_url.py::test_raw_parts_for_relative_double_path", "tests/test_url.py::test_parts_for_empty_url", "tests/test_url.py::test_raw_parts_non_ascii", "tests/test_url.py::test_parts_non_ascii", "tests/test_url.py::test_name_for_empty_url", "tests/test_url.py::test_raw_name", "tests/test_url.py::test_raw_name_root", "tests/test_url.py::test_raw_name_root2", "tests/test_url.py::test_raw_name_root3", "tests/test_url.py::test_relative_raw_name", "tests/test_url.py::test_relative_raw_name_starting_from_slash", "tests/test_url.py::test_relative_raw_name_slash", "tests/test_url.py::test_name_non_ascii", "tests/test_url.py::test_plus_in_path", "tests/test_url.py::test_parent_raw_path", "tests/test_url.py::test_parent_raw_parts", "tests/test_url.py::test_double_parent_raw_path", "tests/test_url.py::test_empty_parent_raw_path", "tests/test_url.py::test_empty_parent_raw_path2", "tests/test_url.py::test_clear_fragment_on_getting_parent", "tests/test_url.py::test_clear_fragment_on_getting_parent_toplevel", "tests/test_url.py::test_clear_query_on_getting_parent", "tests/test_url.py::test_clear_query_on_getting_parent_toplevel", "tests/test_url.py::test_div_root", "tests/test_url.py::test_div_root_with_slash", "tests/test_url.py::test_div", "tests/test_url.py::test_div_with_slash", "tests/test_url.py::test_div_path_starting_from_slash_is_forbidden", "tests/test_url.py::test_div_cleanup_query_and_fragment", "tests/test_url.py::test_div_for_empty_url", "tests/test_url.py::test_div_for_relative_url", "tests/test_url.py::test_div_for_relative_url_started_with_slash", "tests/test_url.py::test_div_non_ascii", "tests/test_url.py::test_div_with_colon_and_at", "tests/test_url.py::test_div_with_dots", "tests/test_url.py::test_with_path", "tests/test_url.py::test_with_path_encoded", "tests/test_url.py::test_with_path_dots", "tests/test_url.py::test_with_path_relative", "tests/test_url.py::test_with_path_query", "tests/test_url.py::test_with_path_fragment", "tests/test_url.py::test_with_path_empty", "tests/test_url.py::test_with_path_leading_slash", "tests/test_url.py::test_with_fragment", "tests/test_url.py::test_with_fragment_safe", "tests/test_url.py::test_with_fragment_non_ascii", "tests/test_url.py::test_with_fragment_None", "tests/test_url.py::test_with_fragment_bad_type", "tests/test_url.py::test_with_name", "tests/test_url.py::test_with_name_for_naked_path", "tests/test_url.py::test_with_name_for_relative_path", "tests/test_url.py::test_with_name_for_relative_path2", "tests/test_url.py::test_with_name_for_relative_path_starting_from_slash", "tests/test_url.py::test_with_name_for_relative_path_starting_from_slash2", "tests/test_url.py::test_with_name_empty", "tests/test_url.py::test_with_name_non_ascii", "tests/test_url.py::test_with_name_with_slash", "tests/test_url.py::test_with_name_non_str", "tests/test_url.py::test_with_name_within_colon_and_at", "tests/test_url.py::test_with_name_dot", "tests/test_url.py::test_with_name_double_dot", "tests/test_url.py::test_is_absolute_for_relative_url", "tests/test_url.py::test_is_absolute_for_absolute_url", "tests/test_url.py::test_is_non_absolute_for_empty_url", "tests/test_url.py::test_is_non_absolute_for_empty_url2", "tests/test_url.py::test_is_absolute_path_starting_from_double_slash", "tests/test_url.py::test_is_default_port_for_relative_url", "tests/test_url.py::test_is_default_port_for_absolute_url_without_port", "tests/test_url.py::test_is_default_port_for_absolute_url_with_default_port", "tests/test_url.py::test_is_default_port_for_absolute_url_with_nondefault_port", "tests/test_url.py::test_is_default_port_for_unknown_scheme", "tests/test_url.py::test_no_scheme", "tests/test_url.py::test_no_scheme2", "tests/test_url.py::test_from_non_allowed", "tests/test_url.py::test_from_idna", "tests/test_url.py::test_to_idna", "tests/test_url.py::test_from_ascii_login", "tests/test_url.py::test_from_non_ascii_login", "tests/test_url.py::test_from_ascii_login_and_password", "tests/test_url.py::test_from_non_ascii_login_and_password", "tests/test_url.py::test_from_ascii_path", "tests/test_url.py::test_from_ascii_path_lower_case", "tests/test_url.py::test_from_non_ascii_path", "tests/test_url.py::test_from_ascii_query_parts", "tests/test_url.py::test_from_non_ascii_query_parts", "tests/test_url.py::test_from_non_ascii_query_parts2", "tests/test_url.py::test_from_ascii_fragment", "tests/test_url.py::test_from_bytes_with_non_ascii_fragment", "tests/test_url.py::test_to_str", "tests/test_url.py::test_to_str_long", "tests/test_url.py::test_decoding_with_2F_in_path", "tests/test_url.py::test_decoding_with_26_and_3D_in_query", "tests/test_url.py::test_fragment_only_url", "tests/test_url.py::test_url_from_url", "tests/test_url.py::test_lowercase_scheme", "tests/test_url.py::test_str_for_empty_url", "tests/test_url.py::test_parent_for_empty_url", "tests/test_url.py::test_empty_value_for_query", "tests/test_url.py::test_decode_pct_in_path", "tests/test_url.py::test_decode_pct_in_path_lower_case", "tests/test_url.py::test_join", "tests/test_url.py::test_join_absolute", "tests/test_url.py::test_join_non_url", "tests/test_url.py::test_join_from_rfc_3986_normal[g:h-g:h]", "tests/test_url.py::test_join_from_rfc_3986_normal[g-http://a/b/c/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[./g-http://a/b/c/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[g/-http://a/b/c/g/]", "tests/test_url.py::test_join_from_rfc_3986_normal[/g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[//g-http://g]", "tests/test_url.py::test_join_from_rfc_3986_normal[?y-http://a/b/c/d;p?y]", "tests/test_url.py::test_join_from_rfc_3986_normal[g?y-http://a/b/c/g?y]", "tests/test_url.py::test_join_from_rfc_3986_normal[#s-http://a/b/c/d;p?q#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[g#s-http://a/b/c/g#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[g?y#s-http://a/b/c/g?y#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[;x-http://a/b/c/;x]", "tests/test_url.py::test_join_from_rfc_3986_normal[g;x-http://a/b/c/g;x]", "tests/test_url.py::test_join_from_rfc_3986_normal[g;x?y#s-http://a/b/c/g;x?y#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[-http://a/b/c/d;p?q]", "tests/test_url.py::test_join_from_rfc_3986_normal[.-http://a/b/c/]", "tests/test_url.py::test_join_from_rfc_3986_normal[./-http://a/b/c/]", "tests/test_url.py::test_join_from_rfc_3986_normal[..-http://a/b/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../-http://a/b/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../g-http://a/b/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[../..-http://a/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../../-http://a/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[../../../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[../../../../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[/./g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[/../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g.-http://a/b/c/g.]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[.g-http://a/b/c/.g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g..-http://a/b/c/g..]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[..g-http://a/b/c/..g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[./../g-http://a/b/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[./g/.-http://a/b/c/g/]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g/./h-http://a/b/c/g/h]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g/../h-http://a/b/c/h]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g;x=1/./y-http://a/b/c/g;x=1/y]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g;x=1/../y-http://a/b/c/y]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g?y/./x-http://a/b/c/g?y/./x]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g?y/../x-http://a/b/c/g?y/../x]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g#s/./x-http://a/b/c/g#s/./x]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g#s/../x-http://a/b/c/g#s/../x]", "tests/test_url.py::test_split_result_non_decoded", "tests/test_url.py::test_human_repr", "tests/test_url.py::test_human_repr_defaults", "tests/test_url.py::test_human_repr_default_port", "tests/test_url.py::test_relative", "tests/test_url.py::test_relative_is_relative", "tests/test_url.py::test_relative_abs_parts_are_removed", "tests/test_url.py::test_relative_fails_on_rel_url", "tests/test_url.py::test_slash_and_question_in_query", "tests/test_url.py::test_slash_and_question_in_fragment", "tests/test_url.py::test_requoting", "tests/test_url_update_netloc.py::test_with_scheme", "tests/test_url_update_netloc.py::test_with_scheme_uppercased", "tests/test_url_update_netloc.py::test_with_scheme_for_relative_url", "tests/test_url_update_netloc.py::test_with_scheme_invalid_type", "tests/test_url_update_netloc.py::test_with_user", "tests/test_url_update_netloc.py::test_with_user_non_ascii", "tests/test_url_update_netloc.py::test_with_user_for_relative_url", "tests/test_url_update_netloc.py::test_with_user_invalid_type", "tests/test_url_update_netloc.py::test_with_user_None", "tests/test_url_update_netloc.py::test_with_user_None_when_password_present", "tests/test_url_update_netloc.py::test_with_password", "tests/test_url_update_netloc.py::test_with_password_non_ascii", "tests/test_url_update_netloc.py::test_with_password_for_relative_url", "tests/test_url_update_netloc.py::test_with_password_None", "tests/test_url_update_netloc.py::test_with_password_invalid_type", "tests/test_url_update_netloc.py::test_from_str_with_host_ipv4", "tests/test_url_update_netloc.py::test_from_str_with_host_ipv6", "tests/test_url_update_netloc.py::test_with_host", "tests/test_url_update_netloc.py::test_with_host_empty", "tests/test_url_update_netloc.py::test_with_host_non_ascii", "tests/test_url_update_netloc.py::test_with_host_for_relative_url", "tests/test_url_update_netloc.py::test_with_host_invalid_type", "tests/test_url_update_netloc.py::test_with_port", "tests/test_url_update_netloc.py::test_with_port_keeps_query_and_fragment", "tests/test_url_update_netloc.py::test_with_port_for_relative_url", "tests/test_url_update_netloc.py::test_with_port_invalid_type" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2017-09-01 11:48:08+00:00
apache-2.0
973
aio-libs__yarl-191
diff --git a/CHANGES.rst b/CHANGES.rst index 5fa41b2..a6d5665 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -1,6 +1,11 @@ CHANGES ======= +1.2.3 (2018-05-03) +------------------ + +* Accept `str` subclasses in `URL` constructor (#190) + 1.2.2 (2018-05-01) ------------------ diff --git a/appveyor.yml b/appveyor.yml index a0f7c19..a8dc45f 100644 --- a/appveyor.yml +++ b/appveyor.yml @@ -4,9 +4,6 @@ environment: PYPI_PASSWD: secure: u+K6dKi7+CXXVFEUG4V7zUyV3w7Ntg0Ork/RGVV0eSQ= matrix: - - PYTHON: "C:\\Python34" - - PYTHON: "C:\\Python34-x64" - DISTUTILS_USE_SDK: "1" - PYTHON: "C:\\Python35" - PYTHON: "C:\\Python35-x64" - PYTHON: "C:\\Python36" diff --git a/yarl/__init__.py b/yarl/__init__.py index ddeeb40..13340c6 100644 --- a/yarl/__init__.py +++ b/yarl/__init__.py @@ -151,6 +151,8 @@ class URL: elif type(val) is SplitResult: if not encoded: raise ValueError("Cannot apply decoding to SplitResult") + elif isinstance(val, str): + val = urlsplit(str(val)) else: raise TypeError("Constructor parameter should be str")
aio-libs/yarl
780975bdb8b8cd7145377280e8adaf6e53f67fce
diff --git a/tests/test_url.py b/tests/test_url.py index a12e25b..598e0fd 100644 --- a/tests/test_url.py +++ b/tests/test_url.py @@ -17,6 +17,13 @@ def test_inheritance(): "from URL is forbidden" == str(ctx.value)) +def test_str_subclass(): + class S(str): + pass + + assert str(URL(S('http://example.com'))) == 'http://example.com' + + def test_is(): u1 = URL('http://example.com') u2 = URL(u1)
`if type(val) is str` is a bit too strict It makes sense to use a subclass of str for example if I want to put a secret into a class but want to censor the repr: https://github.com/hynek/environ_config/blob/69b1c8ab25fde3c20fa21de1a044e30760c86d36/src/environ/secrets.py#L114-L124 This breaks with the latest versions.
0.0
780975bdb8b8cd7145377280e8adaf6e53f67fce
[ "tests/test_url.py::test_str_subclass" ]
[ "tests/test_url.py::test_inheritance", "tests/test_url.py::test_is", "tests/test_url.py::test_absolute_url_without_host", "tests/test_url.py::test_url_is_not_str", "tests/test_url.py::test_str", "tests/test_url.py::test_repr", "tests/test_url.py::test_origin", "tests/test_url.py::test_origin_not_absolute_url", "tests/test_url.py::test_origin_no_scheme", "tests/test_url.py::test_drop_dots", "tests/test_url.py::test_abs_cmp", "tests/test_url.py::test_abs_hash", "tests/test_url.py::test_scheme", "tests/test_url.py::test_raw_user", "tests/test_url.py::test_raw_user_non_ascii", "tests/test_url.py::test_no_user", "tests/test_url.py::test_user_non_ascii", "tests/test_url.py::test_raw_password", "tests/test_url.py::test_raw_password_non_ascii", "tests/test_url.py::test_password_non_ascii", "tests/test_url.py::test_password_without_user", "tests/test_url.py::test_raw_host", "tests/test_url.py::test_raw_host_non_ascii", "tests/test_url.py::test_host_non_ascii", "tests/test_url.py::test_localhost", "tests/test_url.py::test_host_with_underscore", "tests/test_url.py::test_raw_host_when_port_is_specified", "tests/test_url.py::test_raw_host_from_str_with_ipv4", "tests/test_url.py::test_raw_host_from_str_with_ipv6", "tests/test_url.py::test_lowercase", "tests/test_url.py::test_lowercase_nonascii", "tests/test_url.py::test_compressed_ipv6", "tests/test_url.py::test_ipv6_zone", "tests/test_url.py::test_ipv4_zone", "tests/test_url.py::test_explicit_port", "tests/test_url.py::test_implicit_port", "tests/test_url.py::test_port_for_relative_url", "tests/test_url.py::test_port_for_unknown_scheme", "tests/test_url.py::test_raw_path_string_empty", "tests/test_url.py::test_raw_path", "tests/test_url.py::test_raw_path_non_ascii", "tests/test_url.py::test_path_non_ascii", "tests/test_url.py::test_path_with_spaces", "tests/test_url.py::test_raw_path_for_empty_url", "tests/test_url.py::test_raw_path_for_colon_and_at", "tests/test_url.py::test_raw_query_string", "tests/test_url.py::test_raw_query_string_non_ascii", "tests/test_url.py::test_query_string_non_ascii", "tests/test_url.py::test_path_qs", "tests/test_url.py::test_raw_path_qs", "tests/test_url.py::test_query_string_spaces", "tests/test_url.py::test_raw_fragment_empty", "tests/test_url.py::test_raw_fragment", "tests/test_url.py::test_raw_fragment_non_ascii", "tests/test_url.py::test_raw_fragment_safe", "tests/test_url.py::test_fragment_non_ascii", "tests/test_url.py::test_raw_parts_empty", "tests/test_url.py::test_raw_parts", "tests/test_url.py::test_raw_parts_without_path", "tests/test_url.py::test_raw_path_parts_with_2F_in_path", "tests/test_url.py::test_raw_path_parts_with_2f_in_path", "tests/test_url.py::test_raw_parts_for_relative_path", "tests/test_url.py::test_raw_parts_for_relative_path_starting_from_slash", "tests/test_url.py::test_raw_parts_for_relative_double_path", "tests/test_url.py::test_parts_for_empty_url", "tests/test_url.py::test_raw_parts_non_ascii", "tests/test_url.py::test_parts_non_ascii", "tests/test_url.py::test_name_for_empty_url", "tests/test_url.py::test_raw_name", "tests/test_url.py::test_raw_name_root", "tests/test_url.py::test_raw_name_root2", "tests/test_url.py::test_raw_name_root3", "tests/test_url.py::test_relative_raw_name", "tests/test_url.py::test_relative_raw_name_starting_from_slash", "tests/test_url.py::test_relative_raw_name_slash", "tests/test_url.py::test_name_non_ascii", "tests/test_url.py::test_plus_in_path", "tests/test_url.py::test_parent_raw_path", "tests/test_url.py::test_parent_raw_parts", "tests/test_url.py::test_double_parent_raw_path", "tests/test_url.py::test_empty_parent_raw_path", "tests/test_url.py::test_empty_parent_raw_path2", "tests/test_url.py::test_clear_fragment_on_getting_parent", "tests/test_url.py::test_clear_fragment_on_getting_parent_toplevel", "tests/test_url.py::test_clear_query_on_getting_parent", "tests/test_url.py::test_clear_query_on_getting_parent_toplevel", "tests/test_url.py::test_div_root", "tests/test_url.py::test_div_root_with_slash", "tests/test_url.py::test_div", "tests/test_url.py::test_div_with_slash", "tests/test_url.py::test_div_path_starting_from_slash_is_forbidden", "tests/test_url.py::test_div_cleanup_query_and_fragment", "tests/test_url.py::test_div_for_empty_url", "tests/test_url.py::test_div_for_relative_url", "tests/test_url.py::test_div_for_relative_url_started_with_slash", "tests/test_url.py::test_div_non_ascii", "tests/test_url.py::test_div_with_colon_and_at", "tests/test_url.py::test_div_with_dots", "tests/test_url.py::test_with_path", "tests/test_url.py::test_with_path_encoded", "tests/test_url.py::test_with_path_dots", "tests/test_url.py::test_with_path_relative", "tests/test_url.py::test_with_path_query", "tests/test_url.py::test_with_path_fragment", "tests/test_url.py::test_with_path_empty", "tests/test_url.py::test_with_path_leading_slash", "tests/test_url.py::test_with_fragment", "tests/test_url.py::test_with_fragment_safe", "tests/test_url.py::test_with_fragment_non_ascii", "tests/test_url.py::test_with_fragment_None", "tests/test_url.py::test_with_fragment_bad_type", "tests/test_url.py::test_with_name", "tests/test_url.py::test_with_name_for_naked_path", "tests/test_url.py::test_with_name_for_relative_path", "tests/test_url.py::test_with_name_for_relative_path2", "tests/test_url.py::test_with_name_for_relative_path_starting_from_slash", "tests/test_url.py::test_with_name_for_relative_path_starting_from_slash2", "tests/test_url.py::test_with_name_empty", "tests/test_url.py::test_with_name_non_ascii", "tests/test_url.py::test_with_name_with_slash", "tests/test_url.py::test_with_name_non_str", "tests/test_url.py::test_with_name_within_colon_and_at", "tests/test_url.py::test_with_name_dot", "tests/test_url.py::test_with_name_double_dot", "tests/test_url.py::test_is_absolute_for_relative_url", "tests/test_url.py::test_is_absolute_for_absolute_url", "tests/test_url.py::test_is_non_absolute_for_empty_url", "tests/test_url.py::test_is_non_absolute_for_empty_url2", "tests/test_url.py::test_is_absolute_path_starting_from_double_slash", "tests/test_url.py::test_is_default_port_for_relative_url", "tests/test_url.py::test_is_default_port_for_absolute_url_without_port", "tests/test_url.py::test_is_default_port_for_absolute_url_with_default_port", "tests/test_url.py::test_is_default_port_for_absolute_url_with_nondefault_port", "tests/test_url.py::test_is_default_port_for_unknown_scheme", "tests/test_url.py::test_no_scheme", "tests/test_url.py::test_no_scheme2", "tests/test_url.py::test_from_non_allowed", "tests/test_url.py::test_from_idna", "tests/test_url.py::test_to_idna", "tests/test_url.py::test_from_ascii_login", "tests/test_url.py::test_from_non_ascii_login", "tests/test_url.py::test_from_ascii_login_and_password", "tests/test_url.py::test_from_non_ascii_login_and_password", "tests/test_url.py::test_from_ascii_path", "tests/test_url.py::test_from_ascii_path_lower_case", "tests/test_url.py::test_from_non_ascii_path", "tests/test_url.py::test_from_ascii_query_parts", "tests/test_url.py::test_from_non_ascii_query_parts", "tests/test_url.py::test_from_non_ascii_query_parts2", "tests/test_url.py::test_from_ascii_fragment", "tests/test_url.py::test_from_bytes_with_non_ascii_fragment", "tests/test_url.py::test_to_str", "tests/test_url.py::test_to_str_long", "tests/test_url.py::test_decoding_with_2F_in_path", "tests/test_url.py::test_decoding_with_26_and_3D_in_query", "tests/test_url.py::test_fragment_only_url", "tests/test_url.py::test_url_from_url", "tests/test_url.py::test_lowercase_scheme", "tests/test_url.py::test_str_for_empty_url", "tests/test_url.py::test_parent_for_empty_url", "tests/test_url.py::test_empty_value_for_query", "tests/test_url.py::test_decode_pct_in_path", "tests/test_url.py::test_decode_pct_in_path_lower_case", "tests/test_url.py::test_join", "tests/test_url.py::test_join_absolute", "tests/test_url.py::test_join_non_url", "tests/test_url.py::test_join_from_rfc_3986_normal[g:h-g:h]", "tests/test_url.py::test_join_from_rfc_3986_normal[g-http://a/b/c/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[./g-http://a/b/c/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[g/-http://a/b/c/g/]", "tests/test_url.py::test_join_from_rfc_3986_normal[/g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[//g-http://g]", "tests/test_url.py::test_join_from_rfc_3986_normal[?y-http://a/b/c/d;p?y]", "tests/test_url.py::test_join_from_rfc_3986_normal[g?y-http://a/b/c/g?y]", "tests/test_url.py::test_join_from_rfc_3986_normal[#s-http://a/b/c/d;p?q#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[g#s-http://a/b/c/g#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[g?y#s-http://a/b/c/g?y#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[;x-http://a/b/c/;x]", "tests/test_url.py::test_join_from_rfc_3986_normal[g;x-http://a/b/c/g;x]", "tests/test_url.py::test_join_from_rfc_3986_normal[g;x?y#s-http://a/b/c/g;x?y#s]", "tests/test_url.py::test_join_from_rfc_3986_normal[-http://a/b/c/d;p?q]", "tests/test_url.py::test_join_from_rfc_3986_normal[.-http://a/b/c/]", "tests/test_url.py::test_join_from_rfc_3986_normal[./-http://a/b/c/]", "tests/test_url.py::test_join_from_rfc_3986_normal[..-http://a/b/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../-http://a/b/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../g-http://a/b/g]", "tests/test_url.py::test_join_from_rfc_3986_normal[../..-http://a/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../../-http://a/]", "tests/test_url.py::test_join_from_rfc_3986_normal[../../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[../../../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[../../../../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[/./g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[/../g-http://a/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g.-http://a/b/c/g.]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[.g-http://a/b/c/.g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g..-http://a/b/c/g..]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[..g-http://a/b/c/..g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[./../g-http://a/b/g]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[./g/.-http://a/b/c/g/]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g/./h-http://a/b/c/g/h]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g/../h-http://a/b/c/h]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g;x=1/./y-http://a/b/c/g;x=1/y]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g;x=1/../y-http://a/b/c/y]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g?y/./x-http://a/b/c/g?y/./x]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g?y/../x-http://a/b/c/g?y/../x]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g#s/./x-http://a/b/c/g#s/./x]", "tests/test_url.py::test_join_from_rfc_3986_abnormal[g#s/../x-http://a/b/c/g#s/../x]", "tests/test_url.py::test_split_result_non_decoded", "tests/test_url.py::test_human_repr", "tests/test_url.py::test_human_repr_defaults", "tests/test_url.py::test_human_repr_default_port", "tests/test_url.py::test_relative", "tests/test_url.py::test_relative_is_relative", "tests/test_url.py::test_relative_abs_parts_are_removed", "tests/test_url.py::test_relative_fails_on_rel_url", "tests/test_url.py::test_slash_and_question_in_query", "tests/test_url.py::test_slash_and_question_in_fragment", "tests/test_url.py::test_requoting" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2018-05-03 11:15:48+00:00
apache-2.0
974
aio-libs__yarl-959
diff --git a/CHANGES/883.bugfix b/CHANGES/883.bugfix new file mode 100644 index 0000000..9864377 --- /dev/null +++ b/CHANGES/883.bugfix @@ -0,0 +1,4 @@ +Started raising :py:exc:`TypeError` when a string value is passed into +:py:meth:`~yarl.URL.build` as the ``port`` argument -- by :user:`commonism`. + +Previously the empty string as port would create malformed URLs when rendered as string representations. diff --git a/yarl/_url.py b/yarl/_url.py index c8f2acb..d5202db 100644 --- a/yarl/_url.py +++ b/yarl/_url.py @@ -233,6 +233,8 @@ class URL: raise ValueError( 'Can\'t mix "authority" with "user", "password", "host" or "port".' ) + if not isinstance(port, (int, type(None))): + raise TypeError("The port is required to be int.") if port and not host: raise ValueError('Can\'t build URL with "port" but without "host".') if query and query_string:
aio-libs/yarl
e8cc8abbf0fa76bda0533b0440204b5b125f56bf
diff --git a/tests/test_url_build.py b/tests/test_url_build.py index 51969fa..ed07736 100644 --- a/tests/test_url_build.py +++ b/tests/test_url_build.py @@ -32,12 +32,28 @@ def test_build_with_scheme_and_host(): assert u == URL("http://127.0.0.1") -def test_build_with_port(): - with pytest.raises(ValueError): - URL.build(port=8000) - - u = URL.build(scheme="http", host="127.0.0.1", port=8000) - assert str(u) == "http://127.0.0.1:8000" [email protected]( + ("port", "exc", "match"), + [ + pytest.param( + 8000, + ValueError, + r"""(?x) + ^ + Can't\ build\ URL\ with\ "port"\ but\ without\ "host"\. + $ + """, + id="port-only", + ), + pytest.param( + "", TypeError, r"^The port is required to be int\.$", id="port-str" + ), + ], +) +def test_build_with_port(port, exc, match): + print(match) + with pytest.raises(exc, match=match): + URL.build(port=port) def test_build_with_user():
regression in URL.build(…,port="") ### Describe the bug Input filtering for with_port #793 changed the logic to render the URL to compare the port to None. https://github.com/aio-libs/yarl/commit/94b8679da05fd7b2d7bc86ed95e84c09f1946d75#r116844287 as it is possible to create a URL with a port="" via URL.build, this results in urls created with an empty port. ### To Reproduce ``` import yarl u = yarl.URL.build(scheme="http", host="api.com", port="", path="/v1") assert str(u) == "http://api.com/v1", str(u) ``` ### Expected behavior Filtering port="" in URL.build. I'd even prefer to allow "" and convert to None to stay backwards compatible. ### Logs/tracebacks ```python-traceback AssertionError: http://api.com:/v1 ``` ### Python Version ```console $ python --version Python 3.10.6 ``` ### multidict Version ```console $ python -m pip show multidict Name: multidict Version: 6.0.2 ``` ### yarl Version ```console $ python -m pip show yarl Name: yarl Version: 1.9.2 ``` ### OS Linux ### Additional context _No response_ ### Code of Conduct - [X] I agree to follow the aio-libs Code of Conduct
0.0
e8cc8abbf0fa76bda0533b0440204b5b125f56bf
[ "tests/test_url_build.py::test_build_with_port[port-str]" ]
[ "tests/test_url_build.py::test_query_str", "tests/test_url_build.py::test_build_path_quoting", "tests/test_url_build.py::test_build_with_none_query_string", "tests/test_url_build.py::test_build_with_scheme_and_host", "tests/test_url_build.py::test_build_with_authority", "tests/test_url_build.py::test_build_with_authority_with_path_without_leading_slash", "tests/test_url_build.py::test_build_with_user", "tests/test_url_build.py::test_build_with_host", "tests/test_url_build.py::test_build_with_authority_percent_encoded", "tests/test_url_build.py::test_build_without_arguments", "tests/test_url_build.py::test_build_drop_dots", "tests/test_url_build.py::test_build_with_scheme", "tests/test_url_build.py::test_build_with_none_host", "tests/test_url_build.py::test_build_with_authority_with_empty_path", "tests/test_url_build.py::test_build_with_port[port-only]", "tests/test_url_build.py::test_build_with_authority_percent_encoded_already_encoded", "tests/test_url_build.py::test_build_query_only", "tests/test_url_build.py::test_build_query_quoting", "tests/test_url_build.py::test_build_already_encoded", "tests/test_url_build.py::test_build_with_authority_and_host", "tests/test_url_build.py::test_build_encode", "tests/test_url_build.py::test_build_with_authority_without_encoding", "tests/test_url_build.py::test_build_simple", "tests/test_url_build.py::test_build_with_query_and_query_string", "tests/test_url_build.py::test_build_with_none_path", "tests/test_url_build.py::test_build_with_user_password", "tests/test_url_build.py::test_query_dict", "tests/test_url_build.py::test_build_with_none_fragment", "tests/test_url_build.py::test_build_with_all", "tests/test_url_build.py::test_build_percent_encoded", "tests/test_url_build.py::test_build_with_authority_with_path_with_leading_slash" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_added_files", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2023-11-21 15:17:46+00:00
apache-2.0
975
airbrake__pybrake-77
diff --git a/pybrake/notifier.py b/pybrake/notifier.py index 9218c51..c673108 100644 --- a/pybrake/notifier.py +++ b/pybrake/notifier.py @@ -295,7 +295,7 @@ class Notifier: needed = "/site-packages/" ind = s.find(needed) if ind > -1: - s = "[SITE_PACKAGES]/" + s[ind + len(needed) :] + s = "/SITE_PACKAGES/" + s[ind + len(needed) :] return s s = s.replace(self._context["rootDirectory"], "/PROJECT_ROOT")
airbrake/pybrake
6970c56dfd3cf8caba339321f020ebc04d8129b0
diff --git a/pybrake/test_notifier.py b/pybrake/test_notifier.py index e7bc2d9..8774ef8 100644 --- a/pybrake/test_notifier.py +++ b/pybrake/test_notifier.py @@ -205,3 +205,9 @@ def _test_rate_limited(): notice = future.result() assert notice["error"] == "IP is rate limited" + +def test_clean_filename(): + notifier = Notifier() + + filename = notifier._clean_filename("home/lib/python3.6/site-packages/python.py") + assert filename == "/SITE_PACKAGES/python.py"
[SITE_PACKAGES] -> /SITE_PACKAGES https://github.com/airbrake/pybrake/blob/master/pybrake/notifier.py#L298
0.0
6970c56dfd3cf8caba339321f020ebc04d8129b0
[ "pybrake/test_notifier.py::test_clean_filename" ]
[ "pybrake/test_notifier.py::test_build_notice_from_exception", "pybrake/test_notifier.py::test_build_notice_from_str", "pybrake/test_notifier.py::test_build_notice_from_none", "pybrake/test_notifier.py::test_environment", "pybrake/test_notifier.py::test_root_directory", "pybrake/test_notifier.py::test_filter_data", "pybrake/test_notifier.py::test_filter_ignore", "pybrake/test_notifier.py::test_filter_ignore_async", "pybrake/test_notifier.py::test_unknown_host", "pybrake/test_notifier.py::test_truncation", "pybrake/test_notifier.py::test_revision_override", "pybrake/test_notifier.py::test_revision_from_git", "pybrake/test_notifier.py::test_keys_blacklist_exact", "pybrake/test_notifier.py::test_keys_blacklist_regexp" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2019-03-23 12:37:51+00:00
mit
976
airspeed-velocity__asv-680
diff --git a/asv/results.py b/asv/results.py index 76dbe6b..8513b71 100644 --- a/asv/results.py +++ b/asv/results.py @@ -4,6 +4,7 @@ from __future__ import (absolute_import, division, print_function, unicode_literals) +import sys import base64 import os import zlib @@ -405,15 +406,31 @@ class Results(object): self._benchmark_version[benchmark_name] = benchmark_version if 'profile' in result and result['profile']: - self._profiles[benchmark_name] = base64.b64encode( + profile_data = base64.b64encode( zlib.compress(result['profile'])) + if sys.version_info[0] >= 3: + profile_data = profile_data.decode('ascii') + self._profiles[benchmark_name] = profile_data def get_profile(self, benchmark_name): """ Get the profile data for the given benchmark name. + + Parameters + ---------- + benchmark_name : str + Name of benchmark + + Returns + ------- + profile_data : bytes + Raw profile data + """ - return zlib.decompress( - base64.b64decode(self._profiles[benchmark_name])) + profile_data = self._profiles[benchmark_name] + if sys.version_info[0] >= 3: + profile_data = profile_data.encode('ascii') + return zlib.decompress(base64.b64decode(profile_data)) def has_profile(self, benchmark_name): """ diff --git a/asv/util.py b/asv/util.py index 748b9ba..34abb88 100644 --- a/asv/util.py +++ b/asv/util.py @@ -643,7 +643,11 @@ def write_json(path, data, api_version=None): data = dict(data) data['version'] = api_version - with long_path_open(path, 'w') as fd: + open_kwargs = {} + if sys.version_info[0] >= 3: + open_kwargs['encoding'] = 'utf-8' + + with long_path_open(path, 'w', **open_kwargs) as fd: json.dump(data, fd, indent=4, sort_keys=True) @@ -656,7 +660,11 @@ def load_json(path, api_version=None, cleanup=True): path = os.path.abspath(path) - with long_path_open(path, 'r') as fd: + open_kwargs = {} + if sys.version_info[0] >= 3: + open_kwargs['encoding'] = 'utf-8' + + with long_path_open(path, 'r', **open_kwargs) as fd: content = fd.read() if cleanup:
airspeed-velocity/asv
8f3e6786472a96c79446f6ca4d56707c90a76f22
diff --git a/test/test_results.py b/test/test_results.py index 2a7c0fb..d983a4a 100644 --- a/test/test_results.py +++ b/test/test_results.py @@ -35,13 +35,13 @@ def test_results(tmpdir): values = { 'suite1.benchmark1': {'result': [float(i * 0.001)], 'stats': [{'foo': 1}], 'samples': [[1,2]], 'number': [6], 'params': [['a']], - 'version': "1"}, + 'version': "1", 'profile': b'\x00\xff'}, 'suite1.benchmark2': {'result': [float(i * i * 0.001)], 'stats': [{'foo': 2}], 'samples': [[3,4]], 'number': [7], 'params': [], - 'version': "1"}, + 'version': "1", 'profile': b'\x00\xff'}, 'suite2.benchmark1': {'result': [float((i + 1) ** -1)], 'stats': [{'foo': 3}], 'samples': [[5,6]], 'number': [8], 'params': [['c']], - 'version': None} + 'version': None, 'profile': b'\x00\xff'} } for key, val in values.items(): @@ -66,6 +66,7 @@ def test_results(tmpdir): assert rr._stats == r._stats assert rr._number == r._number assert rr._samples == r._samples + assert rr._profiles == r._profiles assert rr.started_at == r._started_at assert rr.ended_at == r._ended_at assert rr.benchmark_version == r._benchmark_version @@ -87,6 +88,9 @@ def test_results(tmpdir): assert r2.get_result_stats(bench, bad_params) == [None, None] assert r2.get_result_samples(bench, bad_params) == ([None, None], [None, None]) + # Get profile + assert r2.get_profile(bench) == b'\x00\xff' + # Check get_result_keys mock_benchmarks = { 'suite1.benchmark1': {'version': '1'}, diff --git a/test/test_util.py b/test/test_util.py index d86167a..19c8ba7 100644 --- a/test/test_util.py +++ b/test/test_util.py @@ -269,3 +269,13 @@ def test_is_main_thread(): thread.join() assert results == [False] + + +def test_json_non_ascii(tmpdir): + non_ascii_data = [{'😼': '難', 'ä': 3}] + + fn = os.path.join(str(tmpdir), "nonascii.json") + util.write_json(fn, non_ascii_data) + data = util.load_json(fn) + + assert data == non_ascii_data diff --git a/test/test_workflow.py b/test/test_workflow.py index 2959f00..5e3983d 100644 --- a/test/test_workflow.py +++ b/test/test_workflow.py @@ -102,7 +102,7 @@ def test_run_publish(capfd, basic_conf): # Tests a typical complete run/publish workflow tools.run_asv_with_conf(conf, 'run', "master~5..master", '--steps=2', - '--quick', '--show-stderr', + '--quick', '--show-stderr', '--profile', _machine_file=machine_file) text, err = capfd.readouterr()
JSON serialization problem "TypeError: Object of type 'bytes' is not JSON serializable" during asv run --profile Python 3.6
0.0
8f3e6786472a96c79446f6ca4d56707c90a76f22
[ "test/test_results.py::test_results" ]
[ "test/test_results.py::test_get_result_hash_from_prefix", "test/test_results.py::test_backward_compat_load", "test/test_results.py::test_json_timestamp", "test/test_results.py::test_iter_results", "test/test_util.py::test_parallelfailure", "test/test_util.py::test_write_unicode_to_ascii", "test/test_util.py::test_which_path", "test/test_util.py::test_write_load_json", "test/test_util.py::test_human_float", "test/test_util.py::test_human_time", "test/test_util.py::test_human_file_size", "test/test_util.py::test_is_main_thread", "test/test_util.py::test_json_non_ascii" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2018-07-21 15:24:37+00:00
bsd-3-clause
977
airspeed-velocity__asv-681
diff --git a/asv/results.py b/asv/results.py index 76dbe6b..8513b71 100644 --- a/asv/results.py +++ b/asv/results.py @@ -4,6 +4,7 @@ from __future__ import (absolute_import, division, print_function, unicode_literals) +import sys import base64 import os import zlib @@ -405,15 +406,31 @@ class Results(object): self._benchmark_version[benchmark_name] = benchmark_version if 'profile' in result and result['profile']: - self._profiles[benchmark_name] = base64.b64encode( + profile_data = base64.b64encode( zlib.compress(result['profile'])) + if sys.version_info[0] >= 3: + profile_data = profile_data.decode('ascii') + self._profiles[benchmark_name] = profile_data def get_profile(self, benchmark_name): """ Get the profile data for the given benchmark name. + + Parameters + ---------- + benchmark_name : str + Name of benchmark + + Returns + ------- + profile_data : bytes + Raw profile data + """ - return zlib.decompress( - base64.b64decode(self._profiles[benchmark_name])) + profile_data = self._profiles[benchmark_name] + if sys.version_info[0] >= 3: + profile_data = profile_data.encode('ascii') + return zlib.decompress(base64.b64decode(profile_data)) def has_profile(self, benchmark_name): """ diff --git a/asv/util.py b/asv/util.py index 748b9ba..8e883dd 100644 --- a/asv/util.py +++ b/asv/util.py @@ -375,7 +375,9 @@ def check_output(args, valid_return_codes=(0,), timeout=600, dots=True, Setting to None ignores all return codes. timeout : number, optional - Kill the process if it lasts longer than `timeout` seconds. + Kill the process if it does not produce any output in `timeout` + seconds. If `None`, there is no timeout. + Default: 10 min dots : bool, optional If `True` (default) write a dot to the console to show @@ -475,7 +477,7 @@ def check_output(args, valid_return_codes=(0,), timeout=600, dots=True, def watcher_run(): while proc.returncode is None: time.sleep(0.1) - if time.time() - start_time[0] > timeout: + if timeout is not None and time.time() - start_time[0] > timeout: was_timeout[0] = True proc.send_signal(signal.CTRL_BREAK_EVENT) @@ -522,8 +524,12 @@ def check_output(args, valid_return_codes=(0,), timeout=600, dots=True, while proc.poll() is None: try: - rlist, wlist, xlist = select.select( - list(fds.keys()), [], [], timeout) + if timeout is None: + rlist, wlist, xlist = select.select( + list(fds.keys()), [], []) + else: + rlist, wlist, xlist = select.select( + list(fds.keys()), [], [], timeout) except select.error as err: if err.args[0] == errno.EINTR: # interrupted by signal handler; try again @@ -643,7 +649,11 @@ def write_json(path, data, api_version=None): data = dict(data) data['version'] = api_version - with long_path_open(path, 'w') as fd: + open_kwargs = {} + if sys.version_info[0] >= 3: + open_kwargs['encoding'] = 'utf-8' + + with long_path_open(path, 'w', **open_kwargs) as fd: json.dump(data, fd, indent=4, sort_keys=True) @@ -656,7 +666,11 @@ def load_json(path, api_version=None, cleanup=True): path = os.path.abspath(path) - with long_path_open(path, 'r') as fd: + open_kwargs = {} + if sys.version_info[0] >= 3: + open_kwargs['encoding'] = 'utf-8' + + with long_path_open(path, 'r', **open_kwargs) as fd: content = fd.read() if cleanup:
airspeed-velocity/asv
8f3e6786472a96c79446f6ca4d56707c90a76f22
diff --git a/test/test_results.py b/test/test_results.py index 2a7c0fb..d983a4a 100644 --- a/test/test_results.py +++ b/test/test_results.py @@ -35,13 +35,13 @@ def test_results(tmpdir): values = { 'suite1.benchmark1': {'result': [float(i * 0.001)], 'stats': [{'foo': 1}], 'samples': [[1,2]], 'number': [6], 'params': [['a']], - 'version': "1"}, + 'version': "1", 'profile': b'\x00\xff'}, 'suite1.benchmark2': {'result': [float(i * i * 0.001)], 'stats': [{'foo': 2}], 'samples': [[3,4]], 'number': [7], 'params': [], - 'version': "1"}, + 'version': "1", 'profile': b'\x00\xff'}, 'suite2.benchmark1': {'result': [float((i + 1) ** -1)], 'stats': [{'foo': 3}], 'samples': [[5,6]], 'number': [8], 'params': [['c']], - 'version': None} + 'version': None, 'profile': b'\x00\xff'} } for key, val in values.items(): @@ -66,6 +66,7 @@ def test_results(tmpdir): assert rr._stats == r._stats assert rr._number == r._number assert rr._samples == r._samples + assert rr._profiles == r._profiles assert rr.started_at == r._started_at assert rr.ended_at == r._ended_at assert rr.benchmark_version == r._benchmark_version @@ -87,6 +88,9 @@ def test_results(tmpdir): assert r2.get_result_stats(bench, bad_params) == [None, None] assert r2.get_result_samples(bench, bad_params) == ([None, None], [None, None]) + # Get profile + assert r2.get_profile(bench) == b'\x00\xff' + # Check get_result_keys mock_benchmarks = { 'suite1.benchmark1': {'version': '1'}, diff --git a/test/test_subprocess.py b/test/test_subprocess.py index 5be4fa7..f883ec7 100644 --- a/test/test_subprocess.py +++ b/test/test_subprocess.py @@ -122,6 +122,16 @@ print(os.environ['TEST_ASV_BAR']) assert output.splitlines() == ['foo', 'bar'] +def test_no_timeout(): + # Check that timeout=None is allowed. + code = "import time; time.sleep(0.05)" + out, err, retcode = util.check_output([sys.executable, "-c", code], timeout=None, + return_stderr=True) + assert out == '' + assert err == '' + assert retcode == 0 + + # This *does* seem to work, only seems untestable somehow... # def test_dots(capsys): # code = r""" diff --git a/test/test_util.py b/test/test_util.py index d86167a..19c8ba7 100644 --- a/test/test_util.py +++ b/test/test_util.py @@ -269,3 +269,13 @@ def test_is_main_thread(): thread.join() assert results == [False] + + +def test_json_non_ascii(tmpdir): + non_ascii_data = [{'😼': '難', 'ä': 3}] + + fn = os.path.join(str(tmpdir), "nonascii.json") + util.write_json(fn, non_ascii_data) + data = util.load_json(fn) + + assert data == non_ascii_data diff --git a/test/test_workflow.py b/test/test_workflow.py index 2959f00..5e3983d 100644 --- a/test/test_workflow.py +++ b/test/test_workflow.py @@ -102,7 +102,7 @@ def test_run_publish(capfd, basic_conf): # Tests a typical complete run/publish workflow tools.run_asv_with_conf(conf, 'run', "master~5..master", '--steps=2', - '--quick', '--show-stderr', + '--quick', '--show-stderr', '--profile', _machine_file=machine_file) text, err = capfd.readouterr()
Bug of asv profile with snakeviz (TypeError: '>' not supported between instances of 'float' and 'NoneType') I was following the [documentation of using asv](https://asv.readthedocs.io/en/stable/using.html) for my project. Everything worked fine, but then I've decided to profile using `asv`, and use a GUI tool for viewing the results. I could not install `RunSnakeRun` due to syntax error in Python 3 (I'm using Python 3.6). Hence, I've decided to install `snakeviz` because it is also mentioned in the `asv` docs. The installation went well, and I've started the `asv profile` command. During the execution of the command, `asv` printed an exception stack trace into the command line (see below). The snakeviz launched successfully, and displayed the results (hopefully) properly. Still, i've decided to report the issue (seems like a tiny bug). ```bash asv profile --gui snakeviz benchmarks.TimeSuite.time_keys ``` The output in the command line is the following: ``` · Discovering benchmarks ·· Uninstalling from conda-py3.6 ·· Building for conda-py3.6 ·· Installing into conda-py3.6 · Profile data does not already exist. Running profiler now. ·· Uninstalling from conda-py3.6 ·· Building for conda-py3.6 ·· Installing into conda-py3.6 ·· Benchmarking conda-py3.6 ··· Running benchmarks.TimeSuite.time_keys 7.66μsException i n thread Thread-58: Traceback (most recent call last): File "c:\users\a-miasta\appdata\local\continuum\anaconda3\envs\qcodes\lib\threading.py", line 916, in _bootstrap_inner self.run() File "c:\users\a-miasta\appdata\local\continuum\anaconda3\envs\qcodes\lib\threading.py", line 864, in run self._target(*self._args, **self._kwargs) File "c:\users\a-miasta\appdata\local\continuum\anaconda3\envs\qcodes\lib\site-packages\asv\util.py", line 407, in watcher_run if time.time() - start_time[0] > timeout: TypeError: '>' not supported between instances of 'float' and 'NoneType' ```
0.0
8f3e6786472a96c79446f6ca4d56707c90a76f22
[ "test/test_results.py::test_results" ]
[ "test/test_results.py::test_get_result_hash_from_prefix", "test/test_results.py::test_backward_compat_load", "test/test_results.py::test_json_timestamp", "test/test_results.py::test_iter_results", "test/test_subprocess.py::test_timeout", "test/test_subprocess.py::test_exception", "test/test_subprocess.py::test_output_timeout", "test/test_subprocess.py::test_env", "test/test_subprocess.py::test_no_timeout", "test/test_util.py::test_parallelfailure", "test/test_util.py::test_write_unicode_to_ascii", "test/test_util.py::test_which_path", "test/test_util.py::test_write_load_json", "test/test_util.py::test_human_float", "test/test_util.py::test_human_time", "test/test_util.py::test_human_file_size", "test/test_util.py::test_is_main_thread", "test/test_util.py::test_json_non_ascii" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2018-07-21 15:38:37+00:00
bsd-3-clause
978
airspeed-velocity__asv-683
diff --git a/asv/benchmark.py b/asv/benchmark.py index 20cf86f..8f6932f 100644 --- a/asv/benchmark.py +++ b/asv/benchmark.py @@ -470,10 +470,12 @@ class TimeBenchmark(Benchmark): samples = [s/number for s in samples] return {'samples': samples, 'number': number} - def benchmark_timing(self, timer, repeat, warmup_time, number=0): + def benchmark_timing(self, timer, repeat, warmup_time, number=0, + min_timeit_count=2): sample_time = self.sample_time start_time = time.time() + timeit_count = 0 if repeat == 0: # automatic number of samples: 10 is large enough to @@ -483,6 +485,8 @@ class TimeBenchmark(Benchmark): def too_slow(timing): # stop taking samples if limits exceeded + if timeit_count < min_timeit_count: + return False if default_number: t = 1.3*sample_time max_time = start_time + min(warmup_time + repeat * t, @@ -508,6 +512,7 @@ class TimeBenchmark(Benchmark): timing = timer.timeit(number) wall_time = time.time() - start actual_timing = max(wall_time, timing) + min_timeit_count += 1 if actual_timing >= sample_time: if time.time() > start_time + warmup_time: @@ -526,8 +531,10 @@ class TimeBenchmark(Benchmark): while True: self._redo_setup_next = False timing = timer.timeit(number) + min_timeit_count += 1 if time.time() >= start_time + warmup_time: break + if too_slow(timing): return [timing], number @@ -535,6 +542,7 @@ class TimeBenchmark(Benchmark): samples = [] for j in range(repeat): timing = timer.timeit(number) + min_timeit_count += 1 samples.append(timing) if too_slow(timing): diff --git a/asv/benchmarks.py b/asv/benchmarks.py index 8dacfbb..0dfb0ee 100644 --- a/asv/benchmarks.py +++ b/asv/benchmarks.py @@ -81,8 +81,6 @@ def run_benchmark(benchmark, root, env, show_stderr=False, - `samples`: List of lists of sampled raw data points, if benchmark produces those and was successful. - - `number`: Repeact count associated with each sample. - - `stats`: List of results of statistical analysis of data. - `profile`: If `profile` is `True` and run was at least partially successful, @@ -126,8 +124,8 @@ def run_benchmark(benchmark, root, env, show_stderr=False, if (selected_idx is not None and benchmark['params'] and param_idx not in selected_idx): # Use NaN to mark the result as skipped - bench_results.append(dict(samples=None, number=None, - result=float('nan'), stats=None)) + bench_results.append(dict(samples=None, result=float('nan'), + stats=None)) bench_profiles.append(None) continue success, data, profile_data, err, out, errcode = \ @@ -139,14 +137,13 @@ def run_benchmark(benchmark, root, env, show_stderr=False, total_count += 1 if success: if isinstance(data, dict) and 'samples' in data: - value, stats = statistics.compute_stats(data['samples']) + value, stats = statistics.compute_stats(data['samples'], + data['number']) result_data = dict(samples=data['samples'], - number=data['number'], result=value, stats=stats) else: result_data = dict(samples=None, - number=None, result=data, stats=None) @@ -155,7 +152,7 @@ def run_benchmark(benchmark, root, env, show_stderr=False, bench_profiles.append(profile_data) else: failure_count += 1 - bench_results.append(dict(samples=None, number=None, result=None, stats=None)) + bench_results.append(dict(samples=None, result=None, stats=None)) bench_profiles.append(None) if data is not None: bad_output = data @@ -181,7 +178,7 @@ def run_benchmark(benchmark, root, env, show_stderr=False, result['stderr'] += err # Produce result - for key in ['samples', 'number', 'result', 'stats']: + for key in ['samples', 'result', 'stats']: result[key] = [x[key] for x in bench_results] if benchmark['params']: diff --git a/asv/commands/run.py b/asv/commands/run.py index 69b73d2..dec7ab8 100644 --- a/asv/commands/run.py +++ b/asv/commands/run.py @@ -307,7 +307,6 @@ class Run(Command): for benchmark_name, d in six.iteritems(results): if not record_samples: d['samples'] = None - d['number'] = None benchmark_version = benchmarks[benchmark_name]['version'] result.add_result(benchmark_name, d, benchmark_version) diff --git a/asv/results.py b/asv/results.py index 8513b71..f7a4c70 100644 --- a/asv/results.py +++ b/asv/results.py @@ -213,7 +213,6 @@ class Results(object): self._date = date self._results = {} self._samples = {} - self._number = {} self._stats = {} self._benchmark_params = {} self._profiles = {} @@ -345,17 +344,11 @@ class Results(object): samples : {None, list} Raw result samples. If the benchmark is parameterized, return a list of values. - number : int - Associated repeat count """ - samples = _compatible_results(self._samples[key], - self._benchmark_params[key], - params) - number = _compatible_results(self._number[key], - self._benchmark_params[key], - params) - return samples, number + return _compatible_results(self._samples[key], + self._benchmark_params[key], + params) def get_result_params(self, key): """ @@ -370,7 +363,6 @@ class Results(object): del self._results[key] del self._benchmark_params[key] del self._samples[key] - del self._number[key] del self._stats[key] # Remove profiles (may be missing) @@ -398,7 +390,6 @@ class Results(object): """ self._results[benchmark_name] = result['result'] self._samples[benchmark_name] = result['samples'] - self._number[benchmark_name] = result['number'] self._stats[benchmark_name] = result['stats'] self._benchmark_params[benchmark_name] = result['params'] self._started_at[benchmark_name] = util.datetime_to_js_timestamp(result['started_at']) @@ -455,8 +446,6 @@ class Results(object): value = {'result': self._results[key]} if self._samples[key] and any(x is not None for x in self._samples[key]): value['samples'] = self._samples[key] - if self._number[key] and any(x is not None for x in self._number[key]): - value['number'] = self._number[key] if self._stats[key] and any(x is not None for x in self._stats[key]): value['stats'] = self._stats[key] if self._benchmark_params[key]: @@ -528,14 +517,13 @@ class Results(object): obj._results = {} obj._samples = {} - obj._number = {} obj._stats = {} obj._benchmark_params = {} for key, value in six.iteritems(d['results']): # Backward compatibility if not isinstance(value, dict): - value = {'result': [value], 'samples': None, 'number': None, + value = {'result': [value], 'samples': None, 'stats': None, 'params': []} if not isinstance(value['result'], list): @@ -545,14 +533,12 @@ class Results(object): value['stats'] = [value['stats']] value.setdefault('samples', None) - value.setdefault('number', None) value.setdefault('stats', None) value.setdefault('params', []) # Assign results obj._results[key] = value['result'] obj._samples[key] = value['samples'] - obj._number[key] = value['number'] obj._stats[key] = value['stats'] obj._benchmark_params[key] = value['params'] @@ -580,7 +566,7 @@ class Results(object): Add any existing old results that aren't overridden by the current results. """ - for dict_name in ('_samples', '_number', '_stats', + for dict_name in ('_samples', '_stats', '_benchmark_params', '_profiles', '_started_at', '_ended_at', '_benchmark_version'): old_dict = getattr(old, dict_name) diff --git a/asv/statistics.py b/asv/statistics.py index 3ef9e06..f05989e 100644 --- a/asv/statistics.py +++ b/asv/statistics.py @@ -11,7 +11,7 @@ import math from .util import inf, nan -def compute_stats(samples): +def compute_stats(samples, number): """ Statistical analysis of measured samples. @@ -19,6 +19,8 @@ def compute_stats(samples): ---------- samples : list of float List of total times (y) of benchmarks. + number : int + Repeat number for each sample. Returns ------- @@ -72,7 +74,8 @@ def compute_stats(samples): 'max': max(Y), 'mean': mean, 'std': std, - 'n': len(Y)} + 'repeat': len(Y), + 'number': number} return result, stats diff --git a/docs/source/dev.rst b/docs/source/dev.rst index 31fea20..7afae00 100644 --- a/docs/source/dev.rst +++ b/docs/source/dev.rst @@ -145,15 +145,11 @@ A benchmark suite directory has the following layout. The This key is omitted if there are no samples recorded. - - ``number``: contains the repeat count(s) associated with the - measured samples. Same format as for ``result``. - - This key is omitted if there are no samples recorded. - - ``stats``: dictionary containing results of statistical analysis. Contains keys ``ci_99`` (confidence interval estimate for the result), ``q_25``, ``q_75`` (percentiles), - ``min``, ``max``, ``mean``, ``std``, and ``n``. + ``min``, ``max``, ``mean``, ``std``, ``repeat``, and + ``number``. This key is omitted if there is no statistical analysis.
airspeed-velocity/asv
47b320d6252fba81581bf37b50571bcca578096d
diff --git a/test/test_results.py b/test/test_results.py index d983a4a..485bfd0 100644 --- a/test/test_results.py +++ b/test/test_results.py @@ -34,13 +34,13 @@ def test_results(tmpdir): values = { 'suite1.benchmark1': {'result': [float(i * 0.001)], 'stats': [{'foo': 1}], - 'samples': [[1,2]], 'number': [6], 'params': [['a']], + 'samples': [[1,2]], 'params': [['a']], 'version': "1", 'profile': b'\x00\xff'}, 'suite1.benchmark2': {'result': [float(i * i * 0.001)], 'stats': [{'foo': 2}], - 'samples': [[3,4]], 'number': [7], 'params': [], + 'samples': [[3,4]], 'params': [], 'version': "1", 'profile': b'\x00\xff'}, 'suite2.benchmark1': {'result': [float((i + 1) ** -1)], 'stats': [{'foo': 3}], - 'samples': [[5,6]], 'number': [8], 'params': [['c']], + 'samples': [[5,6]], 'params': [['c']], 'version': None, 'profile': b'\x00\xff'} } @@ -64,7 +64,6 @@ def test_results(tmpdir): for rr in [r2, r3]: assert rr._results == r._results assert rr._stats == r._stats - assert rr._number == r._number assert rr._samples == r._samples assert rr._profiles == r._profiles assert rr.started_at == r._started_at @@ -79,14 +78,13 @@ def test_results(tmpdir): assert params == values[bench]['params'] assert r2.get_result_value(bench, params) == values[bench]['result'] assert r2.get_result_stats(bench, params) == values[bench]['stats'] - assert r2.get_result_samples(bench, params) == (values[bench]['samples'], - values[bench]['number']) + assert r2.get_result_samples(bench, params) == values[bench]['samples'] # Get with different parameters than stored (should return n/a) bad_params = [['foo', 'bar']] assert r2.get_result_value(bench, bad_params) == [None, None] assert r2.get_result_stats(bench, bad_params) == [None, None] - assert r2.get_result_samples(bench, bad_params) == ([None, None], [None, None]) + assert r2.get_result_samples(bench, bad_params) == [None, None] # Get profile assert r2.get_profile(bench) == b'\x00\xff' @@ -150,7 +148,6 @@ def test_json_timestamp(tmpdir): 'params': [], 'stats': None, 'samples': None, - 'number': None, 'started_at': stamp1, 'ended_at': stamp2 } diff --git a/test/test_statistics.py b/test/test_statistics.py index 2bba2ad..6a19a28 100644 --- a/test/test_statistics.py +++ b/test/test_statistics.py @@ -30,14 +30,15 @@ except ImportError: def test_compute_stats(): np.random.seed(1) - assert statistics.compute_stats([]) == (None, None) - assert statistics.compute_stats([15.0]) == (15.0, None) + assert statistics.compute_stats([], 1) == (None, None) + assert statistics.compute_stats([15.0], 1) == (15.0, None) for nsamples, true_mean in product([10, 50, 250], [0, 0.3, 0.6]): samples = np.random.randn(nsamples) + true_mean - result, stats = statistics.compute_stats(samples) + result, stats = statistics.compute_stats(samples, 42) - assert np.allclose(stats['n'], len(samples)) + assert stats['repeat'] == len(samples) + assert stats['number'] == 42 assert np.allclose(stats['mean'], np.mean(samples)) assert np.allclose(stats['q_25'], np.percentile(samples, 25)) assert np.allclose(stats['q_75'], np.percentile(samples, 75)) @@ -64,8 +65,8 @@ def test_is_different(): for true_mean, n, significant in [(0.05, 10, False), (0.05, 100, True), (0.1, 10, True)]: samples_a = 0 + 0.1 * np.random.rand(n) samples_b = true_mean + 0.1 * np.random.rand(n) - result_a, stats_a = statistics.compute_stats(samples_a) - result_b, stats_b = statistics.compute_stats(samples_b) + result_a, stats_a = statistics.compute_stats(samples_a, 1) + result_b, stats_b = statistics.compute_stats(samples_b, 1) assert statistics.is_different(stats_a, stats_b) == significant
Big time difference for benchmarks that require high warmup I was running a benchmark with latest asv 0.3dev0 and I observed a big time difference from asv 0.2. * 0.2 https://github.com/poliastro/poliastro-benchmarks/blob/df6a71330f08c0c0ae1369818bc5af8106bba62f/results/ks1/d32f3ab8-conda-py3.6-matplotlib2.1-nomkl-numba-numpy1.14-scipy1.0.json#L31 * 0.3dev0 https://github.com/poliastro/poliastro-benchmarks/blob/f47fb57f2db0d76649ae7337867221b3738f057a/results/ks1/d3238535-conda-py3.6-matplotlib2.1-nomkl-numba-numpy1.14-scipy1.0.json#L34 After doing a git bisect, I arrived to [this commit](https://github.com/airspeed-velocity/asv/commit/db5cc300d39eb890292cf979d90f255b57dc9887) and [pull request](https://github.com/airspeed-velocity/asv/pull/493), which as far as I understand has not been backported to 0.2 yet. This particular benchmark calls a function accelerated with `@jit(nopython=True)`, so I suspected that warmup time had something to do with it. After playing a little bit with the parameters, I found that this diff brought back the old time measurement with asv 0.3dev0: ```diff diff --git a/benchmarks/examples.py b/benchmarks/examples.py index 13e86d8..d034eed 100644 --- a/benchmarks/examples.py +++ b/benchmarks/examples.py @@ -3,3 +3,5 @@ from poliastro.examples import iss def time_propagate_iss_one_period(): iss.propagate(iss.period) + +time_propagate_iss_one_period.repeat = 3 ``` So there is ~~a UX issue and~~ a measurement issue: * ~~The UX issue is that, as far as I know, there's no way to know _a posteriori_ how many repetitions, number of samples, etc did asv compute for a benchmark, as this information is not stored in the results.~~ * The measurement issue is that, with the current benchmark methodology, if a function requires a "big" warmup time (in this case, doing the numba JIT compilation), it will be run only once, which might or might not be representative of the intended result.
0.0
47b320d6252fba81581bf37b50571bcca578096d
[ "test/test_results.py::test_results", "test/test_results.py::test_json_timestamp" ]
[ "test/test_results.py::test_get_result_hash_from_prefix", "test/test_results.py::test_backward_compat_load", "test/test_results.py::test_iter_results", "test/test_statistics.py::test_quantile_ci_small", "test/test_statistics.py::test_quantile_ci_r", "test/test_statistics.py::test_laplace_posterior_basic" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2018-07-21 17:52:33+00:00
bsd-3-clause
979
airspeed-velocity__asv-702
diff --git a/asv/commands/profiling.py b/asv/commands/profiling.py index afabf6c..8028862 100644 --- a/asv/commands/profiling.py +++ b/asv/commands/profiling.py @@ -13,7 +13,7 @@ import tempfile from . import Command from ..benchmarks import Benchmarks -from ..console import log +from ..console import log, color_print from ..environment import get_environments, is_existing_only from ..machine import Machine from ..profiling import ProfilerGui @@ -123,8 +123,10 @@ class Profile(Command): machine_name = Machine.get_unique_machine_name() if revision is None: - revision = conf.branches[0] - commit_hash = repo.get_hash_from_name(revision) + rev = conf.branches[0] + else: + rev = revision + commit_hash = repo.get_hash_from_name(rev) profile_data = None checked_out = set() @@ -192,6 +194,8 @@ class Profile(Command): profile_data = results.get_profile(benchmark_name) + log.flush() + if gui is not None: log.debug("Opening gui {0}".format(gui)) with temp_profile(profile_data) as profile_path: @@ -200,6 +204,7 @@ class Profile(Command): with io.open(output, 'wb') as fd: fd.write(profile_data) else: + color_print('') with temp_profile(profile_data) as profile_path: stats = pstats.Stats(profile_path) stats.sort_stats('cumulative') diff --git a/asv/console.py b/asv/console.py index b573bd0..a7a6dac 100644 --- a/asv/console.py +++ b/asv/console.py @@ -274,9 +274,13 @@ class Log(object): else: rest = parts[1] + indent = self._indent + 1 + if self._total: - color_print('[{0:6.02f}%] '.format( - (float(self._count) / self._total) * 100.0), end='') + progress_msg = '[{0:6.02f}%] '.format( + (float(self._count) / self._total) * 100.0) + color_print(progress_msg, end='') + indent += len(progress_msg) color_print('·' * self._indent, end='') color_print(' ', end='') @@ -299,7 +303,6 @@ class Log(object): else: color = 'red' - indent = self._indent + 11 spaces = ' ' * indent color_print(first_line, color, end='') if rest is not None:
airspeed-velocity/asv
c9560bd78defaf02eecefc43e54953c10fb3a0d8
diff --git a/test/test_console.py b/test/test_console.py index a0e141f..282a389 100644 --- a/test/test_console.py +++ b/test/test_console.py @@ -11,7 +11,7 @@ import sys import locale import itertools -from asv.console import _write_with_fallback, color_print +from asv.console import _write_with_fallback, color_print, log def test_write_with_fallback(tmpdir, capfd): @@ -110,3 +110,19 @@ def test_color_print_nofail(capfd): assert 'indeed' in out assert 'really' in out assert 'not really' in out + + +def test_log_indent(capsys): + log.set_nitems(0) + log.info("First\nSecond") + + out, err = capsys.readouterr() + lines = out.lstrip().splitlines() + assert lines[0].index('First') == lines[1].index('Second') + + log.set_nitems(1) + log.info("First\nSecond") + + out, err = capsys.readouterr() + lines = out.lstrip().splitlines() + assert lines[0].index('First') == lines[1].index('Second') diff --git a/test/test_dev.py b/test/test_dev.py index 0d188d9..48453fe 100644 --- a/test/test_dev.py +++ b/test/test_dev.py @@ -42,6 +42,7 @@ def generate_basic_conf(tmpdir, repo_subdir=''): 'html_dir': 'html', 'repo': repo_path, 'project': 'asv', + 'branches': ['master'], 'matrix': { "six": [None], "colorama": ["0.3.6", "0.3.7"],
"asv profile" broken with existing environment ``` $ asv profile -E existing comm.Transfer.time_tcp_large_transfers_uncompressible · An explicit revision may not be specified when using an existing environment. ``` Same with: ``` $ asv profile --python=same comm.Transfer.time_tcp_large_transfers_uncompressible · An explicit revision may not be specified when using an existing environment. ``` I also tried with: ``` asv run --python=same --profile -b time_tcp_large_transfers_uncompressible ``` which doesn't seem to save a profile output anywhere. This is with asv version 0.2.1.
0.0
c9560bd78defaf02eecefc43e54953c10fb3a0d8
[ "test/test_console.py::test_log_indent", "test/test_dev.py::test_profile_python_same" ]
[ "test/test_console.py::test_write_with_fallback", "test/test_console.py::test_color_print_nofail", "test/test_dev.py::test_dev", "test/test_dev.py::test_dev_with_repo_subdir", "test/test_dev.py::test_run_python_same", "test/test_dev.py::test_dev_python_arg", "test/test_dev.py::test_run_steps_arg" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2018-08-18 18:14:52+00:00
bsd-3-clause
980
airspeed-velocity__asv-733
diff --git a/asv/util.py b/asv/util.py index c7a58e7..42688af 100644 --- a/asv/util.py +++ b/asv/util.py @@ -106,6 +106,13 @@ def human_float(value, significant=3, truncate_small=None, significant_zeros=Fal """ if value == 0: return "0" + elif math.isinf(value) or math.isnan(value): + return "{}".format(value) + elif value < 0: + sign = "-" + value = -value + else: + sign = "" logv = math.log10(value) magnitude = int(math.floor(logv)) + 1 @@ -127,7 +134,7 @@ def human_float(value, significant=3, truncate_small=None, significant_zeros=Fal else: fmt = "{{0:.{0}f}}".format(num_digits) - formatted = fmt.format(value) + formatted = sign + fmt.format(value) if not significant_zeros and '.' in formatted and 'e' not in fmt: formatted = formatted.rstrip('0')
airspeed-velocity/asv
d069dc4a375a60402acc0bbe1b7df938768b0c16
diff --git a/test/test_util.py b/test/test_util.py index 364bcf2..ccd8832 100644 --- a/test/test_util.py +++ b/test/test_util.py @@ -192,6 +192,17 @@ def test_human_float(): ("0", 0.001, 2, 0), ("0", 0.001, 2, 1), ("0.001", 0.001, 2, 2), + + # non-finite + ("inf", float('inf'), 1), + ("-inf", -float('inf'), 1), + ("nan", float('nan'), 1), + + # negative + ("-1", -1.2345, 1), + ("-0.00100", -0.001, 3, None, True), + ("-0", -0.001, 2, 1), + ("-0.001", -0.001, 2, 2), ] for item in items:
util.human_float doesn't print +-inf or nan properly Raises exceptions in `math.log10`: ``` File "asv/util.py", line 110, in human_float logv = math.log10(value) ValueError: math domain error ``` on +/-inf or nan inputs. This can be triggered in `asv show` and maybe elsewhere.
0.0
d069dc4a375a60402acc0bbe1b7df938768b0c16
[ "test/test_util.py::test_human_float" ]
[ "test/test_util.py::test_parallelfailure", "test/test_util.py::test_write_unicode_to_ascii", "test/test_util.py::test_which_path", "test/test_util.py::test_write_load_json", "test/test_util.py::test_human_time", "test/test_util.py::test_human_file_size", "test/test_util.py::test_is_main_thread", "test/test_util.py::test_json_non_ascii", "test/test_util.py::test_interpolate_command", "test/test_util.py::test_datetime_to_js_timestamp", "test/test_util.py::test_datetime_to_timestamp" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2018-09-07 22:41:44+00:00
bsd-3-clause
981
airspeed-velocity__asv-734
diff --git a/asv/util.py b/asv/util.py index c7a58e7..42688af 100644 --- a/asv/util.py +++ b/asv/util.py @@ -106,6 +106,13 @@ def human_float(value, significant=3, truncate_small=None, significant_zeros=Fal """ if value == 0: return "0" + elif math.isinf(value) or math.isnan(value): + return "{}".format(value) + elif value < 0: + sign = "-" + value = -value + else: + sign = "" logv = math.log10(value) magnitude = int(math.floor(logv)) + 1 @@ -127,7 +134,7 @@ def human_float(value, significant=3, truncate_small=None, significant_zeros=Fal else: fmt = "{{0:.{0}f}}".format(num_digits) - formatted = fmt.format(value) + formatted = sign + fmt.format(value) if not significant_zeros and '.' in formatted and 'e' not in fmt: formatted = formatted.rstrip('0') diff --git a/asv/www/graphdisplay.js b/asv/www/graphdisplay.js index 3d6446c..b0d80e4 100644 --- a/asv/www/graphdisplay.js +++ b/asv/www/graphdisplay.js @@ -147,9 +147,13 @@ $(document).ready(function() { var cursor = []; var stack = [tree]; - /* Note: this relies on the fact that the benchmark names are - sorted. */ - $.each($.asv.master_json.benchmarks, function(bm_name, bm) { + /* Sort keys for tree construction */ + var benchmark_keys = Object.keys($.asv.master_json.benchmarks); + benchmark_keys.sort(); + + /* Build tree */ + $.each(benchmark_keys, function(i, bm_name) { + var bm = $.asv.master_json.benchmarks[bm_name]; var parts = bm_name.split('.'); var i = 0; var j;
airspeed-velocity/asv
d069dc4a375a60402acc0bbe1b7df938768b0c16
diff --git a/test/test_util.py b/test/test_util.py index 364bcf2..ccd8832 100644 --- a/test/test_util.py +++ b/test/test_util.py @@ -192,6 +192,17 @@ def test_human_float(): ("0", 0.001, 2, 0), ("0", 0.001, 2, 1), ("0.001", 0.001, 2, 2), + + # non-finite + ("inf", float('inf'), 1), + ("-inf", -float('inf'), 1), + ("nan", float('nan'), 1), + + # negative + ("-1", -1.2345, 1), + ("-0.00100", -0.001, 3, None, True), + ("-0", -0.001, 2, 1), + ("-0.001", -0.001, 2, 2), ] for item in items:
Left sidepanel benchmark list wrong The left-sidepanel benchmark list tree is not constructed correctly: items appear several times https://pv.github.io/numpy-bench/#bench_function_base.Where.time_2_broadcast
0.0
d069dc4a375a60402acc0bbe1b7df938768b0c16
[ "test/test_util.py::test_human_float" ]
[ "test/test_util.py::test_parallelfailure", "test/test_util.py::test_write_unicode_to_ascii", "test/test_util.py::test_which_path", "test/test_util.py::test_write_load_json", "test/test_util.py::test_human_time", "test/test_util.py::test_human_file_size", "test/test_util.py::test_is_main_thread", "test/test_util.py::test_json_non_ascii", "test/test_util.py::test_interpolate_command", "test/test_util.py::test_datetime_to_js_timestamp", "test/test_util.py::test_datetime_to_timestamp" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks", "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2018-09-07 22:59:41+00:00
bsd-3-clause
982
airspeed-velocity__asv-794
diff --git a/.travis.yml b/.travis.yml index 86ed09c..c9aff08 100644 --- a/.travis.yml +++ b/.travis.yml @@ -1,7 +1,5 @@ language: python -sudo: false - env: global: - USE_CONDA=false @@ -31,11 +29,9 @@ matrix: - python: 3.8-dev dist: xenial - sudo: true - python: 3.7 dist: xenial - sudo: true - python: 2.7 @@ -51,7 +47,8 @@ matrix: - python: 3.6 env: USE_CONDA=true - - python: pypy3.5-5.10.1 + - python: pypy3.5-6.0 + dist: xenial cache: directories: diff --git a/asv/commands/run.py b/asv/commands/run.py index cf1a52e..74d88d0 100644 --- a/asv/commands/run.py +++ b/asv/commands/run.py @@ -92,6 +92,11 @@ class Run(Command): benchmark functions faster. The results are unlikely to be useful, and thus are not saved.""") common_args.add_environment(parser) + parser.add_argument( + "--set-commit-hash", default=None, + help="""Set the commit hash to use when recording benchmark + results. This makes results to be saved also when using an + existing environment.""") common_args.add_launch_method(parser) parser.add_argument( "--dry-run", "-n", action="store_true", @@ -136,7 +141,7 @@ class Run(Command): conf=conf, range_spec=args.range, steps=args.steps, bench=args.bench, attribute=args.attribute, parallel=args.parallel, show_stderr=args.show_stderr, quick=args.quick, - profile=args.profile, env_spec=args.env_spec, + profile=args.profile, env_spec=args.env_spec, set_commit_hash=args.set_commit_hash, dry_run=args.dry_run, machine=args.machine, skip_successful=args.skip_existing_successful or args.skip_existing, skip_failed=args.skip_existing_failed or args.skip_existing, @@ -149,7 +154,7 @@ class Run(Command): @classmethod def run(cls, conf, range_spec=None, steps=None, bench=None, attribute=None, parallel=1, - show_stderr=False, quick=False, profile=False, env_spec=None, + show_stderr=False, quick=False, profile=False, env_spec=None, set_commit_hash=None, dry_run=False, machine=None, _machine_file=None, skip_successful=False, skip_failed=False, skip_existing_commits=False, record_samples=False, append_samples=False, pull=True, interleave_processes=False, @@ -161,7 +166,7 @@ class Run(Command): environments = list(environment.get_environments(conf, env_spec)) - if environment.is_existing_only(environments): + if environment.is_existing_only(environments) and set_commit_hash is None: # No repository required, so skip using it conf.dvcs = "none" @@ -386,11 +391,15 @@ class Run(Command): params['python'] = env.python params.update(env.requirements) - skip_save = (dry_run or isinstance(env, environment.ExistingEnvironment)) + skip_save = dry_run or (isinstance(env, environment.ExistingEnvironment) + and set_commit_hash is None) skip_list = skipped_benchmarks[(commit_hash, env.name)] benchmark_set = benchmarks.filter_out(skip_list) + if set_commit_hash is not None: + commit_hash = set_commit_hash + result = Results( params, env.requirements,
airspeed-velocity/asv
c46d9cb573bbca397433cdaf9e5728a9992ba283
diff --git a/test/test_run.py b/test/test_run.py new file mode 100644 index 0000000..814ae2c --- /dev/null +++ b/test/test_run.py @@ -0,0 +1,61 @@ +# -*- coding: utf-8 -*- +# Licensed under a 3-clause BSD style license - see LICENSE.rst + +from __future__ import (absolute_import, division, print_function, + unicode_literals) + +import os +from os.path import abspath, dirname, join, relpath + +import six +import pytest +import shutil + +from asv import config +from asv import results +from asv import environment + +from . import tools + + [email protected] +def basic_conf(tmpdir): + tmpdir = six.text_type(tmpdir) + local = abspath(dirname(__file__)) + os.chdir(tmpdir) + + shutil.copytree(os.path.join(local, 'benchmark'), 'benchmark') + + shutil.copyfile(join(local, 'asv-machine.json'), + join(tmpdir, 'asv-machine.json')) + + repo = tools.generate_test_repo(tmpdir) + repo_path = relpath(repo.path) + + conf_dict = { + 'benchmark_dir': 'benchmark', + 'results_dir': 'results_workflow', + 'repo': repo_path, + 'project': 'asv', + 'environment_type': "existing", + 'python': "same" + } + + conf = config.Config.from_json(conf_dict) + + return tmpdir, conf, repo + + +def test_set_commit_hash(capsys, basic_conf): + tmpdir, conf, repo = basic_conf + commit_hash = repo.get_branch_hashes()[0] + + tools.run_asv_with_conf(conf, 'run', '--set-commit-hash=' + commit_hash, _machine_file=join(tmpdir, 'asv-machine.json')) + + env_name = list(environment.get_environments(conf, None))[0].name + result_filename = commit_hash[:conf.hash_length] + '-' + env_name + '.json' + assert result_filename in os.listdir(join('results_workflow', 'orangutan')) + + result_path = join('results_workflow', 'orangutan', result_filename) + times = results.Results.load(result_path) + assert times.commit_hash == commit_hash
Help comparing benchmarks across virtualenvs Sorry if this is the wrong place to ask. Sorry too that I am sure I am missing something obvious. I am using asv on Windows : https://github.com/numpy/numpy/issues/5479 I'm comparing performance of numpy in two virtualenvs, one with MKL linking, the other with ATLAS linking. I told `asv machine` that I have two machines one called 'mike-mkl' and the other 'mike-atlas', identical other than the names. Then I ran the benchmarks in the MKL virtualenv as: ``` cd numpy/benchmarks asv run --python=same --machine=mike-mkl ``` In the ATLAS virtualenv: ``` cd numpy/benchmarks asv run --python=same --machine=mike-atlas ``` I was expecting this to store the two sets of benchmarks, but it appears from the `results/benchmarks.json` file size and the `asv preview` output, that they overwrite each other. What is the right way to record / show these benchmarks relative to one another?
0.0
c46d9cb573bbca397433cdaf9e5728a9992ba283
[ "test/test_run.py::test_set_commit_hash" ]
[]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2019-02-20 10:10:15+00:00
bsd-3-clause
983
aiven__aiven-client-247
diff --git a/.github/CODEOWNERS b/.github/CODEOWNERS new file mode 100644 index 0000000..0f08232 --- /dev/null +++ b/.github/CODEOWNERS @@ -0,0 +1,1 @@ +* @aiven/team-dark-matter diff --git a/aiven/client/cli.py b/aiven/client/cli.py index 68bc4eb..2c0cb84 100644 --- a/aiven/client/cli.py +++ b/aiven/client/cli.py @@ -298,7 +298,12 @@ class AivenCLI(argx.CommandLineTool): """Return project given as cmdline argument or the default project from config file""" if getattr(self.args, "project", None) and self.args.project: return self.args.project - return self.config.get("default_project") + default_project = self.config.get("default_project") + if not default_project: + raise argx.UserError( + "Specify project: use --project in the command line or the default_project item in the config file." + ) + return default_project @no_auth @arg("pattern", nargs="*", help="command search pattern")
aiven/aiven-client
f5432a3d2ae452fb3e2d7ba2e5f56c20f9533688
diff --git a/tests/test_cli.py b/tests/test_cli.py index 42edfea..9fa2229 100644 --- a/tests/test_cli.py +++ b/tests/test_cli.py @@ -7,6 +7,7 @@ from aiven.client import AivenClient from aiven.client.cli import AivenCLI, ClientFactory, EOL_ADVANCE_WARNING_TIME from collections import namedtuple +from contextlib import contextmanager from datetime import datetime, timedelta, timezone from unittest import mock @@ -295,3 +296,25 @@ def test_update_service_connection_pool(): aiven_client.update_service_connection_pool.assert_called_with( project="testproject", service="pg-foo-bar", pool_name="foo", dbname=None, pool_size=42, pool_mode=None ) + + +@contextmanager +def mock_config(return_value): + with mock.patch("aiven.client.argx.Config", side_effect=lambda _: return_value): + yield + + +def test_get_project(caplog): + # https://github.com/aiven/aiven-client/issues/246 + aiven_client = mock.Mock(spec_set=AivenClient) + aiven_client.get_services.side_effect = lambda project: [] + args = ["service", "list"] + with mock_config({}): + assert build_aiven_cli(aiven_client).run(args=args) == 1 + assert "specify project" in caplog.text.lower() + caplog.clear() + assert build_aiven_cli(aiven_client).run(args=args + ["--project", "project_0"]) is None + assert not caplog.text + with mock_config({"default_project": "project_1"}): + assert build_aiven_cli(aiven_client).run(args=args) is None + assert not caplog.text
Error quote_from_bytes() # What happened? Ran the following command and got the error `avn --auth-token $AIVEN_USER_TOKEN service list` ``` Traceback (most recent call last): File "/usr/bin/avn", line 8, in <module> sys.exit(main()) File "/usr/lib/python3.8/site-packages/aiven/client/__main__.py", line 5, in main AivenCLI().main() File "/usr/lib/python3.8/site-packages/aiven/client/argx.py", line 309, in main sys.exit(self.run(args)) File "/usr/lib/python3.8/site-packages/aiven/client/argx.py", line 281, in run return self.run_actual(args) File "/usr/lib/python3.8/site-packages/aiven/client/argx.py", line 303, in run_actual return func() # pylint: disable=not-callable File "/usr/lib/python3.8/site-packages/aiven/client/cli.py", line 966, in service__list services = self.client.get_services(project=self.get_project()) File "/usr/lib/python3.8/site-packages/aiven/client/client.py", line 1546, in get_services self.build_path("project", project, "service"), File "/usr/lib/python3.8/site-packages/aiven/client/client.py", line 168, in build_path return "/" + "/".join(quote(part, safe="") for part in parts) File "/usr/lib/python3.8/site-packages/aiven/client/client.py", line 168, in <genexpr> return "/" + "/".join(quote(part, safe="") for part in parts) File "/usr/lib/python3.8/urllib/parse.py", line 851, in quote return quote_from_bytes(string, safe) File "/usr/lib/python3.8/urllib/parse.py", line 876, in quote_from_bytes raise TypeError("quote_from_bytes() expected bytes") TypeError: quote_from_bytes() expected bytes ``` # What did you expect to happen? A list of all services # What else do we need to know? This command fails on the following system: Alpine Linux 3.12.0 ``` > python3 --version Python 3.8.10 > avn --version aiven-client 2.14.4 ``` This command run successfully on Ubuntu 20.04, with same version of python3 and aiven-client
0.0
f5432a3d2ae452fb3e2d7ba2e5f56c20f9533688
[ "tests/test_cli.py::test_get_project" ]
[ "tests/test_cli.py::test_cli", "tests/test_cli.py::test_cloud_list", "tests/test_cli.py::test_service_plans", "tests/test_cli.py::test_service_types_v", "tests/test_cli.py::test_service_user_create", "tests/test_cli.py::test_service_topic_create", "tests/test_cli.py::test_service_topic_create_with_tags", "tests/test_cli.py::test_service_topic_update", "tests/test_cli.py::test_help", "tests/test_cli.py::test_create_user_config", "tests/test_cli.py::test_service_task_create_migration_check", "tests/test_cli.py::test_service_task_get_migration_check", "tests/test_cli.py::test_version_eol_check", "tests/test_cli.py::test_create_service_connection_pool", "tests/test_cli.py::test_update_service_connection_pool" ]
{ "failed_lite_validators": [ "has_added_files" ], "has_test_patch": true, "is_lite": false }
2021-12-23 16:38:45+00:00
apache-2.0
984
aj-white__cipher_typer-5
diff --git a/cipher_typer/cipher.py b/cipher_typer/cipher.py index 9db77a1..4563c39 100644 --- a/cipher_typer/cipher.py +++ b/cipher_typer/cipher.py @@ -153,29 +153,17 @@ class CaeserSeedCipher: return self.translated def encrypt(self, message: str, key: int = 0) -> str: + if key > self.max_key_length: + raise IndexError(f"key must be less than {self.max_key_length}") self.translated = "" self.key = key self.message = message return self._crypto("encrypt") def decrypt(self, message: str, key: int = 0) -> str: + if key > self.max_key_length: + raise IndexError(f"key must be less than {self.max_key_length}") self.translated = "" self.key = key self.message = message return self._crypto("decrypt") - - -if __name__ == "__main__": - print("Using CaeserCipher:") - cipher = CaeserCipher() - print(cipher.encrypt("Secret message.", 13)) - print(cipher.decrypt("'rpErGmzrFFntr`", 13)) - print(cipher.encrypt("John Doe will be on the [08:00] train @King's Cross", 56)) - print(cipher.decrypt("9>-=%3>*%{.;;%'*%>=%^-*%KT#DTTL%^[&.=%J .=,u]%2[>]]", 56)) - - print("\nUsing CaeserSeedCipher:") - c = CaeserSeedCipher() - print(c.encrypt("Secret message.", 13)) - print(c.decrypt("hx5dx}fqx%%HDx-", 13)) - print(c.encrypt("John Doe will be on the [08:00] train @King's Cross", 56)) - print(c.decrypt("lG#R27G:2rD||2b:2GR2_#:29uEzuu%2_c?DR2BTDR=,`2xcG``", 56)) diff --git a/dev-requirements.in b/dev-requirements.in new file mode 100644 index 0000000..f2578c6 --- /dev/null +++ b/dev-requirements.in @@ -0,0 +1,2 @@ +-r requirements.txt +pytest \ No newline at end of file diff --git a/dev-requirements.txt b/dev-requirements.txt new file mode 100644 index 0000000..9688534 --- /dev/null +++ b/dev-requirements.txt @@ -0,0 +1,32 @@ +# +# This file is autogenerated by pip-compile +# To update, run: +# +# pip-compile dev-requirements.in +# +atomicwrites==1.4.0 + # via pytest +attrs==21.2.0 + # via pytest +click==7.1.2 + # via + # -r requirements.txt + # typer +colorama==0.4.4 + # via pytest +iniconfig==1.1.1 + # via pytest +packaging==20.9 + # via pytest +pluggy==0.13.1 + # via pytest +py==1.10.0 + # via pytest +pyparsing==2.4.7 + # via packaging +pytest==6.2.4 + # via -r dev-requirements.in +toml==0.10.2 + # via pytest +typer==0.3.2 + # via -r requirements.txt diff --git a/setup.cfg b/setup.cfg index f5f4db1..0b489e1 100644 --- a/setup.cfg +++ b/setup.cfg @@ -4,10 +4,15 @@ version = 0.1.0 description = command line utility to encrypt and decrypt text author = Andrew White author_email = [email protected] -url = ... +url = https://github.com/aj-white/cipher_typer +license = MIT +license_file = LICENSE [options] packages = find: +install_requires = + typer>=0.3.2 +python_requires = >=3.6.1 [option.packages.find] exclude =
aj-white/cipher_typer
4a44c446657f9cc9acc9ffd22e9a01e455b0798b
diff --git a/tests/__init__.py b/tests/__init__.py new file mode 100644 index 0000000..e69de29 diff --git a/tests/test_cipher.py b/tests/test_cipher.py new file mode 100644 index 0000000..2892e8f --- /dev/null +++ b/tests/test_cipher.py @@ -0,0 +1,134 @@ +import string + +import pytest +from cipher_typer.cipher import CaeserCipher, CaeserSeedCipher, InvalidSelector + + +def test_caeser_all_no_key(): + c = CaeserCipher("all") + message = string.ascii_letters + string.digits + enc = c.encrypt(message) + dec = c.decrypt(enc) + assert dec == message + + +def test_caeser_all(): + c = CaeserCipher("all") + message = string.ascii_letters + string.digits + enc = c.encrypt(message, 25) + dec = c.decrypt(enc, 25) + assert dec == message + + +def test_caeser_lower(): + c = CaeserCipher("lower") + message = string.ascii_lowercase + enc = c.encrypt(message, 18) + dec = c.decrypt(enc, 18) + assert dec == message + + +def test_caeser_upper(): + c = CaeserCipher("upper") + message = string.ascii_uppercase + enc = c.encrypt(message, 13) + dec = c.decrypt(enc, 13) + assert dec == message + + +def test_caeser_both(): + c = CaeserCipher("both") + message = "I am BOTH Upper and lowerCase" + enc = c.encrypt(message, 9) + dec = c.decrypt(enc, 9) + assert dec == message + + +def test_caeser_key_error(): + c = CaeserCipher("lower") + message = string.ascii_lowercase + with pytest.raises(IndexError): + assert c.encrypt(message, 56) + assert c.decrypt(message, 87) + + +def test_caeser_invalid_selector(): + with pytest.raises(InvalidSelector): + assert CaeserCipher("jeff") + + +def test_caeser_mixed_case_message_with_lower(): + c = CaeserCipher("lower") + message = "I am in B8th CaseS" + assert c.encrypt(message, 7) == "I ht pu B8ao ChzlS" + + +def test_caser_mixed_case_message_with_upper(): + c = CaeserCipher("upper") + message = "&I am in UPper and LowerCASE WIth 67" + assert c.encrypt(message, 18) == "&A am in MHper and DowerUSKW OAth 67" + + +# Test CaserSeedCipher class +def test_caeser_seed_all_no_key(): + cs = CaeserSeedCipher() + message = string.ascii_letters + string.digits + enc = cs.encrypt(message) + dec = cs.decrypt(enc) + assert dec == message + + +def test_caeser_seed_all(): + cs = CaeserSeedCipher() + message = string.ascii_letters + " " + string.digits + "#" + enc = cs.encrypt(message, 60) + dec = cs.decrypt(enc, 60) + assert dec == message + + +def test_caeser_seed_lower(): + cs = CaeserSeedCipher("lower") + message = string.ascii_lowercase + enc = cs.encrypt(message, 3) + dec = cs.decrypt(enc, 3) + assert dec == message + + +def test_caeser_seed_upper(): + cs = CaeserSeedCipher("upper") + message = string.ascii_uppercase + enc = cs.encrypt(message, 11) + dec = cs.decrypt(enc, 11) + assert dec == message + + +def test_caeser_seed_both(): + cs = CaeserSeedCipher("both") + message = string.ascii_letters + enc = cs.encrypt(message, 12) + dec = cs.decrypt(enc, 12) + assert dec == message + + +def test_caeser_seed_key_error(): + cs = CaeserSeedCipher() + with pytest.raises(IndexError): + assert cs.encrypt("Jeff", 100) + assert cs.decrypt("Jeff", 230) + + +def test_caeser_seed_invalid_selector(): + with pytest.raises(InvalidSelector): + assert CaeserSeedCipher("poo") + + +def test_caser_seed_mixed_case_lower(): + cs = CaeserSeedCipher("lower") + message = "I am in B8th CaseS" + assert cs.encrypt(message, 7) == "I kq lp B8od CktbS" + + +def test_caser_seed_mixed_case_upper(): + cs = CaeserSeedCipher("upper") + message = "&I am in UPper and LowerCASE WIth 67" + assert cs.encrypt(message, 18) == "&S am in JMper and EowerVFCK XSth 67"
Missing tests Please write tests and remove 'examples in cipher.py
0.0
4a44c446657f9cc9acc9ffd22e9a01e455b0798b
[ "tests/test_cipher.py::test_caeser_seed_key_error" ]
[ "tests/test_cipher.py::test_caeser_all_no_key", "tests/test_cipher.py::test_caeser_all", "tests/test_cipher.py::test_caeser_lower", "tests/test_cipher.py::test_caeser_upper", "tests/test_cipher.py::test_caeser_both", "tests/test_cipher.py::test_caeser_key_error", "tests/test_cipher.py::test_caeser_invalid_selector", "tests/test_cipher.py::test_caeser_mixed_case_message_with_lower", "tests/test_cipher.py::test_caser_mixed_case_message_with_upper", "tests/test_cipher.py::test_caeser_seed_all_no_key", "tests/test_cipher.py::test_caeser_seed_all", "tests/test_cipher.py::test_caeser_seed_lower", "tests/test_cipher.py::test_caeser_seed_upper", "tests/test_cipher.py::test_caeser_seed_both", "tests/test_cipher.py::test_caeser_seed_invalid_selector", "tests/test_cipher.py::test_caser_seed_mixed_case_lower", "tests/test_cipher.py::test_caser_seed_mixed_case_upper" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_added_files", "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2021-06-29 16:06:30+00:00
mit
985
akaihola__darker-584
diff --git a/CHANGES.rst b/CHANGES.rst index 92c84ff..74ed0f3 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -21,6 +21,7 @@ Fixed ``--stdout`` option. This makes the option compatible with the `new Black extension for VSCode`__. - Badge links in the README on GitHub. +- Handling of relative paths and running from elsewhere than repository root. __ https://github.com/microsoft/vscode-black-formatter diff --git a/src/darker/__main__.py b/src/darker/__main__.py index 9373431..f9c77d4 100644 --- a/src/darker/__main__.py +++ b/src/darker/__main__.py @@ -516,10 +516,14 @@ def main( # pylint: disable=too-many-locals,too-many-branches,too-many-statemen if args.skip_magic_trailing_comma is not None: black_config["skip_magic_trailing_comma"] = args.skip_magic_trailing_comma - paths, root = resolve_paths(args.stdin_filename, args.src) + paths, common_root = resolve_paths(args.stdin_filename, args.src) + # `common_root` is now the common root of given paths, + # not necessarily the repository root. + # `paths` are the unmodified paths from `--stdin-filename` or `SRC`, + # so either relative to the current working directory or absolute paths. revrange = RevisionRange.parse_with_common_ancestor( - args.revision, root, args.stdin_filename is not None + args.revision, common_root, args.stdin_filename is not None ) output_mode = OutputMode.from_args(args) write_modified_files = not args.check and output_mode == OutputMode.NOTHING @@ -539,7 +543,7 @@ def main( # pylint: disable=too-many-locals,too-many-branches,too-many-statemen ) if revrange.rev2 != STDIN: - missing = get_missing_at_revision(paths, revrange.rev2, root) + missing = get_missing_at_revision(paths, revrange.rev2, common_root) if missing: missing_reprs = " ".join(repr(str(path)) for path in missing) rev2_repr = ( @@ -550,9 +554,9 @@ def main( # pylint: disable=too-many-locals,too-many-branches,too-many-statemen f"Error: Path(s) {missing_reprs} do not exist in {rev2_repr}", ) - # These paths are relative to `root`: - files_to_process = filter_python_files(paths, root, {}) - files_to_blacken = filter_python_files(paths, root, black_config) + # These paths are relative to `common_root`: + files_to_process = filter_python_files(paths, common_root, {}) + files_to_blacken = filter_python_files(paths, common_root, black_config) # Now decide which files to reformat (Black & isort). Note that this doesn't apply # to linting. if output_mode == OutputMode.CONTENT or revrange.rev2 == STDIN: @@ -563,11 +567,11 @@ def main( # pylint: disable=too-many-locals,too-many-branches,too-many-statemen black_exclude = set() else: # In other modes, only reformat files which have been modified. - if git_is_repository(root): + if git_is_repository(common_root): # Get the modified files only. - repo_root = find_project_root((str(root),)) + repo_root = find_project_root((str(common_root),)) changed_files = { - (repo_root / file).relative_to(root) + (repo_root / file).relative_to(common_root) for file in git_get_modified_python_files(paths, revrange, repo_root) } # Filter out changed files that are not supposed to be processed @@ -584,7 +588,7 @@ def main( # pylint: disable=too-many-locals,too-many-branches,too-many-statemen formatting_failures_on_modified_lines = False for path, old, new in sorted( format_edited_parts( - root, + common_root, changed_files_to_reformat, Exclusions( black=black_exclude, @@ -602,16 +606,16 @@ def main( # pylint: disable=too-many-locals,too-many-branches,too-many-statemen # there were any changes to the original formatting_failures_on_modified_lines = True if output_mode == OutputMode.DIFF: - print_diff(path, old, new, root, use_color) + print_diff(path, old, new, common_root, use_color) elif output_mode == OutputMode.CONTENT: print_source(new, use_color) if write_modified_files: modify_file(path, new) linter_failures_on_modified_lines = run_linters( args.lint, - root, + common_root, # paths to lint are not limited to modified files or just Python files: - {p.resolve().relative_to(root) for p in paths}, + {p.resolve().relative_to(common_root) for p in paths}, revrange, use_color, ) diff --git a/src/darker/git.py b/src/darker/git.py index fff2eb1..e89ca86 100644 --- a/src/darker/git.py +++ b/src/darker/git.py @@ -76,25 +76,33 @@ def should_reformat_file(path: Path) -> bool: return path.exists() and get_path_in_repo(path).suffix == ".py" -def _git_exists_in_revision(path: Path, rev2: str, cwd: Path) -> bool: +def _git_exists_in_revision(path: Path, rev2: str, git_cwd: Path) -> bool: """Return ``True`` if the given path exists in the given Git revision - :param path: The path of the file or directory to check + :param path: The path of the file or directory to check, either relative to current + working directory or absolute :param rev2: The Git revision to look at - :param cwd: The Git repository root + :param git_cwd: The working directory to use when invoking Git. This has to be + either the root of the working tree, or another directory inside it. :return: ``True`` if the file or directory exists at the revision, or ``False`` if it doesn't. """ - if (cwd / path).resolve() == cwd.resolve(): - return True + while not git_cwd.exists(): + # The working directory for running Git doesn't exist. Walk up the directory + # tree until we find an existing directory. This is necessary because `git + # cat-file` doesn't work if the current working directory doesn't exist. + git_cwd = git_cwd.parent + relative_path = (Path.cwd() / path).relative_to(git_cwd.resolve()) # Surprise: On Windows, `git cat-file` doesn't work with backslash directory # separators in paths. We need to use Posix paths and forward slashes instead. - cmd = ["git", "cat-file", "-e", f"{rev2}:{path.as_posix()}"] - logger.debug("[%s]$ %s", cwd, " ".join(cmd)) + # Surprise #2: `git cat-file` assumes paths are relative to the repository root. + # We need to prepend `./` to paths relative to the working directory. + cmd = ["git", "cat-file", "-e", f"{rev2}:./{relative_path.as_posix()}"] + logger.debug("[%s]$ %s", git_cwd, " ".join(cmd)) result = run( # nosec cmd, - cwd=str(cwd), + cwd=str(git_cwd), check=False, stderr=DEVNULL, env=make_git_env(), @@ -108,9 +116,10 @@ def get_missing_at_revision(paths: Iterable[Path], rev2: str, cwd: Path) -> Set[ In case of ``WORKTREE``, just check if the files exist on the filesystem instead of asking Git. - :param paths: Paths to check + :param paths: Paths to check, relative to the current working directory or absolute :param rev2: The Git revision to look at, or ``WORKTREE`` for the working tree - :param cwd: The Git repository root + :param cwd: The working directory to use when invoking Git. This has to be either + the root of the working tree, or another directory inside it. :return: The set of file or directory paths which are missing in the revision """ @@ -120,15 +129,15 @@ def get_missing_at_revision(paths: Iterable[Path], rev2: str, cwd: Path) -> Set[ def _git_diff_name_only( - rev1: str, rev2: str, relative_paths: Iterable[Path], cwd: Path + rev1: str, rev2: str, relative_paths: Iterable[Path], repo_root: Path ) -> Set[Path]: """Collect names of changed files between commits from Git :param rev1: The old commit to compare to :param rev2: The new commit to compare, or the string ``":WORKTREE:"`` to compare current working tree to ``rev1`` - :param relative_paths: Relative paths to the files to compare - :param cwd: The Git repository root + :param relative_paths: Relative paths from repository root to the files to compare + :param repo_root: The Git repository root :return: Relative paths of changed files """ @@ -143,7 +152,7 @@ def _git_diff_name_only( ] if rev2 != WORKTREE: diff_cmd.insert(diff_cmd.index("--"), rev2) - lines = git_check_output_lines(diff_cmd, cwd) + lines = git_check_output_lines(diff_cmd, repo_root) return {Path(line) for line in lines} @@ -153,7 +162,7 @@ def _git_ls_files_others(relative_paths: Iterable[Path], cwd: Path) -> Set[Path] This will return those files in ``relative_paths`` which are untracked and not excluded by ``.gitignore`` or other Git's exclusion mechanisms. - :param relative_paths: Relative paths to the files to consider + :param relative_paths: Relative paths from repository root to the files to consider :param cwd: The Git repository root :return: Relative paths of untracked files @@ -170,23 +179,26 @@ def _git_ls_files_others(relative_paths: Iterable[Path], cwd: Path) -> Set[Path] def git_get_modified_python_files( - paths: Iterable[Path], revrange: RevisionRange, cwd: Path + paths: Iterable[Path], revrange: RevisionRange, repo_root: Path ) -> Set[Path]: """Ask Git for modified and untracked ``*.py`` files - ``git diff --name-only --relative <rev> -- <path(s)>`` - ``git ls-files --others --exclude-standard -- <path(s)>`` - :param paths: Relative paths to the files to diff + :param paths: Files to diff, either relative to the current working dir or absolute :param revrange: Git revision range to compare - :param cwd: The Git repository root + :param repo_root: The Git repository root :return: File names relative to the Git repository root """ - changed_paths = _git_diff_name_only(revrange.rev1, revrange.rev2, paths, cwd) + repo_paths = [path.resolve().relative_to(repo_root) for path in paths] + changed_paths = _git_diff_name_only( + revrange.rev1, revrange.rev2, repo_paths, repo_root + ) if revrange.rev2 == WORKTREE: - changed_paths.update(_git_ls_files_others(paths, cwd)) - return {path for path in changed_paths if should_reformat_file(cwd / path)} + changed_paths.update(_git_ls_files_others(repo_paths, repo_root)) + return {path for path in changed_paths if should_reformat_file(repo_root / path)} def _revision_vs_lines(
akaihola/darker
b2360a61274f2455790aa81e97fac9a3827e24fd
diff --git a/src/darker/tests/test_git.py b/src/darker/tests/test_git.py index 8601faf..8b65ed8 100644 --- a/src/darker/tests/test_git.py +++ b/src/darker/tests/test_git.py @@ -69,7 +69,7 @@ def test_git_exists_in_revision_git_call(retval, expect): result = git._git_exists_in_revision(Path("path.py"), "rev2", Path(".")) run.assert_called_once_with( - ["git", "cat-file", "-e", "rev2:path.py"], + ["git", "cat-file", "-e", "rev2:./path.py"], cwd=".", check=False, stderr=DEVNULL, @@ -79,54 +79,125 @@ def test_git_exists_in_revision_git_call(retval, expect): @pytest.mark.kwparametrize( - dict(rev2="{add}", path="dir/a.py", expect=True), - dict(rev2="{add}", path="dir/b.py", expect=True), - dict(rev2="{add}", path="dir/", expect=True), - dict(rev2="{add}", path="dir", expect=True), - dict(rev2="{del_a}", path="dir/a.py", expect=False), - dict(rev2="{del_a}", path="dir/b.py", expect=True), - dict(rev2="{del_a}", path="dir/", expect=True), - dict(rev2="{del_a}", path="dir", expect=True), - dict(rev2="HEAD", path="dir/a.py", expect=False), - dict(rev2="HEAD", path="dir/b.py", expect=False), - dict(rev2="HEAD", path="dir/", expect=False), - dict(rev2="HEAD", path="dir", expect=False), + dict(cwd=".", rev2="{add}", path="x/dir/a.py", expect=True), + dict(cwd=".", rev2="{add}", path="x/dir/sub/b.py", expect=True), + dict(cwd=".", rev2="{add}", path="x/dir/", expect=True), + dict(cwd=".", rev2="{add}", path="x/dir", expect=True), + dict(cwd=".", rev2="{add}", path="x/dir/sub", expect=True), + dict(cwd=".", rev2="{del_a}", path="x/dir/a.py", expect=False), + dict(cwd=".", rev2="{del_a}", path="x/dir/sub/b.py", expect=True), + dict(cwd=".", rev2="{del_a}", path="x/dir/", expect=True), + dict(cwd=".", rev2="{del_a}", path="x/dir", expect=True), + dict(cwd=".", rev2="{del_a}", path="x/dir/sub", expect=True), + dict(cwd=".", rev2="HEAD", path="x/dir/a.py", expect=False), + dict(cwd=".", rev2="HEAD", path="x/dir/sub/b.py", expect=False), + dict(cwd=".", rev2="HEAD", path="x/dir/", expect=False), + dict(cwd=".", rev2="HEAD", path="x/dir", expect=False), + dict(cwd=".", rev2="HEAD", path="x/dir/sub", expect=False), + dict(cwd="x", rev2="{add}", path="dir/a.py", expect=True), + dict(cwd="x", rev2="{add}", path="dir/sub/b.py", expect=True), + dict(cwd="x", rev2="{add}", path="dir/", expect=True), + dict(cwd="x", rev2="{add}", path="dir", expect=True), + dict(cwd="x", rev2="{add}", path="dir/sub", expect=True), + dict(cwd="x", rev2="{del_a}", path="dir/a.py", expect=False), + dict(cwd="x", rev2="{del_a}", path="dir/sub/b.py", expect=True), + dict(cwd="x", rev2="{del_a}", path="dir/", expect=True), + dict(cwd="x", rev2="{del_a}", path="dir", expect=True), + dict(cwd="x", rev2="{del_a}", path="dir/sub", expect=True), + dict(cwd="x", rev2="HEAD", path="dir/a.py", expect=False), + dict(cwd="x", rev2="HEAD", path="dir/sub/b.py", expect=False), + dict(cwd="x", rev2="HEAD", path="dir/", expect=False), + dict(cwd="x", rev2="HEAD", path="dir", expect=False), + dict(cwd="x", rev2="HEAD", path="dir/sub", expect=False), ) -def test_git_exists_in_revision(git_repo, rev2, path, expect): +def test_git_exists_in_revision(git_repo, monkeypatch, cwd, rev2, path, expect): """``_get_exists_in_revision()`` detects file/dir existence correctly""" - git_repo.add({"dir/a.py": "", "dir/b.py": ""}, commit="Add dir/*.py") + git_repo.add( + {"x/README": "", "x/dir/a.py": "", "x/dir/sub/b.py": ""}, + commit="Add x/dir/*.py", + ) add = git_repo.get_hash() - git_repo.add({"dir/a.py": None}, commit="Delete dir/a.py") + git_repo.add({"x/dir/a.py": None}, commit="Delete x/dir/a.py") del_a = git_repo.get_hash() - git_repo.add({"dir/b.py": None}, commit="Delete dir/b.py") + git_repo.add({"x/dir/sub/b.py": None}, commit="Delete x/dir/b.py") + monkeypatch.chdir(cwd) result = git._git_exists_in_revision( - Path(path), rev2.format(add=add, del_a=del_a), git_repo.root + Path(path), rev2.format(add=add, del_a=del_a), git_repo.root / "x/dir/sub" ) assert result == expect @pytest.mark.kwparametrize( - dict(rev2="{add}", expect=set()), - dict(rev2="{del_a}", expect={Path("dir/a.py")}), - dict(rev2="HEAD", expect={Path("dir"), Path("dir/a.py"), Path("dir/b.py")}), + dict( + paths={"x/dir", "x/dir/a.py", "x/dir/sub", "x/dir/sub/b.py"}, + rev2="{add}", + expect=set(), + ), + dict( + paths={"x/dir", "x/dir/a.py", "x/dir/sub", "x/dir/sub/b.py"}, + rev2="{del_a}", + expect={"x/dir/a.py"}, + ), + dict( + paths={"x/dir", "x/dir/a.py", "x/dir/sub", "x/dir/sub/b.py"}, + rev2="HEAD", + expect={"x/dir", "x/dir/a.py", "x/dir/sub", "x/dir/sub/b.py"}, + ), + dict( + paths={"x/dir", "x/dir/a.py", "x/dir/sub", "x/dir/sub/b.py"}, + rev2=":WORKTREE:", + expect={"x/dir", "x/dir/a.py", "x/dir/sub", "x/dir/sub/b.py"}, + ), + dict( + paths={"dir", "dir/a.py", "dir/sub", "dir/sub/b.py"}, + cwd="x", + rev2="{add}", + expect=set(), + ), + dict( + paths={"dir", "dir/a.py", "dir/sub", "dir/sub/b.py"}, + cwd="x", + rev2="{del_a}", + expect={"dir/a.py"}, + ), + dict( + paths={"dir", "dir/a.py", "dir/sub", "dir/sub/b.py"}, + cwd="x", + rev2="HEAD", + expect={"dir", "dir/a.py", "dir/sub", "dir/sub/b.py"}, + ), + dict( + paths={"dir", "dir/a.py", "dir/sub", "dir/sub/b.py"}, + cwd="x", + rev2=":WORKTREE:", + expect={"dir", "dir/a.py", "dir/sub", "dir/sub/b.py"}, + ), + cwd=".", + git_cwd=".", ) -def test_get_missing_at_revision(git_repo, rev2, expect): +def test_get_missing_at_revision( + git_repo, monkeypatch, paths, cwd, git_cwd, rev2, expect +): """``get_missing_at_revision()`` returns missing files/directories correctly""" - git_repo.add({"dir/a.py": "", "dir/b.py": ""}, commit="Add dir/*.py") + git_repo.add( + {"x/README": "", "x/dir/a.py": "", "x/dir/sub/b.py": ""}, + commit="Add x/dir/**/*.py", + ) add = git_repo.get_hash() - git_repo.add({"dir/a.py": None}, commit="Delete dir/a.py") + git_repo.add({"x/dir/a.py": None}, commit="Delete x/dir/a.py") del_a = git_repo.get_hash() - git_repo.add({"dir/b.py": None}, commit="Delete dir/b.py") + git_repo.add({"x/dir/sub/b.py": None}, commit="Delete x/dir/sub/b.py") + monkeypatch.chdir(git_repo.root / cwd) result = git.get_missing_at_revision( - {Path("dir"), Path("dir/a.py"), Path("dir/b.py")}, + {Path(p) for p in paths}, rev2.format(add=add, del_a=del_a), - git_repo.root, + git_repo.root / git_cwd, ) - assert result == expect + assert result == {Path(p) for p in expect} def test_get_missing_at_revision_worktree(git_repo): @@ -224,7 +295,7 @@ def test_git_get_modified_python_files(git_repo, modify_paths, paths, expect): revrange = RevisionRange("HEAD", ":WORKTREE:") result = git.git_get_modified_python_files( - {root / p for p in paths}, revrange, cwd=root + {root / p for p in paths}, revrange, repo_root=root ) assert result == {Path(p) for p in expect}
Relative path in a repo subdirectory not found when using hash symmetric difference <!-- NOTE: To ask for help using Darker, please use Discussions (see the top of this page). This form is only for reporting bugs. --> **Describe the bug** Relative path in a repo subdirectory not found when using `--revision=<hash>...<hash>` but not when using `--revision=origin/main...`. **To Reproduce** Steps to reproduce the behavior: 1. Clone this repository: https://github.com/dshemetov/darker-test 2. See the README.md in the repo for instructions **Expected behavior** The behavior between these should be consistent, I believe. **Environment (please complete the following information):** - OS: Ubuntu 20.04 - Python version 3.8, 3.10 (doesn't really matter) - Darker version 1.7.2 - Black version 23.10.1 **Steps before ready to implement:** - [x] Reproduce - [x] Understand the reason - [x] Design a fix and update the description
0.0
b2360a61274f2455790aa81e97fac9a3827e24fd
[ "src/darker/tests/test_git.py::test_git_exists_in_revision_git_call[0-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision_git_call[1-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision_git_call[2-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{add}-x/dir/a.py-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{add}-x/dir/sub/b.py-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{add}-x/dir/-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{add}-x/dir-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{add}-x/dir/sub-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{del_a}-x/dir/a.py-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{del_a}-x/dir/sub/b.py-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{del_a}-x/dir/-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{del_a}-x/dir-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-{del_a}-x/dir/sub-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-HEAD-x/dir/a.py-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-HEAD-x/dir/sub/b.py-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-HEAD-x/dir/-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-HEAD-x/dir-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[.-HEAD-x/dir/sub-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{add}-dir/a.py-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{add}-dir/sub/b.py-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{add}-dir/-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{add}-dir-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{add}-dir/sub-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{del_a}-dir/a.py-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{del_a}-dir/sub/b.py-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{del_a}-dir/-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{del_a}-dir-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-{del_a}-dir/sub-True]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-HEAD-dir/a.py-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-HEAD-dir/sub/b.py-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-HEAD-dir/-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-HEAD-dir-False]", "src/darker/tests/test_git.py::test_git_exists_in_revision[x-HEAD-dir/sub-False]", "src/darker/tests/test_git.py::test_get_missing_at_revision[x-.-paths4-{add}-expect4]", "src/darker/tests/test_git.py::test_get_missing_at_revision[x-.-paths5-{del_a}-expect5]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths0-paths0-expect0]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths1-paths1-expect1]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths2-paths2-expect2]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths3-paths3-expect3]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths4-paths4-expect4]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths5-paths5-expect5]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths6-paths6-expect6]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths7-paths7-expect7]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths8-paths8-expect8]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths9-paths9-expect9]", "src/darker/tests/test_git.py::test_git_get_modified_python_files[modify_paths10-paths10-expect10]" ]
[ "src/darker/tests/test_git.py::test_get_path_in_repo[file.py-file.py]", "src/darker/tests/test_git.py::test_get_path_in_repo[subdir/file.py-subdir/file.py]", "src/darker/tests/test_git.py::test_get_path_in_repo[file.py.12345.tmp-file.py]", "src/darker/tests/test_git.py::test_get_path_in_repo[subdir/file.py.12345.tmp-subdir/file.py]", "src/darker/tests/test_git.py::test_get_path_in_repo[file.py.tmp-file.py.tmp]", "src/darker/tests/test_git.py::test_get_path_in_repo[subdir/file.py.tmp-subdir/file.py.tmp]", "src/darker/tests/test_git.py::test_get_path_in_repo[file.12345.tmp-file.12345.tmp]", "src/darker/tests/test_git.py::test_get_path_in_repo[subdir/file.12345.tmp-subdir/file.12345.tmp]", "src/darker/tests/test_git.py::test_should_reformat_file[.-False-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main-True-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main.c-True-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main.py-True-True]", "src/darker/tests/test_git.py::test_should_reformat_file[main.py-False-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main.pyx-True-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main.pyi-True-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main.pyc-True-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main.pyo-True-False]", "src/darker/tests/test_git.py::test_should_reformat_file[main.js-True-False]", "src/darker/tests/test_git.py::test_get_missing_at_revision[.-.-paths0-{add}-expect0]", "src/darker/tests/test_git.py::test_get_missing_at_revision[.-.-paths1-{del_a}-expect1]", "src/darker/tests/test_git.py::test_get_missing_at_revision[.-.-paths2-HEAD-expect2]", "src/darker/tests/test_git.py::test_get_missing_at_revision[.-.-paths3-:WORKTREE:-expect3]", "src/darker/tests/test_git.py::test_get_missing_at_revision[x-.-paths6-HEAD-expect6]", "src/darker/tests/test_git.py::test_get_missing_at_revision[x-.-paths7-:WORKTREE:-expect7]", "src/darker/tests/test_git.py::test_get_missing_at_revision_worktree", "src/darker/tests/test_git.py::test_git_diff_name_only", "src/darker/tests/test_git.py::test_git_ls_files_others", "src/darker/tests/test_git.py::test_git_get_modified_python_files_revision_range[from", "src/darker/tests/test_git.py::test_edited_linenums_differ_compare_revisions[0-expect0]", "src/darker/tests/test_git.py::test_edited_linenums_differ_compare_revisions[1-expect1]", "src/darker/tests/test_git.py::test_edited_linenums_differ_compare_revisions[2-expect2]", "src/darker/tests/test_git.py::test_edited_linenums_differ_compare_revisions[3-expect3]", "src/darker/tests/test_git.py::test_edited_linenums_differ_revision_vs_lines[0-expect0]", "src/darker/tests/test_git.py::test_edited_linenums_differ_revision_vs_lines[1-expect1]", "src/darker/tests/test_git.py::test_edited_linenums_differ_revision_vs_lines[2-expect2]", "src/darker/tests/test_git.py::test_edited_linenums_differ_revision_vs_lines[3-expect3]", "src/darker/tests/test_git.py::test_edited_linenums_differ_revision_vs_lines_multiline_strings[0-expect0]", "src/darker/tests/test_git.py::test_edited_linenums_differ_revision_vs_lines_multiline_strings[1-expect1]", "src/darker/tests/test_git.py::test_local_gitconfig_ignored_by_gitrepofixture" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2024-04-15 16:50:57+00:00
bsd-3-clause
986
akaihola__pgtricks-13
diff --git a/CHANGES.rst b/CHANGES.rst index 3fc8314..c3796a7 100644 --- a/CHANGES.rst +++ b/CHANGES.rst @@ -13,6 +13,9 @@ Removed Fixed ----- +- Very large tables are now sorted without crashing. This is done by merge sorting + in temporary files. + 1.0.0_ / 2021-09-11 ==================== diff --git a/mypy.ini b/mypy.ini index ed30dab..bbb2f00 100644 --- a/mypy.ini +++ b/mypy.ini @@ -32,6 +32,9 @@ strict_equality = True disallow_any_decorated = False disallow_untyped_defs = False +[mypy-pgtricks.mergesort] +disallow_any_explicit = False + [mypy-pytest.*] ignore_missing_imports = True diff --git a/pgtricks/mergesort.py b/pgtricks/mergesort.py new file mode 100644 index 0000000..f22f020 --- /dev/null +++ b/pgtricks/mergesort.py @@ -0,0 +1,76 @@ +"""Merge sort implementation to handle large files by sorting them in partitions.""" + +from __future__ import annotations + +import sys +from heapq import merge +from tempfile import TemporaryFile +from typing import IO, Any, Callable, Iterable, Iterator, cast + + +class MergeSort(Iterable[str]): + """Merge sort implementation to handle large files by sorting them in partitions.""" + + def __init__( + self, + key: Callable[[str], Any] = str, + directory: str = ".", + max_memory: int = 190, + ) -> None: + """Initialize the merge sort object.""" + self._key = key + self._directory = directory + self._max_memory = max_memory + # Use binary mode to avoid newline conversion on Windows. + self._partitions: list[IO[bytes]] = [] + self._iterating: Iterable[str] | None = None + self._buffer: list[str] = [] + self._memory_counter: int = sys.getsizeof(self._buffer) + self._flush() + + def append(self, line: str) -> None: + """Append a line to the set of lines to be sorted.""" + if self._iterating: + message = "Can't append lines after starting to sort" + raise ValueError(message) + self._memory_counter -= sys.getsizeof(self._buffer) + self._buffer.append(line) + self._memory_counter += sys.getsizeof(self._buffer) + self._memory_counter += sys.getsizeof(line) + if self._memory_counter >= self._max_memory: + self._flush() + + def _flush(self) -> None: + if self._buffer: + # Use binary mode to avoid newline conversion on Windows. + self._partitions.append(TemporaryFile(mode="w+b", dir=self._directory)) + self._partitions[-1].writelines( + line.encode("UTF-8") for line in sorted(self._buffer, key=self._key) + ) + self._buffer = [] + self._memory_counter = sys.getsizeof(self._buffer) + + def __next__(self) -> str: + """Return the next line in the sorted list of lines.""" + if not self._iterating: + if self._partitions: + # At least one partition has already been flushed to disk. + # Iterate the merge sort for all partitions. + self._flush() + for partition in self._partitions: + partition.seek(0) + self._iterating = merge( + *[ + (line.decode("UTF-8") for line in partition) + for partition in self._partitions + ], + key=self._key, + ) + else: + # All lines fit in memory. Iterate the list of lines directly. + self._iterating = iter(sorted(self._buffer, key=self._key)) + return next(cast(Iterator[str], self._iterating)) + + def __iter__(self) -> Iterator[str]: + """Return the iterator object for the sorted list of lines.""" + return self diff --git a/pgtricks/pg_dump_splitsort.py b/pgtricks/pg_dump_splitsort.py index 56908ea..aab1258 100755 --- a/pgtricks/pg_dump_splitsort.py +++ b/pgtricks/pg_dump_splitsort.py @@ -1,15 +1,23 @@ #!/usr/bin/env python +from __future__ import annotations + import functools +import io import os import re -import sys -from typing import IO, List, Match, Optional, Pattern, Tuple, Union, cast +from argparse import ArgumentParser +from typing import IO, Iterable, Match, Pattern, cast + +from pgtricks.mergesort import MergeSort COPY_RE = re.compile(r'COPY .*? \(.*?\) FROM stdin;\n$') +KIBIBYTE, MEBIBYTE, GIBIBYTE = 2**10, 2**20, 2**30 +MEMORY_UNITS = {"": 1, "k": KIBIBYTE, "m": MEBIBYTE, "g": GIBIBYTE} -def try_float(s1: str, s2: str) -> Union[Tuple[str, str], Tuple[float, float]]: +def try_float(s1: str, s2: str) -> tuple[str, str] | tuple[float, float]: + """Convert two strings to floats. Return original ones on conversion error.""" if not s1 or not s2 or s1[0] not in '0123456789.-' or s2[0] not in '0123456789.-': # optimization return s1, s2 @@ -22,7 +30,8 @@ def try_float(s1: str, s2: str) -> Union[Tuple[str, str], Tuple[float, float]]: def linecomp(l1: str, l2: str) -> int: p1 = l1.split('\t', 1) p2 = l2.split('\t', 1) - v1, v2 = cast(Tuple[float, float], try_float(p1[0], p2[0])) + # TODO: unquote cast after support for Python 3.8 is dropped + v1, v2 = cast("tuple[float, float]", try_float(p1[0], p2[0])) result = (v1 > v2) - (v1 < v2) # modifying a line to see whether Darker works: if not result and len(p1) == len(p2) == 2: @@ -37,9 +46,10 @@ SEQUENCE_SET_RE = re.compile(r'-- Name: .+; Type: SEQUENCE SET; Schema: |' class Matcher(object): def __init__(self) -> None: - self._match: Optional[Match[str]] = None + self._match: Match[str] | None = None - def match(self, pattern: Pattern[str], data: str) -> Optional[Match[str]]: + def match(self, pattern: Pattern[str], data: str) -> Match[str] | None: + """Match the regular expression pattern against the data.""" self._match = pattern.match(data) return self._match @@ -49,34 +59,44 @@ class Matcher(object): return self._match.group(group1) -def split_sql_file(sql_filepath: str) -> None: - +def split_sql_file( # noqa: C901 too complex + sql_filepath: str, + max_memory: int = 100 * MEBIBYTE, +) -> None: + """Split a SQL file so that each COPY statement is in its own file.""" directory = os.path.dirname(sql_filepath) - output: Optional[IO[str]] = None - buf: List[str] = [] + # `output` needs to be instantiated before the inner functions are defined. + # Assign it a dummy string I/O object so type checking is happy. + # This will be replaced with the prologue SQL file object. + output: IO[str] = io.StringIO() + buf: list[str] = [] def flush() -> None: - cast(IO[str], output).writelines(buf) + output.writelines(buf) buf[:] = [] + def writelines(lines: Iterable[str]) -> None: + if buf: + flush() + output.writelines(lines) + def new_output(filename: str) -> IO[str]: if output: output.close() return open(os.path.join(directory, filename), 'w') - copy_lines: Optional[List[str]] = None + sorted_data_lines: MergeSort | None = None counter = 0 output = new_output('0000_prologue.sql') matcher = Matcher() for line in open(sql_filepath): - if copy_lines is None: + if sorted_data_lines is None: if line in ('\n', '--\n'): buf.append(line) elif line.startswith('SET search_path = '): - flush() - buf.append(line) + writelines([line]) else: if matcher.match(DATA_COMMENT_RE, line): counter += 1 @@ -86,28 +106,54 @@ def split_sql_file(sql_filepath: str) -> None: schema=matcher.group('schema'), table=matcher.group('table'))) elif COPY_RE.match(line): - copy_lines = [] + sorted_data_lines = MergeSort( + key=functools.cmp_to_key(linecomp), + max_memory=max_memory, + ) elif SEQUENCE_SET_RE.match(line): pass elif 1 <= counter < 9999: counter = 9999 output = new_output('%04d_epilogue.sql' % counter) - buf.append(line) - flush() + writelines([line]) else: - if line == '\\.\n': - copy_lines.sort(key=functools.cmp_to_key(linecomp)) - buf.extend(copy_lines) - buf.append(line) - flush() - copy_lines = None + if line == "\\.\n": + writelines(sorted_data_lines) + writelines(line) + sorted_data_lines = None else: - copy_lines.append(line) + sorted_data_lines.append(line) flush() +def memory_size(size: str) -> int: + """Parse a human-readable memory size. + + :param size: The memory size to parse, e.g. "100MB". + :return: The memory size in bytes. + :raise ValueError: If the memory size is invalid. + + """ + match = re.match(r"([\d._]+)\s*([kmg]?)b?", size.lower().strip()) + if not match: + message = f"Invalid memory size: {size}" + raise ValueError(message) + return int(float(match.group(1)) * MEMORY_UNITS[match.group(2)]) + + def main() -> None: - split_sql_file(sys.argv[1]) + parser = ArgumentParser(description="Split a SQL file into smaller files.") + parser.add_argument("sql_filepath", help="The SQL file to split.") + parser.add_argument( + "-m", + "--max-memory", + default=100 * MEBIBYTE, + type=memory_size, + help="Max memory to use, e.g. 50_000, 200000000, 100kb, 100MB (default), 2Gig.", + ) + args = parser.parse_args() + + split_sql_file(args.sql_filepath, args.max_memory) if __name__ == '__main__': diff --git a/pyproject.toml b/pyproject.toml index 086fffd..6f3739b 100644 --- a/pyproject.toml +++ b/pyproject.toml @@ -21,7 +21,9 @@ ignore = [ "ANN201", # Missing return type annotation for public function #"ANN204", # Missing return type annotation for special method `__init__` #"C408", # Unnecessary `dict` call (rewrite as a literal) + "PLR2004", # Magic value used in comparison "S101", # Use of `assert` detected + "SLF001", # Private member accessed ] [tool.ruff.lint.isort]
akaihola/pgtricks
c5ba05b4db22a74388b0c2b863e1c4a9f0467c8b
diff --git a/pgtricks/tests/test_mergesort.py b/pgtricks/tests/test_mergesort.py new file mode 100644 index 0000000..6f7c0b6 --- /dev/null +++ b/pgtricks/tests/test_mergesort.py @@ -0,0 +1,110 @@ +"""Tests for the `pgtricks.mergesort` module.""" + +import functools +from types import GeneratorType +from typing import Iterable, cast + +import pytest + +from pgtricks.mergesort import MergeSort +from pgtricks.pg_dump_splitsort import linecomp + +# This is the biggest amount of memory which can't hold two one-character lines on any +# platform. On Windows it's slightly smaller than on Unix. +JUST_BELOW_TWO_SHORT_LINES = 174 + + [email protected]("lf", ["\n", "\r\n"]) +def test_mergesort_append(tmpdir, lf): + """Test appending lines to the merge sort object.""" + m = MergeSort(directory=tmpdir, max_memory=JUST_BELOW_TWO_SHORT_LINES) + m.append(f"1{lf}") + assert m._buffer == [f"1{lf}"] + m.append(f"2{lf}") + assert m._buffer == [] + m.append(f"3{lf}") + assert m._buffer == [f"3{lf}"] + assert len(m._partitions) == 1 + pos = m._partitions[0].tell() + m._partitions[0].seek(0) + assert m._partitions[0].read() == f"1{lf}2{lf}".encode() + assert pos == len(f"1{lf}2{lf}") + + [email protected]("lf", ["\n", "\r\n"]) +def test_mergesort_flush(tmpdir, lf): + """Test flushing the buffer to disk.""" + m = MergeSort(directory=tmpdir, max_memory=JUST_BELOW_TWO_SHORT_LINES) + for value in [1, 2, 3]: + m.append(f"{value}{lf}") + m._flush() + assert len(m._partitions) == 2 + assert m._partitions[0].tell() == len(f"1{lf}2{lf}") + m._partitions[0].seek(0) + assert m._partitions[0].read() == f"1{lf}2{lf}".encode() + pos = m._partitions[1].tell() + m._partitions[1].seek(0) + assert m._partitions[1].read() == f"3{lf}".encode() + assert pos == len(f"3{lf}") + + [email protected]("lf", ["\n", "\r\n"]) +def test_mergesort_iterate_disk(tmpdir, lf): + """Test iterating over the sorted lines on disk.""" + m = MergeSort(directory=tmpdir, max_memory=JUST_BELOW_TWO_SHORT_LINES) + for value in [3, 1, 4, 1, 5, 9, 2, 6, 5, 3, 8, 4]: + m.append(f"{value}{lf}") + assert next(m) == f"1{lf}" + assert isinstance(m._iterating, GeneratorType) + assert next(m) == f"1{lf}" + assert next(m) == f"2{lf}" + assert next(m) == f"3{lf}" + assert next(m) == f"3{lf}" + assert next(m) == f"4{lf}" + assert next(m) == f"4{lf}" + assert next(m) == f"5{lf}" + assert next(m) == f"5{lf}" + assert next(m) == f"6{lf}" + assert next(m) == f"8{lf}" + assert next(m) == f"9{lf}" + with pytest.raises(StopIteration): + next(m) + + [email protected]("lf", ["\n", "\r\n"]) +def test_mergesort_iterate_memory(tmpdir, lf): + """Test iterating over the sorted lines when all lines fit in memory.""" + m = MergeSort( + directory=tmpdir, + max_memory=1000000, + key=functools.cmp_to_key(linecomp), + ) + for value in [3, 1, 4, 1, 5, 9, 2, 10, 6, 5, 3, 8, 4]: + m.append(f"{value}{lf}") + assert next(m) == f"1{lf}" + assert not isinstance(m._iterating, GeneratorType) + assert iter(cast(Iterable[str], m._iterating)) is m._iterating + assert next(m) == f"1{lf}" + assert next(m) == f"2{lf}" + assert next(m) == f"3{lf}" + assert next(m) == f"3{lf}" + assert next(m) == f"4{lf}" + assert next(m) == f"4{lf}" + assert next(m) == f"5{lf}" + assert next(m) == f"5{lf}" + assert next(m) == f"6{lf}" + assert next(m) == f"8{lf}" + assert next(m) == f"9{lf}" + assert next(m) == f"10{lf}" + with pytest.raises(StopIteration): + next(m) + + [email protected]("lf", ["\n", "\r\n"]) +def test_mergesort_key(tmpdir, lf): + """Test sorting lines based on a key function.""" + m = MergeSort(directory=tmpdir, key=lambda line: -int(line[0])) + for value in [3, 1, 4, 1, 5, 9, 2, 6, 5, 3, 8, 4]: + m.append(f"{value}{lf}") + result = "".join(value[0] for value in m) + assert result == "986554433211" diff --git a/pgtricks/tests/test_pg_dump_splitsort.py b/pgtricks/tests/test_pg_dump_splitsort.py index 3305c03..74e6b56 100644 --- a/pgtricks/tests/test_pg_dump_splitsort.py +++ b/pgtricks/tests/test_pg_dump_splitsort.py @@ -1,8 +1,9 @@ from functools import cmp_to_key +from textwrap import dedent import pytest -from pgtricks.pg_dump_splitsort import linecomp, try_float +from pgtricks.pg_dump_splitsort import linecomp, memory_size, split_sql_file, try_float @pytest.mark.parametrize( @@ -101,3 +102,111 @@ def test_linecomp_by_sorting(): [r'\N', r'\N', r'\N'], [r'\N', 'foo', '.42'], ] + + +PROLOGUE = dedent( + """ + + -- + -- Name: table1; Type: TABLE; Schema: public; Owner: + -- + + (information for table1 goes here) + """, +) + +TABLE1_COPY = dedent( + r""" + + -- Data for Name: table1; Type: TABLE DATA; Schema: public; + + COPY foo (id) FROM stdin; + 3 + 1 + 4 + 1 + 5 + 9 + 2 + 6 + 5 + 3 + 8 + 4 + \. + """, +) + +TABLE1_COPY_SORTED = dedent( + r""" + + -- Data for Name: table1; Type: TABLE DATA; Schema: public; + + COPY foo (id) FROM stdin; + 1 + 1 + 2 + 3 + 3 + 4 + 4 + 5 + 5 + 6 + 8 + 9 + \. + """, +) + +EPILOGUE = dedent( + """ + -- epilogue + """, +) + + +def test_split_sql_file(tmpdir): + """Test splitting a SQL file with COPY statements.""" + sql_file = tmpdir / "test.sql" + sql_file.write(PROLOGUE + TABLE1_COPY + EPILOGUE) + + split_sql_file(sql_file, max_memory=190) + + split_files = sorted(path.relto(tmpdir) for path in tmpdir.listdir()) + assert split_files == [ + "0000_prologue.sql", + "0001_public.table1.sql", + "9999_epilogue.sql", + "test.sql", + ] + assert (tmpdir / "0000_prologue.sql").read() == PROLOGUE + assert (tmpdir / "0001_public.table1.sql").read() == TABLE1_COPY_SORTED + assert (tmpdir / "9999_epilogue.sql").read() == EPILOGUE + + [email protected]( + ("size", "expect"), + [ + ("0", 0), + ("1", 1), + ("1k", 1024), + ("1m", 1024**2), + ("1g", 1024**3), + ("100_000K", 102400000), + ("1.5M", 1536 * 1024), + ("1.5G", 1536 * 1024**2), + ("1.5", 1), + ("1.5 kibibytes", 1536), + ("1.5 Megabytes", 1024 * 1536), + ("1.5 Gigs", 1024**2 * 1536), + ("1.5KB", 1536), + (".5MB", 512 * 1024), + ("20GB", 20 * 1024**3), + ], +) +def test_memory_size(size, expect): + """Test parsing human-readable memory sizes with `memory_size`.""" + result = memory_size(size) + + assert result == expect
Use Too Much Memory, Killed by System I'm using this project to split the .sql file to make the pg_dump dumped file in an order that backup programs can deduplicate the existing data. The dumped file is more than 1000GB, which is a kind of big. So I guess the data may be sorted in memory, so it's easy to use out.
0.0
c5ba05b4db22a74388b0c2b863e1c4a9f0467c8b
[ "pgtricks/tests/test_mergesort.py::mypy", "pgtricks/tests/test_mergesort.py::mypy-status", "pgtricks/tests/test_mergesort.py::test_mergesort_append[\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_append[\\r\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_flush[\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_flush[\\r\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_iterate_disk[\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_iterate_disk[\\r\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_iterate_memory[\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_iterate_memory[\\r\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_key[\\n]", "pgtricks/tests/test_mergesort.py::test_mergesort_key[\\r\\n]", "pgtricks/tests/test_pg_dump_splitsort.py::mypy", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[--expect0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[foo--expect1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[foo-bar-expect2]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[0-1-expect3]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[0-one-expect4]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[0.0-0.0-expect5]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[0.0-one", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[0.-1.-expect7]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[0.-one-expect8]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[4.2-0.42-expect9]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[4.2-four", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[-.42--0.042-expect11]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[-.42-minus", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[\\\\N-\\\\N-expect13]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[foo-\\\\N-expect14]", "pgtricks/tests/test_pg_dump_splitsort.py::test_try_float[-4.2-\\\\N-expect15]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[--0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[a-b--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[b-a-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[0-1--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[1-0-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[0--1-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[-1-0--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[0-0-0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[-1--1-0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[0.42-0.042-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[4.2-42.0--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[-.42-.42--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[.42--.42-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[\"32.0\"-\"4.20\"--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[foo\\ta-bar\\tb-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[foo\\tb-foo\\ta-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[foo\\t0.42-foo\\t4.2--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[foo\\tbar\\t0.42424242424242\\tbaz-foo\\tbar\\t0.42424242424242\\tbaz-0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[foo-0-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[0-foo--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[42--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[-42--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[42-42.0-0_0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[42-\\\\N--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[\\\\N-42-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[42-42.0-0_1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[-\\\\N--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[\\\\N--1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp[\\\\N-\\\\N-0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_linecomp_by_sorting", "pgtricks/tests/test_pg_dump_splitsort.py::test_split_sql_file", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[0-0]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1k-1024]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1m-1048576]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1g-1073741824]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[100_000K-102400000]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1.5M-1572864]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1.5G-1610612736]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1.5-1]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1.5", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[1.5KB-1536]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[.5MB-524288]", "pgtricks/tests/test_pg_dump_splitsort.py::test_memory_size[20GB-21474836480]" ]
[]
{ "failed_lite_validators": [ "has_added_files", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2020-07-04 07:59:52+00:00
bsd-3-clause
987
aklajnert__changelogd-26
diff --git a/changelog.d/minor.a6ea1885.entry.yaml b/changelog.d/minor.a6ea1885.entry.yaml new file mode 100644 index 0000000..7734ed4 --- /dev/null +++ b/changelog.d/minor.a6ea1885.entry.yaml @@ -0,0 +1,5 @@ +message: Trim whitespace from multi-value fields. +pr_ids: +- '26' +timestamp: 1665243991 +type: minor diff --git a/changelogd/changelogd.py b/changelogd/changelogd.py index 74d7b2f..273d1b4 100644 --- a/changelogd/changelogd.py +++ b/changelogd/changelogd.py @@ -1,9 +1,11 @@ # -*- coding: utf-8 -*- """Main module.""" +import csv import datetime import getpass import glob import hashlib +import io import json import logging import os @@ -60,7 +62,9 @@ class EntryField: if value is None and not self.required: break if value is not None and self.multiple: - value = value.split(",") + csv_string = io.StringIO(value) + reader = csv.reader(csv_string, delimiter=",") + value = [value.strip() for value in next(reader)] return value
aklajnert/changelogd
538833969df3df5242f85c90195093d4f7ed5c72
diff --git a/tests/test_entry.py b/tests/test_entry.py index 11791a0..4dbe575 100644 --- a/tests/test_entry.py +++ b/tests/test_entry.py @@ -111,6 +111,34 @@ def test_non_interactive_data(setup_env, type_input): } +def test_multi_value_string(setup_env): + runner = CliRunner() + runner.invoke(commands.init) + + entry = runner.invoke( + commands.entry, + ["--type", "1", "--message", "test message"], + input='a, b,"c,d", e,f', + ) + assert entry.exit_code == 0 + + entries = glob.glob(str(setup_env / "changelog.d" / "*entry.yaml")) + assert len(entries) == 1 + + with open(entries[0]) as entry_fh: + entry_content = yaml.load(entry_fh) + + assert entry_content.pop("timestamp") + assert entry_content == { + "git_email": "[email protected]", + "git_user": "Some User", + "issue_id": ["a", "b", "c,d", "e", "f"], + "message": "test message", + "os_user": "test-user", + "type": "feature", + } + + def test_entry_missing_message_types(setup_env, caplog): runner = CliRunner() runner.invoke(commands.init)
Trim whitespace before/after comma in multiple: true fields * changelogd version: 0.1.5 * Python version: 3.10.6 * Operating System: Mac OS ### Description When I add multiple entries to an entry for a field with `multiple: true`, if I put a space after the comma, the value for the second entry (and subsequent entries) end up being single quoted with a leading space in the entry.yaml file. Since this happens while producing the entry.yaml file, trimming the whitespace in the entry.md template doesn't help. So I'd need a config option or just have it trim the whitespace before/after the comma separated values by default. ### What I Did ``` # entry changelogd entry Select message type [1]: 1 Merge Request (number only) (required): 1 Messages (separate multiple values with comma): string1, string2 Created changelog entry at /pathToRepo/changelog.d/other.56871af2.entry.yaml # entry.yaml output example merge_request: '1' messages: - string1 - ' string2' timestamp: 1663063391 type: other ```
0.0
538833969df3df5242f85c90195093d4f7ed5c72
[ "tests/test_entry.py::test_multi_value_string" ]
[ "tests/test_entry.py::test_incorrect_input_entry", "tests/test_entry.py::test_entry_help", "tests/test_entry.py::test_non_interactive_data[1]", "tests/test_entry.py::test_non_interactive_data[feature]", "tests/test_entry.py::test_entry_missing_message_types", "tests/test_entry.py::test_entry_incorrect_entry_fields", "tests/test_entry.py::test_user_data" ]
{ "failed_lite_validators": [ "has_added_files" ], "has_test_patch": true, "is_lite": false }
2022-10-08 15:45:52+00:00
mit
988
akolar__ogn-lib-10
diff --git a/ogn_lib/parser.py b/ogn_lib/parser.py index f43f6cb..a2ca7ea 100644 --- a/ogn_lib/parser.py +++ b/ogn_lib/parser.py @@ -627,3 +627,33 @@ class ServerParser(Parser): """ return {'comment': comment} + + +class Spot(Parser): + """ + Parser for Spot-formatted APRS messages. + """ + + __destto__ = ['OGSPOT', 'OGSPOT-1'] + + @staticmethod + def _parse_protocol_specific(comment): + """ + Parses the comment string from Spot's APRS messages. + + :param str comment: comment string + :return: parsed comment + :rtype: dict + """ + + fields = comment.split(' ', maxsplit=2) + + if len(fields) < 3: + raise exceptions.ParseError('SPOT comment incorrectly formatted: ' + 'received {}'.format(comment)) + + return { + 'id': fields[0], + 'model': fields[1], + 'status': fields[2] + }
akolar/ogn-lib
4526578e5fe7e897c6e0f08edfa180e75e88203f
diff --git a/tests/test_parser.py b/tests/test_parser.py index cb9b05c..bcd3247 100644 --- a/tests/test_parser.py +++ b/tests/test_parser.py @@ -440,6 +440,18 @@ class TestNaviter: assert data['address_type'] is constants.AddressType.naviter +class TestSpot: + def test_parse_protocol_specific(self): + data = parser.Spot._parse_protocol_specific('id0-2860357 SPOT3 GOOD') + assert data['id'] == 'id0-2860357' + assert data['model'] == 'SPOT3' + assert data['status'] == 'GOOD' + + def test_parse_protocol_specific_fail(self): + with pytest.raises(exceptions.ParseError): + parser.Spot._parse_protocol_specific('id0-2860357 SPOT3') + + class TestServerParser: def test_parse_message_beacon(self, mocker):
Implement parser for Spot messages (OGSPOT)
0.0
4526578e5fe7e897c6e0f08edfa180e75e88203f
[ "tests/test_parser.py::TestSpot::test_parse_protocol_specific", "tests/test_parser.py::TestSpot::test_parse_protocol_specific_fail" ]
[ "tests/test_parser.py::TestParserBase::test_new_no_id", "tests/test_parser.py::TestParserBase::test_new_single_id", "tests/test_parser.py::TestParserBase::test_new_multi_id", "tests/test_parser.py::TestParserBase::test_no_destto", "tests/test_parser.py::TestParserBase::test_new_wrong_id", "tests/test_parser.py::TestParserBase::test_set_default", "tests/test_parser.py::TestParserBase::test_call", "tests/test_parser.py::TestParserBase::test_call_server", "tests/test_parser.py::TestParserBase::test_call_no_parser", "tests/test_parser.py::TestParserBase::test_call_default", "tests/test_parser.py::TestParserBase::test_call_failed", "tests/test_parser.py::TestParser::test_pattern_header", "tests/test_parser.py::TestParser::test_pattern_header_matches_all", "tests/test_parser.py::TestParser::test_pattern_location", "tests/test_parser.py::TestParser::test_pattern_location_matches_all", "tests/test_parser.py::TestParser::test_pattern_comment_common", "tests/test_parser.py::TestParser::test_pattern_comment_common_matches_all", "tests/test_parser.py::TestParser::test_pattern_all", "tests/test_parser.py::TestParser::test_pattern_all_matches_all", "tests/test_parser.py::TestParser::test_parse_msg_no_match", "tests/test_parser.py::TestParser::test_parse_msg_calls", "tests/test_parser.py::TestParser::test_parse_msg", "tests/test_parser.py::TestParser::test_parse_msg_full", "tests/test_parser.py::TestParser::test_parse_msg_delete_update", "tests/test_parser.py::TestParser::test_parse_msg_comment", "tests/test_parser.py::TestParser::test_parse_digipeaters", "tests/test_parser.py::TestParser::test_parse_digipeaters_relayed", "tests/test_parser.py::TestParser::test_parse_digipeaters_unknown_format", "tests/test_parser.py::TestParser::test_parse_heading_speed", "tests/test_parser.py::TestParser::test_parse_heading_speed_both_missing", "tests/test_parser.py::TestParser::test_parse_heading_speed_null_input", "tests/test_parser.py::TestParser::test_parse_altitude", "tests/test_parser.py::TestParser::test_parse_altitude_missing", "tests/test_parser.py::TestParser::test_parse_attrs", "tests/test_parser.py::TestParser::test_parse_timestamp_h", "tests/test_parser.py::TestParser::test_parse_timestamp_z", "tests/test_parser.py::TestParser::test_parse_time_past", "tests/test_parser.py::TestParser::test_parse_time_future", "tests/test_parser.py::TestParser::test_parse_datetime", "tests/test_parser.py::TestParser::test_parse_location_sign", "tests/test_parser.py::TestParser::test_parse_location_value", "tests/test_parser.py::TestParser::test_parse_protocol_specific", "tests/test_parser.py::TestParser::test_get_location_update_func", "tests/test_parser.py::TestParser::test_update_location_decimal_same", "tests/test_parser.py::TestParser::test_update_location_decimal_positive", "tests/test_parser.py::TestParser::test_update_location_decimal_negative", "tests/test_parser.py::TestParser::test_call", "tests/test_parser.py::TestParser::test_update_data", "tests/test_parser.py::TestParser::test_update_data_missing", "tests/test_parser.py::TestAPRS::test_parse_protocol_specific", "tests/test_parser.py::TestAPRS::test_parse_id_string", "tests/test_parser.py::TestNaviter::test_parse_protocol_specific", "tests/test_parser.py::TestNaviter::test_parse_id_string", "tests/test_parser.py::TestServerParser::test_parse_message_beacon", "tests/test_parser.py::TestServerParser::test_parse_message_status", "tests/test_parser.py::TestServerParser::test_parse_beacon_comment" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2018-02-26 13:37:55+00:00
mit
989
akolar__ogn-lib-11
diff --git a/ogn_lib/parser.py b/ogn_lib/parser.py index a2ca7ea..00093ea 100644 --- a/ogn_lib/parser.py +++ b/ogn_lib/parser.py @@ -629,31 +629,32 @@ class ServerParser(Parser): return {'comment': comment} -class Spot(Parser): +class Spider(Parser): """ - Parser for Spot-formatted APRS messages. + Parser for Spider-formatted APRS messages. """ - __destto__ = ['OGSPOT', 'OGSPOT-1'] + __destto__ = ['OGSPID', 'OGSPID-1'] @staticmethod def _parse_protocol_specific(comment): """ - Parses the comment string from Spot's APRS messages. + Parses the comment string from Spider's APRS messages. :param str comment: comment string :return: parsed comment :rtype: dict """ - fields = comment.split(' ', maxsplit=2) + fields = comment.split(' ', maxsplit=3) - if len(fields) < 3: - raise exceptions.ParseError('SPOT comment incorrectly formatted: ' - 'received {}'.format(comment)) + if len(fields) < 4: + raise exceptions.ParseError('Spider comment incorrectly formatted:' + ' received {}'.format(comment)) return { 'id': fields[0], - 'model': fields[1], - 'status': fields[2] + 'signal_strength': fields[1], + 'spider_id': fields[2], + 'gps_status': fields[3] }
akolar/ogn-lib
5ab4b003315931c1d1f1ac3a9e29532305aa5fff
diff --git a/tests/test_parser.py b/tests/test_parser.py index bcd3247..f179511 100644 --- a/tests/test_parser.py +++ b/tests/test_parser.py @@ -442,14 +442,16 @@ class TestNaviter: class TestSpot: def test_parse_protocol_specific(self): - data = parser.Spot._parse_protocol_specific('id0-2860357 SPOT3 GOOD') - assert data['id'] == 'id0-2860357' - assert data['model'] == 'SPOT3' - assert data['status'] == 'GOOD' + data = parser.Spider._parse_protocol_specific('id300234010617040 +19dB' + ' LWE 3D') + assert data['id'] == 'id300234010617040' + assert data['signal_strength'] == '+19dB' + assert data['spider_id'] == 'LWE' + assert data['gps_status'] == '3D' def test_parse_protocol_specific_fail(self): with pytest.raises(exceptions.ParseError): - parser.Spot._parse_protocol_specific('id0-2860357 SPOT3') + parser.Spider._parse_protocol_specific('id300234010617040 +19dB') class TestServerParser:
Implement parser for Spider messages (OGSPID)
0.0
5ab4b003315931c1d1f1ac3a9e29532305aa5fff
[ "tests/test_parser.py::TestSpot::test_parse_protocol_specific", "tests/test_parser.py::TestSpot::test_parse_protocol_specific_fail" ]
[ "tests/test_parser.py::TestParserBase::test_new_no_id", "tests/test_parser.py::TestParserBase::test_new_single_id", "tests/test_parser.py::TestParserBase::test_new_multi_id", "tests/test_parser.py::TestParserBase::test_no_destto", "tests/test_parser.py::TestParserBase::test_new_wrong_id", "tests/test_parser.py::TestParserBase::test_set_default", "tests/test_parser.py::TestParserBase::test_call", "tests/test_parser.py::TestParserBase::test_call_server", "tests/test_parser.py::TestParserBase::test_call_no_parser", "tests/test_parser.py::TestParserBase::test_call_default", "tests/test_parser.py::TestParserBase::test_call_failed", "tests/test_parser.py::TestParser::test_pattern_header", "tests/test_parser.py::TestParser::test_pattern_header_matches_all", "tests/test_parser.py::TestParser::test_pattern_location", "tests/test_parser.py::TestParser::test_pattern_location_matches_all", "tests/test_parser.py::TestParser::test_pattern_comment_common", "tests/test_parser.py::TestParser::test_pattern_comment_common_matches_all", "tests/test_parser.py::TestParser::test_pattern_all", "tests/test_parser.py::TestParser::test_pattern_all_matches_all", "tests/test_parser.py::TestParser::test_parse_msg_no_match", "tests/test_parser.py::TestParser::test_parse_msg_calls", "tests/test_parser.py::TestParser::test_parse_msg", "tests/test_parser.py::TestParser::test_parse_msg_full", "tests/test_parser.py::TestParser::test_parse_msg_delete_update", "tests/test_parser.py::TestParser::test_parse_msg_comment", "tests/test_parser.py::TestParser::test_parse_digipeaters", "tests/test_parser.py::TestParser::test_parse_digipeaters_relayed", "tests/test_parser.py::TestParser::test_parse_digipeaters_unknown_format", "tests/test_parser.py::TestParser::test_parse_heading_speed", "tests/test_parser.py::TestParser::test_parse_heading_speed_both_missing", "tests/test_parser.py::TestParser::test_parse_heading_speed_null_input", "tests/test_parser.py::TestParser::test_parse_altitude", "tests/test_parser.py::TestParser::test_parse_altitude_missing", "tests/test_parser.py::TestParser::test_parse_attrs", "tests/test_parser.py::TestParser::test_parse_timestamp_h", "tests/test_parser.py::TestParser::test_parse_timestamp_z", "tests/test_parser.py::TestParser::test_parse_time_past", "tests/test_parser.py::TestParser::test_parse_time_future", "tests/test_parser.py::TestParser::test_parse_datetime", "tests/test_parser.py::TestParser::test_parse_location_sign", "tests/test_parser.py::TestParser::test_parse_location_value", "tests/test_parser.py::TestParser::test_parse_protocol_specific", "tests/test_parser.py::TestParser::test_get_location_update_func", "tests/test_parser.py::TestParser::test_update_location_decimal_same", "tests/test_parser.py::TestParser::test_update_location_decimal_positive", "tests/test_parser.py::TestParser::test_update_location_decimal_negative", "tests/test_parser.py::TestParser::test_call", "tests/test_parser.py::TestParser::test_update_data", "tests/test_parser.py::TestParser::test_update_data_missing", "tests/test_parser.py::TestAPRS::test_parse_protocol_specific", "tests/test_parser.py::TestAPRS::test_parse_id_string", "tests/test_parser.py::TestNaviter::test_parse_protocol_specific", "tests/test_parser.py::TestNaviter::test_parse_id_string", "tests/test_parser.py::TestServerParser::test_parse_message_beacon", "tests/test_parser.py::TestServerParser::test_parse_message_status", "tests/test_parser.py::TestServerParser::test_parse_beacon_comment" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2018-02-26 13:39:09+00:00
mit
990
akolar__ogn-lib-12
diff --git a/ogn_lib/parser.py b/ogn_lib/parser.py index abbe761..4df961f 100644 --- a/ogn_lib/parser.py +++ b/ogn_lib/parser.py @@ -686,3 +686,31 @@ class Spider(Parser): 'spider_id': fields[2], 'gps_status': fields[3] } + + +class Skylines(Parser): + """ + Parser for Spider-formatted APRS messages. + """ + + __destto__ = ['OGSKYL', 'OGSKYL-1'] + + @staticmethod + def _parse_protocol_specific(comment): + """ + Parses the comment string from Spider's APRS messages. + :param str comment: comment string + :return: parsed comment + :rtype: dict + """ + + fields = comment.split(' ', maxsplit=1) + + if len(fields) < 2: + raise exceptions.ParseError('Skylines comment incorrectly formatted:' + ' received {}'.format(comment)) + + return { + 'id': fields[0], + 'vertical_speed': int(fields[1][:3]) * FEET_TO_METERS + }
akolar/ogn-lib
8321ac10ba83ecf6566956b001b0644c34c7bdf9
diff --git a/tests/test_parser.py b/tests/test_parser.py index 8fd96a5..fa7c7cd 100644 --- a/tests/test_parser.py +++ b/tests/test_parser.py @@ -466,6 +466,21 @@ class TestSpider: parser.Spider._parse_protocol_specific('id300234010617040 +19dB') +class TestSkylines: + def test_parse_protocol_specific(self): + data = parser.Skylines._parse_protocol_specific('id2816 +000fpm') + assert data['id'] == 'id2816' + assert data['vertical_speed'] == 0 + + data = parser.Skylines._parse_protocol_specific('id2816 +159fpm') + assert data['id'] == 'id2816' + assert abs(data['vertical_speed'] - 4.57) < 0.1 + + def test_parse_protocol_specific_fail(self): + with pytest.raises(exceptions.ParseError): + parser.Skylines._parse_protocol_specific('id1111') + + class TestServerParser: def test_parse_message_beacon(self, mocker):
Implement parser for Skylines messages (OGSKYL)
0.0
8321ac10ba83ecf6566956b001b0644c34c7bdf9
[ "tests/test_parser.py::TestSkylines::test_parse_protocol_specific", "tests/test_parser.py::TestSkylines::test_parse_protocol_specific_fail" ]
[ "tests/test_parser.py::TestParserBase::test_new_no_id", "tests/test_parser.py::TestParserBase::test_new_single_id", "tests/test_parser.py::TestParserBase::test_new_multi_id", "tests/test_parser.py::TestParserBase::test_no_destto", "tests/test_parser.py::TestParserBase::test_new_wrong_id", "tests/test_parser.py::TestParserBase::test_set_default", "tests/test_parser.py::TestParserBase::test_call", "tests/test_parser.py::TestParserBase::test_call_server", "tests/test_parser.py::TestParserBase::test_call_no_parser", "tests/test_parser.py::TestParserBase::test_call_default", "tests/test_parser.py::TestParserBase::test_call_failed", "tests/test_parser.py::TestParser::test_pattern_header", "tests/test_parser.py::TestParser::test_pattern_header_matches_all", "tests/test_parser.py::TestParser::test_pattern_location", "tests/test_parser.py::TestParser::test_pattern_location_matches_all", "tests/test_parser.py::TestParser::test_pattern_comment_common", "tests/test_parser.py::TestParser::test_pattern_comment_common_matches_all", "tests/test_parser.py::TestParser::test_pattern_all", "tests/test_parser.py::TestParser::test_pattern_all_matches_all", "tests/test_parser.py::TestParser::test_parse_msg_no_match", "tests/test_parser.py::TestParser::test_parse_msg_calls", "tests/test_parser.py::TestParser::test_parse_msg", "tests/test_parser.py::TestParser::test_parse_msg_full", "tests/test_parser.py::TestParser::test_parse_msg_delete_update", "tests/test_parser.py::TestParser::test_parse_msg_comment", "tests/test_parser.py::TestParser::test_parse_digipeaters", "tests/test_parser.py::TestParser::test_parse_digipeaters_relayed", "tests/test_parser.py::TestParser::test_parse_digipeaters_unknown_format", "tests/test_parser.py::TestParser::test_parse_heading_speed", "tests/test_parser.py::TestParser::test_parse_heading_speed_both_missing", "tests/test_parser.py::TestParser::test_parse_heading_speed_null_input", "tests/test_parser.py::TestParser::test_parse_altitude", "tests/test_parser.py::TestParser::test_parse_altitude_missing", "tests/test_parser.py::TestParser::test_parse_attrs", "tests/test_parser.py::TestParser::test_parse_timestamp_h", "tests/test_parser.py::TestParser::test_parse_timestamp_z", "tests/test_parser.py::TestParser::test_parse_time_past", "tests/test_parser.py::TestParser::test_parse_time_future", "tests/test_parser.py::TestParser::test_parse_datetime", "tests/test_parser.py::TestParser::test_parse_location_sign", "tests/test_parser.py::TestParser::test_parse_location_value", "tests/test_parser.py::TestParser::test_parse_protocol_specific", "tests/test_parser.py::TestParser::test_get_location_update_func", "tests/test_parser.py::TestParser::test_update_location_decimal_same", "tests/test_parser.py::TestParser::test_update_location_decimal_positive", "tests/test_parser.py::TestParser::test_update_location_decimal_negative", "tests/test_parser.py::TestParser::test_call", "tests/test_parser.py::TestParser::test_update_data", "tests/test_parser.py::TestParser::test_update_data_missing", "tests/test_parser.py::TestAPRS::test_parse_protocol_specific", "tests/test_parser.py::TestAPRS::test_parse_id_string", "tests/test_parser.py::TestNaviter::test_parse_protocol_specific", "tests/test_parser.py::TestNaviter::test_parse_id_string", "tests/test_parser.py::TestSpot::test_parse_protocol_specific", "tests/test_parser.py::TestSpot::test_parse_protocol_specific_fail", "tests/test_parser.py::TestSpider::test_parse_protocol_specific", "tests/test_parser.py::TestSpider::test_parse_protocol_specific_fail", "tests/test_parser.py::TestServerParser::test_parse_message_beacon", "tests/test_parser.py::TestServerParser::test_parse_message_status", "tests/test_parser.py::TestServerParser::test_parse_beacon_comment" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2018-02-26 13:56:28+00:00
mit
991
akolar__ogn-lib-13
diff --git a/ogn_lib/parser.py b/ogn_lib/parser.py index 4df961f..e50eb80 100644 --- a/ogn_lib/parser.py +++ b/ogn_lib/parser.py @@ -714,3 +714,32 @@ class Skylines(Parser): 'id': fields[0], 'vertical_speed': int(fields[1][:3]) * FEET_TO_METERS } + + +class LiveTrack24(Parser): + """ + Parser for LiveTrack24-formatted APRS messages. + """ + + __destto__ = ['OGLT24', 'OGLT24-1'] + + @staticmethod + def _parse_protocol_specific(comment): + """ + Parses the comment string from LiveTrack24's APRS messages. + :param str comment: comment string + :return: parsed comment + :rtype: dict + """ + + fields = comment.split(' ', maxsplit=2) + + if len(fields) < 3: + raise exceptions.ParseError('LT24 comment incorrectly formatted:' + ' received {}'.format(comment)) + + return { + 'id': fields[0], + 'vertical_speed': int(fields[1][:3]) * FEET_TO_METERS, + 'source': fields[2] + }
akolar/ogn-lib
dd7b9bf33caee17a839240a134246881e9c7c32f
diff --git a/tests/test_parser.py b/tests/test_parser.py index fa7c7cd..fb5ec8d 100644 --- a/tests/test_parser.py +++ b/tests/test_parser.py @@ -481,6 +481,23 @@ class TestSkylines: parser.Skylines._parse_protocol_specific('id1111') +class TestLT24: + def test_parse_protocol_specific(self): + data = parser.LiveTrack24._parse_protocol_specific('id25387 +000fpm GPS') + assert data['id'] == 'id25387' + assert data['vertical_speed'] == 0 + assert data['source'] == 'GPS' + + data = parser.LiveTrack24._parse_protocol_specific('id25387 +159fpm GPS') + assert data['id'] == 'id25387' + assert abs(data['vertical_speed'] - 4.57) < 0.1 + assert data['source'] == 'GPS' + + def test_parse_protocol_specific_fail(self): + with pytest.raises(exceptions.ParseError): + parser.LiveTrack24._parse_protocol_specific('id11111 GPS') + + class TestServerParser: def test_parse_message_beacon(self, mocker):
Implement parser for LiveTrack24 messages (OGLT24)
0.0
dd7b9bf33caee17a839240a134246881e9c7c32f
[ "tests/test_parser.py::TestLT24::test_parse_protocol_specific", "tests/test_parser.py::TestLT24::test_parse_protocol_specific_fail" ]
[ "tests/test_parser.py::TestParserBase::test_new_no_id", "tests/test_parser.py::TestParserBase::test_new_single_id", "tests/test_parser.py::TestParserBase::test_new_multi_id", "tests/test_parser.py::TestParserBase::test_no_destto", "tests/test_parser.py::TestParserBase::test_new_wrong_id", "tests/test_parser.py::TestParserBase::test_set_default", "tests/test_parser.py::TestParserBase::test_call", "tests/test_parser.py::TestParserBase::test_call_server", "tests/test_parser.py::TestParserBase::test_call_no_parser", "tests/test_parser.py::TestParserBase::test_call_default", "tests/test_parser.py::TestParserBase::test_call_failed", "tests/test_parser.py::TestParser::test_pattern_header", "tests/test_parser.py::TestParser::test_pattern_header_matches_all", "tests/test_parser.py::TestParser::test_pattern_location", "tests/test_parser.py::TestParser::test_pattern_location_matches_all", "tests/test_parser.py::TestParser::test_pattern_comment_common", "tests/test_parser.py::TestParser::test_pattern_comment_common_matches_all", "tests/test_parser.py::TestParser::test_pattern_all", "tests/test_parser.py::TestParser::test_pattern_all_matches_all", "tests/test_parser.py::TestParser::test_parse_msg_no_match", "tests/test_parser.py::TestParser::test_parse_msg_calls", "tests/test_parser.py::TestParser::test_parse_msg", "tests/test_parser.py::TestParser::test_parse_msg_full", "tests/test_parser.py::TestParser::test_parse_msg_delete_update", "tests/test_parser.py::TestParser::test_parse_msg_comment", "tests/test_parser.py::TestParser::test_parse_digipeaters", "tests/test_parser.py::TestParser::test_parse_digipeaters_relayed", "tests/test_parser.py::TestParser::test_parse_digipeaters_unknown_format", "tests/test_parser.py::TestParser::test_parse_heading_speed", "tests/test_parser.py::TestParser::test_parse_heading_speed_both_missing", "tests/test_parser.py::TestParser::test_parse_heading_speed_null_input", "tests/test_parser.py::TestParser::test_parse_altitude", "tests/test_parser.py::TestParser::test_parse_altitude_missing", "tests/test_parser.py::TestParser::test_parse_attrs", "tests/test_parser.py::TestParser::test_parse_timestamp_h", "tests/test_parser.py::TestParser::test_parse_timestamp_z", "tests/test_parser.py::TestParser::test_parse_time_past", "tests/test_parser.py::TestParser::test_parse_time_future", "tests/test_parser.py::TestParser::test_parse_datetime", "tests/test_parser.py::TestParser::test_parse_location_sign", "tests/test_parser.py::TestParser::test_parse_location_value", "tests/test_parser.py::TestParser::test_parse_protocol_specific", "tests/test_parser.py::TestParser::test_get_location_update_func", "tests/test_parser.py::TestParser::test_update_location_decimal_same", "tests/test_parser.py::TestParser::test_update_location_decimal_positive", "tests/test_parser.py::TestParser::test_update_location_decimal_negative", "tests/test_parser.py::TestParser::test_call", "tests/test_parser.py::TestParser::test_update_data", "tests/test_parser.py::TestParser::test_update_data_missing", "tests/test_parser.py::TestAPRS::test_parse_protocol_specific", "tests/test_parser.py::TestAPRS::test_parse_id_string", "tests/test_parser.py::TestNaviter::test_parse_protocol_specific", "tests/test_parser.py::TestNaviter::test_parse_id_string", "tests/test_parser.py::TestSpot::test_parse_protocol_specific", "tests/test_parser.py::TestSpot::test_parse_protocol_specific_fail", "tests/test_parser.py::TestSpider::test_parse_protocol_specific", "tests/test_parser.py::TestSpider::test_parse_protocol_specific_fail", "tests/test_parser.py::TestSkylines::test_parse_protocol_specific", "tests/test_parser.py::TestSkylines::test_parse_protocol_specific_fail", "tests/test_parser.py::TestServerParser::test_parse_message_beacon", "tests/test_parser.py::TestServerParser::test_parse_message_status", "tests/test_parser.py::TestServerParser::test_parse_beacon_comment" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2018-02-26 14:12:12+00:00
mit
992
akolar__ogn-lib-18
diff --git a/ogn_lib/parser.py b/ogn_lib/parser.py index 4ae680a..f3b51ae 100644 --- a/ogn_lib/parser.py +++ b/ogn_lib/parser.py @@ -773,7 +773,7 @@ class LiveTrack24(Parser): class Capturs(Parser): - __destto__ = ['OGLT24', 'OGLT24-1'] + __destto__ = ['OGCAPT', 'OGCAPT-1'] @staticmethod def _preprocess_message(message):
akolar/ogn-lib
fb920126739e2ac5dba17b6dd14b718b1952090f
diff --git a/tests/test_parser.py b/tests/test_parser.py index c1c0a9c..937c193 100644 --- a/tests/test_parser.py +++ b/tests/test_parser.py @@ -426,6 +426,14 @@ class TestAPRS: assert data['aircraft_type'] is constants.AirplaneType.glider assert data['address_type'] is constants.AddressType.flarm + def test_registered(self, mocker): + mocker.spy(parser.APRS, '_parse_protocol_specific') + parser.Parser("FLRDDA5BA>APRS,qAS,LFMX:/165829h4415.41N/00600.03E'342/" + "049/A=005524 id0ADDA5BA -454fpm -1.1rot 8.8dB 0e " + "+51.2kHz gps4x5") + parser.APRS._parse_protocol_specific.assert_called_once_with( + 'id0ADDA5BA -454fpm -1.1rot 8.8dB 0e +51.2kHz gps4x5') + class TestNaviter: @@ -459,6 +467,13 @@ class TestNaviter: assert data['aircraft_type'] is constants.AirplaneType.paraglider assert data['address_type'] is constants.AddressType.naviter + def test_registered(self, mocker): + mocker.spy(parser.Naviter, '_parse_protocol_specific') + parser.Parser("NAV04220E>OGNAVI,qAS,NAVITER:/140748h4552.27N/01155.61E" + "'090/012/A=006562 !W81! id044004220E +060fpm +1.2rot") + parser.Naviter._parse_protocol_specific.assert_called_once_with( + '!W81! id044004220E +060fpm +1.2rot') + class TestSpot: def test_parse_protocol_specific(self): @@ -471,6 +486,13 @@ class TestSpot: with pytest.raises(exceptions.ParseError): parser.Spot._parse_protocol_specific('id0-2860357 SPOT3') + def test_registered(self, mocker): + mocker.spy(parser.Spot, '_parse_protocol_specific') + parser.Parser("ICA3E7540>OGSPOT,qAS,SPOT:/161427h1448.35S/04610.86W'" + "000/000/A=008677 id0-2860357 SPOT3 GOOD") + parser.Spot._parse_protocol_specific.assert_called_once_with( + 'id0-2860357 SPOT3 GOOD') + class TestSpider: def test_parse_protocol_specific(self): @@ -485,6 +507,13 @@ class TestSpider: with pytest.raises(exceptions.ParseError): parser.Spider._parse_protocol_specific('id300234010617040 +19dB') + def test_registered(self, mocker): + mocker.spy(parser.Spider, '_parse_protocol_specific') + parser.Parser("FLRDDF944>OGSPID,qAS,SPIDER:/190930h3322.78S/07034.60W'" + "000/000/A=002263 id300234010617040 +19dB LWE 3D") + parser.Spider._parse_protocol_specific.assert_called_once_with( + 'id300234010617040 +19dB LWE 3D') + class TestSkylines: def test_parse_protocol_specific(self): @@ -500,6 +529,13 @@ class TestSkylines: with pytest.raises(exceptions.ParseError): parser.Skylines._parse_protocol_specific('id1111') + def test_registered(self, mocker): + mocker.spy(parser.Skylines, '_parse_protocol_specific') + parser.Parser("FLRDDDD78>OGSKYL,qAS,SKYLINES:/134403h4225.90N/00144.8" + "3E'000/000/A=008438 id2816 +000fpm") + parser.Skylines._parse_protocol_specific.assert_called_once_with( + 'id2816 +000fpm') + class TestLT24: def test_parse_protocol_specific(self): @@ -517,6 +553,13 @@ class TestLT24: with pytest.raises(exceptions.ParseError): parser.LiveTrack24._parse_protocol_specific('id11111 GPS') + def test_registered(self, mocker): + mocker.spy(parser.LiveTrack24, '_parse_protocol_specific') + parser.Parser("FLRDDE48A>OGLT24,qAS,LT24:/102606h4030.47N/00338.38W'" + "000/018/A=002267 id25387 +000fpm GPS") + parser.LiveTrack24._parse_protocol_specific.assert_called_once_with( + 'id25387 +000fpm GPS') + class TestCapturs: def test_process(self): @@ -530,6 +573,12 @@ class TestCapturs: assert msg == msg_original[:-1] + def test_registered(self, mocker): + mocker.spy(parser.Capturs, '_preprocess_message') + msg = ("FLRDDEEF1>OGCAPT,qAS,CAPTURS:/065144h4837.56N/00233.80E'000/000/") + parser.Parser(msg) + parser.Capturs._preprocess_message.assert_called_once_with(msg) + class TestServerParser:
Capturs parser has invalid callsign Capturs parser is registered using OGLT24 instead of OGCAPT.
0.0
fb920126739e2ac5dba17b6dd14b718b1952090f
[ "tests/test_parser.py::TestLT24::test_registered", "tests/test_parser.py::TestCapturs::test_registered" ]
[ "tests/test_parser.py::TestParserBase::test_new_no_id", "tests/test_parser.py::TestParserBase::test_new_single_id", "tests/test_parser.py::TestParserBase::test_new_multi_id", "tests/test_parser.py::TestParserBase::test_no_destto", "tests/test_parser.py::TestParserBase::test_new_wrong_id", "tests/test_parser.py::TestParserBase::test_set_default", "tests/test_parser.py::TestParserBase::test_call", "tests/test_parser.py::TestParserBase::test_call_server", "tests/test_parser.py::TestParserBase::test_call_no_parser", "tests/test_parser.py::TestParserBase::test_call_default", "tests/test_parser.py::TestParserBase::test_call_failed", "tests/test_parser.py::TestParser::test_pattern_header", "tests/test_parser.py::TestParser::test_pattern_header_matches_all", "tests/test_parser.py::TestParser::test_pattern_location", "tests/test_parser.py::TestParser::test_pattern_location_matches_all", "tests/test_parser.py::TestParser::test_pattern_comment_common", "tests/test_parser.py::TestParser::test_pattern_comment_common_matches_all", "tests/test_parser.py::TestParser::test_pattern_all", "tests/test_parser.py::TestParser::test_pattern_all_matches_all", "tests/test_parser.py::TestParser::test_parse_msg_no_match", "tests/test_parser.py::TestParser::test_parse_msg_calls", "tests/test_parser.py::TestParser::test_parse_msg", "tests/test_parser.py::TestParser::test_parse_msg_full", "tests/test_parser.py::TestParser::test_parse_msg_delete_update", "tests/test_parser.py::TestParser::test_parse_msg_comment", "tests/test_parser.py::TestParser::test_preprocess_message", "tests/test_parser.py::TestParser::test_parse_digipeaters", "tests/test_parser.py::TestParser::test_parse_digipeaters_relayed", "tests/test_parser.py::TestParser::test_parse_digipeaters_unknown_format", "tests/test_parser.py::TestParser::test_parse_heading_speed", "tests/test_parser.py::TestParser::test_parse_heading_speed_both_missing", "tests/test_parser.py::TestParser::test_parse_heading_speed_null_input", "tests/test_parser.py::TestParser::test_parse_altitude", "tests/test_parser.py::TestParser::test_parse_altitude_missing", "tests/test_parser.py::TestParser::test_parse_attrs", "tests/test_parser.py::TestParser::test_parse_timestamp_h", "tests/test_parser.py::TestParser::test_parse_timestamp_z", "tests/test_parser.py::TestParser::test_parse_time_past", "tests/test_parser.py::TestParser::test_parse_time_future", "tests/test_parser.py::TestParser::test_parse_datetime", "tests/test_parser.py::TestParser::test_parse_location_sign", "tests/test_parser.py::TestParser::test_parse_location_value", "tests/test_parser.py::TestParser::test_parse_protocol_specific", "tests/test_parser.py::TestParser::test_conv_fpm_to_ms", "tests/test_parser.py::TestParser::test_conv_fpm_to_ms_sign", "tests/test_parser.py::TestParser::test_get_location_update_func", "tests/test_parser.py::TestParser::test_update_location_decimal_same", "tests/test_parser.py::TestParser::test_update_location_decimal_positive", "tests/test_parser.py::TestParser::test_update_location_decimal_negative", "tests/test_parser.py::TestParser::test_call", "tests/test_parser.py::TestParser::test_update_data", "tests/test_parser.py::TestParser::test_update_data_missing", "tests/test_parser.py::TestAPRS::test_parse_protocol_specific", "tests/test_parser.py::TestAPRS::test_parse_id_string", "tests/test_parser.py::TestAPRS::test_registered", "tests/test_parser.py::TestNaviter::test_parse_protocol_specific", "tests/test_parser.py::TestNaviter::test_parse_id_string", "tests/test_parser.py::TestNaviter::test_registered", "tests/test_parser.py::TestSpot::test_parse_protocol_specific", "tests/test_parser.py::TestSpot::test_parse_protocol_specific_fail", "tests/test_parser.py::TestSpot::test_registered", "tests/test_parser.py::TestSpider::test_parse_protocol_specific", "tests/test_parser.py::TestSpider::test_parse_protocol_specific_fail", "tests/test_parser.py::TestSpider::test_registered", "tests/test_parser.py::TestSkylines::test_parse_protocol_specific", "tests/test_parser.py::TestSkylines::test_parse_protocol_specific_fail", "tests/test_parser.py::TestSkylines::test_registered", "tests/test_parser.py::TestLT24::test_parse_protocol_specific", "tests/test_parser.py::TestLT24::test_parse_protocol_specific_fail", "tests/test_parser.py::TestCapturs::test_process", "tests/test_parser.py::TestCapturs::test_preprocess", "tests/test_parser.py::TestServerParser::test_parse_message_beacon", "tests/test_parser.py::TestServerParser::test_parse_message_status", "tests/test_parser.py::TestServerParser::test_parse_beacon_comment" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2018-02-28 06:21:43+00:00
mit
993
alanmcruickshank__sqlfluff-188
diff --git a/src/sqlfluff/dialects/dialect_ansi.py b/src/sqlfluff/dialects/dialect_ansi.py index cea93c05..addb10f1 100644 --- a/src/sqlfluff/dialects/dialect_ansi.py +++ b/src/sqlfluff/dialects/dialect_ansi.py @@ -491,8 +491,15 @@ class SelectTargetElementSegment(BaseSegment): parse_grammar = OneOf( # * Ref('StarSegment'), - # blah.* - Sequence(Ref('SingleIdentifierGrammar'), Ref('DotSegment'), Ref('StarSegment'), code_only=False), + # blah.* + blah.blah.* + Sequence( + Ref('SingleIdentifierGrammar'), Ref('DotSegment'), + Sequence( + Ref('SingleIdentifierGrammar'), Ref('DotSegment'), + optional=True + ), + Ref('StarSegment'), code_only=False + ), Sequence( OneOf( Ref('LiteralGrammar'),
alanmcruickshank/sqlfluff
e456a4b67d16a0cb2b38c978e3dd0b91be2ce31a
diff --git a/test/dialects_ansi_test.py b/test/dialects_ansi_test.py index 91f29dc5..149b5e88 100644 --- a/test/dialects_ansi_test.py +++ b/test/dialects_ansi_test.py @@ -81,7 +81,10 @@ def test__dialect__ansi__file_from_raw(raw, res, caplog): "CAST(num AS INT64)"), # Casting as datatype with arguments ("SelectTargetElementSegment", - "CAST(num AS numeric(8,4))") + "CAST(num AS numeric(8,4))"), + # Wildcard field selection + ("SelectTargetElementSegment", "a.*"), + ("SelectTargetElementSegment", "a.b.*") ] ) def test__dialect__ansi_specific_segment_parses(segmentref, raw, caplog):
PRS Error: Found unparsable segment @L001P008: 'a.b.*...' SQL query to reproduce: ```sql SELECT a.b.* FROM t ```
0.0
e456a4b67d16a0cb2b38c978e3dd0b91be2ce31a
[ "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[SelectTargetElementSegment-a.b.*]" ]
[ "test/dialects_ansi_test.py::test__dialect__ansi__file_from_raw[a", "test/dialects_ansi_test.py::test__dialect__ansi__file_from_raw[b.c-res1]", "test/dialects_ansi_test.py::test__dialect__ansi__file_from_raw[abc", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[SelectKeywordSegment-select]", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[NakedIdentifierSegment-online_sales]", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[NumericLiteralSegment-1000.0]", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-online_sales", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[IntervalLiteralSegment-INTERVAL", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-CASE", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-CAST(ROUND(online_sales", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-name", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[SelectTargetElementSegment-MIN", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-DATE_ADD(CURRENT_DATE('America/New_York'),", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-my_array[1]]", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-my_array[OFFSET(1)]]", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-my_array[5:8]]", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-4", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-bits[OFFSET(0)]", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[SelectTargetElementSegment-(count_18_24", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[ExpressionSegment-count_18_24", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[SelectStatementSegment-SELECT", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[SelectTargetElementSegment-CAST(num", "test/dialects_ansi_test.py::test__dialect__ansi_specific_segment_parses[SelectTargetElementSegment-a.*]" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2020-02-16 21:03:08+00:00
mit
994
alanmcruickshank__sqlfluff-195
diff --git a/.gitignore b/.gitignore index fed2d343..4899559b 100644 --- a/.gitignore +++ b/.gitignore @@ -16,6 +16,7 @@ env .tox venv .venv +.python-version # Ignore coverage reports .coverage diff --git a/src/sqlfluff/cli/commands.py b/src/sqlfluff/cli/commands.py index a8bb8e90..16672d55 100644 --- a/src/sqlfluff/cli/commands.py +++ b/src/sqlfluff/cli/commands.py @@ -1,6 +1,7 @@ """Contains the CLI.""" import sys +import json import click # For the profiler @@ -111,8 +112,11 @@ def rules(**kwargs): @cli.command() @common_options [email protected]('-f', '--format', 'format', default='human', + type=click.Choice(['human', 'json'], case_sensitive=False), + help='What format to return the lint result in.') @click.argument('paths', nargs=-1) -def lint(paths, **kwargs): +def lint(paths, format, **kwargs): """Lint SQL files via passing a list of files or using stdin. PATH is the path to a sql file or directory to lint. This can be either a @@ -132,12 +136,13 @@ def lint(paths, **kwargs): """ c = get_config(**kwargs) - lnt = get_linter(c) + lnt = get_linter(c, silent=format == 'json') verbose = c.get('verbose') config_string = format_config(lnt, verbose=verbose) if len(config_string) > 0: lnt.log(config_string) + # add stdin if specified via lone '-' if ('-',) == paths: result = lnt.lint_string_wrapped(sys.stdin.read(), fname='stdin', verbosity=verbose) @@ -151,6 +156,10 @@ def lint(paths, **kwargs): sys.exit(1) # Output the final stats lnt.log(format_linting_result_footer(result, verbose=verbose)) + + if format == 'json': + click.echo(json.dumps(result.as_records())) + sys.exit(result.stats()['exit code']) diff --git a/src/sqlfluff/errors.py b/src/sqlfluff/errors.py index 8768703c..fee9577e 100644 --- a/src/sqlfluff/errors.py +++ b/src/sqlfluff/errors.py @@ -96,6 +96,17 @@ class SQLBaseError(ValueError): """ return self.rule_code(), self.line_no(), self.line_pos(), self.desc() + def get_info_dict(self): + """Get a dictionary representation of this violation. + + Returns: + A `dictionary` with keys (code, line_no, line_pos, description) + """ + return dict(zip( + ('code', 'line_no', 'line_pos', 'description'), + self.get_info_tuple() + )) + def ignore_if_in(self, ignore_iterable): """Ignore this violation if it matches the iterable.""" # Type conversion diff --git a/src/sqlfluff/linter.py b/src/sqlfluff/linter.py index 933c2569..4ce17449 100644 --- a/src/sqlfluff/linter.py +++ b/src/sqlfluff/linter.py @@ -386,6 +386,20 @@ class LintingResult: all_stats['status'] = 'FAIL' if all_stats['violations'] > 0 else 'PASS' return all_stats + def as_records(self): + """Return the result as a list of dictionaries. + + Each record contains a key specifying the filepath, and a list of violations. This + method is useful for serialization as all objects will be builtin python types + (ints, strs). + """ + return [ + {'filepath': path, 'violations': [v.get_info_dict() for v in violations]} + for lintedpath in self.paths + for path, violations in lintedpath.violations().items() + if violations + ] + def persist_changes(self, verbosity=0, output_func=None, **kwargs): """Run all the fixes for all the files and return a dict.""" return self.combine_dicts(
alanmcruickshank/sqlfluff
97099ae22db068faaaf6fb4a68d73f0274551e5b
diff --git a/test/cli_commands_test.py b/test/cli_commands_test.py index e161e4f4..d2c24ac3 100644 --- a/test/cli_commands_test.py +++ b/test/cli_commands_test.py @@ -4,6 +4,7 @@ import configparser import tempfile import os import shutil +import json # Testing libraries import pytest @@ -210,3 +211,44 @@ def test__cli__command__fix_no_force(rule, fname, prompt, exit_code): generic_roundtrip_test( test_file, rule, force=False, final_exit_code=exit_code, fix_input=prompt) + + [email protected]('sql,expected,exit_code', [ + ('select * from tbl', [], 0), # empty list if no violations + ( + 'SElect * from tbl', + [{ + "filepath": "stdin", + "violations": [ + { + "code": "L010", + "line_no": 1, + "line_pos": 1, + "description": "Inconsistent capitalisation of keywords." + } + ] + }], + 65 + ) +]) +def test__cli__command_lint_json_from_stdin(sql, expected, exit_code): + """Check an explicit JSON return value for a single error.""" + result = invoke_assert_code( + args=[lint, ('-', '--rules', 'L010', '--format', 'json')], + cli_input=sql, + ret_code=exit_code + ) + assert json.loads(result.output) == expected + + +def test__cli__command_lint_json_multiple_files(): + """Check the general format of JSON output for multiple files.""" + fpath = 'test/fixtures/linter/indentation_errors.sql' + + # note the file is in here twice. two files = two payloads. + result = invoke_assert_code( + args=[lint, (fpath, fpath, '--format', 'json')], + ret_code=65, + ) + result = json.loads(result.output) + assert len(result) == 2
Option to output lint result as JSON I was toying around with creating a vscode linter extension for sqlfluff. The process entails wrapping a `sqlfluff lint` subprocess and parsing its output into the structure expected by vscode's linting API. It wouldn't be _very_ difficult to process the stdout as a string, but this reveals a possible need for a `--json` option so that the linting results can be machine readable in general. I am not sure how easy this would be to accomplish but it possible it might be very easy and a quick win. Happy to work on this if all agree it is a good idea!
0.0
97099ae22db068faaaf6fb4a68d73f0274551e5b
[ "test/cli_commands_test.py::test__cli__command_lint_json_multiple_files", "test/cli_commands_test.py::test__cli__command_lint_json_from_stdin[select", "test/cli_commands_test.py::test__cli__command_lint_json_from_stdin[SElect" ]
[ "test/cli_commands_test.py::test__cli__command_lint_parse[command6]", "test/cli_commands_test.py::test__cli__command_lint_parse[command1]", "test/cli_commands_test.py::test__cli__command_lint_parse[command10]", "test/cli_commands_test.py::test__cli__command_lint_parse[command14]", "test/cli_commands_test.py::test__cli__command__fix_no_force[L001-test/fixtures/linter/indentation_errors.sql-n-65]", "test/cli_commands_test.py::test__cli__command_lint_parse[command7]", "test/cli_commands_test.py::test__cli__command_lint_parse[command4]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command0]", "test/cli_commands_test.py::test__cli__command_lint_parse[command9]", "test/cli_commands_test.py::test__cli__command_dialect", "test/cli_commands_test.py::test__cli__command__fix[L008-test/fixtures/linter/whitespace_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_parse[command2]", "test/cli_commands_test.py::test__cli__command_lint_parse[command16]", "test/cli_commands_test.py::test__cli__command_lint_parse[command15]", "test/cli_commands_test.py::test__cli__command__fix[L003-test/fixtures/linter/indentation_error_hard.sql]", "test/cli_commands_test.py::test__cli__command_versioning", "test/cli_commands_test.py::test__cli__command_lint_parse[command8]", "test/cli_commands_test.py::test__cli__command_version", "test/cli_commands_test.py::test__cli__command_lint_parse[command3]", "test/cli_commands_test.py::test__cli__command__fix[L001-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command3]", "test/cli_commands_test.py::test__cli__command_rules", "test/cli_commands_test.py::test__cli__command_lint_parse[command12]", "test/cli_commands_test.py::test__cli__command__fix[L008-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command1]", "test/cli_commands_test.py::test__cli__command_lint_parse[command13]", "test/cli_commands_test.py::test__cli__command_lint_parse[command0]", "test/cli_commands_test.py::test__cli__command__fix_no_force[L001-test/fixtures/linter/indentation_errors.sql-y-0]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command2]", "test/cli_commands_test.py::test__cli__command_directed", "test/cli_commands_test.py::test__cli__command_fix_stdin", "test/cli_commands_test.py::test__cli__command__fix_fail[L004-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_parse[command5]", "test/cli_commands_test.py::test__cli__command_lint_parse[command11]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2020-02-24 00:41:18+00:00
mit
995
alanmcruickshank__sqlfluff-198
diff --git a/src/sqlfluff/cli/commands.py b/src/sqlfluff/cli/commands.py index 16672d55..ac4b9a00 100644 --- a/src/sqlfluff/cli/commands.py +++ b/src/sqlfluff/cli/commands.py @@ -3,6 +3,8 @@ import sys import json +import oyaml as yaml + import click # For the profiler import pstats @@ -113,7 +115,7 @@ def rules(**kwargs): @cli.command() @common_options @click.option('-f', '--format', 'format', default='human', - type=click.Choice(['human', 'json'], case_sensitive=False), + type=click.Choice(['human', 'json', 'yaml'], case_sensitive=False), help='What format to return the lint result in.') @click.argument('paths', nargs=-1) def lint(paths, format, **kwargs): @@ -136,7 +138,7 @@ def lint(paths, format, **kwargs): """ c = get_config(**kwargs) - lnt = get_linter(c, silent=format == 'json') + lnt = get_linter(c, silent=format in ('json', 'yaml')) verbose = c.get('verbose') config_string = format_config(lnt, verbose=verbose) @@ -159,6 +161,8 @@ def lint(paths, format, **kwargs): if format == 'json': click.echo(json.dumps(result.as_records())) + elif format == 'yaml': + click.echo(yaml.dump(result.as_records())) sys.exit(result.stats()['exit code']) @@ -257,7 +261,7 @@ def fix(force, paths, **kwargs): @click.option('-c', '--code-only', is_flag=True, help='Output only the code elements of the parse tree.') @click.option('-f', '--format', default='human', - type=click.Choice(['human', 'yaml'], case_sensitive=False), + type=click.Choice(['human', 'json', 'yaml'], case_sensitive=False), help='What format to return the parse result in.') @click.option('--profiler', is_flag=True, help='Set this flag to engage the python profiler.') @@ -271,7 +275,7 @@ def parse(path, code_only, format, profiler, **kwargs): """ c = get_config(**kwargs) # We don't want anything else to be logged if we want a yaml output - lnt = get_linter(c, silent=format == 'yaml') + lnt = get_linter(c, silent=format in ('json', 'yaml')) verbose = c.get('verbose') recurse = c.get('recurse') @@ -290,23 +294,54 @@ def parse(path, code_only, format, profiler, **kwargs): sys.exit(1) pr = cProfile.Profile() pr.enable() + try: - # A single path must be specified for this command - for parsed, violations, time_dict in lnt.parse_path(path, verbosity=verbose, recurse=recurse): - if parsed: - if format == 'human': + # handle stdin if specified via lone '-' + if '-' == path: + # put the parser result in a list to iterate later + config = lnt.config.make_child_from_path('stdin') + result = [lnt.parse_string( + sys.stdin.read(), + 'stdin', + verbosity=verbose, + recurse=recurse, + config=config + )] + else: + # A single path must be specified for this command + result = lnt.parse_path(path, verbosity=verbose, recurse=recurse) + + # iterative print for human readout + if format == 'human': + for parsed, violations, time_dict in result: + if parsed: lnt.log(parsed.stringify(code_only=code_only)) - elif format == 'yaml': - click.echo(parsed.to_yaml(code_only=code_only, show_raw=True)) - else: - # TODO: Make this prettier - lnt.log('...Failed to Parse...') - nv += len(violations) - for v in violations: - lnt.log(format_violation(v, verbose=verbose)) - if verbose >= 2: - lnt.log("==== timings ====") - lnt.log(cli_table(time_dict.items())) + else: + # TODO: Make this prettier + lnt.log('...Failed to Parse...') + nv += len(violations) + for v in violations: + lnt.log(format_violation(v, verbose=verbose)) + if verbose >= 2: + lnt.log("==== timings ====") + lnt.log(cli_table(time_dict.items())) + else: + # collect result and print as single payload + # will need to zip in the file paths + filepaths = ['stdin'] if '-' == path else lnt.paths_from_path(path) + result = [ + dict( + filepath=filepath, + segments=parsed.as_record(code_only=code_only, show_raw=True) + ) + for filepath, (parsed, _, _) in zip(filepaths, result) + ] + + if format == 'yaml': + click.echo(yaml.dump(result)) + elif format == 'json': + click.echo(json.dumps(result)) + except IOError: click.echo(colorize('The path {0!r} could not be accessed. Check it exists.'.format(path), 'red')) sys.exit(1) diff --git a/src/sqlfluff/parser/segments_base.py b/src/sqlfluff/parser/segments_base.py index e2ef6690..55381a92 100644 --- a/src/sqlfluff/parser/segments_base.py +++ b/src/sqlfluff/parser/segments_base.py @@ -13,7 +13,7 @@ These are the fundamental building blocks of the rest of the parser. """ import logging -import oyaml as yaml + from io import StringIO from .match import MatchResult, curtail_string, join_segments_raw @@ -522,31 +522,33 @@ class BaseSegment: result = (self.type, tuple(seg.to_tuple(**kwargs) for seg in self.segments if not seg.is_meta)) return result - def to_yaml(self, **kwargs): - """Return a yaml structure from this segment.""" - tpl = self.to_tuple(**kwargs) - - def _structural_simplify(elem): - """Simplify the structure recursively so it outputs nicely in yaml.""" - if isinstance(elem, tuple): - # Does this look like an element? - if len(elem) == 2 and isinstance(elem[0], str): - # This looks like a single element, make a dict - elem = {elem[0]: _structural_simplify(elem[1])} - elif isinstance(elem[0], tuple): - # This looks like a list of elements. - keys = [e[0] for e in elem] - # Any duplicate elements? - if len(set(keys)) == len(keys): - # No, we can use a mapping typle - elem = {e[0]: _structural_simplify(e[1]) for e in elem} - else: - # Yes, this has to be a list :( - elem = [_structural_simplify(e) for e in elem] - return elem + @classmethod + def structural_simplify(cls, elem): + """Simplify the structure recursively so it serializes nicely in json/yaml.""" + if isinstance(elem, tuple): + # Does this look like an element? + if len(elem) == 2 and isinstance(elem[0], str): + # This looks like a single element, make a dict + elem = {elem[0]: cls.structural_simplify(elem[1])} + elif isinstance(elem[0], tuple): + # This looks like a list of elements. + keys = [e[0] for e in elem] + # Any duplicate elements? + if len(set(keys)) == len(keys): + # No, we can use a mapping typle + elem = {e[0]: cls.structural_simplify(e[1]) for e in elem} + else: + # Yes, this has to be a list :( + elem = [cls.structural_simplify(e) for e in elem] + return elem + + def as_record(self, **kwargs): + """Return the segment as a structurally simplified record. - obj = _structural_simplify(tpl) - return yaml.dump(obj) + This is useful for serialization to yaml or json. + kwargs passed to to_tuple + """ + return self.structural_simplify(self.to_tuple(**kwargs)) @classmethod def match(cls, segments, parse_context):
alanmcruickshank/sqlfluff
4e11c4ecb334f401a22b4e7b3fc3e5ad899b91f0
diff --git a/test/cli_commands_test.py b/test/cli_commands_test.py index 602d8085..44ff31e8 100644 --- a/test/cli_commands_test.py +++ b/test/cli_commands_test.py @@ -1,261 +1,296 @@ -"""The Test file for CLI (General).""" - -import configparser -import tempfile -import os -import shutil -import json -import subprocess - -# Testing libraries -import pytest -from click.testing import CliRunner - -# We import the library directly here to get the version -import sqlfluff -from sqlfluff.cli.commands import lint, version, rules, fix, parse - - -def invoke_assert_code(ret_code=0, args=None, kwargs=None, cli_input=None): - """Invoke a command and check return code.""" - args = args or [] - kwargs = kwargs or {} - if cli_input: - kwargs['input'] = cli_input - runner = CliRunner() - result = runner.invoke(*args, **kwargs) - # Output the CLI code for debugging - print(result.output) - # Check return codes - if ret_code == 0: - if result.exception: - raise result.exception - assert ret_code == result.exit_code - return result - - -def test__cli__command_directed(): - """Basic checking of lint functionality.""" - result = invoke_assert_code( - ret_code=65, - args=[lint, ['-n', 'test/fixtures/linter/indentation_error_simple.sql']] - ) - # We should get a readout of what the error was - check_a = "L: 2 | P: 4 | L003" - # NB: Skip the number at the end because it's configurable - check_b = "Indentation" - assert check_a in result.output - assert check_b in result.output - - -def test__cli__command_dialect(): - """Check the script raises the right exception on an unknown dialect.""" - # The dialect is unknown should be a non-zero exit code - invoke_assert_code( - ret_code=66, - args=[lint, ['-n', '--dialect', 'faslkjh', 'test/fixtures/linter/indentation_error_simple.sql']] - ) - - [email protected]('command', [ - ('-', '-n', ), ('-', '-n', '-v',), ('-', '-n', '-vv',), ('-', '-vv',), -]) -def test__cli__command_lint_stdin(command): - """Check basic commands on a simple script using stdin. - - The subprocess command should exit without errors, as no issues should be found. - """ - with open('test/fixtures/cli/passing_a.sql', 'r') as test_file: - sql = test_file.read() - invoke_assert_code(args=[lint, command], cli_input=sql) - - [email protected]('command', [ - # Test basic linting - (lint, ['-n', 'test/fixtures/cli/passing_b.sql']), - # Original tests from test__cli__command_lint - (lint, ['-n', 'test/fixtures/cli/passing_a.sql']), - (lint, ['-n', '-v', 'test/fixtures/cli/passing_a.sql']), - (lint, ['-n', '-vvvv', 'test/fixtures/cli/passing_a.sql']), - (lint, ['-vvvv', 'test/fixtures/cli/passing_a.sql']), - # Test basic linting with very high verbosity - (lint, ['-n', 'test/fixtures/cli/passing_b.sql', '-vvvvvvvvvvv']), - # Check basic parsing - (parse, ['-n', 'test/fixtures/cli/passing_b.sql']), - # Test basic parsing with very high verbosity - (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '-vvvvvvvvvvv']), - # Check basic parsing, with the code only option - (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '-c']), - # Check basic parsing, with the yaml output - (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '-c', '-f', 'yaml']), - (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '--format', 'yaml']), - # Check linting works in specifying rules - (lint, ['-n', '--rules', 'L001', 'test/fixtures/linter/operator_errors.sql']), - # Check linting works in specifying multiple rules - (lint, ['-n', '--rules', 'L001,L002', 'test/fixtures/linter/operator_errors.sql']), - # Check linting works with both included and excluded rules - (lint, ['-n', '--rules', 'L001,L006', '--exclude-rules', 'L006', 'test/fixtures/linter/operator_errors.sql']), - # Check linting works with just excluded rules - (lint, ['-n', '--exclude-rules', 'L006,L007', 'test/fixtures/linter/operator_errors.sql']), - # Check the script doesn't raise an unexpected exception with badly formed files. - (fix, ['--rules', 'L001', 'test/fixtures/cli/fail_many.sql', '-vvvvvvv'], 'y'), - # Check that ignoring works (also checks that unicode files parse). - (lint, ['-n', '--exclude-rules', 'L003,L009', '--ignore', 'parsing,lexing', 'test/fixtures/linter/parse_lex_error.sql']), -]) -def test__cli__command_lint_parse(command): - """Check basic commands on a more complicated script.""" - invoke_assert_code(args=command) - - -def test__cli__command_versioning(): - """Check version command.""" - # Get the package version info - pkg_version = sqlfluff.__version__ - # Get the version info from the config file - config = configparser.ConfigParser() - config.read_file(open('src/sqlfluff/config.ini')) - config_version = config['sqlfluff']['version'] - assert pkg_version == config_version - # Get the version from the cli - runner = CliRunner() - result = runner.invoke(version) - assert result.exit_code == 0 - # We need to strip to remove the newline characters - assert result.output.strip() == pkg_version - - -def test__cli__command_version(): - """Just check version command for exceptions.""" - # Get the package version info - pkg_version = sqlfluff.__version__ - runner = CliRunner() - result = runner.invoke(version) - assert result.exit_code == 0 - assert pkg_version in result.output - # Check a verbose version - result = runner.invoke(version, ['-v']) - assert result.exit_code == 0 - assert pkg_version in result.output - - -def test__cli__command_rules(): - """Just check rules command for exceptions.""" - invoke_assert_code(args=[rules]) - - -def generic_roundtrip_test(source_file, rulestring, final_exit_code=0, force=True, fix_input=None, fix_exit_code=0): - """A test for roundtrip testing, take a file buffer, lint, fix and lint. - - This is explicitly different from the linter version of this, in that - it uses the command line rather than the direct api. - """ - filename = 'testing.sql' - # Lets get the path of a file to use - tempdir_path = tempfile.mkdtemp() - filepath = os.path.join(tempdir_path, filename) - # Open the example file and write the content to it - with open(filepath, mode='w') as dest_file: - for line in source_file: - dest_file.write(line) - # Check that we first detect the issue - invoke_assert_code(ret_code=65, args=[lint, ['--rules', rulestring, filepath]]) - # Fix the file (in force mode) - if force: - fix_args = ['--rules', rulestring, '-f', filepath] - else: - fix_args = ['--rules', rulestring, filepath] - invoke_assert_code(ret_code=fix_exit_code, args=[fix, fix_args], cli_input=fix_input) - # Now lint the file and check for exceptions - invoke_assert_code(ret_code=final_exit_code, args=[lint, ['--rules', rulestring, filepath]]) - shutil.rmtree(tempdir_path) - - [email protected]('rule,fname', [ - ('L001', 'test/fixtures/linter/indentation_errors.sql'), - ('L008', 'test/fixtures/linter/whitespace_errors.sql'), - ('L008', 'test/fixtures/linter/indentation_errors.sql'), - # Really stretching the ability of the fixer to re-indent a file - ('L003', 'test/fixtures/linter/indentation_error_hard.sql') -]) -def test__cli__command__fix(rule, fname): - """Test the round trip of detecting, fixing and then not detecting the rule.""" - with open(fname, mode='r') as test_file: - generic_roundtrip_test(test_file, rule) - - [email protected]('rule,fname', [ - # NB: L004 currently has no fix routine. - ('L004', 'test/fixtures/linter/indentation_errors.sql') -]) -def test__cli__command__fix_fail(rule, fname): - """Test the round trip of detecting, fixing and then still detecting the rule.""" - with open(fname, mode='r') as test_file: - generic_roundtrip_test(test_file, rule, fix_exit_code=1, final_exit_code=65) - - -def test__cli__command_fix_stdin(monkeypatch): - """Check stdin input for fix works.""" - sql = 'select * from tbl' - expected = 'fixed sql!' - monkeypatch.setattr("sqlfluff.linter.LintedFile.fix_string", lambda x: expected) - result = invoke_assert_code(args=[fix, ('-', '--rules', 'L001')], cli_input=sql) - assert result.output == expected - - [email protected]('rule,fname,prompt,exit_code', [ - ('L001', 'test/fixtures/linter/indentation_errors.sql', 'y', 0), - ('L001', 'test/fixtures/linter/indentation_errors.sql', 'n', 65) -]) -def test__cli__command__fix_no_force(rule, fname, prompt, exit_code): - """Round trip test, using the prompts.""" - with open(fname, mode='r') as test_file: - generic_roundtrip_test( - test_file, rule, force=False, final_exit_code=exit_code, - fix_input=prompt) - - [email protected]('sql,expected,exit_code', [ - ('select * from tbl', [], 0), # empty list if no violations - ( - 'SElect * from tbl', - [{ - "filepath": "stdin", - "violations": [ - { - "code": "L010", - "line_no": 1, - "line_pos": 1, - "description": "Inconsistent capitalisation of keywords." - } - ] - }], - 65 - ) -]) -def test__cli__command_lint_json_from_stdin(sql, expected, exit_code): - """Check an explicit JSON return value for a single error.""" - result = invoke_assert_code( - args=[lint, ('-', '--rules', 'L010', '--format', 'json')], - cli_input=sql, - ret_code=exit_code - ) - assert json.loads(result.output) == expected - - -def test__cli__command_lint_json_multiple_files(): - """Check the general format of JSON output for multiple files.""" - fpath = 'test/fixtures/linter/indentation_errors.sql' - - # note the file is in here twice. two files = two payloads. - result = invoke_assert_code( - args=[lint, (fpath, fpath, '--format', 'json')], - ret_code=65, - ) - result = json.loads(result.output) - assert len(result) == 2 - - -def test___main___help(): - """Test that the CLI can be access via __main__.""" - # nonzero exit is good enough - subprocess.check_output(['python', '-m', 'sqlfluff', '--help']) +"""The Test file for CLI (General).""" + +import configparser +import tempfile +import os +import shutil +import json +import oyaml as yaml +import subprocess + +# Testing libraries +import pytest +from click.testing import CliRunner + +# We import the library directly here to get the version +import sqlfluff +from sqlfluff.cli.commands import lint, version, rules, fix, parse + + +def invoke_assert_code(ret_code=0, args=None, kwargs=None, cli_input=None): + """Invoke a command and check return code.""" + args = args or [] + kwargs = kwargs or {} + if cli_input: + kwargs['input'] = cli_input + runner = CliRunner() + result = runner.invoke(*args, **kwargs) + # Output the CLI code for debugging + print(result.output) + # Check return codes + if ret_code == 0: + if result.exception: + raise result.exception + assert ret_code == result.exit_code + return result + + +def test__cli__command_directed(): + """Basic checking of lint functionality.""" + result = invoke_assert_code( + ret_code=65, + args=[lint, ['-n', 'test/fixtures/linter/indentation_error_simple.sql']] + ) + # We should get a readout of what the error was + check_a = "L: 2 | P: 4 | L003" + # NB: Skip the number at the end because it's configurable + check_b = "Indentation" + assert check_a in result.output + assert check_b in result.output + + +def test__cli__command_dialect(): + """Check the script raises the right exception on an unknown dialect.""" + # The dialect is unknown should be a non-zero exit code + invoke_assert_code( + ret_code=66, + args=[lint, ['-n', '--dialect', 'faslkjh', 'test/fixtures/linter/indentation_error_simple.sql']] + ) + + [email protected]('command', [ + ('-', '-n', ), ('-', '-n', '-v',), ('-', '-n', '-vv',), ('-', '-vv',), +]) +def test__cli__command_lint_stdin(command): + """Check basic commands on a simple script using stdin. + + The subprocess command should exit without errors, as no issues should be found. + """ + with open('test/fixtures/cli/passing_a.sql', 'r') as test_file: + sql = test_file.read() + invoke_assert_code(args=[lint, command], cli_input=sql) + + [email protected]('command', [ + # Test basic linting + (lint, ['-n', 'test/fixtures/cli/passing_b.sql']), + # Original tests from test__cli__command_lint + (lint, ['-n', 'test/fixtures/cli/passing_a.sql']), + (lint, ['-n', '-v', 'test/fixtures/cli/passing_a.sql']), + (lint, ['-n', '-vvvv', 'test/fixtures/cli/passing_a.sql']), + (lint, ['-vvvv', 'test/fixtures/cli/passing_a.sql']), + # Test basic linting with very high verbosity + (lint, ['-n', 'test/fixtures/cli/passing_b.sql', '-vvvvvvvvvvv']), + # Check basic parsing + (parse, ['-n', 'test/fixtures/cli/passing_b.sql']), + # Test basic parsing with very high verbosity + (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '-vvvvvvvvvvv']), + # Check basic parsing, with the code only option + (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '-c']), + # Check basic parsing, with the yaml output + (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '-c', '-f', 'yaml']), + (parse, ['-n', 'test/fixtures/cli/passing_b.sql', '--format', 'yaml']), + # Check linting works in specifying rules + (lint, ['-n', '--rules', 'L001', 'test/fixtures/linter/operator_errors.sql']), + # Check linting works in specifying multiple rules + (lint, ['-n', '--rules', 'L001,L002', 'test/fixtures/linter/operator_errors.sql']), + # Check linting works with both included and excluded rules + (lint, ['-n', '--rules', 'L001,L006', '--exclude-rules', 'L006', 'test/fixtures/linter/operator_errors.sql']), + # Check linting works with just excluded rules + (lint, ['-n', '--exclude-rules', 'L006,L007', 'test/fixtures/linter/operator_errors.sql']), + # Check the script doesn't raise an unexpected exception with badly formed files. + (fix, ['--rules', 'L001', 'test/fixtures/cli/fail_many.sql', '-vvvvvvv'], 'y'), + # Check that ignoring works (also checks that unicode files parse). + (lint, ['-n', '--exclude-rules', 'L003,L009', '--ignore', 'parsing,lexing', 'test/fixtures/linter/parse_lex_error.sql']), +]) +def test__cli__command_lint_parse(command): + """Check basic commands on a more complicated script.""" + invoke_assert_code(args=command) + + +def test__cli__command_versioning(): + """Check version command.""" + # Get the package version info + pkg_version = sqlfluff.__version__ + # Get the version info from the config file + config = configparser.ConfigParser() + config.read_file(open('src/sqlfluff/config.ini')) + config_version = config['sqlfluff']['version'] + assert pkg_version == config_version + # Get the version from the cli + runner = CliRunner() + result = runner.invoke(version) + assert result.exit_code == 0 + # We need to strip to remove the newline characters + assert result.output.strip() == pkg_version + + +def test__cli__command_version(): + """Just check version command for exceptions.""" + # Get the package version info + pkg_version = sqlfluff.__version__ + runner = CliRunner() + result = runner.invoke(version) + assert result.exit_code == 0 + assert pkg_version in result.output + # Check a verbose version + result = runner.invoke(version, ['-v']) + assert result.exit_code == 0 + assert pkg_version in result.output + + +def test__cli__command_rules(): + """Just check rules command for exceptions.""" + invoke_assert_code(args=[rules]) + + +def generic_roundtrip_test(source_file, rulestring, final_exit_code=0, force=True, fix_input=None, fix_exit_code=0): + """A test for roundtrip testing, take a file buffer, lint, fix and lint. + + This is explicitly different from the linter version of this, in that + it uses the command line rather than the direct api. + """ + filename = 'testing.sql' + # Lets get the path of a file to use + tempdir_path = tempfile.mkdtemp() + filepath = os.path.join(tempdir_path, filename) + # Open the example file and write the content to it + with open(filepath, mode='w') as dest_file: + for line in source_file: + dest_file.write(line) + # Check that we first detect the issue + invoke_assert_code(ret_code=65, args=[lint, ['--rules', rulestring, filepath]]) + # Fix the file (in force mode) + if force: + fix_args = ['--rules', rulestring, '-f', filepath] + else: + fix_args = ['--rules', rulestring, filepath] + invoke_assert_code(ret_code=fix_exit_code, args=[fix, fix_args], cli_input=fix_input) + # Now lint the file and check for exceptions + invoke_assert_code(ret_code=final_exit_code, args=[lint, ['--rules', rulestring, filepath]]) + shutil.rmtree(tempdir_path) + + [email protected]('rule,fname', [ + ('L001', 'test/fixtures/linter/indentation_errors.sql'), + ('L008', 'test/fixtures/linter/whitespace_errors.sql'), + ('L008', 'test/fixtures/linter/indentation_errors.sql'), + # Really stretching the ability of the fixer to re-indent a file + ('L003', 'test/fixtures/linter/indentation_error_hard.sql') +]) +def test__cli__command__fix(rule, fname): + """Test the round trip of detecting, fixing and then not detecting the rule.""" + with open(fname, mode='r') as test_file: + generic_roundtrip_test(test_file, rule) + + [email protected]('rule,fname', [ + # NB: L004 currently has no fix routine. + ('L004', 'test/fixtures/linter/indentation_errors.sql') +]) +def test__cli__command__fix_fail(rule, fname): + """Test the round trip of detecting, fixing and then still detecting the rule.""" + with open(fname, mode='r') as test_file: + generic_roundtrip_test(test_file, rule, fix_exit_code=1, final_exit_code=65) + + +def test__cli__command_fix_stdin(monkeypatch): + """Check stdin input for fix works.""" + sql = 'select * from tbl' + expected = 'fixed sql!' + monkeypatch.setattr("sqlfluff.linter.LintedFile.fix_string", lambda x: expected) + result = invoke_assert_code(args=[fix, ('-', '--rules', 'L001')], cli_input=sql) + assert result.output == expected + + [email protected]('rule,fname,prompt,exit_code', [ + ('L001', 'test/fixtures/linter/indentation_errors.sql', 'y', 0), + ('L001', 'test/fixtures/linter/indentation_errors.sql', 'n', 65) +]) +def test__cli__command__fix_no_force(rule, fname, prompt, exit_code): + """Round trip test, using the prompts.""" + with open(fname, mode='r') as test_file: + generic_roundtrip_test( + test_file, rule, force=False, final_exit_code=exit_code, + fix_input=prompt) + + [email protected]('serialize', ['yaml', 'json']) +def test__cli__command_parse_serialize_from_stdin(serialize): + """Check that the parser serialized output option is working. + + Not going to test for the content of the output as that is subject to change. + """ + result = invoke_assert_code( + args=[parse, ('-', '--format', serialize)], + cli_input='select * from tbl', + ) + if serialize == 'json': + result = json.loads(result.output) + elif serialize == 'yaml': + result = yaml.load(result.output) + else: + raise Exception + result = result[0] # only one file + assert result['filepath'] == 'stdin' + + [email protected]('serialize', ['yaml', 'json']) [email protected]('sql,expected,exit_code', [ + ('select * from tbl', [], 0), # empty list if no violations + ( + 'SElect * from tbl', + [{ + "filepath": "stdin", + "violations": [ + { + "code": "L010", + "line_no": 1, + "line_pos": 1, + "description": "Inconsistent capitalisation of keywords." + } + ] + }], + 65 + ) +]) +def test__cli__command_lint_serialize_from_stdin(serialize, sql, expected, exit_code): + """Check an explicit serialized return value for a single error.""" + result = invoke_assert_code( + args=[lint, ('-', '--rules', 'L010', '--format', serialize)], + cli_input=sql, + ret_code=exit_code + ) + + if serialize == 'json': + assert json.loads(result.output) == expected + elif serialize == 'yaml': + assert yaml.load(result.output) == expected + else: + raise Exception + + [email protected]('serialize', ['yaml', 'json']) +def test__cli__command_lint_serialize_multiple_files(serialize): + """Check the general format of JSON output for multiple files.""" + fpath = 'test/fixtures/linter/indentation_errors.sql' + + # note the file is in here twice. two files = two payloads. + result = invoke_assert_code( + args=[lint, (fpath, fpath, '--format', serialize)], + ret_code=65, + ) + + if serialize == 'json': + result = json.loads(result.output) + elif serialize == 'yaml': + result = yaml.load(result.output) + else: + raise Exception + assert len(result) == 2 + + +def test___main___help(): + """Test that the CLI can be access via __main__.""" + # nonzero exit is good enough + subprocess.check_output(['python', '-m', 'sqlfluff', '--help'])
Consistent yaml and json output on `parse` and `lint` @nolanbconaway this would be a great one to follow up from #195 . The `parse` command has a yaml output option. The `lint` command now has a json output option. I think that both should have both yaml and json outputs.
0.0
4e11c4ecb334f401a22b4e7b3fc3e5ad899b91f0
[ "test/cli_commands_test.py::test__cli__command_parse_serialize_from_stdin[json]" ]
[ "test/cli_commands_test.py::test__cli__command_version", "test/cli_commands_test.py::test__cli__command_lint_stdin[command2]", "test/cli_commands_test.py::test__cli__command_lint_parse[command15]", "test/cli_commands_test.py::test__cli__command_lint_parse[command4]", "test/cli_commands_test.py::test__cli__command_lint_parse[command1]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command0]", "test/cli_commands_test.py::test__cli__command__fix_no_force[L001-test/fixtures/linter/indentation_errors.sql-n-65]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command3]", "test/cli_commands_test.py::test__cli__command_lint_parse[command16]", "test/cli_commands_test.py::test__cli__command_lint_parse[command8]", "test/cli_commands_test.py::test__cli__command_versioning", "test/cli_commands_test.py::test__cli__command_lint_parse[command2]", "test/cli_commands_test.py::test__cli__command__fix_fail[L004-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_serialize_multiple_files[json]", "test/cli_commands_test.py::test__cli__command__fix[L008-test/fixtures/linter/whitespace_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_parse[command5]", "test/cli_commands_test.py::test__cli__command_lint_parse[command11]", "test/cli_commands_test.py::test__cli__command__fix[L001-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command1]", "test/cli_commands_test.py::test__cli__command_lint_parse[command7]", "test/cli_commands_test.py::test__cli__command_lint_parse[command13]", "test/cli_commands_test.py::test__cli__command__fix_no_force[L001-test/fixtures/linter/indentation_errors.sql-y-0]", "test/cli_commands_test.py::test__cli__command_fix_stdin", "test/cli_commands_test.py::test__cli__command__fix[L003-test/fixtures/linter/indentation_error_hard.sql]", "test/cli_commands_test.py::test__cli__command_rules", "test/cli_commands_test.py::test__cli__command_lint_parse[command14]", "test/cli_commands_test.py::test__cli__command_lint_parse[command10]", "test/cli_commands_test.py::test__cli__command_lint_parse[command12]", "test/cli_commands_test.py::test__cli__command_lint_parse[command3]", "test/cli_commands_test.py::test__cli__command_lint_parse[command6]", "test/cli_commands_test.py::test__cli__command_lint_parse[command9]", "test/cli_commands_test.py::test___main___help", "test/cli_commands_test.py::test__cli__command_directed", "test/cli_commands_test.py::test__cli__command_dialect", "test/cli_commands_test.py::test__cli__command__fix[L008-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command_lint_parse[command0]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2020-02-29 16:41:51+00:00
mit
996
alanmcruickshank__sqlfluff-231
diff --git a/src/sqlfluff/dialects/dialect_ansi.py b/src/sqlfluff/dialects/dialect_ansi.py index 5834c196..4432b171 100644 --- a/src/sqlfluff/dialects/dialect_ansi.py +++ b/src/sqlfluff/dialects/dialect_ansi.py @@ -89,7 +89,7 @@ ansi_dialect.add( # also use a regex to explicitly exclude disallowed keywords. NakedIdentifierSegment=ReSegment.make( r"[A-Z0-9_]*[A-Z][A-Z0-9_]*", name='identifier', type='naked_identifier', - _anti_template=r"^(SELECT|JOIN|ON|USING|CROSS|INNER|LEFT|RIGHT|OUTER|INTERVAL|CASE|FULL)$"), + _anti_template=r"^(SELECT|JOIN|ON|USING|CROSS|INNER|LEFT|RIGHT|OUTER|INTERVAL|CASE|FULL|NULL)$"), FunctionNameSegment=ReSegment.make(r"[A-Z][A-Z0-9_]*", name='function_name', type='function_name'), # Maybe data types should be more restrictive? DatatypeIdentifierSegment=ReSegment.make(r"[A-Z][A-Z0-9_]*", name='data_type_identifier', type='data_type_identifier'), @@ -206,7 +206,10 @@ ansi_dialect.add( LiteralGrammar=OneOf( Ref('QuotedLiteralSegment'), Ref('NumericLiteralSegment'), Ref('BooleanLiteralGrammar'), Ref('QualifiedNumericLiteralSegment'), - Ref('IntervalLiteralSegment') + Ref('IntervalLiteralSegment'), + # NB: Null is included in the literals, because it is a keyword which + # can otherwise be easily mistaken for an identifier. + Ref('NullKeywordSegment') ), )
alanmcruickshank/sqlfluff
d10ea3fdb524f7b0363e99ae710aee679d837300
diff --git a/test/rules_std_test.py b/test/rules_std_test.py index 8acee7a1..c5ef40b0 100644 --- a/test/rules_std_test.py +++ b/test/rules_std_test.py @@ -84,6 +84,9 @@ def assert_rule_pass_in_sql(code, sql, configs=None): # Test that fixes are consistent ('L014', 'fail', 'SELECT a, B', 'SELECT a, b', None), ('L014', 'fail', 'SELECT B, a', 'SELECT B, A', None), + # Test that NULL is classed as a keyword and not an identifier + ('L014', 'pass', 'SELECT NULL, a', None, None), + ('L010', 'fail', 'SELECT null, a', 'SELECT NULL, a', None), # Test that we don't fail * operators in brackets ('L006', 'pass', 'SELECT COUNT(*) FROM tbl\n', None, None), # Long lines (with config override)
Bogus capitalization warning involving SAFE_CAST, NULL, and AS Input #1 : ``` SELECT SAFE_CAST(NULL AS STRING) AS age_label FROM `table` ``` Input #2: ``` SELECT NULL AS age_label FROM `table` ``` Either of these files results in a similar warning: ``` $ sqlfluff lint --exclude-rules L001 --dialect bigquery test2.sql == [test2.sql] FAIL L: 2 | P: 34 | L014 | Inconsistent capitalisation of unquoted identifiers. ``` I'm not sure if the `SAFE_CAST` is important or not, but am including it in case it's a different parsing pattern, etc. @alanmcruickshank: I'd be happy to work on some tickets if you'd like to suggest any (this one or others)! February was busy for me, but I'm starting to have some discretionary time again.
0.0
d10ea3fdb524f7b0363e99ae710aee679d837300
[ "test/rules_std_test.py::test__rules__std_string[L014-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L010-fail-SELECT" ]
[ "test/rules_std_test.py::test__rules__std_string[L001-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L002-fail-", "test/rules_std_test.py::test__rules__std_string[L003-fail-", "test/rules_std_test.py::test__rules__std_string[L004-pass-", "test/rules_std_test.py::test__rules__std_string[L004-pass-\\t\\tSELECT", "test/rules_std_test.py::test__rules__std_string[L004-fail-", "test/rules_std_test.py::test__rules__std_string[L005-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L008-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L008-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L015-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L015-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L014-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L006-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L016-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L016-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L016-fail-", "test/rules_std_test.py::test__rules__std_string[L010-fail-SeLeCt", "test/rules_std_test.py::test__rules__std_string[L006-pass-select\\n", "test/rules_std_test.py::test__rules__std_string[L003-pass-SELECT\\n", "test/rules_std_test.py::test__rules__std_file[L001-test/fixtures/linter/indentation_errors.sql-violations0]", "test/rules_std_test.py::test__rules__std_file[L002-test/fixtures/linter/indentation_errors.sql-violations1]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/indentation_errors.sql-violations2]", "test/rules_std_test.py::test__rules__std_file[L004-test/fixtures/linter/indentation_errors.sql-violations3]", "test/rules_std_test.py::test__rules__std_file[L005-test/fixtures/linter/whitespace_errors.sql-violations4]", "test/rules_std_test.py::test__rules__std_file[L008-test/fixtures/linter/whitespace_errors.sql-violations5]", "test/rules_std_test.py::test__rules__std_file[L006-test/fixtures/linter/operator_errors.sql-violations6]", "test/rules_std_test.py::test__rules__std_file[L007-test/fixtures/linter/operator_errors.sql-violations7]", "test/rules_std_test.py::test__rules__std_file[L006-test/fixtures/linter/operator_errors_negative.sql-violations8]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/indentation_error_hard.sql-violations9]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/indentation_error_contained.sql-violations10]", "test/rules_std_test.py::test__rules__std_L003_process_raw_stack" ]
{ "failed_lite_validators": [ "has_issue_reference" ], "has_test_patch": true, "is_lite": false }
2020-04-12 14:02:57+00:00
mit
997
alanmcruickshank__sqlfluff-262
diff --git a/src/sqlfluff/parser/lexer.py b/src/sqlfluff/parser/lexer.py index 1eb4da37..ebbcb859 100644 --- a/src/sqlfluff/parser/lexer.py +++ b/src/sqlfluff/parser/lexer.py @@ -69,6 +69,10 @@ class SingletonMatcher: ) idx = trim_span[1] cont_pos_buff = cont_pos_buff.advance_by(matched[:trim_span[1]]) + # Have we consumed the whole string? This avoids us having + # an empty string on the end. + if idx == len(matched): + break # Is it at the end? if trim_span[1] == len(matched): seg_buff += (
alanmcruickshank/sqlfluff
8618eedb6a986dc873fbff5c14709fe0e07cd0e8
diff --git a/test/parser_lexer_test.py b/test/parser_lexer_test.py index 6b8ba2a9..8fbd5301 100644 --- a/test/parser_lexer_test.py +++ b/test/parser_lexer_test.py @@ -46,8 +46,9 @@ def assert_matches(instring, matcher, matchstring): ("abc -- comment \nblah", ['abc', ' ', "-- comment ", "\n", "blah"]), ("abc # comment \nblah", ['abc', ' ', "# comment ", "\n", "blah"]), # Note the more complicated parsing of block comments. - # This tests subdivision and trimming + # This tests subdivision and trimming (incl the empty case) ("abc /* comment \nblah*/", ['abc', ' ', "/* comment", " ", "\n", "blah*/"]), + ("abc /*\n\t\n*/", ['abc', ' ', "/*", "\n", "\t", "\n", "*/"]), # Test Singletons ("*-+bd/", ['*', '-', '+', 'bd', '/']), # Test Negatives and Minus
FileSegment error raised when using tabs Hey, I got the following error: TypeError: In constructing <class 'sqlfluff.parser.segments_file.FileSegment'>, found an element of the segments tuple which isn't contigious with previous: <whitespace_RawSegment: ([4](1, 2, 2)) '\t'> > <newline_RawSegment: ([4](1, 2, 2)) '\n'>. End pos: [5](1, 2, 3). Prev String: '\t' By using this input file /* */ Please note that in the comment is an invisible tab in the otherwise empty line.
0.0
8618eedb6a986dc873fbff5c14709fe0e07cd0e8
[ "test/parser_lexer_test.py::test__parser__lexer_obj[abc" ]
[ "test/parser_lexer_test.py::test__parser__lexer_obj[a", "test/parser_lexer_test.py::test__parser__lexer_obj[b.c-res1]", "test/parser_lexer_test.py::test__parser__lexer_obj[abc'\\n", "test/parser_lexer_test.py::test__parser__lexer_obj[*-+bd/-res8]", "test/parser_lexer_test.py::test__parser__lexer_obj[2+4", "test/parser_lexer_test.py::test__parser__lexer_singleton[.fsaljk-.]", "test/parser_lexer_test.py::test__parser__lexer_singleton[fsaljk-None]", "test/parser_lexer_test.py::test__parser__lexer_regex[fsaljk-f-f0]", "test/parser_lexer_test.py::test__parser__lexer_regex[fsaljk-f-f1]", "test/parser_lexer_test.py::test__parser__lexer_regex[fsaljk-[fas]*-fsa]", "test/parser_lexer_test.py::test__parser__lexer_regex[", "test/parser_lexer_test.py::test__parser__lexer_regex['something", "test/parser_lexer_test.py::test__parser__lexer_regex['", "test/parser_lexer_test.py::test__parser__lexer_multimatcher", "test/parser_lexer_test.py::test__parser__lexer_fail", "test/parser_lexer_test.py::test__parser__lexer_fail_via_parse" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2020-04-22 11:08:40+00:00
mit
998
alanmcruickshank__sqlfluff-29
diff --git a/src/sqlfluff/cli/commands.py b/src/sqlfluff/cli/commands.py index 3aac14db..c5efaddc 100644 --- a/src/sqlfluff/cli/commands.py +++ b/src/sqlfluff/cli/commands.py @@ -6,9 +6,9 @@ import click from ..dialects import dialect_selector from ..linter import Linter -from .formatters import (format_config, format_linting_result, - format_linting_violations, format_rules, - format_violation) +from .formatters import (format_config, format_rules, + format_violation, format_linting_result_header, + format_linting_result_footer) from .helpers import cli_table, get_package_version @@ -21,7 +21,7 @@ def common_options(f): return f -def get_linter(dialiect_string, rule_string, exclude_rule_string): +def get_linter(dialiect_string, rule_string, exclude_rule_string, color=False): """ A generic way of getting hold of a linter """ try: dialect_obj = dialect_selector(dialiect_string) @@ -38,8 +38,9 @@ def get_linter(dialiect_string, rule_string, exclude_rule_string): excluded_rule_list = exclude_rule_string.split(',') else: excluded_rule_list = None - # Instantiate the linter and return - return Linter(dialect=dialect_obj, rule_whitelist=rule_list, rule_blacklist=excluded_rule_list) + # Instantiate the linter and return (with an output function) + return Linter(dialect=dialect_obj, rule_whitelist=rule_list, rule_blacklist=excluded_rule_list, + output_func=lambda m: click.echo(m, color=color)) @click.group() @@ -56,7 +57,8 @@ def version(verbose, nocolor, dialect, rules, exclude_rules): color = False if nocolor else None if verbose > 0: # Instantiate the linter - lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules) + lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules, + color=color) click.echo(format_config(lnt, verbose=verbose)) else: click.echo(get_package_version(), color=color) @@ -69,7 +71,8 @@ def rules(verbose, nocolor, dialect, rules, exclude_rules): # Configure Color color = False if nocolor else None # Instantiate the linter - lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules) + lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules, + color=color) click.echo(format_rules(lnt), color=color) @@ -95,21 +98,22 @@ def lint(verbose, nocolor, dialect, rules, exclude_rules, paths): # Configure Color color = False if nocolor else None # Instantiate the linter - lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules) + lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules, color=color) config_string = format_config(lnt, verbose=verbose) if len(config_string) > 0: - click.echo(config_string, color=color) + lnt.log(config_string) # Lint the paths if verbose > 1: - click.echo("==== logging ====") + lnt.log("==== logging ====") # add stdin if specified via lone '-' if ('-',) == paths: result = lnt.lint_string(sys.stdin.read(), name='stdin', verbosity=verbose) else: + # Output the results as we go + lnt.log(format_linting_result_header(verbose=verbose)) result = lnt.lint_paths(paths, verbosity=verbose) - # Output the results - output = format_linting_result(result, verbose=verbose) - click.echo(output, color=color) + # Output the final stats + lnt.log(format_linting_result_footer(result, verbose=verbose)) sys.exit(result.stats()['exit code']) @@ -121,22 +125,21 @@ def fix(verbose, nocolor, dialect, rules, exclude_rules, force, paths): """ Fix SQL files """ # Configure Color color = False if nocolor else None - # Instantiate the linter - lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules) + # Instantiate the linter (with an output function) + lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules, color=color) config_string = format_config(lnt, verbose=verbose) if len(config_string) > 0: - click.echo(config_string, color=color) + lnt.log(config_string) # Check that if fix is specified, that we have picked only a subset of rules if lnt.rule_whitelist is None: - click.echo(("The fix option is only available in combination" - " with --rules. This is for your own safety!")) + lnt.log(("The fix option is only available in combination" + " with --rules. This is for your own safety!")) sys.exit(1) - # Lint the paths (not with the fix argument at this stage) - result = lnt.lint_paths(paths) + # Lint the paths (not with the fix argument at this stage), outputting as we go. + lnt.log("==== finding violations ====") + result = lnt.lint_paths(paths, verbosity=verbose) if result.num_violations() > 0: - click.echo("==== violations found ====") - click.echo(format_linting_violations(result, verbose=verbose), color=color) click.echo("==== fixing violations ====") click.echo("{0} violations found of rule{1} {2}".format( result.num_violations(), @@ -185,29 +188,25 @@ def parse(verbose, nocolor, dialect, rules, exclude_rules, path, recurse): if recurse == 0: recurse = True # Instantiate the linter - lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules) + lnt = get_linter(dialiect_string=dialect, rule_string=rules, exclude_rule_string=exclude_rules, color=color) config_string = format_config(lnt, verbose=verbose) if len(config_string) > 0: - click.echo(config_string, color=color) + lnt.log(config_string) nv = 0 # A single path must be specified for this command for parsed, violations, time_dict in lnt.parse_path(path, verbosity=verbose, recurse=recurse): - click.echo('=== [\u001b[30;1m{0}\u001b[0m] ==='.format(path), color=color) if parsed: - click.echo(parsed.stringify()) + lnt.log(parsed.stringify()) else: # TODO: Make this prettier - click.echo('...Failed to Parse...', color=color) + lnt.log('...Failed to Parse...') nv += len(violations) for v in violations: - click.echo( - format_violation(v, verbose=verbose), - color=color - ) + lnt.log(format_violation(v, verbose=verbose)) if verbose >= 2: - click.echo("==== timings ====") - click.echo(cli_table(time_dict.items())) + lnt.log("==== timings ====") + lnt.log(cli_table(time_dict.items())) if nv > 0: sys.exit(66) else: diff --git a/src/sqlfluff/cli/formatters.py b/src/sqlfluff/cli/formatters.py index 352b3601..45a3f27a 100644 --- a/src/sqlfluff/cli/formatters.py +++ b/src/sqlfluff/cli/formatters.py @@ -18,6 +18,10 @@ def format_filename(filename, success=False, verbose=0, success_text='PASS'): + "] " + status_string) +def format_path(path): + return '=== [ path: {0} ] ===\n'.format(colorize(path, 'lightgrey')) + + def format_violation(violation, verbose=0): if isinstance(violation, SQLBaseError): code, line, pos, desc = violation.get_info_tuple() @@ -51,26 +55,37 @@ def format_fix(fix, verbose=0): ) -def format_violations(violations, verbose=0): +def format_file_violations(fname, res, verbose=0): + text_buffer = StringIO() + # Success is having no violations + success = len(res) == 0 + + # Only print the filename if it's either a failure or verbosity > 1 + if verbose > 1 or not success: + text_buffer.write(format_filename(fname, success=success, verbose=verbose)) + text_buffer.write('\n') + + # If we have violations, print them + if not success: + # sort by position in file + s = sorted(res, key=lambda v: v.char_pos()) + for violation in s: + text_buffer.write(format_violation(violation, verbose=verbose)) + text_buffer.write('\n') + str_buffer = text_buffer.getvalue() + # Remove the trailing newline if there is one + if len(str_buffer) > 0 and str_buffer[-1] == '\n': + str_buffer = str_buffer[:-1] + return str_buffer + + +def format_path_violations(violations, verbose=0): # Violations should be a dict keys = sorted(violations.keys()) text_buffer = StringIO() for key in keys: - # Success is having no violations - success = len(violations[key]) == 0 - - # Only print the filename if it's either a failure or verbosity > 1 - if verbose > 1 or not success: - text_buffer.write(format_filename(key, success=success, verbose=verbose)) - text_buffer.write('\n') - - # If we have violations, print them - if not success: - # sort by position in file - s = sorted(violations[key], key=lambda v: v.char_pos()) - for violation in s: - text_buffer.write(format_violation(violation, verbose=verbose)) - text_buffer.write('\n') + text_buffer.write(format_file_violations(key, violations[key], verbose=verbose)) + text_buffer.write('\n') str_buffer = text_buffer.getvalue() # Remove the trailing newline if there is one if len(str_buffer) > 0 and str_buffer[-1] == '\n': @@ -101,27 +116,58 @@ def format_linting_stats(result, verbose=0): return text_buffer.getvalue() +def format_linting_path(p, verbose=0): + text_buffer = StringIO() + if verbose > 0: + text_buffer.write(format_path(p)) + return text_buffer.getvalue() + + +def _format_path_linting_violations(result, verbose=0): + text_buffer = StringIO() + text_buffer.write(format_linting_path(result.path)) + text_buffer.write(format_path_violations(result.violations(), verbose=verbose)) + return text_buffer.getvalue() + + def format_linting_violations(result, verbose=0): """ Assume we're passed a LintingResult """ text_buffer = StringIO() - for path in result.paths: - if verbose > 0: - text_buffer.write('=== [ path: {0} ] ===\n'.format(colorize(path.path, 'lightgrey'))) - text_buffer.write(format_violations(path.violations(), verbose=verbose)) + if hasattr(result, 'paths'): + # We've got a full path + for path in result.paths: + text_buffer.write(_format_path_linting_violations(path, verbose=verbose)) + else: + # We've got an individual + text_buffer.write(_format_path_linting_violations(result, verbose=verbose)) return text_buffer.getvalue() -def format_linting_result(result, verbose=0): +def format_linting_result_header(verbose=0): """ Assume we're passed a LintingResult """ text_buffer = StringIO() if verbose >= 1: text_buffer.write("==== readout ====\n") - text_buffer.write(format_linting_violations(result, verbose=verbose)) + return text_buffer.getvalue() + + +def format_linting_result_footer(result, verbose=0): + """ Assume we're passed a LintingResult """ + text_buffer = StringIO() text_buffer.write('\n') text_buffer.write(format_linting_stats(result, verbose=verbose)) return text_buffer.getvalue() +def format_linting_result(result, verbose=0): + """ Assume we're passed a LintingResult """ + text_buffer = StringIO() + text_buffer.write(format_linting_result_header(verbose=verbose)) + text_buffer.write(format_linting_violations(result, verbose=verbose)) + text_buffer.write(format_linting_result_footer(result, verbose=verbose)) + return text_buffer.getvalue() + + def format_config(linter, verbose=0): text_buffer = StringIO() # Only show version information if verbosity is high enough diff --git a/src/sqlfluff/linter.py b/src/sqlfluff/linter.py index af97e26d..4a954d74 100644 --- a/src/sqlfluff/linter.py +++ b/src/sqlfluff/linter.py @@ -12,6 +12,8 @@ from .parser.segments_file import FileSegment from .parser.segments_base import verbosity_logger, frame_msg, ParseContext from .rules.std import standard_rule_set +from .cli.formatters import format_linting_path, format_file_violations + class LintedFile(namedtuple('ProtoFile', ['path', 'violations', 'time_dict', 'tree'])): __slots__ = () @@ -131,7 +133,8 @@ class LintingResult(object): class Linter(object): - def __init__(self, dialect=None, sql_exts=('.sql',), rule_whitelist=None, rule_blacklist=None): + def __init__(self, dialect=None, sql_exts=('.sql',), rule_whitelist=None, + rule_blacklist=None, output_func=None): # NB: dialect defaults to ansi if "none" supplied if isinstance(dialect, str) or dialect is None: dialect = dialect_selector(dialect) @@ -141,6 +144,14 @@ class Linter(object): # assume that this is a list of rule codes self.rule_whitelist = rule_whitelist self.rule_blacklist = rule_blacklist + # Used for logging as we go + self.output_func = output_func + + def log(self, msg): + if self.output_func: + # Check we've actually got a meaningful message + if msg.strip(' \n\t'): + self.output_func(msg) def get_ruleset(self): """ @@ -286,7 +297,10 @@ class Linter(object): vs += linting_errors - return LintedFile(fname, vs, time_dict, parsed) + res = LintedFile(fname, vs, time_dict, parsed) + # Do the logging as appropriate + self.log(format_file_violations(fname, res.violations, verbose=verbosity)) + return res def paths_from_path(self, path): # take a path (potentially a directory) and return just the sql files @@ -324,6 +338,7 @@ class Linter(object): def lint_path(self, path, verbosity=0, fix=False): linted_path = LintedPath(path) + self.log(format_linting_path(path, verbose=verbosity)) for fname in self.paths_from_path(path): with open(fname, 'r') as f: linted_path.add(self.lint_file(f, fname=fname, verbosity=verbosity, fix=fix)) @@ -343,5 +358,6 @@ class Linter(object): def parse_path(self, path, verbosity=0, recurse=True): for fname in self.paths_from_path(path): + self.log('=== [\u001b[30;1m{0}\u001b[0m] ==='.format(fname)) with open(fname, 'r') as f: yield self.parse_file(f, fname=fname, verbosity=verbosity, recurse=recurse) diff --git a/src/sqlfluff/parser/grammar.py b/src/sqlfluff/parser/grammar.py index 6823e412..ea2ed0ae 100644 --- a/src/sqlfluff/parser/grammar.py +++ b/src/sqlfluff/parser/grammar.py @@ -251,7 +251,7 @@ class BaseGrammar(object): # Have we been passed an empty list? if len(segments) == 0: - return MatchResult.from_empty() + return ((), MatchResult.from_unmatched(segments), None) # Get hold of the bracket matchers from the dialect, and append them # to the list of matchers. diff --git a/src/sqlfluff/parser/lexer.py b/src/sqlfluff/parser/lexer.py index cfe708d8..edc959ba 100644 --- a/src/sqlfluff/parser/lexer.py +++ b/src/sqlfluff/parser/lexer.py @@ -178,7 +178,7 @@ class Lexer(object): res = self.matcher.match(raw, start_pos) if len(res.new_string) > 0: raise SQLLexError( - "Unable to lex characters: '{0}...'".format( + "Unable to lex characters: '{0!r}...'".format( res.new_string[:10]), pos=res.new_pos )
alanmcruickshank/sqlfluff
613379caafb358dfd6a390f41986b0e0e8b6d30d
diff --git a/test/cli_commands_test.py b/test/cli_commands_test.py index 972ccf5b..1acf65f4 100644 --- a/test/cli_commands_test.py +++ b/test/cli_commands_test.py @@ -12,11 +12,24 @@ import sqlfluff from sqlfluff.cli.commands import lint, version, rules, fix, parse +def invoke_assert_code(ret_code=0, args=None, kwargs=None): + args = args or [] + kwargs = kwargs or {} + runner = CliRunner() + result = runner.invoke(*args, **kwargs) + if ret_code == 0: + if result.exception: + raise result.exception + assert ret_code == result.exit_code + return result + + def test__cli__command_directed(): """ Basic checking of lint functionality """ - runner = CliRunner() - result = runner.invoke(lint, ['-n', 'test/fixtures/linter/indentation_error_simple.sql']) - assert result.exit_code == 65 + result = invoke_assert_code( + ret_code=65, + args=[lint, ['-n', 'test/fixtures/linter/indentation_error_simple.sql']] + ) # We should get a readout of what the error was check_a = "L: 2 | P: 1 | L003" # NB: Skip the number at the end because it's configurable @@ -27,10 +40,11 @@ def test__cli__command_directed(): def test__cli__command_dialect(): """ Check the script raises the right exception on an unknown dialect """ - runner = CliRunner() - result = runner.invoke(lint, ['-n', '--dialect', 'faslkjh', 'test/fixtures/linter/indentation_error_simple.sql']) # The dialect is unknown should be a non-zero exit code - assert result.exit_code == 66 + invoke_assert_code( + ret_code=66, + args=[lint, ['-n', '--dialect', 'faslkjh', 'test/fixtures/linter/indentation_error_simple.sql']] + ) def test__cli__command_lint_a(): @@ -39,19 +53,14 @@ def test__cli__command_lint_a(): The subprocess command should exit without errors, as no issues should be found. """ - runner = CliRunner() # Not verbose - result = runner.invoke(lint, ['-n', 'test/fixtures/cli/passing_a.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', 'test/fixtures/cli/passing_a.sql']]) # Verbose - result = runner.invoke(lint, ['-n', '-v', 'test/fixtures/cli/passing_a.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', '-v', 'test/fixtures/cli/passing_a.sql']]) # Very Verbose - result = runner.invoke(lint, ['-n', '-vv', 'test/fixtures/cli/passing_a.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', '-vvvv', 'test/fixtures/cli/passing_a.sql']]) # Very Verbose (Colored) - result = runner.invoke(lint, ['-vv', 'test/fixtures/cli/passing_a.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-vvvv', 'test/fixtures/cli/passing_a.sql']]) @pytest.mark.parametrize('command', [ @@ -64,9 +73,7 @@ def test__cli__command_lint_stdin(command): """ with open('test/fixtures/cli/passing_a.sql', 'r') as f: sql = f.read() - runner = CliRunner() - result = runner.invoke(lint, command, input=sql) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, command], kwargs=dict(input=sql)) def test__cli__command_lint_b(): @@ -75,18 +82,14 @@ def test__cli__command_lint_b(): The subprocess command should exit without errors, as no issues should be found. """ - runner = CliRunner() - result = runner.invoke(lint, ['-n', 'test/fixtures/cli/passing_b.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', 'test/fixtures/cli/passing_b.sql']]) def test__cli__command_parse(): """ Check parse command """ - runner = CliRunner() - result = runner.invoke(parse, ['-n', 'test/fixtures/cli/passing_b.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[parse, ['-n', 'test/fixtures/cli/passing_b.sql']]) def test__cli__command_lint_c_rules_single(): @@ -95,9 +98,7 @@ def test__cli__command_lint_c_rules_single(): The subprocess command should exit without erros, as no issues should be found. """ - runner = CliRunner() - result = runner.invoke(lint, ['-n', '--rules', 'L001', 'test/fixtures/linter/operator_errors.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', '--rules', 'L001', 'test/fixtures/linter/operator_errors.sql']]) def test__cli__command_lint_c_rules_multi(): @@ -106,9 +107,7 @@ def test__cli__command_lint_c_rules_multi(): The subprocess command should exit without erros, as no issues should be found. """ - runner = CliRunner() - result = runner.invoke(lint, ['-n', '--rules', 'L001,L002', 'test/fixtures/linter/operator_errors.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', '--rules', 'L001,L002', 'test/fixtures/linter/operator_errors.sql']]) def test__cli__command_lint_c_exclude_rules_single(): @@ -117,9 +116,7 @@ def test__cli__command_lint_c_exclude_rules_single(): The subprocess command should exit without erros, as no issues should be found. """ - runner = CliRunner() - result = runner.invoke(lint, ['-n', '--rules', 'L001,L006', '--exclude-rules', 'L006', 'test/fixtures/linter/operator_errors.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', '--rules', 'L001,L006', '--exclude-rules', 'L006', 'test/fixtures/linter/operator_errors.sql']]) def test__cli__command_lint_c_exclude_rules_multi(): @@ -128,9 +125,7 @@ def test__cli__command_lint_c_exclude_rules_multi(): The subprocess command should exit without erros, as no issues should be found. """ - runner = CliRunner() - result = runner.invoke(lint, ['-n', '--exclude-rules', 'L006,L007', 'test/fixtures/linter/operator_errors.sql']) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['-n', '--exclude-rules', 'L006,L007', 'test/fixtures/linter/operator_errors.sql']]) def test__cli__command_versioning(): @@ -165,9 +160,7 @@ def test__cli__command_version(): def test__cli__command_rules(): """ Just check rules command for exceptions """ - runner = CliRunner() - result = runner.invoke(rules) - assert result.exit_code == 0 + invoke_assert_code(args=[rules]) def generic_roundtrip_test(source_file, rulestring): @@ -180,16 +173,12 @@ def generic_roundtrip_test(source_file, rulestring): with open(filepath, mode='w') as dest_file: for line in source_file: dest_file.write(line) - runner = CliRunner() # Check that we first detect the issue - result = runner.invoke(lint, ['--rules', rulestring, filepath]) - assert result.exit_code == 65 + invoke_assert_code(ret_code=65, args=[lint, ['--rules', rulestring, filepath]]) # Fix the file (in force mode) - result = runner.invoke(fix, ['--rules', rulestring, '-f', filepath]) - assert result.exit_code == 0 + invoke_assert_code(args=[fix, ['--rules', rulestring, '-f', filepath]]) # Now lint the file and check for exceptions - result = runner.invoke(lint, ['--rules', rulestring, filepath]) - assert result.exit_code == 0 + invoke_assert_code(args=[lint, ['--rules', rulestring, filepath]]) shutil.rmtree(tempdir_path) diff --git a/test/cli_formatters_test.py b/test/cli_formatters_test.py index 8c8ccf0b..6a29eba3 100644 --- a/test/cli_formatters_test.py +++ b/test/cli_formatters_test.py @@ -6,7 +6,7 @@ from sqlfluff.rules.crawler import RuleGhost from sqlfluff.parser import RawSegment from sqlfluff.parser.markers import FilePositionMarker from sqlfluff.errors import SQLLintError -from sqlfluff.cli.formatters import format_filename, format_violation, format_violations +from sqlfluff.cli.formatters import format_filename, format_violation, format_path_violations def escape_ansi(line): @@ -50,7 +50,7 @@ def test__cli__formatters__violations(): segment=RawSegment('blah', FilePositionMarker(0, 2, 11, 3)), rule=RuleGhost('C', 'DESC'))] } - f = format_violations(v) + f = format_path_violations(v) k = sorted(['foo', 'bar']) chk = { 'foo': ["L: 21 | P: 3 | B | DESC", "L: 25 | P: 2 | A | DESC"],
Feature Request: CLI that updates while running, rather than afterward The current CLI looks like it's frozen while linting large directories. It should spit out output as it goes rather than just waiting until the end. Potentially with some options for a progress bar or similar.
0.0
613379caafb358dfd6a390f41986b0e0e8b6d30d
[ "test/cli_commands_test.py::test__cli__command_directed", "test/cli_commands_test.py::test__cli__command_dialect", "test/cli_commands_test.py::test__cli__command_lint_a", "test/cli_commands_test.py::test__cli__command_lint_stdin[command0]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command1]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command2]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command3]", "test/cli_commands_test.py::test__cli__command_lint_b", "test/cli_commands_test.py::test__cli__command_parse", "test/cli_commands_test.py::test__cli__command_lint_c_rules_single", "test/cli_commands_test.py::test__cli__command_lint_c_rules_multi", "test/cli_commands_test.py::test__cli__command_lint_c_exclude_rules_single", "test/cli_commands_test.py::test__cli__command_lint_c_exclude_rules_multi", "test/cli_commands_test.py::test__cli__command_versioning", "test/cli_commands_test.py::test__cli__command_version", "test/cli_commands_test.py::test__cli__command_rules", "test/cli_commands_test.py::test__cli__command__fix_L001", "test/cli_commands_test.py::test__cli__command__fix_L008_a", "test/cli_commands_test.py::test__cli__command__fix_L008_b", "test/cli_formatters_test.py::test__cli__formatters__filename_nocol", "test/cli_formatters_test.py::test__cli__formatters__filename_col", "test/cli_formatters_test.py::test__cli__formatters__violation", "test/cli_formatters_test.py::test__cli__formatters__violations" ]
[]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2019-11-11 16:47:43+00:00
mit
999
alanmcruickshank__sqlfluff-298
diff --git a/.gitignore b/.gitignore index 4899559b..eee1fe42 100644 --- a/.gitignore +++ b/.gitignore @@ -1,5 +1,6 @@ -# Ignore VSCode +# Ignore IDE files .vscode +.idea # Ignore Python cache and prebuilt things .cache diff --git a/src/sqlfluff/cli/commands.py b/src/sqlfluff/cli/commands.py index edb81563..8df0a6a9 100644 --- a/src/sqlfluff/cli/commands.py +++ b/src/sqlfluff/cli/commands.py @@ -153,7 +153,7 @@ def lint(paths, format, **kwargs): # Output the results as we go lnt.log(format_linting_result_header(verbose=verbose)) try: - result = lnt.lint_paths(paths, verbosity=verbose) + result = lnt.lint_paths(paths, verbosity=verbose, ignore_non_existent_files=False) except IOError: click.echo(colorize('The path(s) {0!r} could not be accessed. Check it/they exist(s).'.format(paths), 'red')) sys.exit(1) @@ -219,7 +219,7 @@ def fix(force, paths, **kwargs): # Lint the paths (not with the fix argument at this stage), outputting as we go. lnt.log("==== finding fixable violations ====") try: - result = lnt.lint_paths(paths, verbosity=verbose, fix=True) + result = lnt.lint_paths(paths, verbosity=verbose, fix=True, ignore_non_existent_files=False) except IOError: click.echo(colorize('The path(s) {0!r} could not be accessed. Check it/they exist(s).'.format(paths), 'red')) sys.exit(1) diff --git a/src/sqlfluff/diff_quality_plugin.py b/src/sqlfluff/diff_quality_plugin.py index c4c28080..afbd50bb 100644 --- a/src/sqlfluff/diff_quality_plugin.py +++ b/src/sqlfluff/diff_quality_plugin.py @@ -25,7 +25,7 @@ class SQLFluffViolationReporter(BaseViolationReporter): """ linter = get_linter(get_config()) linter.output_func = None - linted_path = linter.lint_path(src_path) + linted_path = linter.lint_path(src_path, ignore_non_existent_files=True) result = [] for violation in linted_path.get_violations(): try: diff --git a/src/sqlfluff/linter.py b/src/sqlfluff/linter.py index fe01f435..0b93433c 100644 --- a/src/sqlfluff/linter.py +++ b/src/sqlfluff/linter.py @@ -800,14 +800,17 @@ class Linter: ) return res - def paths_from_path(self, path, ignore_file_name='.sqlfluffignore'): + def paths_from_path(self, path, ignore_file_name='.sqlfluffignore', ignore_non_existent_files=False): """Return a set of sql file paths from a potentially more ambigious path string. Here we also deal with the .sqlfluffignore file if present. """ if not os.path.exists(path): - raise IOError("Specified path does not exist") + if ignore_non_existent_files: + return [] + else: + raise IOError("Specified path does not exist") # Files referred to exactly are never ignored. if not os.path.isdir(path): @@ -858,11 +861,11 @@ class Linter: result.add(linted_path) return result - def lint_path(self, path, verbosity=0, fix=False): + def lint_path(self, path, verbosity=0, fix=False, ignore_non_existent_files=False): """Lint a path.""" linted_path = LintedPath(path) self.log(format_linting_path(path, verbose=verbosity)) - for fname in self.paths_from_path(path): + for fname in self.paths_from_path(path, ignore_non_existent_files=ignore_non_existent_files): config = self.config.make_child_from_path(fname) # Handle unicode issues gracefully with open(fname, 'r', encoding='utf8', errors='backslashreplace') as target_file: @@ -872,7 +875,7 @@ class Linter: fix=fix, config=config)) return linted_path - def lint_paths(self, paths, verbosity=0, fix=False): + def lint_paths(self, paths, verbosity=0, fix=False, ignore_non_existent_files=False): """Lint an iterable of paths.""" # If no paths specified - assume local if len(paths) == 0: @@ -882,7 +885,8 @@ class Linter: for path in paths: # Iterate through files recursively in the specified directory (if it's a directory) # or read the file directly if it's not - result.add(self.lint_path(path, verbosity=verbosity, fix=fix)) + result.add(self.lint_path(path, verbosity=verbosity, fix=fix, + ignore_non_existent_files=ignore_non_existent_files)) return result def parse_path(self, path, verbosity=0, recurse=True):
alanmcruickshank/sqlfluff
2931c3a0bdeea4588751db964c28a74f34628081
diff --git a/test/linter_test.py b/test/linter_test.py index ba8a0312..841f94c1 100644 --- a/test/linter_test.py +++ b/test/linter_test.py @@ -33,6 +33,20 @@ def test__linter__path_from_paths__file(): assert normalise_paths(paths) == {'test.fixtures.linter.indentation_errors.sql'} +def test__linter__path_from_paths__not_exist(): + """Test extracting paths from a file path.""" + lntr = Linter(config=FluffConfig()) + with pytest.raises(IOError): + lntr.paths_from_path('asflekjfhsakuefhse') + + +def test__linter__path_from_paths__not_exist_ignore(): + """Test extracting paths from a file path.""" + lntr = Linter(config=FluffConfig()) + paths = lntr.paths_from_path('asflekjfhsakuefhse', ignore_non_existent_files=True) + assert len(paths) == 0 + + def test__linter__path_from_paths__dot(): """Test extracting paths from a dot.""" lntr = Linter(config=FluffConfig())
Error using diff-quality with deleted files When running `diff-quality --violations sqlfluff` pre-commit when I have a file staged that has been deleted I get the following error ``` Quality tool not installed: 'sqlfluff' ``` Digging into this a little bit more, the code actually breaks in the sqlfluff linter.py file, specifically in the `paths_from_path` function. It fails on this line because the path doesn't exist locally: ``` if not os.path.exists(path): ``` The OSError that gets raised ends up ultimately getting caught in `diff_quality_tool.py` line 272 and reporting that the quality tool is not installed. So issue 1 error message isn't helpful and issue 2 is the fact that it's trying to check the quality of a deleted file. Diving a bit deeper into what's going on, it looks like the diff-cover tool doesn't have any support currently for only listing added / modified files so sqlfluff will always receive the deleted files and fail. One potential solution here is to add a check for if the file exists in sql_fluff's `diff_quality_plugin.py` file before attempting to lint it. Let me know what you think of the above, happy to take a crack at the solution if you have an idea on how you want to fix it. Also quick way to test this yourself, delete a SQL file in an existing repo and before committing it try running `diff-quality --violations sqlfluff` first.
0.0
2931c3a0bdeea4588751db964c28a74f34628081
[ "test/linter_test.py::test__linter__path_from_paths__not_exist_ignore" ]
[ "test/linter_test.py::test__linter__path_from_paths__dir", "test/linter_test.py::test__linter__path_from_paths__file", "test/linter_test.py::test__linter__path_from_paths__not_exist", "test/linter_test.py::test__linter__path_from_paths__dot", "test/linter_test.py::test__linter__path_from_paths__ignore[test/fixtures/linter/sqlfluffignore]", "test/linter_test.py::test__linter__path_from_paths__ignore[test/fixtures/linter/sqlfluffignore/]", "test/linter_test.py::test__linter__path_from_paths__ignore[test/fixtures/linter/sqlfluffignore/.]", "test/linter_test.py::test__linter__lint_string_vs_file[test/fixtures/linter/indentation_errors.sql]", "test/linter_test.py::test__linter__lint_string_vs_file[test/fixtures/linter/whitespace_errors.sql]", "test/linter_test.py::test__linter__linting_result__sum_dicts", "test/linter_test.py::test__linter__linting_result__combine_dicts" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2020-05-07 14:46:44+00:00
mit
1,000
alanmcruickshank__sqlfluff-307
diff --git a/src/sqlfluff/rules/std.py b/src/sqlfluff/rules/std.py index a11d1cd1..135be2a4 100644 --- a/src/sqlfluff/rules/std.py +++ b/src/sqlfluff/rules/std.py @@ -2101,3 +2101,18 @@ class Rule_L029(BaseCrawler): # Actually lint if segment.raw.upper() in dialect.sets('unreserved_keywords'): return LintResult(anchor=segment) + + +@std_rule_set.register +class Rule_L030(Rule_L010): + """Inconsistent capitalisation of function names. + + The functionality for this rule is inherited from :obj:`Rule_L010`. + + Args: + capitalisation_policy (:obj:`str`): The capitalisation policy to + enforce. One of 'consistent', 'upper', 'lower', 'capitalise'. + + """ + + _target_elems = (('name', 'function_name'),)
alanmcruickshank/sqlfluff
ec833c1b8931b0f7d42917e5813926d73e62db7c
diff --git a/test/rules_std_test.py b/test/rules_std_test.py index b4c81976..f3b66520 100644 --- a/test/rules_std_test.py +++ b/test/rules_std_test.py @@ -174,6 +174,10 @@ def assert_rule_pass_in_sql(code, sql, configs=None): ('L029', 'fail', 'SELECT 1 as parameter', None, None), ('L029', 'pass', 'SELECT parameter', None, None), # should pass on default config as not alias ('L029', 'fail', 'SELECT parameter', None, {'rules': {'L029': {'only_aliases': False}}}), + # Inconsistent capitalisation of functions + ('L030', 'fail', 'SELECT MAX(id), min(id) from table', 'SELECT MAX(id), MIN(id) from table', None), + ('L030', 'fail', 'SELECT MAX(id), min(id) from table', 'SELECT max(id), min(id) from table', + {'rules': {'L030': {'capitalisation_policy': 'lower'}}}) ]) def test__rules__std_string(rule, pass_fail, qry, fixed, configs): """Test that a rule passes/fails on a given string.
Are functions not treated as keywords ? Not an issue, more like a question. With ``` [sqlfluff:rules:L010] capitalisation_policy = lower ``` using sqlfluff fix --rules L010 on ```sql SELECT MAX(id) from table ``` becomes ```sql select MAX(id) from table ``` Shouldn't `MAX` be also lower cased ?
0.0
ec833c1b8931b0f7d42917e5813926d73e62db7c
[ "test/rules_std_test.py::test__rules__std_string[L030-fail-SELECT" ]
[ "test/rules_std_test.py::test__rules__std_string[L001-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L002-fail-", "test/rules_std_test.py::test__rules__std_string[L003-fail-", "test/rules_std_test.py::test__rules__std_string[L004-pass-", "test/rules_std_test.py::test__rules__std_string[L004-pass-\\t\\tSELECT", "test/rules_std_test.py::test__rules__std_string[L004-fail-", "test/rules_std_test.py::test__rules__std_string[L005-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L008-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L008-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L014-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L015-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L015-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L014-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L010-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L006-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L016-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L016-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L016-fail-", "test/rules_std_test.py::test__rules__std_string[L010-fail-SeLeCt", "test/rules_std_test.py::test__rules__std_string[L006-pass-select\\n", "test/rules_std_test.py::test__rules__std_string[L003-pass-SELECT\\n", "test/rules_std_test.py::test__rules__std_string[L019-fail-SELECT\\n", "test/rules_std_test.py::test__rules__std_string[L019-pass-SELECT\\n", "test/rules_std_test.py::test__rules__std_string[L003-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L003-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L023-fail-WITH", "test/rules_std_test.py::test__rules__std_string[L024-fail-select", "test/rules_std_test.py::test__rules__std_string[L024-pass-select", "test/rules_std_test.py::test__rules__std_string[L026-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L026-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L028-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L028-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L025-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L029-pass-CREATE", "test/rules_std_test.py::test__rules__std_string[L029-fail-CREATE", "test/rules_std_test.py::test__rules__std_string[L029-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L029-pass-SELECT", "test/rules_std_test.py::test__rules__std_file[L001-test/fixtures/linter/indentation_errors.sql-violations0]", "test/rules_std_test.py::test__rules__std_file[L002-test/fixtures/linter/indentation_errors.sql-violations1]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/indentation_errors.sql-violations2]", "test/rules_std_test.py::test__rules__std_file[L004-test/fixtures/linter/indentation_errors.sql-violations3]", "test/rules_std_test.py::test__rules__std_file[L005-test/fixtures/linter/whitespace_errors.sql-violations4]", "test/rules_std_test.py::test__rules__std_file[L019-test/fixtures/linter/whitespace_errors.sql-violations5]", "test/rules_std_test.py::test__rules__std_file[L008-test/fixtures/linter/whitespace_errors.sql-violations6]", "test/rules_std_test.py::test__rules__std_file[L006-test/fixtures/linter/operator_errors.sql-violations7]", "test/rules_std_test.py::test__rules__std_file[L007-test/fixtures/linter/operator_errors.sql-violations8]", "test/rules_std_test.py::test__rules__std_file[L006-test/fixtures/linter/operator_errors_negative.sql-violations9]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/indentation_error_hard.sql-violations10]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/indentation_error_contained.sql-violations11]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/block_comment_errors.sql-violations12]", "test/rules_std_test.py::test__rules__std_file[L016-test/fixtures/linter/block_comment_errors.sql-violations13]", "test/rules_std_test.py::test__rules__std_file[L016-test/fixtures/linter/block_comment_errors_2.sql-violations14]", "test/rules_std_test.py::test__rules__std_file[L027-test/fixtures/linter/column_references.sql-violations15]", "test/rules_std_test.py::test__rules__std_file[L026-test/fixtures/linter/column_references.sql-violations16]", "test/rules_std_test.py::test__rules__std_file[L025-test/fixtures/linter/column_references.sql-violations17]", "test/rules_std_test.py::test__rules__std_file[L021-test/fixtures/linter/select_distinct_group_by.sql-violations18]", "test/rules_std_test.py::test__rules__std_file[L006-test/fixtures/linter/operator_errors_ignore.sql-violations19]", "test/rules_std_test.py::test__rules__std_L003_process_raw_stack" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2020-05-08 21:04:28+00:00
mit
1,001
alanmcruickshank__sqlfluff-336
diff --git a/src/sqlfluff/cli/commands.py b/src/sqlfluff/cli/commands.py index 88fa54a9..d16999b7 100644 --- a/src/sqlfluff/cli/commands.py +++ b/src/sqlfluff/cli/commands.py @@ -205,7 +205,7 @@ def fix(force, paths, **kwargs): be interpreted like passing the current working directory as a path argument. """ c = get_config(**kwargs) - lnt = get_linter(c) + lnt = get_linter(c, silent=('-',) == paths) verbose = c.get('verbose') config_string = format_config(lnt, verbose=verbose) @@ -221,7 +221,7 @@ def fix(force, paths, **kwargs): if ('-',) == paths: stdin = sys.stdin.read() result = lnt.lint_string_wrapped(stdin, fname='stdin', verbosity=verbose, fix=True) - stdout = result.paths[0].files[0].fix_string(verbosity=verbose) + stdout = result.paths[0].files[0].fix_string(verbosity=verbose)[0] click.echo(stdout, nl=False) sys.exit()
alanmcruickshank/sqlfluff
27e052ab5f2c98be68fc86af61f9e5b7acc42910
diff --git a/test/cli_commands_test.py b/test/cli_commands_test.py index c9b50a61..15a9126b 100644 --- a/test/cli_commands_test.py +++ b/test/cli_commands_test.py @@ -199,17 +199,14 @@ def test__cli__command__fix(rule, fname): # generic_roundtrip_test(test_file, rule, fix_exit_code=1, final_exit_code=65) -def test__cli__command_fix_stdin(monkeypatch): [email protected]('stdin,rules,stdout', [ + ('select * from t', 'L003', 'select * from t'), # no change + (' select * from t', 'L003', 'select * from t'), # fix preceding whitespace +]) +def test__cli__command_fix_stdin(stdin, rules, stdout): """Check stdin input for fix works.""" - sql = 'select * from tbl' - expected = 'fixed sql!' - - def _patched_fix(self, verbosity=0): - return expected - - monkeypatch.setattr("sqlfluff.linter.LintedFile.fix_string", _patched_fix) - result = invoke_assert_code(args=[fix, ('-', '--rules', 'L001')], cli_input=sql) - assert result.output == expected + result = invoke_assert_code(args=[fix, ('-', '--rules', rules)], cli_input=stdin) + assert result.output == stdout @pytest.mark.parametrize('rule,fname,prompt,exit_code', [
Fix from stdin writes more than the fixed sql to stdout When it was originally written, fixing from stdin printed the fixed sql to stdout and noting else. That way you could do things like ```sh echo ' select * from t' | sqlfluff fix - --rules L003 > fixed.sql ``` At least in 0.3.3, a lint result gets printed out, and the fixed string is printed as a python tuple: ```sh bash-3.2$ sqlfluff version 0.3.3 bash-3.2$ echo ' select * from t' | sqlfluff fix - --rules L003 == [stdin] FAIL L: 1 | P: 2 | L003 | First line has unexpected indent ('select * from t\n', True) ```
0.0
27e052ab5f2c98be68fc86af61f9e5b7acc42910
[ "test/cli_commands_test.py::test__cli__command_fix_stdin[select", "test/cli_commands_test.py::test__cli__command_fix_stdin[" ]
[ "test/cli_commands_test.py::test__cli__command_directed", "test/cli_commands_test.py::test__cli__command_dialect", "test/cli_commands_test.py::test__cli__command_lint_stdin[command0]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command1]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command2]", "test/cli_commands_test.py::test__cli__command_lint_stdin[command3]", "test/cli_commands_test.py::test__cli__command_lint_parse[command0]", "test/cli_commands_test.py::test__cli__command_lint_parse[command1]", "test/cli_commands_test.py::test__cli__command_lint_parse[command2]", "test/cli_commands_test.py::test__cli__command_lint_parse[command3]", "test/cli_commands_test.py::test__cli__command_lint_parse[command4]", "test/cli_commands_test.py::test__cli__command_lint_parse[command5]", "test/cli_commands_test.py::test__cli__command_lint_parse[command6]", "test/cli_commands_test.py::test__cli__command_lint_parse[command7]", "test/cli_commands_test.py::test__cli__command_lint_parse[command8]", "test/cli_commands_test.py::test__cli__command_lint_parse[command9]", "test/cli_commands_test.py::test__cli__command_lint_parse[command10]", "test/cli_commands_test.py::test__cli__command_lint_parse[command11]", "test/cli_commands_test.py::test__cli__command_lint_parse[command12]", "test/cli_commands_test.py::test__cli__command_lint_parse[command13]", "test/cli_commands_test.py::test__cli__command_lint_parse[command14]", "test/cli_commands_test.py::test__cli__command_lint_parse[command15]", "test/cli_commands_test.py::test__cli__command_lint_parse[command16]", "test/cli_commands_test.py::test__cli__command_lint_parse[command17]", "test/cli_commands_test.py::test__cli__command_versioning", "test/cli_commands_test.py::test__cli__command_version", "test/cli_commands_test.py::test__cli__command_rules", "test/cli_commands_test.py::test__cli__command__fix[L001-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command__fix[L008-test/fixtures/linter/whitespace_errors.sql]", "test/cli_commands_test.py::test__cli__command__fix[L008-test/fixtures/linter/indentation_errors.sql]", "test/cli_commands_test.py::test__cli__command__fix[L003-test/fixtures/linter/indentation_error_hard.sql]", "test/cli_commands_test.py::test__cli__command__fix_no_force[L001-test/fixtures/linter/indentation_errors.sql-y-0]", "test/cli_commands_test.py::test__cli__command__fix_no_force[L001-test/fixtures/linter/indentation_errors.sql-n-65]", "test/cli_commands_test.py::test__cli__command_parse_serialize_from_stdin[yaml]", "test/cli_commands_test.py::test__cli__command_parse_serialize_from_stdin[json]", "test/cli_commands_test.py::test__cli__command_lint_serialize_from_stdin[select", "test/cli_commands_test.py::test__cli__command_lint_serialize_from_stdin[SElect", "test/cli_commands_test.py::test__cli__command_lint_serialize_multiple_files[yaml]", "test/cli_commands_test.py::test__cli__command_lint_serialize_multiple_files[json]", "test/cli_commands_test.py::test___main___help" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2020-05-16 01:11:59+00:00
mit
1,002
alanmcruickshank__sqlfluff-82
diff --git a/src/sqlfluff/errors.py b/src/sqlfluff/errors.py index 8400feab..f75dec43 100644 --- a/src/sqlfluff/errors.py +++ b/src/sqlfluff/errors.py @@ -21,9 +21,14 @@ class SQLBaseError(ValueError): NB: For violations which don't directly implement a rule this attempts to return the error message linked to whatever - caused the violation. + caused the violation. Optionally some errors may have their + description set directly. """ - if hasattr(self, 'rule'): + if hasattr(self, 'description') and self.description: + # This can only override if it's present AND + # if it's non-null. + return self.description + elif hasattr(self, 'rule'): return self.rule.description else: # Return the first element - probably a string message @@ -148,6 +153,7 @@ class SQLLintError(SQLBaseError): self.segment = kwargs.pop('segment', None) self.rule = kwargs.pop('rule', None) self.fixes = kwargs.pop('fixes', []) + self.description = kwargs.pop('description', None) super(SQLLintError, self).__init__(*args, **kwargs) def check_tuple(self): diff --git a/src/sqlfluff/rules/base.py b/src/sqlfluff/rules/base.py index 67e4d35e..01f7349e 100644 --- a/src/sqlfluff/rules/base.py +++ b/src/sqlfluff/rules/base.py @@ -37,21 +37,29 @@ class LintResult(object): memory (:obj:`dict`, optional): An object which stores any working memory for the crawler. The `memory` returned in any `LintResult` will be passed as an input to the next segment to be crawled. + description (:obj:`str`, optional): A description of the problem + identified as part of this result. This will override the + description of the rule as what gets reported to the user + with the problem if provided. """ - def __init__(self, anchor=None, fixes=None, memory=None): + def __init__(self, anchor=None, fixes=None, memory=None, description=None): # An anchor of none, means no issue self.anchor = anchor # Fixes might be blank self.fixes = fixes or [] # Memory is passed back in the linting result self.memory = memory + # store a description_override for later + self.description = description def to_linting_error(self, rule): """Convert a linting result to a :exc:`SQLLintError` if appropriate.""" if self.anchor: - return SQLLintError(rule=rule, segment=self.anchor, fixes=self.fixes) + # Allow description override from the LintRestult + description = self.description or rule.description + return SQLLintError(rule=rule, segment=self.anchor, fixes=self.fixes, description=description) else: return None diff --git a/src/sqlfluff/rules/std.py b/src/sqlfluff/rules/std.py index 18985943..6d1b2c1f 100644 --- a/src/sqlfluff/rules/std.py +++ b/src/sqlfluff/rules/std.py @@ -241,6 +241,7 @@ class Rule_L006(BaseCrawler): # anchor is our signal as to whether there's a problem anchor = None fixes = [] + description = None # The parent stack tells us whether we're in an expression or not. if parent_stack and parent_stack[-1].type == 'expression': @@ -251,6 +252,8 @@ class Rule_L006(BaseCrawler): anchor, fixes = _handle_previous_segments( memory['since_code'], anchor=segment, this_segment=segment, fixes=fixes) + if anchor: + description = "Operators should be preceded by a space." else: # It's not an operator, we can evaluate what happened after an # operator if that's the last code we saw. @@ -259,6 +262,8 @@ class Rule_L006(BaseCrawler): anchor, fixes = _handle_previous_segments( memory['since_code'], anchor=memory['last_code'], this_segment=segment, fixes=fixes) + if anchor: + description = "Operators should be followed by a space." else: # This isn't an operator, and the thing before it wasn't # either. I don't think that's an issue for now. @@ -276,7 +281,7 @@ class Rule_L006(BaseCrawler): # Anchor is our signal as to whether there's a problem if anchor: - return LintResult(anchor=anchor, memory=memory, fixes=fixes) + return LintResult(anchor=anchor, memory=memory, fixes=fixes, description=description) else: return LintResult(memory=memory)
alanmcruickshank/sqlfluff
c8307ba40c0346108ba7db0683975e651835a753
diff --git a/test/cli_formatters_test.py b/test/cli_formatters_test.py index 84cad892..ca6f55d9 100644 --- a/test/cli_formatters_test.py +++ b/test/cli_formatters_test.py @@ -45,20 +45,21 @@ def test__cli__formatters__violations(): 'foo': [ SQLLintError( segment=RawSegment('blah', FilePositionMarker(0, 25, 2, 26)), - rule=RuleGhost('A', 'DESC')), + rule=RuleGhost('A', 'DESCR')), + # Here we check the optional description override SQLLintError( segment=RawSegment('blah', FilePositionMarker(0, 21, 3, 22)), - rule=RuleGhost('B', 'DESC'))], + rule=RuleGhost('B', 'DESCR'), description='foo')], 'bar': [ SQLLintError( segment=RawSegment('blah', FilePositionMarker(0, 2, 11, 3)), - rule=RuleGhost('C', 'DESC'))] + rule=RuleGhost('C', 'DESCR'))] } f = format_path_violations(v) k = sorted(['foo', 'bar']) chk = { - 'foo': ["L: 21 | P: 3 | B | DESC", "L: 25 | P: 2 | A | DESC"], - 'bar': ["L: 2 | P: 11 | C | DESC"] + 'foo': ["L: 21 | P: 3 | B | foo", "L: 25 | P: 2 | A | DESCR"], + 'bar': ["L: 2 | P: 11 | C | DESCR"] } chk2 = [] for elem in k:
"Whitespace around operators" check reports the same warning twice Query: ``` SELECT a/b AS click_rate FROM t ``` Output: ``` $ sqlfluff lint test.sql == [test.sql] FAIL L: 2 | P: 6 | L006 | Operators should be surrounded by a single whitespace. L: 2 | P: 7 | L006 | Operators should be surrounded by a single whitespace. ``` Note the warning is correct, but it is reported twice -- apparently once on the operator and once on the second operand.
0.0
c8307ba40c0346108ba7db0683975e651835a753
[ "test/cli_formatters_test.py::test__cli__formatters__violations" ]
[ "test/cli_formatters_test.py::test__cli__formatters__filename_nocol", "test/cli_formatters_test.py::test__cli__formatters__filename_col", "test/cli_formatters_test.py::test__cli__formatters__violation" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2019-12-06 13:22:35+00:00
mit
1,003
alanmcruickshank__sqlfluff-93
diff --git a/CHANGELOG.md b/CHANGELOG.md index 654a7d54..2f59106b 100644 --- a/CHANGELOG.md +++ b/CHANGELOG.md @@ -7,6 +7,10 @@ and this project adheres to [Semantic Versioning](https://semver.org/spec/v2.0.0 ## [Unreleased] +### Changed + +- Fixed the "inconsistent" bug in L010. Thanks [@nolanbconaway](https://github.com/nolanbconaway) + ### Added - `--format` option to the `parse` command that allows a yaml output. This diff --git a/src/sqlfluff/rules/std.py b/src/sqlfluff/rules/std.py index 6d1b2c1f..71f0fff9 100644 --- a/src/sqlfluff/rules/std.py +++ b/src/sqlfluff/rules/std.py @@ -458,9 +458,15 @@ class Rule_L010(BaseCrawler): elif policy == "capitalize": new_raw = seg.raw.capitalize() elif policy == "consistent": - if cases_seen: - # Get an element from what we've already seen - return make_replacement(seg, list(cases_seen)[0]) + # The only case we DONT allow here is "inconsistent", + # because it doesn't actually help us. + filtered_cases_seen = [c for c in cases_seen if c != "inconsistent"] + if filtered_cases_seen: + # Get an element from what we've already seen. + return make_replacement( + seg, + list(filtered_cases_seen)[0] + ) else: # If we haven't seen anything yet, then let's default # to upper @@ -477,7 +483,15 @@ class Rule_L010(BaseCrawler): # No need to update memory return LintResult(memory=memory) elif ( - (self.capitalisation_policy == "consistent" and cases_seen and seen_case not in cases_seen) + # Are we required to be consistent? (and this is inconsistent?) + ( + self.capitalisation_policy == "consistent" and ( + # Either because we've seen multiple + (cases_seen and seen_case not in cases_seen) + # Or just because this one is inconsistent internally + or seen_case == "inconsistent") + ) + # Are we just required to be specfic? # Policy is either upper, lower or capitalize or (self.capitalisation_policy != "consistent" and seen_case != self.capitalisation_policy) ):
alanmcruickshank/sqlfluff
c390b493bea0afd3a996ba30bcf4d5032bb85022
diff --git a/test/rules_std_test.py b/test/rules_std_test.py index 90feb91d..146221b4 100644 --- a/test/rules_std_test.py +++ b/test/rules_std_test.py @@ -24,13 +24,22 @@ def assert_rule_fail_in_sql(code, sql): lerrs, _, _, _ = r.crawl(parsed, fix=True) print("Errors Found: {0}".format(lerrs)) assert any([v.rule.code == code for v in lerrs]) - fixes = [] - for e in lerrs: - fixes += e.fixes - print("Fixes to apply: {0}".format(fixes)) + fixed = parsed # use this as our buffer (yes it's a bit of misnomer right here) while True: - l_fixes = fixes - fixed, fixes = parsed.apply_fixes(fixes) + # We get the errors again, but this time skip the assertion + # because we're in the loop. If we asserted on every loop then + # we're stuffed. + lerrs, _, _, _ = r.crawl(fixed, fix=True) + print("Errors Found: {0}".format(lerrs)) + fixes = [] + for e in lerrs: + fixes += e.fixes + if not fixes: + print("Done") + break + print("Fixes to apply: {0}".format(fixes)) + l_fixes = fixes # Save the fixes to compare to later + fixed, fixes = fixed.apply_fixes(fixes) # iterate until all fixes applied if fixes: if fixes == l_fixes: @@ -38,8 +47,6 @@ def assert_rule_fail_in_sql(code, sql): "Fixes aren't being applied: {0!r}".format(fixes)) else: continue - else: - break return fixed.raw @@ -70,7 +77,10 @@ def assert_rule_pass_in_sql(code, sql): ('L014', 'fail', 'SELECT a, B', 'SELECT a, b'), ('L014', 'fail', 'SELECT B, a', 'SELECT B, A'), # Test that we don't fail * operators in brackets - ('L006', 'pass', 'SELECT COUNT(*) FROM tbl\n', None) + ('L006', 'pass', 'SELECT COUNT(*) FROM tbl\n', None), + # Test that we don't have the "inconsistent" bug + ('L010', 'fail', 'SeLeCt 1', 'SELECT 1'), + ('L010', 'fail', 'SeLeCt 1 from blah', 'SELECT 1 FROM blah'), ]) def test__rules__std_string(rule, pass_fail, qry, fixed): """Test that a rule passes/fails on a given string.
Bug: fix ValueError: Unexpected capitalisation policy: 'inconsistent' I don't even know what is happening here! ``` ➜ sqlfluff version 0.2.4 ➜ echo 'selECT * from table;' > test.sql ➜ sqlfluff fix test.sql --rules L001,L002,L003,L004,L005,L006,L007,L008,L009,L010,L011,L012,L013,L014 ==== finding violations ==== Traceback (most recent call last): File "/Users/nolan/anaconda3/bin/sqlfluff", line 10, in <module> sys.exit(cli()) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/click/core.py", line 764, in __call__ return self.main(*args, **kwargs) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/click/core.py", line 717, in main rv = self.invoke(ctx) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/click/core.py", line 1137, in invoke return _process_result(sub_ctx.command.invoke(sub_ctx)) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/click/core.py", line 956, in invoke return ctx.invoke(self.callback, **ctx.params) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/click/core.py", line 555, in invoke return callback(*args, **kwargs) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/cli/commands.py", line 174, in fix result = lnt.lint_paths(paths, verbosity=verbose) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/linter.py", line 605, in lint_paths result.add(self.lint_path(path, verbosity=verbosity, fix=fix)) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/linter.py", line 592, in lint_path fix=fix, config=config)) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/linter.py", line 536, in lint_string lerrs, _, _, _ = crawler.crawl(parsed) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/rules/base.py", line 192, in crawl raw_stack=raw_stack, fix=fix, memory=memory) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/rules/base.py", line 192, in crawl raw_stack=raw_stack, fix=fix, memory=memory) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/rules/base.py", line 192, in crawl raw_stack=raw_stack, fix=fix, memory=memory) [Previous line repeated 1 more time] File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/rules/base.py", line 162, in crawl raw_stack=raw_stack, memory=memory) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/rules/std.py", line 488, in _eval segment, self.capitalisation_policy)) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/rules/std.py", line 463, in make_replacement return make_replacement(seg, list(cases_seen)[0]) File "/Users/nolan/anaconda3/lib/python3.7/site-packages/sqlfluff/rules/std.py", line 469, in make_replacement raise ValueError("Unexpected capitalisation policy: {0!r}".format(policy)) ValueError: Unexpected capitalisation policy: 'inconsistent' ```
0.0
c390b493bea0afd3a996ba30bcf4d5032bb85022
[ "test/rules_std_test.py::test__rules__std_string[L010-fail-SeLeCt" ]
[ "test/rules_std_test.py::test__rules__std_string[L001-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L002-fail-", "test/rules_std_test.py::test__rules__std_string[L003-fail-", "test/rules_std_test.py::test__rules__std_string[L004-pass-", "test/rules_std_test.py::test__rules__std_string[L004-pass-\\t\\tSELECT", "test/rules_std_test.py::test__rules__std_string[L004-fail-", "test/rules_std_test.py::test__rules__std_string[L005-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L008-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L008-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L014-pass-SELECT", "test/rules_std_test.py::test__rules__std_string[L014-fail-SELECT", "test/rules_std_test.py::test__rules__std_string[L006-pass-SELECT", "test/rules_std_test.py::test__rules__std_file[L001-test/fixtures/linter/indentation_errors.sql-violations0]", "test/rules_std_test.py::test__rules__std_file[L002-test/fixtures/linter/indentation_errors.sql-violations1]", "test/rules_std_test.py::test__rules__std_file[L003-test/fixtures/linter/indentation_errors.sql-violations2]", "test/rules_std_test.py::test__rules__std_file[L004-test/fixtures/linter/indentation_errors.sql-violations3]", "test/rules_std_test.py::test__rules__std_file[L005-test/fixtures/linter/whitespace_errors.sql-violations4]", "test/rules_std_test.py::test__rules__std_file[L008-test/fixtures/linter/whitespace_errors.sql-violations5]", "test/rules_std_test.py::test__rules__std_file[L006-test/fixtures/linter/operator_errors.sql-violations6]", "test/rules_std_test.py::test__rules__std_file[L007-test/fixtures/linter/operator_errors.sql-violations7]", "test/rules_std_test.py::test__rules__std_file[L006-test/fixtures/linter/operator_errors_negative.sql-violations8]" ]
{ "failed_lite_validators": [ "has_many_modified_files" ], "has_test_patch": true, "is_lite": false }
2019-12-09 17:48:28+00:00
mit
1,004
albertyw__git-browse-49
diff --git a/git_browse/browse.py b/git_browse/browse.py index 47ccaeb..451f605 100755 --- a/git_browse/browse.py +++ b/git_browse/browse.py @@ -369,7 +369,8 @@ def get_git_config() -> str: def get_git_url(git_config_file: str) -> str: - config = configparser.ConfigParser() + # strict is removed here because gitconfig allows for multiple "fetch" keys + config = configparser.ConfigParser(strict=False) config.read(git_config_file) try: git_url = config['remote "origin"']['url']
albertyw/git-browse
ee46082dd3dea8fbaa3148d67c26004f5b1f2b6b
diff --git a/git_browse/tests/test.py b/git_browse/tests/test.py index 9578999..cb3ba05 100644 --- a/git_browse/tests/test.py +++ b/git_browse/tests/test.py @@ -2,6 +2,7 @@ import os import re import shutil import sys +import tempfile from typing import List, cast import unittest from unittest.mock import MagicMock, patch @@ -248,14 +249,22 @@ class GetGitConfig(unittest.TestCase): class GetGitURL(unittest.TestCase): def setUp(self) -> None: - self.git_config_file = os.path.join( + git_config_file = os.path.join( BASE_DIRECTORY, '.git', 'config' ) + with open(git_config_file, 'rb') as handle: + configs = handle.read() + self.git_config_file = tempfile.NamedTemporaryFile() + self.git_config_file.write(configs) + self.git_config_file.seek(0) + + def tearDown(self) -> None: + self.git_config_file.close() def test_url(self) -> None: - git_url = browse.get_git_url(self.git_config_file) + git_url = browse.get_git_url(self.git_config_file.name) expected = '[email protected]:albertyw/git-browse' self.assertEqual(git_url.replace('.git', ''), expected) @@ -263,6 +272,21 @@ class GetGitURL(unittest.TestCase): with self.assertRaises(RuntimeError): browse.get_git_url(BASE_DIRECTORY) + def test_multiple_fetch(self) -> None: + # For https://github.com/albertyw/git-browse/issues/48 + config_contents = ( + '[remote "origin"]\n' + ' fetch = refs/heads/my_name/*:refs/remotes/origin/my_name/*\n' + ' fetch = refs/heads/master:refs/remotes/origin/master\n' + ' url = [email protected]:albertyw/git-browse\n' + ) + config_file = tempfile.NamedTemporaryFile() + config_file.write(config_contents.encode('utf-8')) + config_file.seek(0) + git_url = browse.get_git_url(config_file.name) + expected = '[email protected]:albertyw/git-browse' + self.assertEqual(git_url.replace('.git', ''), expected) + class ParseGitURL(unittest.TestCase): def setUp(self) -> None:
Support running with multiple fetch configs gitconfig allows for multiple fetch configs which breaks configparser: https://stackoverflow.com/questions/15507264/can-i-specify-in-git-config-to-fetch-multiple-refspecs
0.0
ee46082dd3dea8fbaa3148d67c26004f5b1f2b6b
[ "git_browse/tests/test.py::GetGitURL::test_multiple_fetch" ]
[ "git_browse/tests/test.py::TestGithubHost::test_commit_hash_url", "git_browse/tests/test.py::TestGithubHost::test_directory_url", "git_browse/tests/test.py::TestGithubHost::test_file_url", "git_browse/tests/test.py::TestGithubHost::test_get_url", "git_browse/tests/test.py::TestGithubHost::test_init", "git_browse/tests/test.py::TestGithubHost::test_root_url", "git_browse/tests/test.py::SourcegraphHost::test_create", "git_browse/tests/test.py::SourcegraphHost::test_create_dot_git", "git_browse/tests/test.py::SourcegraphHost::test_get_url_commit", "git_browse/tests/test.py::SourcegraphHost::test_get_url_directory", "git_browse/tests/test.py::SourcegraphHost::test_get_url_file", "git_browse/tests/test.py::SourcegraphHost::test_get_url_root", "git_browse/tests/test.py::SourcegraphHost::test_init", "git_browse/tests/test.py::SourcegraphHost::test_valid_focus_object", "git_browse/tests/test.py::TestGodocsHost::test_create", "git_browse/tests/test.py::TestGodocsHost::test_create_dot_git", "git_browse/tests/test.py::TestGodocsHost::test_get_url_commit", "git_browse/tests/test.py::TestGodocsHost::test_get_url_directory", "git_browse/tests/test.py::TestGodocsHost::test_get_url_file", "git_browse/tests/test.py::TestGodocsHost::test_get_url_root", "git_browse/tests/test.py::TestGodocsHost::test_init", "git_browse/tests/test.py::TestGodocsHost::test_valid_focus_object", "git_browse/tests/test.py::GitObject::test_is_directory", "git_browse/tests/test.py::FocusObject::test_default", "git_browse/tests/test.py::FocusObject::test_init", "git_browse/tests/test.py::FocusObject::test_is_directory", "git_browse/tests/test.py::FocusObject::test_is_not_directory", "git_browse/tests/test.py::FocusObject::test_is_not_root", "git_browse/tests/test.py::FocusObject::test_is_root", "git_browse/tests/test.py::FocusHash::test_init", "git_browse/tests/test.py::FocusHash::test_is_commit_hash", "git_browse/tests/test.py::GetRepositoryRoot::test_fail_get", "git_browse/tests/test.py::GetRepositoryRoot::test_get", "git_browse/tests/test.py::GetGitConfig::test_get", "git_browse/tests/test.py::GetGitURL::test_bad_url", "git_browse/tests/test.py::ParseGitURL::test_broken_url", "git_browse/tests/test.py::ParseGitURL::test_https_url", "git_browse/tests/test.py::ParseGitURL::test_sourcegraph_github_host", "git_browse/tests/test.py::ParseGitURL::test_sourcegraph_uber_host", "git_browse/tests/test.py::ParseGitURL::test_ssh_url", "git_browse/tests/test.py::TestGetFocusObject::test_default_focus_object", "git_browse/tests/test.py::TestGetFocusObject::test_directory_focus_object", "git_browse/tests/test.py::TestGetFocusObject::test_file_focus_object", "git_browse/tests/test.py::TestGetFocusObject::test_get_focus_hash", "git_browse/tests/test.py::TestGetFocusObject::test_invalid_phabricator_object", "git_browse/tests/test.py::TestGetFocusObject::test_nonexistend_focus_object", "git_browse/tests/test.py::TestGetFocusObject::test_phabricator_object", "git_browse/tests/test.py::TestGetCommitHash::test_get_hash", "git_browse/tests/test.py::TestGetCommitHash::test_get_unknown_hash", "git_browse/tests/test.py::TestOpenURL::test_dry_open_url", "git_browse/tests/test.py::TestOpenURL::test_open_subprocess", "git_browse/tests/test.py::TestOpenURL::test_open_url", "git_browse/tests/test.py::FullTest::test_check_version" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2020-10-19 04:46:20+00:00
mit
1,005
albertyw__git-browse-65
diff --git a/git_browse/sourcegraph.py b/git_browse/sourcegraph.py index 0b6bb06..404364a 100644 --- a/git_browse/sourcegraph.py +++ b/git_browse/sourcegraph.py @@ -4,7 +4,7 @@ from git_browse import phabricator, typedefs PUBLIC_SOURCEGRAPH_URL = "https://sourcegraph.com/" -UBER_SOURCEGRAPH_URL = "https://sourcegraph.uberinternal.com/" +UBER_SOURCEGRAPH_URL = "https://sg.uberinternal.com/" class SourcegraphHost(typedefs.Host): @@ -40,14 +40,18 @@ class SourcegraphHost(typedefs.Host): self.host_class = host_class def get_url(self, git_object: typedefs.GitObject) -> str: - sourcegraph_url = PUBLIC_SOURCEGRAPH_URL if self.host_class == phabricator.PhabricatorHost: - sourcegraph_url = UBER_SOURCEGRAPH_URL - repository_url = "%s%s/%s" % ( - sourcegraph_url, - self.host, - self.repository, - ) + repository_url = "%s%s/uber-code/%s" % ( + UBER_SOURCEGRAPH_URL, + self.host, + self.repository.replace('/', '-'), + ) + else: + repository_url = "%s%s/%s" % ( + PUBLIC_SOURCEGRAPH_URL, + self.host, + self.repository, + ) if git_object.is_commit_hash(): return self.commit_hash_url(repository_url, git_object) if git_object.is_root():
albertyw/git-browse
063f2a5e8e199f927b413191d991b381a00e79a5
diff --git a/git_browse/tests/test_sourcegraph.py b/git_browse/tests/test_sourcegraph.py index 418513e..bfc999e 100644 --- a/git_browse/tests/test_sourcegraph.py +++ b/git_browse/tests/test_sourcegraph.py @@ -2,7 +2,7 @@ import os import pathlib import unittest -from git_browse import sourcegraph, phabricator, typedefs +from git_browse import github, sourcegraph, phabricator, typedefs BASE_DIRECTORY = pathlib.Path(__file__).parents[2] @@ -10,27 +10,32 @@ BASE_DIRECTORY = pathlib.Path(__file__).parents[2] class SourcegraphHost(unittest.TestCase): def setUp(self) -> None: self.obj = sourcegraph.SourcegraphHost( + typedefs.GitConfig("", "master"), + "github.com", + "albertyw/git-browse", + ) + self.uber_obj = sourcegraph.SourcegraphHost( typedefs.GitConfig("", "master"), "code.uber.internal", - "asdf", + "asdf/qwer", ) - self.obj.host_class = phabricator.PhabricatorHost + self.uber_obj.host_class = phabricator.PhabricatorHost def test_init(self) -> None: - self.assertEqual(self.obj.host, "code.uber.internal") - self.assertEqual(self.obj.repository, "asdf") + self.assertEqual(self.obj.host, "github.com") + self.assertEqual(self.obj.repository, "albertyw/git-browse") def test_create(self) -> None: - repo = "[email protected]:a/b" + repo = "[email protected]:a/b" git_config = typedefs.GitConfig(repo, "master") - git_config.try_url_match(phabricator.UBER_SSH_GITOLITE_URL) + git_config.try_url_match(github.GITHUB_SSH_URL) obj = sourcegraph.SourcegraphHost.create(git_config) self.assertEqual(obj.repository, "a/b") def test_create_dot_git(self) -> None: - repo = "[email protected]:a/b.git" + repo = "[email protected]:a/b.git" git_config = typedefs.GitConfig(repo, "master") - git_config.try_url_match(phabricator.UBER_SSH_GITOLITE_URL) + git_config.try_url_match(github.GITHUB_SSH_URL) obj = sourcegraph.SourcegraphHost.create(git_config) self.assertEqual(obj.repository, "a/b") @@ -39,31 +44,84 @@ class SourcegraphHost(unittest.TestCase): url = self.obj.get_url(git_object) self.assertEqual( url, - sourcegraph.UBER_SOURCEGRAPH_URL - + "code.uber.internal/asdf/-/commit/abcd", + sourcegraph.PUBLIC_SOURCEGRAPH_URL + + "github.com/albertyw/git-browse/-/commit/abcd", ) def test_get_url_root(self) -> None: git_object = typedefs.FocusObject(os.sep) url = self.obj.get_url(git_object) self.assertEqual( - url, sourcegraph.UBER_SOURCEGRAPH_URL + "code.uber.internal/asdf" + url, sourcegraph.PUBLIC_SOURCEGRAPH_URL + "github.com/albertyw/git-browse" ) def test_get_url_directory(self) -> None: - git_object = typedefs.FocusObject("zxcv" + os.sep) + git_object = typedefs.FocusObject("git_browse" + os.sep) url = self.obj.get_url(git_object) self.assertEqual( url, - sourcegraph.UBER_SOURCEGRAPH_URL - + "code.uber.internal/asdf/-/tree/zxcv/", + sourcegraph.PUBLIC_SOURCEGRAPH_URL + + "github.com/albertyw/git-browse/-/tree/git_browse/", ) def test_get_url_file(self) -> None: - git_object = typedefs.FocusObject("zxcv") + git_object = typedefs.FocusObject("README.md") url = self.obj.get_url(git_object) + self.assertEqual( + url, + sourcegraph.PUBLIC_SOURCEGRAPH_URL + + "github.com/albertyw/git-browse/-/blob/README.md", + ) + + def test_uber_init(self) -> None: + self.assertEqual(self.uber_obj.host, "code.uber.internal") + self.assertEqual(self.uber_obj.repository, "asdf/qwer") + + def test_uber_create(self) -> None: + repo = "[email protected]:a/b" + git_config = typedefs.GitConfig(repo, "master") + git_config.try_url_match(phabricator.UBER_SSH_GITOLITE_URL) + obj = sourcegraph.SourcegraphHost.create(git_config) + self.assertEqual(obj.repository, "a/b") + + def test_uber_create_dot_git(self) -> None: + repo = "[email protected]:a/b.git" + git_config = typedefs.GitConfig(repo, "master") + git_config.try_url_match(phabricator.UBER_SSH_GITOLITE_URL) + obj = sourcegraph.SourcegraphHost.create(git_config) + self.assertEqual(obj.repository, "a/b") + + def test_uber_get_url_commit(self) -> None: + git_object = typedefs.FocusHash("abcd") + url = self.uber_obj.get_url(git_object) + self.assertEqual( + url, + sourcegraph.UBER_SOURCEGRAPH_URL + + "code.uber.internal/uber-code/asdf-qwer/-/commit/abcd", + ) + + def test_uber_get_url_root(self) -> None: + git_object = typedefs.FocusObject(os.sep) + url = self.uber_obj.get_url(git_object) + self.assertEqual( + url, sourcegraph.UBER_SOURCEGRAPH_URL + + "code.uber.internal/uber-code/asdf-qwer" + ) + + def test_uber_get_url_directory(self) -> None: + git_object = typedefs.FocusObject("zxcv" + os.sep) + url = self.uber_obj.get_url(git_object) + self.assertEqual( + url, + sourcegraph.UBER_SOURCEGRAPH_URL + + "code.uber.internal/uber-code/asdf-qwer/-/tree/zxcv/", + ) + + def test_uber_get_url_file(self) -> None: + git_object = typedefs.FocusObject("zxcv") + url = self.uber_obj.get_url(git_object) self.assertEqual( url, sourcegraph.UBER_SOURCEGRAPH_URL - + "code.uber.internal/asdf/-/blob/zxcv", + + "code.uber.internal/uber-code/asdf-qwer/-/blob/zxcv", )
Support sg.uberinternal.com Instead of `https://sourcegraph.uberinternal.com/code.uber.internal/<repo_namespace>/<repo_name>` Use `https://sg.uberinternal.com/code.uber.internal/uber-code/<repo_namespace>-<repo_name>`
0.0
063f2a5e8e199f927b413191d991b381a00e79a5
[ "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_uber_get_url_commit", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_uber_get_url_directory", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_uber_get_url_file", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_uber_get_url_root" ]
[ "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_create", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_create_dot_git", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_get_url_commit", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_get_url_directory", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_get_url_file", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_get_url_root", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_init", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_uber_create", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_uber_create_dot_git", "git_browse/tests/test_sourcegraph.py::SourcegraphHost::test_uber_init" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks" ], "has_test_patch": true, "is_lite": false }
2024-01-28 08:37:11+00:00
mit
1,006
albertyw__git-reviewers-30
diff --git a/git_reviewers/reviewers.py b/git_reviewers/reviewers.py index e4eee15..77ec78e 100755 --- a/git_reviewers/reviewers.py +++ b/git_reviewers/reviewers.py @@ -101,6 +101,18 @@ class FindLogReviewers(FindFileLogReviewers): """ Find the changed files between current status and master """ git_diff_files_command = ['git', 'diff', 'master', '--name-only'] git_diff_files = self.run_command(git_diff_files_command) + if not git_diff_files: + return FindHistoricalReviewers().get_changed_files() + return git_diff_files + + +class FindHistoricalReviewers(FindFileLogReviewers): + def get_changed_files(self) -> List[str]: + """Find all git files """ + git_diff_files_command = [ + 'git', 'ls-tree', '-r', 'master', '--name-only' + ] + git_diff_files = self.run_command(git_diff_files_command) return git_diff_files
albertyw/git-reviewers
c3a916e554a058e3e3e3527f5692d0efed97ed83
diff --git a/git_reviewers/tests/test.py b/git_reviewers/tests/test.py index 87e2df4..933ebd6 100644 --- a/git_reviewers/tests/test.py +++ b/git_reviewers/tests/test.py @@ -110,6 +110,27 @@ class TestLogReviewers(unittest.TestCase): files = self.finder.get_changed_files() self.assertEqual(files, ['README.rst', 'setup.py']) + @patch('git_reviewers.reviewers.FindHistoricalReviewers') + @patch('subprocess.run') + def test_no_diffs(self, mock_run, mock_historical): + process = MagicMock() + process.stdout = b'' + mock_run.return_value = process + mock_historical().get_changed_files.return_value = ['asdf'] + files = self.finder.get_changed_files() + self.assertEqual(files, ['asdf']) + + +class TestHistoricalReviewers(unittest.TestCase): + def setUp(self): + self.finder = reviewers.FindHistoricalReviewers() + + def test_get_changed_files(self): + changed_files = ['README.rst', 'setup.py'] + self.finder.run_command = MagicMock(return_value=changed_files) + files = self.finder.get_changed_files() + self.assertEqual(files, ['README.rst', 'setup.py']) + class TestFindArcCommitReviewers(unittest.TestCase): def setUp(self):
Make git-reviewers work with commits that only add new files Read reviewers from entire repository history
0.0
c3a916e554a058e3e3e3527f5692d0efed97ed83
[ "git_reviewers/tests/test.py::TestLogReviewers::test_no_diffs", "git_reviewers/tests/test.py::TestHistoricalReviewers::test_get_changed_files" ]
[ "git_reviewers/tests/test.py::TestFindReviewers::test_check_phabricator_activated", "git_reviewers/tests/test.py::TestFindReviewers::test_check_phabricator_activated_none", "git_reviewers/tests/test.py::TestFindReviewers::test_extract_uber_username_from_email", "git_reviewers/tests/test.py::TestFindReviewers::test_extract_username_from_generic_email", "git_reviewers/tests/test.py::TestFindReviewers::test_get_reviewers", "git_reviewers/tests/test.py::TestFindReviewers::test_run_command", "git_reviewers/tests/test.py::TestFindReviewers::test_run_command_empty_response", "git_reviewers/tests/test.py::TestFindLogReviewers::test_get_changed_files", "git_reviewers/tests/test.py::TestFindLogReviewers::test_gets_generic_emails", "git_reviewers/tests/test.py::TestFindLogReviewers::test_gets_reviewers", "git_reviewers/tests/test.py::TestFindLogReviewers::test_gets_uber_emails", "git_reviewers/tests/test.py::TestFindLogReviewers::test_gets_user_weight", "git_reviewers/tests/test.py::TestLogReviewers::test_get_changed_files", "git_reviewers/tests/test.py::TestFindArcCommitReviewers::test_multiple_reviews", "git_reviewers/tests/test.py::TestFindArcCommitReviewers::test_no_reviewers", "git_reviewers/tests/test.py::TestFindArcCommitReviewers::test_reviewers", "git_reviewers/tests/test.py::TestShowReviewers::test_copy_reviewers", "git_reviewers/tests/test.py::TestShowReviewers::test_copy_reviewers_no_pbcopy", "git_reviewers/tests/test.py::TestShowReviewers::test_show_reviewers", "git_reviewers/tests/test.py::TestGetReviewers::test_verbose_reviewers", "git_reviewers/tests/test.py::TestMain::test_ignore_reviewers", "git_reviewers/tests/test.py::TestMain::test_main", "git_reviewers/tests/test.py::TestMain::test_phabricator_disabled_reviewers", "git_reviewers/tests/test.py::TestMain::test_version" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2018-10-15 03:42:39+00:00
mit
1,007
albumentations-team__albumentations-1055
diff --git a/albumentations/core/composition.py b/albumentations/core/composition.py index 7a78e43..d9f53c4 100644 --- a/albumentations/core/composition.py +++ b/albumentations/core/composition.py @@ -48,6 +48,12 @@ def get_always_apply(transforms: typing.Union["BaseCompose", TransformsSeqType]) class BaseCompose(metaclass=SerializableMeta): def __init__(self, transforms: TransformsSeqType, p: float): + if isinstance(transforms, (BaseCompose, BasicTransform)): + warnings.warn( + "transforms is single transform, but a sequence is expected! Transform will be wrapped into list." + ) + transforms = [transforms] + self.transforms = transforms self.p = p @@ -276,7 +282,7 @@ class OneOf(BaseCompose): def __init__(self, transforms: TransformsSeqType, p: float = 0.5): super(OneOf, self).__init__(transforms, p) - transforms_ps = [t.p for t in transforms] + transforms_ps = [t.p for t in self.transforms] s = sum(transforms_ps) self.transforms_ps = [t / s for t in transforms_ps] @@ -308,7 +314,7 @@ class SomeOf(BaseCompose): super(SomeOf, self).__init__(transforms, p) self.n = n self.replace = replace - transforms_ps = [t.p for t in transforms] + transforms_ps = [t.p for t in self.transforms] s = sum(transforms_ps) self.transforms_ps = [t / s for t in transforms_ps] @@ -347,9 +353,9 @@ class OneOrOther(BaseCompose): if first is None or second is None: raise ValueError("You must set both first and second or set transforms argument.") transforms = [first, second] - elif len(transforms) != 2: - warnings.warn("Length of transforms is not equal to 2.") super(OneOrOther, self).__init__(transforms, p) + if len(self.transforms) != 2: + warnings.warn("Length of transforms is not equal to 2.") def __call__(self, *args, force_apply: bool = False, **data) -> typing.Dict[str, typing.Any]: if self.replay_mode:
albumentations-team/albumentations
6741f516672f559eb6a4a9ebe521b43065426341
diff --git a/tests/test_core.py b/tests/test_core.py index 18e677b..5d69d29 100644 --- a/tests/test_core.py +++ b/tests/test_core.py @@ -1,26 +1,43 @@ from __future__ import absolute_import +import typing from unittest import mock -from unittest.mock import Mock, MagicMock, call +from unittest.mock import MagicMock, Mock, call import cv2 import numpy as np import pytest -from albumentations.core.transforms_interface import to_tuple, ImageOnlyTransform, DualTransform +from albumentations import ( + BasicTransform, + Blur, + Crop, + HorizontalFlip, + MedianBlur, + Normalize, + PadIfNeeded, + Resize, + Rotate, +) from albumentations.augmentations.bbox_utils import check_bboxes from albumentations.core.composition import ( - OneOrOther, + BaseCompose, + BboxParams, Compose, + KeypointParams, OneOf, + OneOrOther, SomeOf, PerChannel, ReplayCompose, - KeypointParams, - BboxParams, Sequential, ) -from albumentations import HorizontalFlip, Rotate, Blur, MedianBlur, PadIfNeeded, Crop +from albumentations.core.transforms_interface import ( + DualTransform, + ImageOnlyTransform, + to_tuple, +) +from .utils import get_filtered_transforms def test_one_or_other(): @@ -332,3 +349,24 @@ def test_bbox_params_is_not_set(image, bboxes): with pytest.raises(ValueError) as exc_info: t(image=image, bboxes=bboxes) assert str(exc_info.value) == "bbox_params must be specified for bbox transformations" + + [email protected]( + "compose_transform", get_filtered_transforms((BaseCompose,), custom_arguments={SomeOf: {"n": 1}}) +) [email protected]( + "inner_transform", + [(Normalize, {}), (Resize, {"height": 100, "width": 100})] + + get_filtered_transforms((BaseCompose,), custom_arguments={SomeOf: {"n": 1}}), # type: ignore +) +def test_single_transform_compose( + compose_transform: typing.Tuple[typing.Type[BaseCompose], dict], + inner_transform: typing.Tuple[typing.Union[typing.Type[BaseCompose], typing.Type[BasicTransform]], dict], +): + compose_cls, compose_kwargs = compose_transform + cls, kwargs = inner_transform + transform = cls(transforms=[], **kwargs) if issubclass(cls, BaseCompose) else cls(**kwargs) + + with pytest.warns(UserWarning): + res_transform = compose_cls(transforms=transform, **compose_kwargs) # type: ignore + assert isinstance(res_transform.transforms, list) diff --git a/tests/utils.py b/tests/utils.py index b5dea11..13d1fb8 100644 --- a/tests/utils.py +++ b/tests/utils.py @@ -1,6 +1,6 @@ +import inspect import random import typing -import inspect import numpy as np from io import StringIO @@ -73,7 +73,9 @@ def get_filtered_transforms( result = [] for name, cls in inspect.getmembers(albumentations): - if not inspect.isclass(cls) or not issubclass(cls, albumentations.BasicTransform): + if not inspect.isclass(cls) or not issubclass( + cls, (albumentations.BasicTransform, albumentations.BaseCompose) + ): continue if "DeprecationWarning" in inspect.getsource(cls) or "FutureWarning" in inspect.getsource(cls):
`A.Compose`, `A.Sequential` components run multiple times inside of `A.OneOf` ## 🐛 Bug Hi, I used `A.OneOf` method on my `A.Compose` objects, but when I run entire pipeline, all components of `A.Compose` objects are called altogether. ## To Reproduce Steps to reproduce the behavior: 1. define augmentation ```python3 class Augmentation(): def __init__(self, dataset_w:int=None, dataset_h:int=None, final_return_w:int=None, final_return_h:int=None): self.train_augmentation = self.set_train_augmentation( dataset_w=dataset_w, dataset_h=dataset_h, final_return_w=final_return_w, final_return_h=final_return_h, ) def get_train_augmentation(self): return lambda image, mask: list(self.train_augmentation(image=image, mask=mask).values()) def set_train_augmentation(self, **kwargs): ret = self.augmentation_method(**kwargs) return ret def _slightly_smaller(self, target_h:int, target_w:int, original_h:int, original_w:int, ratio:float=0.5 )->tuple: assert 0. < ratio and ratio < 1, f'0 < ratio {repr(ratio)} < 1' dw = int((original_w - target_w) * ratio) dh = int((original_h - target_h) * ratio) return (target_h + dh, target_w + dw) def _get_crop(self, target_h:int, target_w:int, )->list: tf = [] tf += [A.RandomCrop(target_h, target_w, p=1.0)] return tf def _get_resize(self, target_h:int, target_w:int )->list: tf = [] tf += [A.Resize(target_h, target_w, p=1.0)] return tf def _get_pad(self, target_h:int, target_w:int )->list: longer_side = target_h if target_h > target_w else target_w tf = [] tf += [A.PadIfNeeded( min_height=longer_side, min_width=longer_side, p=1.0, border_mode=4)] return tf def _get_resize_crop(self, target_h:int, target_w:int, original_h:int, original_w:int, )->list: tf = [] tf += self._get_resize(*self._slightly_smaller( target_h, target_w, original_h, original_w) ) tf += self._get_crop(target_h, target_w) return tf def _get_crop_resize(self, target_h:int, target_w:int, original_h:int, original_w:int, )->list: tf = [] tf += self._get_crop(*self._slightly_smaller( target_h, target_w, original_h, original_w) ) tf += self._get_resize(target_h, target_w) return tf def _get_pad_resize(self, target_h:int, target_w:int, original_h:int, original_w:int, )->list: tf = [] tf += self._get_pad(original_h, original_w) tf += self._get_reszie(target_h, target_w) return tf def _get_pad_crop(self, target_h:int, target_w:int, original_h:int, original_w:int, )->list: tf = [] tf += self._get_pad(original_h, original_w) tf += self._get_crop(target_h, target_w) return tf def _get_pad_resize_crop(self, target_h:int, target_w:int, original_h:int, original_w:int, )->list: tf = [] tf += self._get_pad(original_h, original_w) tf += self._get_resize(*self._slightly_smaller( target_h, target_w, original_h, original_w) ) tf += self._get_crop(target_h, target_w) return tf def _get_pad_crop_resize(self, target_h:int, target_w:int, original_h:int, original_w:int, )->list: tf = [] tf += self._get_pad(original_h, original_w) tf += self._get_crop(*self._slightly_smaller( target_h, target_w, original_h, original_w) ) tf += self._get_resize(target_h, target_w) return tf def augmentation_method(self, dataset_w=None, dataset_h=None, final_return_w=None, final_return_h=None, ): kwargs = {'target_h':final_return_h, 'target_w':final_return_w, 'original_h':dataset_h, 'original_w':dataset_w} print(self._get_resize_crop(**kwargs)) print(self._get_crop_resize(**kwargs)) print(self._get_pad_crop_resize(**kwargs)) print(self._get_pad_resize_crop(**kwargs)) tf = A.OneOf([ #A.Compose(self._get_resize_crop(**kwargs), p=1.0), # <-- this line makes error either. A.Compose(self._get_crop_resize(**kwargs), p=1.0), A.Compose(self._get_pad_crop_resize(**kwargs), p=1.0), A.Compose(self._get_pad_resize_crop(**kwargs), p=1.0), ], p=1.0) return A.Compose(tf, p=1.0) ``` 2. new instance ```python3 aug = Augmentation(DATASET_WIDTH, DATASET_HEIGHT, DATASET_TRAINING_TARGET_W, DATASET_TRAINING_TARGET_H) aug_fn_for_train = aug.get_train_augmentation() ``` 3. run pipeline ```python3 image_train_debug, mask_train_debug = aug_fn_for_train(image, mask) ``` ## Expected behavior Doing augmentation from randomly selected one of the composed pipeline. ```python3 tf = A.OneOf([ A.Compose(self._get_resize_crop(**kwargs), p=1.0), # 25% A.Compose(self._get_crop_resize(**kwargs), p=1.0), # 25% A.Compose(self._get_pad_crop_resize(**kwargs), p=1.0), # 25% A.Compose(self._get_pad_resize_crop(**kwargs), p=1.0), # 25% ], p=1.0) ``` ## Environment - Albumentations version (e.g., 0.1.8): 0.1.12 - Python version (e.g., 3.7): python3.8 - OS (e.g., Linux): Google COLAB COLAB - How you installed albumentations (`conda`, `pip`, source): colab default installed - Any other relevant information: ## Additional context ![image](https://user-images.githubusercontent.com/46595649/140026181-b83675c0-e0aa-473f-9a7f-b75440508adb.png) <!-- Add any other context about the problem here. -->
0.0
6741f516672f559eb6a4a9ebe521b43065426341
[ "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform5]" ]
[ "tests/test_core.py::test_one_or_other", "tests/test_core.py::test_compose", "tests/test_core.py::test_always_apply", "tests/test_core.py::test_one_of", "tests/test_core.py::test_n_of[True-1]", "tests/test_core.py::test_n_of[True-2]", "tests/test_core.py::test_n_of[True-5]", "tests/test_core.py::test_n_of[True-10]", "tests/test_core.py::test_n_of[False-1]", "tests/test_core.py::test_n_of[False-2]", "tests/test_core.py::test_n_of[False-5]", "tests/test_core.py::test_n_of[False-10]", "tests/test_core.py::test_sequential", "tests/test_core.py::test_to_tuple", "tests/test_core.py::test_image_only_transform", "tests/test_core.py::test_dual_transform", "tests/test_core.py::test_additional_targets", "tests/test_core.py::test_check_bboxes_with_correct_values", "tests/test_core.py::test_check_bboxes_with_values_less_than_zero", "tests/test_core.py::test_check_bboxes_with_values_greater_than_one", "tests/test_core.py::test_check_bboxes_with_end_greater_that_start", "tests/test_core.py::test_per_channel_mono", "tests/test_core.py::test_per_channel_multi", "tests/test_core.py::test_deterministic_oneof", "tests/test_core.py::test_deterministic_one_or_other", "tests/test_core.py::test_deterministic_sequential", "tests/test_core.py::test_named_args", "tests/test_core.py::test_targets_type_check[targets0-None-image", "tests/test_core.py::test_targets_type_check[targets1-None-mask", "tests/test_core.py::test_targets_type_check[targets2-additional_targets2-image1", "tests/test_core.py::test_targets_type_check[targets3-additional_targets3-mask1", "tests/test_core.py::test_check_each_transform[targets0-None-keypoint_params0-expected0]", "tests/test_core.py::test_check_each_transform[targets1-None-keypoint_params1-expected1]", "tests/test_core.py::test_check_each_transform[targets2-bbox_params2-None-expected2]", "tests/test_core.py::test_check_each_transform[targets3-bbox_params3-None-expected3]", "tests/test_core.py::test_check_each_transform[targets4-bbox_params4-keypoint_params4-expected4]", "tests/test_core.py::test_check_each_transform[targets5-bbox_params5-keypoint_params5-expected5]", "tests/test_core.py::test_check_each_transform[targets6-bbox_params6-keypoint_params6-expected6]", "tests/test_core.py::test_check_each_transform[targets7-bbox_params7-keypoint_params7-expected7]", "tests/test_core.py::test_bbox_params_is_not_set" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_media", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2021-11-05 19:40:25+00:00
mit
1,008
albumentations-team__albumentations-1214
diff --git a/albumentations/augmentations/geometric/rotate.py b/albumentations/augmentations/geometric/rotate.py index e05be7a..ba79f1d 100644 --- a/albumentations/augmentations/geometric/rotate.py +++ b/albumentations/augmentations/geometric/rotate.py @@ -6,6 +6,7 @@ import cv2 import numpy as np from ...core.transforms_interface import DualTransform, to_tuple +from ..crops import functional as FCrops from . import functional as F __all__ = ["Rotate", "RandomRotate90", "SafeRotate"] @@ -63,6 +64,7 @@ class Rotate(DualTransform): list of float): padding value if border_mode is cv2.BORDER_CONSTANT applied for masks. method (str): rotation method used for the bounding boxes. Should be one of "largest_box" or "ellipse". Default: "largest_box" + crop_border (bool): If True would make a largest possible crop within rotated image p (float): probability of applying the transform. Default: 0.5. Targets: @@ -80,6 +82,7 @@ class Rotate(DualTransform): value=None, mask_value=None, method="largest_box", + crop_border=False, always_apply=False, p=0.5, ): @@ -90,27 +93,86 @@ class Rotate(DualTransform): self.value = value self.mask_value = mask_value self.method = method + self.crop_border = crop_border if method not in ["largest_box", "ellipse"]: raise ValueError(f"Rotation method {self.method} is not valid.") - def apply(self, img, angle=0, interpolation=cv2.INTER_LINEAR, **params): - return F.rotate(img, angle, interpolation, self.border_mode, self.value) + def apply( + self, img, angle=0, interpolation=cv2.INTER_LINEAR, x_min=None, x_max=None, y_min=None, y_max=None, **params + ): + img_out = F.rotate(img, angle, interpolation, self.border_mode, self.value) + if self.crop_border: + img_out = FCrops.crop(img_out, x_min, y_min, x_max, y_max) + return img_out + + def apply_to_mask(self, img, angle=0, x_min=None, x_max=None, y_min=None, y_max=None, **params): + img_out = F.rotate(img, angle, cv2.INTER_NEAREST, self.border_mode, self.mask_value) + if self.crop_border: + img_out = FCrops.crop(img_out, x_min, y_min, x_max, y_max) + return img_out + + def apply_to_bbox(self, bbox, angle=0, x_min=None, x_max=None, y_min=None, y_max=None, cols=0, rows=0, **params): + bbox_out = F.bbox_rotate(bbox, angle, self.method, rows, cols) + if self.crop_border: + bbox_out = FCrops.bbox_crop(bbox_out, x_min, y_min, x_max, y_max, rows, cols) + return bbox_out + + def apply_to_keypoint( + self, keypoint, angle=0, x_min=None, x_max=None, y_min=None, y_max=None, cols=0, rows=0, **params + ): + keypoint_out = F.keypoint_rotate(keypoint, angle, rows, cols, **params) + if self.crop_border: + keypoint_out = FCrops.crop_keypoint_by_coords(keypoint_out, (x_min, x_max, y_min, y_max)) + return keypoint_out - def apply_to_mask(self, img, angle=0, **params): - return F.rotate(img, angle, cv2.INTER_NEAREST, self.border_mode, self.mask_value) + @staticmethod + def _rotated_rect_with_max_area(h, w, angle): + """ + Given a rectangle of size wxh that has been rotated by 'angle' (in + degrees), computes the width and height of the largest possible + axis-aligned rectangle (maximal area) within the rotated rectangle. - def get_params(self): - return {"angle": random.uniform(self.limit[0], self.limit[1])} + Code from: https://stackoverflow.com/questions/16702966/rotate-image-and-crop-out-black-borders + """ + + angle = math.radians(angle) + width_is_longer = w >= h + side_long, side_short = (w, h) if width_is_longer else (h, w) + + # since the solutions for angle, -angle and 180-angle are all the same, + # it is sufficient to look at the first quadrant and the absolute values of sin,cos: + sin_a, cos_a = abs(math.sin(angle)), abs(math.cos(angle)) + if side_short <= 2.0 * sin_a * cos_a * side_long or abs(sin_a - cos_a) < 1e-10: + # half constrained case: two crop corners touch the longer side, + # the other two corners are on the mid-line parallel to the longer line + x = 0.5 * side_short + wr, hr = (x / sin_a, x / cos_a) if width_is_longer else (x / cos_a, x / sin_a) + else: + # fully constrained case: crop touches all 4 sides + cos_2a = cos_a * cos_a - sin_a * sin_a + wr, hr = (w * cos_a - h * sin_a) / cos_2a, (h * cos_a - w * sin_a) / cos_2a + + return dict( + x_min=max(0, int(w / 2 - wr / 2)), + x_max=min(w, int(w / 2 + wr / 2)), + y_min=max(0, int(h / 2 - hr / 2)), + y_max=min(h, int(h / 2 + hr / 2)), + ) - def apply_to_bbox(self, bbox, angle=0, **params): - return F.bbox_rotate(bbox, angle, self.method, params["rows"], params["cols"]) + @property + def targets_as_params(self) -> List[str]: + return ["image"] - def apply_to_keypoint(self, keypoint, angle=0, **params): - return F.keypoint_rotate(keypoint, angle, **params) + def get_params_dependent_on_targets(self, params: Dict[str, Any]) -> Dict[str, Any]: + out_params = {"angle": random.uniform(self.limit[0], self.limit[1])} + if self.crop_border: + h, w = params["image"].shape[:2] + out_params.update(self._rotated_rect_with_max_area(h, w, out_params["angle"])) + return out_params def get_transform_init_args_names(self): - return ("limit", "interpolation", "border_mode", "value", "mask_value", "method") + return ("limit", "interpolation", "border_mode", "value", "mask_value", "method", "crop_border") class SafeRotate(DualTransform):
albumentations-team/albumentations
3f321e23ef301a28ef6e2bf52d7b1aebb3ac1fca
diff --git a/tests/test_serialization.py b/tests/test_serialization.py index 76de63b..40157bf 100644 --- a/tests/test_serialization.py +++ b/tests/test_serialization.py @@ -133,6 +133,7 @@ AUGMENTATION_CLS_PARAMS = [ "interpolation": cv2.INTER_CUBIC, "border_mode": cv2.BORDER_CONSTANT, "value": (10, 10, 10), + "crop_border": False, }, ], [ diff --git a/tests/test_transforms.py b/tests/test_transforms.py index f83be9f..5f0e0db 100644 --- a/tests/test_transforms.py +++ b/tests/test_transforms.py @@ -38,6 +38,16 @@ def test_rotate_interpolation(interpolation): assert np.array_equal(data["mask"], expected_mask) +def test_rotate_crop_border(): + image = np.random.randint(low=100, high=256, size=(100, 100, 3), dtype=np.uint8) + border_value = 13 + aug = A.Rotate(limit=(45, 45), p=1, value=border_value, border_mode=cv2.BORDER_CONSTANT, crop_border=True) + aug_img = aug(image=image)["image"] + expected_size = int(np.round(100 / np.sqrt(2))) + assert aug_img.shape[0] == expected_size + assert (aug_img == border_value).sum() == 0 + + @pytest.mark.parametrize("interpolation", [cv2.INTER_NEAREST, cv2.INTER_LINEAR, cv2.INTER_CUBIC]) def test_shift_scale_rotate_interpolation(interpolation): image = np.random.randint(low=0, high=256, size=(100, 100, 3), dtype=np.uint8)
Rotate and Crop within borders **Problem:** Currently all Rotation augmentations introduce boundary where pixel values are not well-defined. I would like to have an option to make a largest possible crop within rotated image. This issue has been discussed before, but still wasn't implemented: #266 #1154 There is a code [from StackOverflow](https://stackoverflow.com/questions/16702966/rotate-image-and-crop-out-black-borders) which calculates such crop, and gives following results: Rotate 5° ![image](https://user-images.githubusercontent.com/14337581/177718762-ee620db9-6f99-4831-8411-52ba3ddaf788.png) Rotate 5° and take largest crop ![image](https://user-images.githubusercontent.com/14337581/177718831-14aa5ae8-7d43-4a0b-a762-d12e2af51047.png) Rotate 10° ![image](https://user-images.githubusercontent.com/14337581/177718898-9ab2bbf0-6d98-4159-844d-1f38d2cd0d94.png) Rotate 10° and take largest crop ![image](https://user-images.githubusercontent.com/14337581/177718920-0ddc430e-ca28-4661-b8ed-55da05fdf12b.png) **Solution:** I'm willing to make a PR with this change but want to discuss implementation first. In my understanding the most simple way would be to add a new flag to `SafeRotate` augmentation. I propose the name `crop_border`. And docstring saying `crop_border (bool): If True would make a largest possible crop within rotated image`. It would by implemented by adding such import `from ..crops import functional as FCrops` and using crop functions inside `SafeRotate` class.
0.0
3f321e23ef301a28ef6e2bf52d7b1aebb3ac1fca
[ "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Rotate-params20]", "tests/test_transforms.py::test_rotate_crop_border" ]
[ "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-FromFloat-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomGridShuffle-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-FromFloat-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomGridShuffle-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-FromFloat-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomGridShuffle-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-FromFloat-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomGridShuffle-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ElasticTransform-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Emboss-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Equalize-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-FancyPCA-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Flip-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GaussNoise-params19]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GaussianBlur-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GlassBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GridDistortion-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GridDropout-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-HorizontalFlip-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-HueSaturationValue-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ISONoise-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ImageCompression-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-InvertImg-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-LongestMaxSize-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MaskDropout-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MedianBlur-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MotionBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MultiplicativeNoise-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-NoOp-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Normalize-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-OpticalDistortion-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-PadIfNeeded-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Perspective-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-PiecewiseAffine-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-PixelDropout-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Posterize-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RGBShift-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomBrightnessContrast-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomCrop-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomFog-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomGamma-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomRain-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomResizedCrop-params49]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomRotate90-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomScale-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomShadow-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomSizedCrop-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomSnow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomSunFlare-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomToneCurve-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Resize-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RingingOvershoot-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Rotate-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-SafeRotate-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Sharpen-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ShiftScaleRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-SmallestMaxSize-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Solarize-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Superpixels-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ToFloat-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ToGray-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ToSepia-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Transpose-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-UnsharpMask-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSizedBBoxSafeCrop-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSizedCrop-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSnow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSunFlare-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Resize-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RingingOvershoot-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Rotate-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-SafeRotate-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Sharpen-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ShiftScaleRotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-SmallestMaxSize-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Solarize-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Superpixels-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ToFloat-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ToGray-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ToSepia-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Transpose-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-UnsharpMask-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-VerticalFlip-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-FromFloat-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Downscale-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Emboss-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Equalize-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-FancyPCA-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Flip-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-GaussNoise-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-GaussianBlur-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-GlassBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-HorizontalFlip-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-HueSaturationValue-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ISONoise-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ImageCompression-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-InvertImg-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-LongestMaxSize-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-MedianBlur-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-MotionBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-MultiplicativeNoise-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-NoOp-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Normalize-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-PadIfNeeded-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Perspective-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-PiecewiseAffine-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-PixelDropout-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Posterize-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RGBShift-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomBrightnessContrast-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomCrop-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomFog-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomGamma-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomRain-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomResizedCrop-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomRotate90-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomScale-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomShadow-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomSizedCrop-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomSnow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomSunFlare-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomToneCurve-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Resize-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RingingOvershoot-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Rotate-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-SafeRotate-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Sharpen-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ShiftScaleRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-SmallestMaxSize-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Solarize-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Superpixels-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ToFloat-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ToGray-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ToSepia-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Transpose-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-UnsharpMask-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-VerticalFlip-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-0-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-0-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-1-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-1-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-42-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-42-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-111-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-111-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-9999-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-9999-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-0-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-0-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-1-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-1-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-42-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-42-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-111-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-111-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-9999-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-9999-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_from_float_serialization", "tests/test_serialization.py::test_transform_pipeline_serialization[0]", "tests/test_serialization.py::test_transform_pipeline_serialization[1]", "tests/test_serialization.py::test_transform_pipeline_serialization[42]", "tests/test_serialization.py::test_transform_pipeline_serialization[111]", "tests/test_serialization.py::test_transform_pipeline_serialization[9999]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints3-xys-labels3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Downscale-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Emboss-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Equalize-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-FancyPCA-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-GaussNoise-params11]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-GaussianBlur-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-GlassBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-HueSaturationValue-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ISONoise-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ImageCompression-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-InvertImg-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-MedianBlur-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-MotionBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-MultiplicativeNoise-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Normalize-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Posterize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RGBShift-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomBrightnessContrast-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomFog-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomGamma-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomRain-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomShadow-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomSnow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomSunFlare-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomToneCurve-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RingingOvershoot-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Sharpen-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Solarize-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Superpixels-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ToFloat-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ToGray-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ToSepia-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-UnsharpMask-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Downscale-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Emboss-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Equalize-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-FancyPCA-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-GaussNoise-params11]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-GaussianBlur-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-GlassBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-HueSaturationValue-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ISONoise-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ImageCompression-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-InvertImg-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-MedianBlur-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-MotionBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-MultiplicativeNoise-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Normalize-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Posterize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RGBShift-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomBrightnessContrast-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomFog-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomGamma-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomRain-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomShadow-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomSnow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomSunFlare-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomToneCurve-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RingingOvershoot-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Sharpen-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Solarize-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Superpixels-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ToFloat-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ToGray-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ToSepia-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-UnsharpMask-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Downscale-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Emboss-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Equalize-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-FancyPCA-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-GaussNoise-params11]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-GaussianBlur-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-GlassBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-HueSaturationValue-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ISONoise-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ImageCompression-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-InvertImg-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-MedianBlur-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-MotionBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-MultiplicativeNoise-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Normalize-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Posterize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RGBShift-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomBrightnessContrast-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomFog-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomGamma-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomRain-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomShadow-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomSnow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomSunFlare-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomToneCurve-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RingingOvershoot-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Sharpen-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Solarize-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Superpixels-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ToFloat-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ToGray-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ToSepia-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-UnsharpMask-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Downscale-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Emboss-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Equalize-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-FancyPCA-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-GaussNoise-params11]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-GaussianBlur-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-GlassBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-HueSaturationValue-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ISONoise-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ImageCompression-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-InvertImg-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-MedianBlur-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-MotionBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-MultiplicativeNoise-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Normalize-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Posterize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RGBShift-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomBrightnessContrast-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomFog-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomGamma-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomRain-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomShadow-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomSnow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomSunFlare-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomToneCurve-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RingingOvershoot-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Sharpen-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Solarize-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Superpixels-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ToFloat-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ToGray-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ToSepia-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-UnsharpMask-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Downscale-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Emboss-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Equalize-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-FancyPCA-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-GaussNoise-params11]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-GaussianBlur-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-GlassBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-HueSaturationValue-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ISONoise-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ImageCompression-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-InvertImg-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-MedianBlur-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-MotionBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-MultiplicativeNoise-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Normalize-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Posterize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RGBShift-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomBrightnessContrast-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomFog-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomGamma-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomRain-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomShadow-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomSnow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomSunFlare-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomToneCurve-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RingingOvershoot-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Sharpen-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Solarize-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Superpixels-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ToFloat-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ToGray-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ToSepia-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-UnsharpMask-params39]", "tests/test_serialization.py::test_lambda_serialization[1-0]", "tests/test_serialization.py::test_lambda_serialization[1-1]", "tests/test_serialization.py::test_lambda_serialization[1-42]", "tests/test_serialization.py::test_lambda_serialization[1-111]", "tests/test_serialization.py::test_lambda_serialization[1-9999]", "tests/test_serialization.py::test_custom_transform_with_overlapping_name", "tests/test_serialization.py::test_serialization_v2_to_dict", "tests/test_serialization.py::test_shorten_class_name[albumentations.augmentations.transforms.HorizontalFlip-HorizontalFlip]", "tests/test_serialization.py::test_shorten_class_name[HorizontalFlip-HorizontalFlip]", "tests/test_serialization.py::test_shorten_class_name[some_module.HorizontalFlip-some_module.HorizontalFlip]", "tests/test_serialization.py::test_template_transform_serialization[1-0]", "tests/test_serialization.py::test_template_transform_serialization[1-1]", "tests/test_serialization.py::test_template_transform_serialization[1-42]", "tests/test_serialization.py::test_template_transform_serialization[1-111]", "tests/test_serialization.py::test_template_transform_serialization[1-9999]", "tests/test_transforms.py::test_transpose_both_image_and_mask", "tests/test_transforms.py::test_rotate_interpolation[0]", "tests/test_transforms.py::test_rotate_interpolation[1]", "tests/test_transforms.py::test_rotate_interpolation[2]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[0]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[1]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[2]", "tests/test_transforms.py::test_optical_distortion_interpolation[0]", "tests/test_transforms.py::test_optical_distortion_interpolation[1]", "tests/test_transforms.py::test_optical_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_interpolation[0]", "tests/test_transforms.py::test_grid_distortion_interpolation[1]", "tests/test_transforms.py::test_grid_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_steps[17]", "tests/test_transforms.py::test_grid_distortion_steps[21]", "tests/test_transforms.py::test_grid_distortion_steps[33]", "tests/test_transforms.py::test_elastic_transform_interpolation[0]", "tests/test_transforms.py::test_elastic_transform_interpolation[1]", "tests/test_transforms.py::test_elastic_transform_interpolation[2]", "tests/test_transforms.py::test_binary_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_binary_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_binary_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_binary_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_binary_mask_interpolation[CropAndPad-params4]", "tests/test_transforms.py::test_binary_mask_interpolation[CropNonEmptyMaskIfExists-params5]", "tests/test_transforms.py::test_binary_mask_interpolation[ElasticTransform-params6]", "tests/test_transforms.py::test_binary_mask_interpolation[Flip-params7]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDistortion-params8]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDropout-params9]", "tests/test_transforms.py::test_binary_mask_interpolation[HorizontalFlip-params10]", "tests/test_transforms.py::test_binary_mask_interpolation[Lambda-params11]", "tests/test_transforms.py::test_binary_mask_interpolation[LongestMaxSize-params12]", "tests/test_transforms.py::test_binary_mask_interpolation[MaskDropout-params13]", "tests/test_transforms.py::test_binary_mask_interpolation[NoOp-params14]", "tests/test_transforms.py::test_binary_mask_interpolation[OpticalDistortion-params15]", "tests/test_transforms.py::test_binary_mask_interpolation[PadIfNeeded-params16]", "tests/test_transforms.py::test_binary_mask_interpolation[Perspective-params17]", "tests/test_transforms.py::test_binary_mask_interpolation[PiecewiseAffine-params18]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomCrop-params19]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomResizedCrop-params21]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomRotate90-params22]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomScale-params23]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomSizedCrop-params24]", "tests/test_transforms.py::test_binary_mask_interpolation[Resize-params25]", "tests/test_transforms.py::test_binary_mask_interpolation[Rotate-params26]", "tests/test_transforms.py::test_binary_mask_interpolation[SafeRotate-params27]", "tests/test_transforms.py::test_binary_mask_interpolation[ShiftScaleRotate-params28]", "tests/test_transforms.py::test_binary_mask_interpolation[SmallestMaxSize-params29]", "tests/test_transforms.py::test_binary_mask_interpolation[Transpose-params30]", "tests/test_transforms.py::test_binary_mask_interpolation[VerticalFlip-params31]", "tests/test_transforms.py::test_semantic_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_semantic_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_semantic_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_semantic_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_semantic_mask_interpolation[CropNonEmptyMaskIfExists-params4]", "tests/test_transforms.py::test_semantic_mask_interpolation[ElasticTransform-params5]", "tests/test_transforms.py::test_semantic_mask_interpolation[Flip-params6]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDistortion-params7]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDropout-params8]", "tests/test_transforms.py::test_semantic_mask_interpolation[HorizontalFlip-params9]", "tests/test_transforms.py::test_semantic_mask_interpolation[Lambda-params10]", "tests/test_transforms.py::test_semantic_mask_interpolation[LongestMaxSize-params11]", "tests/test_transforms.py::test_semantic_mask_interpolation[MaskDropout-params12]", "tests/test_transforms.py::test_semantic_mask_interpolation[NoOp-params13]", "tests/test_transforms.py::test_semantic_mask_interpolation[OpticalDistortion-params14]", "tests/test_transforms.py::test_semantic_mask_interpolation[PadIfNeeded-params15]", "tests/test_transforms.py::test_semantic_mask_interpolation[Perspective-params16]", "tests/test_transforms.py::test_semantic_mask_interpolation[PiecewiseAffine-params17]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomCrop-params18]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomResizedCrop-params20]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomRotate90-params21]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomScale-params22]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomSizedCrop-params23]", "tests/test_transforms.py::test_semantic_mask_interpolation[Resize-params24]", "tests/test_transforms.py::test_semantic_mask_interpolation[Rotate-params25]", "tests/test_transforms.py::test_semantic_mask_interpolation[SafeRotate-params26]", "tests/test_transforms.py::test_semantic_mask_interpolation[ShiftScaleRotate-params27]", "tests/test_transforms.py::test_semantic_mask_interpolation[SmallestMaxSize-params28]", "tests/test_transforms.py::test_semantic_mask_interpolation[Transpose-params29]", "tests/test_transforms.py::test_semantic_mask_interpolation[VerticalFlip-params30]", "tests/test_transforms.py::test_multiprocessing_support[AdvancedBlur-params0]", "tests/test_transforms.py::test_multiprocessing_support[Affine-params1]", "tests/test_transforms.py::test_multiprocessing_support[Blur-params2]", "tests/test_transforms.py::test_multiprocessing_support[CLAHE-params3]", "tests/test_transforms.py::test_multiprocessing_support[CenterCrop-params4]", "tests/test_transforms.py::test_multiprocessing_support[ChannelDropout-params5]", "tests/test_transforms.py::test_multiprocessing_support[ChannelShuffle-params6]", "tests/test_transforms.py::test_multiprocessing_support[CoarseDropout-params7]", "tests/test_transforms.py::test_multiprocessing_support[ColorJitter-params8]", "tests/test_transforms.py::test_multiprocessing_support[Crop-params9]", "tests/test_transforms.py::test_multiprocessing_support[CropAndPad-params10]", "tests/test_transforms.py::test_multiprocessing_support[Downscale-params11]", "tests/test_transforms.py::test_multiprocessing_support[ElasticTransform-params12]", "tests/test_transforms.py::test_multiprocessing_support[Emboss-params13]", "tests/test_transforms.py::test_multiprocessing_support[Equalize-params14]", "tests/test_transforms.py::test_multiprocessing_support[FancyPCA-params15]", "tests/test_transforms.py::test_multiprocessing_support[Flip-params16]", "tests/test_transforms.py::test_multiprocessing_support[GaussNoise-params18]", "tests/test_transforms.py::test_multiprocessing_support[GaussianBlur-params19]", "tests/test_transforms.py::test_multiprocessing_support[GlassBlur-params20]", "tests/test_transforms.py::test_multiprocessing_support[GridDistortion-params21]", "tests/test_transforms.py::test_multiprocessing_support[GridDropout-params22]", "tests/test_transforms.py::test_multiprocessing_support[HorizontalFlip-params23]", "tests/test_transforms.py::test_multiprocessing_support[HueSaturationValue-params24]", "tests/test_transforms.py::test_multiprocessing_support[ISONoise-params25]", "tests/test_transforms.py::test_multiprocessing_support[ImageCompression-params26]", "tests/test_transforms.py::test_multiprocessing_support[InvertImg-params27]", "tests/test_transforms.py::test_multiprocessing_support[Lambda-params28]", "tests/test_transforms.py::test_multiprocessing_support[LongestMaxSize-params29]", "tests/test_transforms.py::test_multiprocessing_support[MedianBlur-params30]", "tests/test_transforms.py::test_multiprocessing_support[MotionBlur-params31]", "tests/test_transforms.py::test_multiprocessing_support[MultiplicativeNoise-params32]", "tests/test_transforms.py::test_multiprocessing_support[NoOp-params33]", "tests/test_transforms.py::test_multiprocessing_support[Normalize-params34]", "tests/test_transforms.py::test_multiprocessing_support[OpticalDistortion-params35]", "tests/test_transforms.py::test_multiprocessing_support[PadIfNeeded-params36]", "tests/test_transforms.py::test_multiprocessing_support[Perspective-params37]", "tests/test_transforms.py::test_multiprocessing_support[PiecewiseAffine-params38]", "tests/test_transforms.py::test_multiprocessing_support[PixelDropout-params39]", "tests/test_transforms.py::test_multiprocessing_support[Posterize-params40]", "tests/test_transforms.py::test_multiprocessing_support[RGBShift-params41]", "tests/test_transforms.py::test_multiprocessing_support[RandomBrightnessContrast-params42]", "tests/test_transforms.py::test_multiprocessing_support[RandomCrop-params43]", "tests/test_transforms.py::test_multiprocessing_support[RandomFog-params44]", "tests/test_transforms.py::test_multiprocessing_support[RandomGamma-params45]", "tests/test_transforms.py::test_multiprocessing_support[RandomRain-params47]", "tests/test_transforms.py::test_multiprocessing_support[RandomResizedCrop-params48]", "tests/test_transforms.py::test_multiprocessing_support[RandomRotate90-params49]", "tests/test_transforms.py::test_multiprocessing_support[RandomScale-params50]", "tests/test_transforms.py::test_multiprocessing_support[RandomShadow-params51]", "tests/test_transforms.py::test_multiprocessing_support[RandomSizedCrop-params52]", "tests/test_transforms.py::test_multiprocessing_support[RandomSnow-params53]", "tests/test_transforms.py::test_multiprocessing_support[RandomSunFlare-params54]", "tests/test_transforms.py::test_multiprocessing_support[RandomToneCurve-params55]", "tests/test_transforms.py::test_multiprocessing_support[Resize-params56]", "tests/test_transforms.py::test_multiprocessing_support[RingingOvershoot-params57]", "tests/test_transforms.py::test_multiprocessing_support[Rotate-params58]", "tests/test_transforms.py::test_multiprocessing_support[SafeRotate-params59]", "tests/test_transforms.py::test_multiprocessing_support[Sharpen-params60]", "tests/test_transforms.py::test_multiprocessing_support[ShiftScaleRotate-params61]", "tests/test_transforms.py::test_multiprocessing_support[SmallestMaxSize-params62]", "tests/test_transforms.py::test_multiprocessing_support[Solarize-params63]", "tests/test_transforms.py::test_multiprocessing_support[Superpixels-params64]", "tests/test_transforms.py::test_multiprocessing_support[TemplateTransform-params65]", "tests/test_transforms.py::test_multiprocessing_support[ToFloat-params66]", "tests/test_transforms.py::test_multiprocessing_support[ToGray-params67]", "tests/test_transforms.py::test_multiprocessing_support[ToSepia-params68]", "tests/test_transforms.py::test_multiprocessing_support[Transpose-params69]", "tests/test_transforms.py::test_multiprocessing_support[UnsharpMask-params70]", "tests/test_transforms.py::test_multiprocessing_support[VerticalFlip-params71]", "tests/test_transforms.py::test_force_apply", "tests/test_transforms.py::test_additional_targets_for_image_only[AdvancedBlur-params0]", "tests/test_transforms.py::test_additional_targets_for_image_only[Blur-params1]", "tests/test_transforms.py::test_additional_targets_for_image_only[CLAHE-params2]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelDropout-params3]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelShuffle-params4]", "tests/test_transforms.py::test_additional_targets_for_image_only[ColorJitter-params5]", "tests/test_transforms.py::test_additional_targets_for_image_only[Downscale-params6]", "tests/test_transforms.py::test_additional_targets_for_image_only[Emboss-params7]", "tests/test_transforms.py::test_additional_targets_for_image_only[Equalize-params8]", "tests/test_transforms.py::test_additional_targets_for_image_only[FDA-params9]", "tests/test_transforms.py::test_additional_targets_for_image_only[FancyPCA-params10]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussNoise-params12]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussianBlur-params13]", "tests/test_transforms.py::test_additional_targets_for_image_only[GlassBlur-params14]", "tests/test_transforms.py::test_additional_targets_for_image_only[HistogramMatching-params15]", "tests/test_transforms.py::test_additional_targets_for_image_only[HueSaturationValue-params16]", "tests/test_transforms.py::test_additional_targets_for_image_only[ISONoise-params17]", "tests/test_transforms.py::test_additional_targets_for_image_only[ImageCompression-params18]", "tests/test_transforms.py::test_additional_targets_for_image_only[InvertImg-params19]", "tests/test_transforms.py::test_additional_targets_for_image_only[MedianBlur-params20]", "tests/test_transforms.py::test_additional_targets_for_image_only[MotionBlur-params21]", "tests/test_transforms.py::test_additional_targets_for_image_only[MultiplicativeNoise-params22]", "tests/test_transforms.py::test_additional_targets_for_image_only[Normalize-params23]", "tests/test_transforms.py::test_additional_targets_for_image_only[PixelDistributionAdaptation-params24]", "tests/test_transforms.py::test_additional_targets_for_image_only[Posterize-params25]", "tests/test_transforms.py::test_additional_targets_for_image_only[RGBShift-params26]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomBrightnessContrast-params27]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomFog-params28]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomGamma-params29]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomRain-params30]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomShadow-params31]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSnow-params32]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSunFlare-params33]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomToneCurve-params34]", "tests/test_transforms.py::test_additional_targets_for_image_only[RingingOvershoot-params35]", "tests/test_transforms.py::test_additional_targets_for_image_only[Sharpen-params36]", "tests/test_transforms.py::test_additional_targets_for_image_only[Solarize-params37]", "tests/test_transforms.py::test_additional_targets_for_image_only[Superpixels-params38]", "tests/test_transforms.py::test_additional_targets_for_image_only[TemplateTransform-params39]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToFloat-params40]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToGray-params41]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToSepia-params42]", "tests/test_transforms.py::test_additional_targets_for_image_only[UnsharpMask-params43]", "tests/test_transforms.py::test_lambda_transform", "tests/test_transforms.py::test_channel_droput", "tests/test_transforms.py::test_equalize", "tests/test_transforms.py::test_crop_non_empty_mask", "tests/test_transforms.py::test_downscale[0]", "tests/test_transforms.py::test_downscale[1]", "tests/test_transforms.py::test_downscale[2]", "tests/test_transforms.py::test_crop_keypoints", "tests/test_transforms.py::test_longest_max_size_keypoints", "tests/test_transforms.py::test_smallest_max_size_keypoints", "tests/test_transforms.py::test_resize_keypoints", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image0]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image1]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image2]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image3]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image0]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image1]", "tests/test_transforms.py::test_mask_dropout", "tests/test_transforms.py::test_grid_dropout_mask[image0]", "tests/test_transforms.py::test_grid_dropout_mask[image1]", "tests/test_transforms.py::test_grid_dropout_params[1e-05-10-10-100-100-50-50]", "tests/test_transforms.py::test_grid_dropout_params[0.9-100-None-200-None-0-0]", "tests/test_transforms.py::test_grid_dropout_params[0.4556-10-20-None-200-0-0]", "tests/test_transforms.py::test_grid_dropout_params[4e-05-None-None-2-100-None-None]", "tests/test_transforms.py::test_gauss_noise_incorrect_var_limit_type", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit3-sigma3-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit4-sigma4-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit5-sigma5-3-0.1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[0.123-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1.321-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-0.234-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1.432-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-0.345-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1.543-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0.456]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1--0.432]", "tests/test_transforms.py::test_shift_scale_separate_shift_x_shift_y", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_perspective_keep_size", "tests/test_transforms.py::test_longest_max_size_list", "tests/test_transforms.py::test_smallest_max_size_list", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform0-image_size0-template_size0]", "tests/test_transforms.py::test_template_transform[0.3-0.5-template_transform1-image_size1-template_size1]", "tests/test_transforms.py::test_template_transform[1.0-0.5-template_transform2-image_size2-template_size2]", "tests/test_transforms.py::test_template_transform[0.5-0.8-template_transform3-image_size3-template_size3]", "tests/test_transforms.py::test_template_transform[0.5-0.2-template_transform4-image_size4-template_size4]", "tests/test_transforms.py::test_template_transform[0.5-0.9-template_transform5-image_size5-template_size5]", "tests/test_transforms.py::test_template_transform[0.5-0.5-None-image_size6-template_size6]", "tests/test_transforms.py::test_template_transform[0.8-0.7-None-image_size7-template_size7]", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform8-image_size8-template_size8]", "tests/test_transforms.py::test_template_transform_incorrect_size", "tests/test_transforms.py::test_template_transform_incorrect_channels[1-3]", "tests/test_transforms.py::test_template_transform_incorrect_channels[6-3]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params0]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params1]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params2]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params3]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params4]", "tests/test_transforms.py::test_affine_scale_ratio[params0]", "tests/test_transforms.py::test_affine_scale_ratio[params1]", "tests/test_transforms.py::test_affine_scale_ratio[params2]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params0]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params1]", "tests/test_transforms.py::test_safe_rotate[-10-targets0-expected0]", "tests/test_transforms.py::test_safe_rotate[10-targets1-expected1]" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_issue_reference", "has_media", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2022-07-07 10:21:54+00:00
mit
1,009
albumentations-team__albumentations-1231
diff --git a/albumentations/augmentations/geometric/functional.py b/albumentations/augmentations/geometric/functional.py index bc3782d..5690726 100644 --- a/albumentations/augmentations/geometric/functional.py +++ b/albumentations/augmentations/geometric/functional.py @@ -461,18 +461,12 @@ def perspective_bbox( for pt in points: pt = perspective_keypoint(pt.tolist() + [0, 0], height, width, matrix, max_width, max_height, keep_size) x, y = pt[:2] - x = np.clip(x, 0, width if keep_size else max_width) - y = np.clip(y, 0, height if keep_size else max_height) x1 = min(x1, x) x2 = max(x2, x) y1 = min(y1, y) y2 = max(y2, y) - x = np.clip([x1, x2], 0, width if keep_size else max_width) - y = np.clip([y1, y2], 0, height if keep_size else max_height) - return normalize_bbox( - (x[0], y[0], x[1], y[1]), height if keep_size else max_height, width if keep_size else max_width - ) + return normalize_bbox((x1, y1, x2, y2), height if keep_size else max_height, width if keep_size else max_width) def rotation2DMatrixToEulerAngles(matrix: np.ndarray, y_up: bool = False) -> float: @@ -575,8 +569,6 @@ def bbox_affine( ] ) points = skimage.transform.matrix_transform(points, matrix.params) - points[:, 0] = np.clip(points[:, 0], 0, output_shape[1]) - points[:, 1] = np.clip(points[:, 1], 0, output_shape[0]) x_min = np.min(points[:, 0]) x_max = np.max(points[:, 0]) y_min = np.min(points[:, 1])
albumentations-team/albumentations
02038645f0b830a3925b45c0703153b11bc4ccef
diff --git a/tests/test_transforms.py b/tests/test_transforms.py index 8a1e75d..1921e1a 100644 --- a/tests/test_transforms.py +++ b/tests/test_transforms.py @@ -1188,3 +1188,40 @@ def test_rotate_equal(img, aug_cls, angle): diff = np.round(np.abs(res_a - res_b)) assert diff[:, :2].max() <= 2 assert (diff[:, -1] % 360).max() <= 1 + + [email protected]( + "get_transform", + [ + lambda sign: A.Affine(translate_px=sign * 2), + lambda sign: A.ShiftScaleRotate(shift_limit=(sign * 0.02, sign * 0.02), scale_limit=0, rotate_limit=0), + ], +) [email protected]( + ["bboxes", "expected", "min_visibility", "sign"], + [ + [[(0, 0, 10, 10, 1)], [], 0.9, -1], + [[(0, 0, 10, 10, 1)], [(0, 0, 8, 8, 1)], 0.6, -1], + [[(90, 90, 100, 100, 1)], [], 0.9, 1], + [[(90, 90, 100, 100, 1)], [(92, 92, 100, 100, 1)], 0.6, 1], + ], +) +def test_bbox_clipping(get_transform, image, bboxes, expected, min_visibility: float, sign: int): + transform = get_transform(sign) + transform.p = 1 + transform = A.Compose([transform], bbox_params=A.BboxParams(format="pascal_voc", min_visibility=min_visibility)) + + res = transform(image=image, bboxes=bboxes)["bboxes"] + assert res == expected + + +def test_bbox_clipping_perspective(): + random.seed(0) + transform = A.Compose( + [A.Perspective(scale=(0.05, 0.05), p=1)], bbox_params=A.BboxParams(format="pascal_voc", min_visibility=0.6) + ) + + image = np.empty([1000, 1000, 3], dtype=np.uint8) + bboxes = np.array([[0, 0, 100, 100, 1]]) + res = transform(image=image, bboxes=bboxes)["bboxes"] + assert len(res) == 0
min_visibility param does not work with A.Affine transform ## 🐛 Bug `min_visibility` param does not work with `A.Affine` transform ## To Reproduce Steps to reproduce the behavior: ``` transform = A.Compose( [A.Affine(translate_px=-20, p=1.0)], bbox_params=A.BboxParams(format='pascal_voc', label_fields=['class_labels'], min_visibility=0.9) ) img = np.zeros((500, 500, 3)) bboxes = np.array([[0, 0, 100, 100]]) transformed = transform(image=img, bboxes=bboxes, class_labels=['class_0']) new_img = transformed['image'] new_bboxes = transformed['bboxes'] print(new_bboxes) # [(0.0, 0.0, 80.0, 80.0)] ``` new_bboxes = [(0.0, 0.0, 80.0, 80.0)], but I expect it should be empty ## Expected behavior `new_bboxes` should be empty, because: - the origin bbox area is 100x100 = 10000px - the transformed bbox area is 80x80 = 6400px - visibility = 6400/10000 = 0.64 < 0.9, then this bbox should be removed ## Environment - Albumentations version: 1.0.3 - Python version: 3.9.13 - OS: MacOS - How you installed albumentations: pip ## Additional context
0.0
02038645f0b830a3925b45c0703153b11bc4ccef
[ "tests/test_transforms.py::test_bbox_clipping[bboxes0-expected0-0.9--1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes2-expected2-0.9-1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping_perspective" ]
[ "tests/test_transforms.py::test_transpose_both_image_and_mask", "tests/test_transforms.py::test_rotate_interpolation[0]", "tests/test_transforms.py::test_rotate_interpolation[1]", "tests/test_transforms.py::test_rotate_interpolation[2]", "tests/test_transforms.py::test_rotate_crop_border", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[0]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[1]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[2]", "tests/test_transforms.py::test_optical_distortion_interpolation[0]", "tests/test_transforms.py::test_optical_distortion_interpolation[1]", "tests/test_transforms.py::test_optical_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_interpolation[0]", "tests/test_transforms.py::test_grid_distortion_interpolation[1]", "tests/test_transforms.py::test_grid_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_steps[17]", "tests/test_transforms.py::test_grid_distortion_steps[21]", "tests/test_transforms.py::test_grid_distortion_steps[33]", "tests/test_transforms.py::test_elastic_transform_interpolation[0]", "tests/test_transforms.py::test_elastic_transform_interpolation[1]", "tests/test_transforms.py::test_elastic_transform_interpolation[2]", "tests/test_transforms.py::test_binary_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_binary_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_binary_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_binary_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_binary_mask_interpolation[CropAndPad-params4]", "tests/test_transforms.py::test_binary_mask_interpolation[CropNonEmptyMaskIfExists-params5]", "tests/test_transforms.py::test_binary_mask_interpolation[ElasticTransform-params6]", "tests/test_transforms.py::test_binary_mask_interpolation[Flip-params7]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDistortion-params8]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDropout-params9]", "tests/test_transforms.py::test_binary_mask_interpolation[HorizontalFlip-params10]", "tests/test_transforms.py::test_binary_mask_interpolation[Lambda-params11]", "tests/test_transforms.py::test_binary_mask_interpolation[LongestMaxSize-params12]", "tests/test_transforms.py::test_binary_mask_interpolation[MaskDropout-params13]", "tests/test_transforms.py::test_binary_mask_interpolation[NoOp-params14]", "tests/test_transforms.py::test_binary_mask_interpolation[OpticalDistortion-params15]", "tests/test_transforms.py::test_binary_mask_interpolation[PadIfNeeded-params16]", "tests/test_transforms.py::test_binary_mask_interpolation[Perspective-params17]", "tests/test_transforms.py::test_binary_mask_interpolation[PiecewiseAffine-params18]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomCrop-params19]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomResizedCrop-params21]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomRotate90-params22]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomScale-params23]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomSizedCrop-params24]", "tests/test_transforms.py::test_binary_mask_interpolation[Resize-params25]", "tests/test_transforms.py::test_binary_mask_interpolation[Rotate-params26]", "tests/test_transforms.py::test_binary_mask_interpolation[SafeRotate-params27]", "tests/test_transforms.py::test_binary_mask_interpolation[ShiftScaleRotate-params28]", "tests/test_transforms.py::test_binary_mask_interpolation[SmallestMaxSize-params29]", "tests/test_transforms.py::test_binary_mask_interpolation[Transpose-params30]", "tests/test_transforms.py::test_binary_mask_interpolation[VerticalFlip-params31]", "tests/test_transforms.py::test_semantic_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_semantic_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_semantic_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_semantic_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_semantic_mask_interpolation[CropNonEmptyMaskIfExists-params4]", "tests/test_transforms.py::test_semantic_mask_interpolation[ElasticTransform-params5]", "tests/test_transforms.py::test_semantic_mask_interpolation[Flip-params6]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDistortion-params7]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDropout-params8]", "tests/test_transforms.py::test_semantic_mask_interpolation[HorizontalFlip-params9]", "tests/test_transforms.py::test_semantic_mask_interpolation[Lambda-params10]", "tests/test_transforms.py::test_semantic_mask_interpolation[LongestMaxSize-params11]", "tests/test_transforms.py::test_semantic_mask_interpolation[MaskDropout-params12]", "tests/test_transforms.py::test_semantic_mask_interpolation[NoOp-params13]", "tests/test_transforms.py::test_semantic_mask_interpolation[OpticalDistortion-params14]", "tests/test_transforms.py::test_semantic_mask_interpolation[PadIfNeeded-params15]", "tests/test_transforms.py::test_semantic_mask_interpolation[Perspective-params16]", "tests/test_transforms.py::test_semantic_mask_interpolation[PiecewiseAffine-params17]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomCrop-params18]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomResizedCrop-params20]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomRotate90-params21]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomScale-params22]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomSizedCrop-params23]", "tests/test_transforms.py::test_semantic_mask_interpolation[Resize-params24]", "tests/test_transforms.py::test_semantic_mask_interpolation[Rotate-params25]", "tests/test_transforms.py::test_semantic_mask_interpolation[SafeRotate-params26]", "tests/test_transforms.py::test_semantic_mask_interpolation[ShiftScaleRotate-params27]", "tests/test_transforms.py::test_semantic_mask_interpolation[SmallestMaxSize-params28]", "tests/test_transforms.py::test_semantic_mask_interpolation[Transpose-params29]", "tests/test_transforms.py::test_semantic_mask_interpolation[VerticalFlip-params30]", "tests/test_transforms.py::test_multiprocessing_support[AdvancedBlur-params0]", "tests/test_transforms.py::test_multiprocessing_support[Affine-params1]", "tests/test_transforms.py::test_multiprocessing_support[Blur-params2]", "tests/test_transforms.py::test_multiprocessing_support[CLAHE-params3]", "tests/test_transforms.py::test_multiprocessing_support[CenterCrop-params4]", "tests/test_transforms.py::test_multiprocessing_support[ChannelDropout-params5]", "tests/test_transforms.py::test_multiprocessing_support[ChannelShuffle-params6]", "tests/test_transforms.py::test_multiprocessing_support[CoarseDropout-params7]", "tests/test_transforms.py::test_multiprocessing_support[ColorJitter-params8]", "tests/test_transforms.py::test_multiprocessing_support[Crop-params9]", "tests/test_transforms.py::test_multiprocessing_support[CropAndPad-params10]", "tests/test_transforms.py::test_multiprocessing_support[Downscale-params11]", "tests/test_transforms.py::test_multiprocessing_support[ElasticTransform-params12]", "tests/test_transforms.py::test_multiprocessing_support[Emboss-params13]", "tests/test_transforms.py::test_multiprocessing_support[Equalize-params14]", "tests/test_transforms.py::test_multiprocessing_support[FancyPCA-params15]", "tests/test_transforms.py::test_multiprocessing_support[Flip-params16]", "tests/test_transforms.py::test_multiprocessing_support[GaussNoise-params18]", "tests/test_transforms.py::test_multiprocessing_support[GaussianBlur-params19]", "tests/test_transforms.py::test_multiprocessing_support[GlassBlur-params20]", "tests/test_transforms.py::test_multiprocessing_support[GridDistortion-params21]", "tests/test_transforms.py::test_multiprocessing_support[GridDropout-params22]", "tests/test_transforms.py::test_multiprocessing_support[HorizontalFlip-params23]", "tests/test_transforms.py::test_multiprocessing_support[HueSaturationValue-params24]", "tests/test_transforms.py::test_multiprocessing_support[ISONoise-params25]", "tests/test_transforms.py::test_multiprocessing_support[ImageCompression-params26]", "tests/test_transforms.py::test_multiprocessing_support[InvertImg-params27]", "tests/test_transforms.py::test_multiprocessing_support[Lambda-params28]", "tests/test_transforms.py::test_multiprocessing_support[LongestMaxSize-params29]", "tests/test_transforms.py::test_multiprocessing_support[MedianBlur-params30]", "tests/test_transforms.py::test_multiprocessing_support[MotionBlur-params31]", "tests/test_transforms.py::test_multiprocessing_support[MultiplicativeNoise-params32]", "tests/test_transforms.py::test_multiprocessing_support[NoOp-params33]", "tests/test_transforms.py::test_multiprocessing_support[Normalize-params34]", "tests/test_transforms.py::test_multiprocessing_support[OpticalDistortion-params35]", "tests/test_transforms.py::test_multiprocessing_support[PadIfNeeded-params36]", "tests/test_transforms.py::test_multiprocessing_support[Perspective-params37]", "tests/test_transforms.py::test_multiprocessing_support[PiecewiseAffine-params38]", "tests/test_transforms.py::test_multiprocessing_support[PixelDropout-params39]", "tests/test_transforms.py::test_multiprocessing_support[Posterize-params40]", "tests/test_transforms.py::test_multiprocessing_support[RGBShift-params41]", "tests/test_transforms.py::test_multiprocessing_support[RandomBrightnessContrast-params42]", "tests/test_transforms.py::test_multiprocessing_support[RandomCrop-params43]", "tests/test_transforms.py::test_multiprocessing_support[RandomFog-params44]", "tests/test_transforms.py::test_multiprocessing_support[RandomGamma-params45]", "tests/test_transforms.py::test_multiprocessing_support[RandomRain-params47]", "tests/test_transforms.py::test_multiprocessing_support[RandomResizedCrop-params48]", "tests/test_transforms.py::test_multiprocessing_support[RandomRotate90-params49]", "tests/test_transforms.py::test_multiprocessing_support[RandomScale-params50]", "tests/test_transforms.py::test_multiprocessing_support[RandomShadow-params51]", "tests/test_transforms.py::test_multiprocessing_support[RandomSizedCrop-params52]", "tests/test_transforms.py::test_multiprocessing_support[RandomSnow-params53]", "tests/test_transforms.py::test_multiprocessing_support[RandomSunFlare-params54]", "tests/test_transforms.py::test_multiprocessing_support[RandomToneCurve-params55]", "tests/test_transforms.py::test_multiprocessing_support[Resize-params56]", "tests/test_transforms.py::test_multiprocessing_support[RingingOvershoot-params57]", "tests/test_transforms.py::test_multiprocessing_support[Rotate-params58]", "tests/test_transforms.py::test_multiprocessing_support[SafeRotate-params59]", "tests/test_transforms.py::test_multiprocessing_support[Sharpen-params60]", "tests/test_transforms.py::test_multiprocessing_support[ShiftScaleRotate-params61]", "tests/test_transforms.py::test_multiprocessing_support[SmallestMaxSize-params62]", "tests/test_transforms.py::test_multiprocessing_support[Solarize-params63]", "tests/test_transforms.py::test_multiprocessing_support[Superpixels-params64]", "tests/test_transforms.py::test_multiprocessing_support[TemplateTransform-params65]", "tests/test_transforms.py::test_multiprocessing_support[ToFloat-params66]", "tests/test_transforms.py::test_multiprocessing_support[ToGray-params67]", "tests/test_transforms.py::test_multiprocessing_support[ToSepia-params68]", "tests/test_transforms.py::test_multiprocessing_support[Transpose-params69]", "tests/test_transforms.py::test_multiprocessing_support[UnsharpMask-params70]", "tests/test_transforms.py::test_multiprocessing_support[VerticalFlip-params71]", "tests/test_transforms.py::test_force_apply", "tests/test_transforms.py::test_additional_targets_for_image_only[AdvancedBlur-params0]", "tests/test_transforms.py::test_additional_targets_for_image_only[Blur-params1]", "tests/test_transforms.py::test_additional_targets_for_image_only[CLAHE-params2]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelDropout-params3]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelShuffle-params4]", "tests/test_transforms.py::test_additional_targets_for_image_only[ColorJitter-params5]", "tests/test_transforms.py::test_additional_targets_for_image_only[Downscale-params6]", "tests/test_transforms.py::test_additional_targets_for_image_only[Emboss-params7]", "tests/test_transforms.py::test_additional_targets_for_image_only[Equalize-params8]", "tests/test_transforms.py::test_additional_targets_for_image_only[FDA-params9]", "tests/test_transforms.py::test_additional_targets_for_image_only[FancyPCA-params10]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussNoise-params12]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussianBlur-params13]", "tests/test_transforms.py::test_additional_targets_for_image_only[GlassBlur-params14]", "tests/test_transforms.py::test_additional_targets_for_image_only[HistogramMatching-params15]", "tests/test_transforms.py::test_additional_targets_for_image_only[HueSaturationValue-params16]", "tests/test_transforms.py::test_additional_targets_for_image_only[ISONoise-params17]", "tests/test_transforms.py::test_additional_targets_for_image_only[ImageCompression-params18]", "tests/test_transforms.py::test_additional_targets_for_image_only[InvertImg-params19]", "tests/test_transforms.py::test_additional_targets_for_image_only[MedianBlur-params20]", "tests/test_transforms.py::test_additional_targets_for_image_only[MotionBlur-params21]", "tests/test_transforms.py::test_additional_targets_for_image_only[MultiplicativeNoise-params22]", "tests/test_transforms.py::test_additional_targets_for_image_only[Normalize-params23]", "tests/test_transforms.py::test_additional_targets_for_image_only[PixelDistributionAdaptation-params24]", "tests/test_transforms.py::test_additional_targets_for_image_only[Posterize-params25]", "tests/test_transforms.py::test_additional_targets_for_image_only[RGBShift-params26]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomBrightnessContrast-params27]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomFog-params28]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomGamma-params29]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomRain-params30]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomShadow-params31]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSnow-params32]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSunFlare-params33]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomToneCurve-params34]", "tests/test_transforms.py::test_additional_targets_for_image_only[RingingOvershoot-params35]", "tests/test_transforms.py::test_additional_targets_for_image_only[Sharpen-params36]", "tests/test_transforms.py::test_additional_targets_for_image_only[Solarize-params37]", "tests/test_transforms.py::test_additional_targets_for_image_only[Superpixels-params38]", "tests/test_transforms.py::test_additional_targets_for_image_only[TemplateTransform-params39]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToFloat-params40]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToGray-params41]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToSepia-params42]", "tests/test_transforms.py::test_additional_targets_for_image_only[UnsharpMask-params43]", "tests/test_transforms.py::test_lambda_transform", "tests/test_transforms.py::test_channel_droput", "tests/test_transforms.py::test_equalize", "tests/test_transforms.py::test_crop_non_empty_mask", "tests/test_transforms.py::test_downscale[0]", "tests/test_transforms.py::test_downscale[1]", "tests/test_transforms.py::test_downscale[2]", "tests/test_transforms.py::test_crop_keypoints", "tests/test_transforms.py::test_longest_max_size_keypoints", "tests/test_transforms.py::test_smallest_max_size_keypoints", "tests/test_transforms.py::test_resize_keypoints", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image0]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image1]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image2]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image3]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image0]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image1]", "tests/test_transforms.py::test_mask_dropout", "tests/test_transforms.py::test_grid_dropout_mask[image0]", "tests/test_transforms.py::test_grid_dropout_mask[image1]", "tests/test_transforms.py::test_grid_dropout_params[1e-05-10-10-100-100-50-50]", "tests/test_transforms.py::test_grid_dropout_params[0.9-100-None-200-None-0-0]", "tests/test_transforms.py::test_grid_dropout_params[0.4556-10-20-None-200-0-0]", "tests/test_transforms.py::test_grid_dropout_params[4e-05-None-None-2-100-None-None]", "tests/test_transforms.py::test_gauss_noise_incorrect_var_limit_type", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit3-sigma3-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit4-sigma4-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit5-sigma5-3-0.1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[0.123-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1.321-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-0.234-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1.432-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-0.345-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1.543-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0.456]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1--0.432]", "tests/test_transforms.py::test_shift_scale_separate_shift_x_shift_y", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_perspective_keep_size", "tests/test_transforms.py::test_longest_max_size_list", "tests/test_transforms.py::test_smallest_max_size_list", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform0-image_size0-template_size0]", "tests/test_transforms.py::test_template_transform[0.3-0.5-template_transform1-image_size1-template_size1]", "tests/test_transforms.py::test_template_transform[1.0-0.5-template_transform2-image_size2-template_size2]", "tests/test_transforms.py::test_template_transform[0.5-0.8-template_transform3-image_size3-template_size3]", "tests/test_transforms.py::test_template_transform[0.5-0.2-template_transform4-image_size4-template_size4]", "tests/test_transforms.py::test_template_transform[0.5-0.9-template_transform5-image_size5-template_size5]", "tests/test_transforms.py::test_template_transform[0.5-0.5-None-image_size6-template_size6]", "tests/test_transforms.py::test_template_transform[0.8-0.7-None-image_size7-template_size7]", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform8-image_size8-template_size8]", "tests/test_transforms.py::test_template_transform_incorrect_size", "tests/test_transforms.py::test_template_transform_incorrect_channels[1-3]", "tests/test_transforms.py::test_template_transform_incorrect_channels[6-3]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params0]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params1]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params2]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params3]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params4]", "tests/test_transforms.py::test_affine_scale_ratio[params0]", "tests/test_transforms.py::test_affine_scale_ratio[params1]", "tests/test_transforms.py::test_affine_scale_ratio[params2]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params0]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params1]", "tests/test_transforms.py::test_safe_rotate[-10-targets0-expected0]", "tests/test_transforms.py::test_safe_rotate[10-targets1-expected1]", "tests/test_transforms.py::test_rotate_equal[-360-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-360-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-360-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img2-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes0-expected0-0.9--1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes1-expected1-0.6--1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes1-expected1-0.6--1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes2-expected2-0.9-1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes3-expected3-0.6-1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes3-expected3-0.6-1-<lambda>1]" ]
{ "failed_lite_validators": [], "has_test_patch": true, "is_lite": true }
2022-07-17 13:19:10+00:00
mit
1,010
albumentations-team__albumentations-1239
diff --git a/albumentations/augmentations/transforms.py b/albumentations/augmentations/transforms.py index 1a74dd0..f2e0c18 100644 --- a/albumentations/augmentations/transforms.py +++ b/albumentations/augmentations/transforms.py @@ -1215,6 +1215,8 @@ class MotionBlur(Blur): Args: blur_limit (int): maximum kernel size for blurring the input image. Should be in range [3, inf). Default: (3, 7). + allow_shifted (bool): if set to true creates non shifted kernels only, + otherwise creates randomly shifted kernels. Default: True. p (float): probability of applying the transform. Default: 0.5. Targets: @@ -1224,6 +1226,22 @@ class MotionBlur(Blur): uint8, float32 """ + def __init__( + self, + blur_limit: Union[int, Sequence[int]] = 7, + allow_shifted: bool = True, + always_apply: bool = False, + p: float = 0.5, + ): + super().__init__(blur_limit=blur_limit, always_apply=always_apply, p=p) + self.allow_shifted = allow_shifted + + if not allow_shifted and self.blur_limit[0] % 2 != 1 or self.blur_limit[1] % 2 != 1: + raise ValueError(f"Blur limit must be odd when centered=True. Got: {self.blur_limit}") + + def get_transform_init_args_names(self): + return super().get_transform_init_args_names() + ("allow_shifted",) + def apply(self, img, kernel=None, **params): return F.convolve(img, kernel=kernel) @@ -1232,12 +1250,35 @@ class MotionBlur(Blur): if ksize <= 2: raise ValueError("ksize must be > 2. Got: {}".format(ksize)) kernel = np.zeros((ksize, ksize), dtype=np.uint8) - xs, xe = random.randint(0, ksize - 1), random.randint(0, ksize - 1) - if xs == xe: - ys, ye = random.sample(range(ksize), 2) + x1, x2 = random.randint(0, ksize - 1), random.randint(0, ksize - 1) + if x1 == x2: + y1, y2 = random.sample(range(ksize), 2) else: - ys, ye = random.randint(0, ksize - 1), random.randint(0, ksize - 1) - cv2.line(kernel, (xs, ys), (xe, ye), 1, thickness=1) + y1, y2 = random.randint(0, ksize - 1), random.randint(0, ksize - 1) + + def make_odd_val(v1, v2): + len_v = abs(v1 - v2) + 1 + if len_v % 2 != 1: + if v2 > v1: + v2 -= 1 + else: + v1 -= 1 + return v1, v2 + + if not self.allow_shifted: + x1, x2 = make_odd_val(x1, x2) + y1, y2 = make_odd_val(y1, y2) + + xc = (x1 + x2) / 2 + yc = (y1 + y2) / 2 + + center = ksize / 2 - 0.5 + dx = xc - center + dy = yc - center + x1, x2 = [int(i - dx) for i in [x1, x2]] + y1, y2 = [int(i - dy) for i in [y1, y2]] + + cv2.line(kernel, (x1, y1), (x2, y2), 1, thickness=1) # Normalize kernel kernel = kernel.astype(np.float32) / np.sum(kernel)
albumentations-team/albumentations
8e958a324cb35d3adf13c03b180b3dc066ef21d5
diff --git a/tests/test_transforms.py b/tests/test_transforms.py index 7b02c0f..d2598f0 100644 --- a/tests/test_transforms.py +++ b/tests/test_transforms.py @@ -1223,3 +1223,31 @@ def test_bbox_clipping_perspective(): bboxes = np.array([[0, 0, 100, 100, 1]]) res = transform(image=image, bboxes=bboxes)["bboxes"] assert len(res) == 0 + + [email protected]("seed", [i for i in range(10)]) +def test_motion_blur_allow_shifted(seed): + random.seed(seed) + + transform = A.MotionBlur(allow_shifted=False) + kernel = transform.get_params()["kernel"] + + center = kernel.shape[0] / 2 - 0.5 + + def check_center(vector): + start = None + end = None + + for i, v in enumerate(vector): + if start is None and v != 0: + start = i + elif start is not None and v == 0: + end = i + break + if end is None: + end = len(vector) + + assert (end + start - 1) / 2 == center + + check_center(kernel.sum(axis=0)) + check_center(kernel.sum(axis=1))
motion blur sometimes causes shift https://github.com/albumentations-team/albumentations/blob/a8dc46ee29f9573c8569213f0d243254980b02f1/albumentations/augmentations/transforms.py#L1695-L1709 When calculating the blur kernel for MotionBlur the line is randomly situated inside the kernel, and not forced to pass through the center. This means that when convolving with such a kernel a shift happens in addition to blurring. I assume it is not intended behavior, and should be fixed. If it is intended, i think you should at least add a flag that will allow users to force a non-shifting kernel (i.e. with a line passing through the center) note that to enforce a non shifting kernel you should also force the kernel size to be odd (which is not enforced right now!). Here are images of kernels generated using the above function with version 1.2.1: <img width="418" alt="image" src="https://user-images.githubusercontent.com/50834050/180171487-e612f799-40a0-469a-a487-e7941406850e.png"> <img width="424" alt="image" src="https://user-images.githubusercontent.com/50834050/180171582-35118852-24c7-4d98-9e4e-38f7fd1c4521.png"> <img width="432" alt="image" src="https://user-images.githubusercontent.com/50834050/180171634-455d5b7c-625f-48c5-8ec7-d7216902942f.png"> <img width="415" alt="image" src="https://user-images.githubusercontent.com/50834050/180171840-4471e337-0e81-4d0e-bce5-e72f9d3ac53c.png"> All of these kernels will cause a shift in the image.
0.0
8e958a324cb35d3adf13c03b180b3dc066ef21d5
[ "tests/test_transforms.py::test_motion_blur_allow_shifted[0]", "tests/test_transforms.py::test_motion_blur_allow_shifted[1]", "tests/test_transforms.py::test_motion_blur_allow_shifted[2]", "tests/test_transforms.py::test_motion_blur_allow_shifted[3]", "tests/test_transforms.py::test_motion_blur_allow_shifted[4]", "tests/test_transforms.py::test_motion_blur_allow_shifted[5]", "tests/test_transforms.py::test_motion_blur_allow_shifted[6]", "tests/test_transforms.py::test_motion_blur_allow_shifted[7]", "tests/test_transforms.py::test_motion_blur_allow_shifted[8]", "tests/test_transforms.py::test_motion_blur_allow_shifted[9]" ]
[ "tests/test_transforms.py::test_transpose_both_image_and_mask", "tests/test_transforms.py::test_rotate_interpolation[0]", "tests/test_transforms.py::test_rotate_interpolation[1]", "tests/test_transforms.py::test_rotate_interpolation[2]", "tests/test_transforms.py::test_rotate_crop_border", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[0]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[1]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[2]", "tests/test_transforms.py::test_optical_distortion_interpolation[0]", "tests/test_transforms.py::test_optical_distortion_interpolation[1]", "tests/test_transforms.py::test_optical_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_interpolation[0]", "tests/test_transforms.py::test_grid_distortion_interpolation[1]", "tests/test_transforms.py::test_grid_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_steps[17]", "tests/test_transforms.py::test_grid_distortion_steps[21]", "tests/test_transforms.py::test_grid_distortion_steps[33]", "tests/test_transforms.py::test_elastic_transform_interpolation[0]", "tests/test_transforms.py::test_elastic_transform_interpolation[1]", "tests/test_transforms.py::test_elastic_transform_interpolation[2]", "tests/test_transforms.py::test_binary_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_binary_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_binary_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_binary_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_binary_mask_interpolation[CropAndPad-params4]", "tests/test_transforms.py::test_binary_mask_interpolation[CropNonEmptyMaskIfExists-params5]", "tests/test_transforms.py::test_binary_mask_interpolation[ElasticTransform-params6]", "tests/test_transforms.py::test_binary_mask_interpolation[Flip-params7]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDistortion-params8]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDropout-params9]", "tests/test_transforms.py::test_binary_mask_interpolation[HorizontalFlip-params10]", "tests/test_transforms.py::test_binary_mask_interpolation[Lambda-params11]", "tests/test_transforms.py::test_binary_mask_interpolation[LongestMaxSize-params12]", "tests/test_transforms.py::test_binary_mask_interpolation[MaskDropout-params13]", "tests/test_transforms.py::test_binary_mask_interpolation[NoOp-params14]", "tests/test_transforms.py::test_binary_mask_interpolation[OpticalDistortion-params15]", "tests/test_transforms.py::test_binary_mask_interpolation[PadIfNeeded-params16]", "tests/test_transforms.py::test_binary_mask_interpolation[Perspective-params17]", "tests/test_transforms.py::test_binary_mask_interpolation[PiecewiseAffine-params18]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomCrop-params19]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomResizedCrop-params21]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomRotate90-params22]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomScale-params23]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomSizedCrop-params24]", "tests/test_transforms.py::test_binary_mask_interpolation[Resize-params25]", "tests/test_transforms.py::test_binary_mask_interpolation[Rotate-params26]", "tests/test_transforms.py::test_binary_mask_interpolation[SafeRotate-params27]", "tests/test_transforms.py::test_binary_mask_interpolation[ShiftScaleRotate-params28]", "tests/test_transforms.py::test_binary_mask_interpolation[SmallestMaxSize-params29]", "tests/test_transforms.py::test_binary_mask_interpolation[Transpose-params30]", "tests/test_transforms.py::test_binary_mask_interpolation[VerticalFlip-params31]", "tests/test_transforms.py::test_semantic_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_semantic_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_semantic_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_semantic_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_semantic_mask_interpolation[CropNonEmptyMaskIfExists-params4]", "tests/test_transforms.py::test_semantic_mask_interpolation[ElasticTransform-params5]", "tests/test_transforms.py::test_semantic_mask_interpolation[Flip-params6]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDistortion-params7]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDropout-params8]", "tests/test_transforms.py::test_semantic_mask_interpolation[HorizontalFlip-params9]", "tests/test_transforms.py::test_semantic_mask_interpolation[Lambda-params10]", "tests/test_transforms.py::test_semantic_mask_interpolation[LongestMaxSize-params11]", "tests/test_transforms.py::test_semantic_mask_interpolation[MaskDropout-params12]", "tests/test_transforms.py::test_semantic_mask_interpolation[NoOp-params13]", "tests/test_transforms.py::test_semantic_mask_interpolation[OpticalDistortion-params14]", "tests/test_transforms.py::test_semantic_mask_interpolation[PadIfNeeded-params15]", "tests/test_transforms.py::test_semantic_mask_interpolation[Perspective-params16]", "tests/test_transforms.py::test_semantic_mask_interpolation[PiecewiseAffine-params17]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomCrop-params18]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomResizedCrop-params20]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomRotate90-params21]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomScale-params22]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomSizedCrop-params23]", "tests/test_transforms.py::test_semantic_mask_interpolation[Resize-params24]", "tests/test_transforms.py::test_semantic_mask_interpolation[Rotate-params25]", "tests/test_transforms.py::test_semantic_mask_interpolation[SafeRotate-params26]", "tests/test_transforms.py::test_semantic_mask_interpolation[ShiftScaleRotate-params27]", "tests/test_transforms.py::test_semantic_mask_interpolation[SmallestMaxSize-params28]", "tests/test_transforms.py::test_semantic_mask_interpolation[Transpose-params29]", "tests/test_transforms.py::test_semantic_mask_interpolation[VerticalFlip-params30]", "tests/test_transforms.py::test_multiprocessing_support[AdvancedBlur-params0]", "tests/test_transforms.py::test_multiprocessing_support[Affine-params1]", "tests/test_transforms.py::test_multiprocessing_support[Blur-params2]", "tests/test_transforms.py::test_multiprocessing_support[CLAHE-params3]", "tests/test_transforms.py::test_multiprocessing_support[CenterCrop-params4]", "tests/test_transforms.py::test_multiprocessing_support[ChannelDropout-params5]", "tests/test_transforms.py::test_multiprocessing_support[ChannelShuffle-params6]", "tests/test_transforms.py::test_multiprocessing_support[CoarseDropout-params7]", "tests/test_transforms.py::test_multiprocessing_support[ColorJitter-params8]", "tests/test_transforms.py::test_multiprocessing_support[Crop-params9]", "tests/test_transforms.py::test_multiprocessing_support[CropAndPad-params10]", "tests/test_transforms.py::test_multiprocessing_support[Downscale-params11]", "tests/test_transforms.py::test_multiprocessing_support[ElasticTransform-params12]", "tests/test_transforms.py::test_multiprocessing_support[Emboss-params13]", "tests/test_transforms.py::test_multiprocessing_support[Equalize-params14]", "tests/test_transforms.py::test_multiprocessing_support[FancyPCA-params15]", "tests/test_transforms.py::test_multiprocessing_support[Flip-params16]", "tests/test_transforms.py::test_multiprocessing_support[GaussNoise-params18]", "tests/test_transforms.py::test_multiprocessing_support[GaussianBlur-params19]", "tests/test_transforms.py::test_multiprocessing_support[GlassBlur-params20]", "tests/test_transforms.py::test_multiprocessing_support[GridDistortion-params21]", "tests/test_transforms.py::test_multiprocessing_support[GridDropout-params22]", "tests/test_transforms.py::test_multiprocessing_support[HorizontalFlip-params23]", "tests/test_transforms.py::test_multiprocessing_support[HueSaturationValue-params24]", "tests/test_transforms.py::test_multiprocessing_support[ISONoise-params25]", "tests/test_transforms.py::test_multiprocessing_support[ImageCompression-params26]", "tests/test_transforms.py::test_multiprocessing_support[InvertImg-params27]", "tests/test_transforms.py::test_multiprocessing_support[Lambda-params28]", "tests/test_transforms.py::test_multiprocessing_support[LongestMaxSize-params29]", "tests/test_transforms.py::test_multiprocessing_support[MedianBlur-params30]", "tests/test_transforms.py::test_multiprocessing_support[MotionBlur-params31]", "tests/test_transforms.py::test_multiprocessing_support[MultiplicativeNoise-params32]", "tests/test_transforms.py::test_multiprocessing_support[NoOp-params33]", "tests/test_transforms.py::test_multiprocessing_support[Normalize-params34]", "tests/test_transforms.py::test_multiprocessing_support[OpticalDistortion-params35]", "tests/test_transforms.py::test_multiprocessing_support[PadIfNeeded-params36]", "tests/test_transforms.py::test_multiprocessing_support[Perspective-params37]", "tests/test_transforms.py::test_multiprocessing_support[PiecewiseAffine-params38]", "tests/test_transforms.py::test_multiprocessing_support[PixelDropout-params39]", "tests/test_transforms.py::test_multiprocessing_support[Posterize-params40]", "tests/test_transforms.py::test_multiprocessing_support[RGBShift-params41]", "tests/test_transforms.py::test_multiprocessing_support[RandomBrightnessContrast-params42]", "tests/test_transforms.py::test_multiprocessing_support[RandomCrop-params43]", "tests/test_transforms.py::test_multiprocessing_support[RandomFog-params44]", "tests/test_transforms.py::test_multiprocessing_support[RandomGamma-params45]", "tests/test_transforms.py::test_multiprocessing_support[RandomRain-params47]", "tests/test_transforms.py::test_multiprocessing_support[RandomResizedCrop-params48]", "tests/test_transforms.py::test_multiprocessing_support[RandomRotate90-params49]", "tests/test_transforms.py::test_multiprocessing_support[RandomScale-params50]", "tests/test_transforms.py::test_multiprocessing_support[RandomShadow-params51]", "tests/test_transforms.py::test_multiprocessing_support[RandomSizedCrop-params52]", "tests/test_transforms.py::test_multiprocessing_support[RandomSnow-params53]", "tests/test_transforms.py::test_multiprocessing_support[RandomSunFlare-params54]", "tests/test_transforms.py::test_multiprocessing_support[RandomToneCurve-params55]", "tests/test_transforms.py::test_multiprocessing_support[Resize-params56]", "tests/test_transforms.py::test_multiprocessing_support[RingingOvershoot-params57]", "tests/test_transforms.py::test_multiprocessing_support[Rotate-params58]", "tests/test_transforms.py::test_multiprocessing_support[SafeRotate-params59]", "tests/test_transforms.py::test_multiprocessing_support[Sharpen-params60]", "tests/test_transforms.py::test_multiprocessing_support[ShiftScaleRotate-params61]", "tests/test_transforms.py::test_multiprocessing_support[SmallestMaxSize-params62]", "tests/test_transforms.py::test_multiprocessing_support[Solarize-params63]", "tests/test_transforms.py::test_multiprocessing_support[Superpixels-params64]", "tests/test_transforms.py::test_multiprocessing_support[TemplateTransform-params65]", "tests/test_transforms.py::test_multiprocessing_support[ToFloat-params66]", "tests/test_transforms.py::test_multiprocessing_support[ToGray-params67]", "tests/test_transforms.py::test_multiprocessing_support[ToSepia-params68]", "tests/test_transforms.py::test_multiprocessing_support[Transpose-params69]", "tests/test_transforms.py::test_multiprocessing_support[UnsharpMask-params70]", "tests/test_transforms.py::test_multiprocessing_support[VerticalFlip-params71]", "tests/test_transforms.py::test_force_apply", "tests/test_transforms.py::test_additional_targets_for_image_only[AdvancedBlur-params0]", "tests/test_transforms.py::test_additional_targets_for_image_only[Blur-params1]", "tests/test_transforms.py::test_additional_targets_for_image_only[CLAHE-params2]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelDropout-params3]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelShuffle-params4]", "tests/test_transforms.py::test_additional_targets_for_image_only[ColorJitter-params5]", "tests/test_transforms.py::test_additional_targets_for_image_only[Downscale-params6]", "tests/test_transforms.py::test_additional_targets_for_image_only[Emboss-params7]", "tests/test_transforms.py::test_additional_targets_for_image_only[Equalize-params8]", "tests/test_transforms.py::test_additional_targets_for_image_only[FDA-params9]", "tests/test_transforms.py::test_additional_targets_for_image_only[FancyPCA-params10]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussNoise-params12]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussianBlur-params13]", "tests/test_transforms.py::test_additional_targets_for_image_only[GlassBlur-params14]", "tests/test_transforms.py::test_additional_targets_for_image_only[HistogramMatching-params15]", "tests/test_transforms.py::test_additional_targets_for_image_only[HueSaturationValue-params16]", "tests/test_transforms.py::test_additional_targets_for_image_only[ISONoise-params17]", "tests/test_transforms.py::test_additional_targets_for_image_only[ImageCompression-params18]", "tests/test_transforms.py::test_additional_targets_for_image_only[InvertImg-params19]", "tests/test_transforms.py::test_additional_targets_for_image_only[MedianBlur-params20]", "tests/test_transforms.py::test_additional_targets_for_image_only[MotionBlur-params21]", "tests/test_transforms.py::test_additional_targets_for_image_only[MultiplicativeNoise-params22]", "tests/test_transforms.py::test_additional_targets_for_image_only[Normalize-params23]", "tests/test_transforms.py::test_additional_targets_for_image_only[PixelDistributionAdaptation-params24]", "tests/test_transforms.py::test_additional_targets_for_image_only[Posterize-params25]", "tests/test_transforms.py::test_additional_targets_for_image_only[RGBShift-params26]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomBrightnessContrast-params27]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomFog-params28]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomGamma-params29]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomRain-params30]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomShadow-params31]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSnow-params32]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSunFlare-params33]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomToneCurve-params34]", "tests/test_transforms.py::test_additional_targets_for_image_only[RingingOvershoot-params35]", "tests/test_transforms.py::test_additional_targets_for_image_only[Sharpen-params36]", "tests/test_transforms.py::test_additional_targets_for_image_only[Solarize-params37]", "tests/test_transforms.py::test_additional_targets_for_image_only[Superpixels-params38]", "tests/test_transforms.py::test_additional_targets_for_image_only[TemplateTransform-params39]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToFloat-params40]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToGray-params41]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToSepia-params42]", "tests/test_transforms.py::test_additional_targets_for_image_only[UnsharpMask-params43]", "tests/test_transforms.py::test_lambda_transform", "tests/test_transforms.py::test_channel_droput", "tests/test_transforms.py::test_equalize", "tests/test_transforms.py::test_crop_non_empty_mask", "tests/test_transforms.py::test_downscale[0]", "tests/test_transforms.py::test_downscale[1]", "tests/test_transforms.py::test_downscale[2]", "tests/test_transforms.py::test_crop_keypoints", "tests/test_transforms.py::test_longest_max_size_keypoints", "tests/test_transforms.py::test_smallest_max_size_keypoints", "tests/test_transforms.py::test_resize_keypoints", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image0]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image1]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image2]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image3]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image0]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image1]", "tests/test_transforms.py::test_mask_dropout", "tests/test_transforms.py::test_grid_dropout_mask[image0]", "tests/test_transforms.py::test_grid_dropout_mask[image1]", "tests/test_transforms.py::test_grid_dropout_params[1e-05-10-10-100-100-50-50]", "tests/test_transforms.py::test_grid_dropout_params[0.9-100-None-200-None-0-0]", "tests/test_transforms.py::test_grid_dropout_params[0.4556-10-20-None-200-0-0]", "tests/test_transforms.py::test_grid_dropout_params[4e-05-None-None-2-100-None-None]", "tests/test_transforms.py::test_gauss_noise_incorrect_var_limit_type", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit3-sigma3-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit4-sigma4-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit5-sigma5-3-0.1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[0.123-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1.321-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-0.234-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1.432-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-0.345-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1.543-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0.456]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1--0.432]", "tests/test_transforms.py::test_shift_scale_separate_shift_x_shift_y", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_perspective_keep_size", "tests/test_transforms.py::test_longest_max_size_list", "tests/test_transforms.py::test_smallest_max_size_list", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform0-image_size0-template_size0]", "tests/test_transforms.py::test_template_transform[0.3-0.5-template_transform1-image_size1-template_size1]", "tests/test_transforms.py::test_template_transform[1.0-0.5-template_transform2-image_size2-template_size2]", "tests/test_transforms.py::test_template_transform[0.5-0.8-template_transform3-image_size3-template_size3]", "tests/test_transforms.py::test_template_transform[0.5-0.2-template_transform4-image_size4-template_size4]", "tests/test_transforms.py::test_template_transform[0.5-0.9-template_transform5-image_size5-template_size5]", "tests/test_transforms.py::test_template_transform[0.5-0.5-None-image_size6-template_size6]", "tests/test_transforms.py::test_template_transform[0.8-0.7-None-image_size7-template_size7]", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform8-image_size8-template_size8]", "tests/test_transforms.py::test_template_transform_incorrect_size", "tests/test_transforms.py::test_template_transform_incorrect_channels[1-3]", "tests/test_transforms.py::test_template_transform_incorrect_channels[6-3]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params0]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params1]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params2]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params3]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params4]", "tests/test_transforms.py::test_affine_scale_ratio[params0]", "tests/test_transforms.py::test_affine_scale_ratio[params1]", "tests/test_transforms.py::test_affine_scale_ratio[params2]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params0]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params1]", "tests/test_transforms.py::test_safe_rotate[-10-targets0-expected0]", "tests/test_transforms.py::test_safe_rotate[10-targets1-expected1]", "tests/test_transforms.py::test_rotate_equal[-360-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-360-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-360-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img2-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes0-expected0-0.9--1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes0-expected0-0.9--1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes1-expected1-0.6--1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes1-expected1-0.6--1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes2-expected2-0.9-1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes2-expected2-0.9-1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes3-expected3-0.6-1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes3-expected3-0.6-1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping_perspective" ]
{ "failed_lite_validators": [ "has_hyperlinks", "has_media" ], "has_test_patch": true, "is_lite": false }
2022-07-29 08:12:47+00:00
mit
1,011
albumentations-team__albumentations-1305
diff --git a/albumentations/augmentations/transforms.py b/albumentations/augmentations/transforms.py index fd9b039..a360f61 100644 --- a/albumentations/augmentations/transforms.py +++ b/albumentations/augmentations/transforms.py @@ -2391,6 +2391,10 @@ class Spatter(ImageOnlyTransform): If tuple of float intensity will be sampled from range `[intensity[0], intensity[1])`. Default: (0.6). mode (string, or list of strings): Type of corruption. Currently, supported options are 'rain' and 'mud'. If list is provided type of corruption will be sampled list. Default: ("rain"). + color (list of (r, g, b) or dict or None): Corruption elements color. + If list uses provided list as color for specified mode. + If dict uses provided color for specified mode. Color for each specified mode should be provided in dict. + If None uses default colors (rain: (238, 238, 175), mud: (20, 42, 63)). p (float): probability of applying the transform. Default: 0.5. Targets: @@ -2412,6 +2416,7 @@ class Spatter(ImageOnlyTransform): cutout_threshold: ScaleFloatType = 0.68, intensity: ScaleFloatType = 0.6, mode: Union[str, Sequence[str]] = "rain", + color: Optional[Union[Sequence[int], Dict[str, Sequence[int]]]] = None, always_apply: bool = False, p: float = 0.5, ): @@ -2422,10 +2427,34 @@ class Spatter(ImageOnlyTransform): self.gauss_sigma = to_tuple(gauss_sigma, gauss_sigma) self.intensity = to_tuple(intensity, intensity) self.cutout_threshold = to_tuple(cutout_threshold, cutout_threshold) + self.color = ( + color + if color is not None + else { + "rain": [238, 238, 175], + "mud": [20, 42, 63], + } + ) self.mode = mode if isinstance(mode, (list, tuple)) else [mode] + + if len(set(self.mode)) > 1 and not isinstance(self.color, dict): + raise ValueError(f"Unsupported color: {self.color}. Please specify color for each mode (use dict for it).") + for i in self.mode: if i not in ["rain", "mud"]: raise ValueError(f"Unsupported color mode: {mode}. Transform supports only `rain` and `mud` mods.") + if isinstance(self.color, dict): + if i not in self.color: + raise ValueError(f"Wrong color definition: {self.color}. Color for mode: {i} not specified.") + if len(self.color[i]) != 3: + raise ValueError( + f"Unsupported color: {self.color[i]} for mode {i}. Color should be presented in RGB format." + ) + + if isinstance(self.color, (list, tuple)): + if len(self.color) != 3: + raise ValueError(f"Unsupported color: {self.color}. Color should be presented in RGB format.") + self.color = {self.mode[0]: self.color} def apply( self, @@ -2451,6 +2480,7 @@ class Spatter(ImageOnlyTransform): sigma = random.uniform(self.gauss_sigma[0], self.gauss_sigma[1]) mode = random.choice(self.mode) intensity = random.uniform(self.intensity[0], self.intensity[1]) + color = np.array(self.color[mode]) / 255.0 liquid_layer = random_utils.normal(size=(h, w), loc=mean, scale=std) liquid_layer = gaussian_filter(liquid_layer, sigma=sigma, mode="nearest") @@ -2471,7 +2501,7 @@ class Spatter(ImageOnlyTransform): m = liquid_layer * dist m *= 1 / np.max(m, axis=(0, 1)) - drops = m[:, :, None] * np.array([238 / 255.0, 238 / 255.0, 175 / 255.0]) * intensity + drops = m[:, :, None] * color * intensity mud = None non_mud = None else: @@ -2479,7 +2509,8 @@ class Spatter(ImageOnlyTransform): m = gaussian_filter(m.astype(np.float32), sigma=sigma, mode="nearest") m[m < 1.2 * cutout_threshold] = 0 m = m[..., np.newaxis] - mud = m * np.array([20 / 255.0, 42 / 255.0, 63 / 255.0]) + + mud = m * color non_mud = 1 - m drops = None @@ -2490,5 +2521,5 @@ class Spatter(ImageOnlyTransform): "mode": mode, } - def get_transform_init_args_names(self) -> Tuple[str, str, str, str, str, str]: - return "mean", "std", "gauss_sigma", "intensity", "cutout_threshold", "mode" + def get_transform_init_args_names(self) -> Tuple[str, str, str, str, str, str, str]: + return "mean", "std", "gauss_sigma", "intensity", "cutout_threshold", "mode", "color"
albumentations-team/albumentations
6c16e391d407849c68b0a964ac3e4458a02205c4
diff --git a/tests/test_transforms.py b/tests/test_transforms.py index 4d697f4..96085e5 100644 --- a/tests/test_transforms.py +++ b/tests/test_transforms.py @@ -1293,3 +1293,31 @@ def test_spatter_incorrect_mode(image): message = f"Unsupported color mode: {unsupported_mode}. Transform supports only `rain` and `mud` mods." assert str(exc_info.value).startswith(message) + + [email protected]( + "unsupported_color,mode,message", + [ + ([255, 255], "rain", "Unsupported color: [255, 255]. Color should be presented in RGB format."), + ( + {"rain": [255, 255, 255]}, + "mud", + "Wrong color definition: {'rain': [255, 255, 255]}. Color for mode: mud not specified.", + ), + ( + {"rain": [255, 255]}, + "rain", + "Unsupported color: [255, 255] for mode rain. Color should be presented in RGB format.", + ), + ( + [255, 255, 255], + ["rain", "mud"], + "Unsupported color: [255, 255, 255]. Please specify color for each mode (use dict for it).", + ), + ], +) +def test_spatter_incorrect_color(unsupported_color, mode, message): + with pytest.raises(ValueError) as exc_info: + A.Spatter(mode=mode, color=unsupported_color) + + assert str(exc_info.value).startswith(message)
Цвет тумана у Spatter()-а Хорошо бы иметь возможность задавать цвет "тумана" https://github.com/albumentations-team/albumentations/blob/master/albumentations/augmentations/transforms.py#L2482 .
0.0
6c16e391d407849c68b0a964ac3e4458a02205c4
[ "tests/test_transforms.py::test_spatter_incorrect_color[unsupported_color0-rain-Unsupported", "tests/test_transforms.py::test_spatter_incorrect_color[unsupported_color1-mud-Wrong", "tests/test_transforms.py::test_spatter_incorrect_color[unsupported_color2-rain-Unsupported", "tests/test_transforms.py::test_spatter_incorrect_color[unsupported_color3-mode3-Unsupported" ]
[ "tests/test_transforms.py::test_transpose_both_image_and_mask", "tests/test_transforms.py::test_rotate_interpolation[0]", "tests/test_transforms.py::test_rotate_interpolation[1]", "tests/test_transforms.py::test_rotate_interpolation[2]", "tests/test_transforms.py::test_rotate_crop_border", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[0]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[1]", "tests/test_transforms.py::test_shift_scale_rotate_interpolation[2]", "tests/test_transforms.py::test_optical_distortion_interpolation[0]", "tests/test_transforms.py::test_optical_distortion_interpolation[1]", "tests/test_transforms.py::test_optical_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_interpolation[0]", "tests/test_transforms.py::test_grid_distortion_interpolation[1]", "tests/test_transforms.py::test_grid_distortion_interpolation[2]", "tests/test_transforms.py::test_grid_distortion_steps[17]", "tests/test_transforms.py::test_grid_distortion_steps[21]", "tests/test_transforms.py::test_grid_distortion_steps[33]", "tests/test_transforms.py::test_elastic_transform_interpolation[0]", "tests/test_transforms.py::test_elastic_transform_interpolation[1]", "tests/test_transforms.py::test_elastic_transform_interpolation[2]", "tests/test_transforms.py::test_binary_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_binary_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_binary_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_binary_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_binary_mask_interpolation[CropAndPad-params4]", "tests/test_transforms.py::test_binary_mask_interpolation[CropNonEmptyMaskIfExists-params5]", "tests/test_transforms.py::test_binary_mask_interpolation[ElasticTransform-params6]", "tests/test_transforms.py::test_binary_mask_interpolation[Flip-params7]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDistortion-params8]", "tests/test_transforms.py::test_binary_mask_interpolation[GridDropout-params9]", "tests/test_transforms.py::test_binary_mask_interpolation[HorizontalFlip-params10]", "tests/test_transforms.py::test_binary_mask_interpolation[Lambda-params11]", "tests/test_transforms.py::test_binary_mask_interpolation[LongestMaxSize-params12]", "tests/test_transforms.py::test_binary_mask_interpolation[MaskDropout-params13]", "tests/test_transforms.py::test_binary_mask_interpolation[NoOp-params14]", "tests/test_transforms.py::test_binary_mask_interpolation[OpticalDistortion-params15]", "tests/test_transforms.py::test_binary_mask_interpolation[PadIfNeeded-params16]", "tests/test_transforms.py::test_binary_mask_interpolation[Perspective-params17]", "tests/test_transforms.py::test_binary_mask_interpolation[PiecewiseAffine-params18]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomCrop-params19]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomCropFromBorders-params20]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomResizedCrop-params22]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomRotate90-params23]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomScale-params24]", "tests/test_transforms.py::test_binary_mask_interpolation[RandomSizedCrop-params25]", "tests/test_transforms.py::test_binary_mask_interpolation[Resize-params26]", "tests/test_transforms.py::test_binary_mask_interpolation[Rotate-params27]", "tests/test_transforms.py::test_binary_mask_interpolation[SafeRotate-params28]", "tests/test_transforms.py::test_binary_mask_interpolation[ShiftScaleRotate-params29]", "tests/test_transforms.py::test_binary_mask_interpolation[SmallestMaxSize-params30]", "tests/test_transforms.py::test_binary_mask_interpolation[Transpose-params31]", "tests/test_transforms.py::test_binary_mask_interpolation[VerticalFlip-params32]", "tests/test_transforms.py::test_semantic_mask_interpolation[Affine-params0]", "tests/test_transforms.py::test_semantic_mask_interpolation[CenterCrop-params1]", "tests/test_transforms.py::test_semantic_mask_interpolation[CoarseDropout-params2]", "tests/test_transforms.py::test_semantic_mask_interpolation[Crop-params3]", "tests/test_transforms.py::test_semantic_mask_interpolation[CropNonEmptyMaskIfExists-params4]", "tests/test_transforms.py::test_semantic_mask_interpolation[ElasticTransform-params5]", "tests/test_transforms.py::test_semantic_mask_interpolation[Flip-params6]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDistortion-params7]", "tests/test_transforms.py::test_semantic_mask_interpolation[GridDropout-params8]", "tests/test_transforms.py::test_semantic_mask_interpolation[HorizontalFlip-params9]", "tests/test_transforms.py::test_semantic_mask_interpolation[Lambda-params10]", "tests/test_transforms.py::test_semantic_mask_interpolation[LongestMaxSize-params11]", "tests/test_transforms.py::test_semantic_mask_interpolation[MaskDropout-params12]", "tests/test_transforms.py::test_semantic_mask_interpolation[NoOp-params13]", "tests/test_transforms.py::test_semantic_mask_interpolation[OpticalDistortion-params14]", "tests/test_transforms.py::test_semantic_mask_interpolation[PadIfNeeded-params15]", "tests/test_transforms.py::test_semantic_mask_interpolation[Perspective-params16]", "tests/test_transforms.py::test_semantic_mask_interpolation[PiecewiseAffine-params17]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomCrop-params18]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomCropFromBorders-params19]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomResizedCrop-params21]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomRotate90-params22]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomScale-params23]", "tests/test_transforms.py::test_semantic_mask_interpolation[RandomSizedCrop-params24]", "tests/test_transforms.py::test_semantic_mask_interpolation[Resize-params25]", "tests/test_transforms.py::test_semantic_mask_interpolation[Rotate-params26]", "tests/test_transforms.py::test_semantic_mask_interpolation[SafeRotate-params27]", "tests/test_transforms.py::test_semantic_mask_interpolation[ShiftScaleRotate-params28]", "tests/test_transforms.py::test_semantic_mask_interpolation[SmallestMaxSize-params29]", "tests/test_transforms.py::test_semantic_mask_interpolation[Transpose-params30]", "tests/test_transforms.py::test_semantic_mask_interpolation[VerticalFlip-params31]", "tests/test_transforms.py::test_multiprocessing_support[AdvancedBlur-params0]", "tests/test_transforms.py::test_multiprocessing_support[Affine-params1]", "tests/test_transforms.py::test_multiprocessing_support[Blur-params2]", "tests/test_transforms.py::test_multiprocessing_support[CLAHE-params3]", "tests/test_transforms.py::test_multiprocessing_support[CenterCrop-params4]", "tests/test_transforms.py::test_multiprocessing_support[ChannelDropout-params5]", "tests/test_transforms.py::test_multiprocessing_support[ChannelShuffle-params6]", "tests/test_transforms.py::test_multiprocessing_support[CoarseDropout-params7]", "tests/test_transforms.py::test_multiprocessing_support[ColorJitter-params8]", "tests/test_transforms.py::test_multiprocessing_support[Crop-params9]", "tests/test_transforms.py::test_multiprocessing_support[CropAndPad-params10]", "tests/test_transforms.py::test_multiprocessing_support[Defocus-params11]", "tests/test_transforms.py::test_multiprocessing_support[Downscale-params12]", "tests/test_transforms.py::test_multiprocessing_support[ElasticTransform-params13]", "tests/test_transforms.py::test_multiprocessing_support[Emboss-params14]", "tests/test_transforms.py::test_multiprocessing_support[Equalize-params15]", "tests/test_transforms.py::test_multiprocessing_support[FancyPCA-params16]", "tests/test_transforms.py::test_multiprocessing_support[Flip-params17]", "tests/test_transforms.py::test_multiprocessing_support[GaussNoise-params19]", "tests/test_transforms.py::test_multiprocessing_support[GaussianBlur-params20]", "tests/test_transforms.py::test_multiprocessing_support[GlassBlur-params21]", "tests/test_transforms.py::test_multiprocessing_support[GridDistortion-params22]", "tests/test_transforms.py::test_multiprocessing_support[GridDropout-params23]", "tests/test_transforms.py::test_multiprocessing_support[HorizontalFlip-params24]", "tests/test_transforms.py::test_multiprocessing_support[HueSaturationValue-params25]", "tests/test_transforms.py::test_multiprocessing_support[ISONoise-params26]", "tests/test_transforms.py::test_multiprocessing_support[ImageCompression-params27]", "tests/test_transforms.py::test_multiprocessing_support[InvertImg-params28]", "tests/test_transforms.py::test_multiprocessing_support[Lambda-params29]", "tests/test_transforms.py::test_multiprocessing_support[LongestMaxSize-params30]", "tests/test_transforms.py::test_multiprocessing_support[MedianBlur-params31]", "tests/test_transforms.py::test_multiprocessing_support[MotionBlur-params32]", "tests/test_transforms.py::test_multiprocessing_support[MultiplicativeNoise-params33]", "tests/test_transforms.py::test_multiprocessing_support[NoOp-params34]", "tests/test_transforms.py::test_multiprocessing_support[Normalize-params35]", "tests/test_transforms.py::test_multiprocessing_support[OpticalDistortion-params36]", "tests/test_transforms.py::test_multiprocessing_support[PadIfNeeded-params37]", "tests/test_transforms.py::test_multiprocessing_support[Perspective-params38]", "tests/test_transforms.py::test_multiprocessing_support[PiecewiseAffine-params39]", "tests/test_transforms.py::test_multiprocessing_support[PixelDropout-params40]", "tests/test_transforms.py::test_multiprocessing_support[Posterize-params41]", "tests/test_transforms.py::test_multiprocessing_support[RGBShift-params42]", "tests/test_transforms.py::test_multiprocessing_support[RandomBrightnessContrast-params43]", "tests/test_transforms.py::test_multiprocessing_support[RandomCrop-params44]", "tests/test_transforms.py::test_multiprocessing_support[RandomCropFromBorders-params45]", "tests/test_transforms.py::test_multiprocessing_support[RandomFog-params46]", "tests/test_transforms.py::test_multiprocessing_support[RandomGamma-params47]", "tests/test_transforms.py::test_multiprocessing_support[RandomRain-params49]", "tests/test_transforms.py::test_multiprocessing_support[RandomResizedCrop-params50]", "tests/test_transforms.py::test_multiprocessing_support[RandomRotate90-params51]", "tests/test_transforms.py::test_multiprocessing_support[RandomScale-params52]", "tests/test_transforms.py::test_multiprocessing_support[RandomShadow-params53]", "tests/test_transforms.py::test_multiprocessing_support[RandomSizedCrop-params54]", "tests/test_transforms.py::test_multiprocessing_support[RandomSnow-params55]", "tests/test_transforms.py::test_multiprocessing_support[RandomSunFlare-params56]", "tests/test_transforms.py::test_multiprocessing_support[RandomToneCurve-params57]", "tests/test_transforms.py::test_multiprocessing_support[Resize-params58]", "tests/test_transforms.py::test_multiprocessing_support[RingingOvershoot-params59]", "tests/test_transforms.py::test_multiprocessing_support[Rotate-params60]", "tests/test_transforms.py::test_multiprocessing_support[SafeRotate-params61]", "tests/test_transforms.py::test_multiprocessing_support[Sharpen-params62]", "tests/test_transforms.py::test_multiprocessing_support[ShiftScaleRotate-params63]", "tests/test_transforms.py::test_multiprocessing_support[SmallestMaxSize-params64]", "tests/test_transforms.py::test_multiprocessing_support[Solarize-params65]", "tests/test_transforms.py::test_multiprocessing_support[Spatter-params66]", "tests/test_transforms.py::test_multiprocessing_support[Superpixels-params67]", "tests/test_transforms.py::test_multiprocessing_support[TemplateTransform-params68]", "tests/test_transforms.py::test_multiprocessing_support[ToFloat-params69]", "tests/test_transforms.py::test_multiprocessing_support[ToGray-params70]", "tests/test_transforms.py::test_multiprocessing_support[ToSepia-params71]", "tests/test_transforms.py::test_multiprocessing_support[Transpose-params72]", "tests/test_transforms.py::test_multiprocessing_support[UnsharpMask-params73]", "tests/test_transforms.py::test_multiprocessing_support[VerticalFlip-params74]", "tests/test_transforms.py::test_multiprocessing_support[ZoomBlur-params75]", "tests/test_transforms.py::test_force_apply", "tests/test_transforms.py::test_additional_targets_for_image_only[AdvancedBlur-params0]", "tests/test_transforms.py::test_additional_targets_for_image_only[Blur-params1]", "tests/test_transforms.py::test_additional_targets_for_image_only[CLAHE-params2]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelDropout-params3]", "tests/test_transforms.py::test_additional_targets_for_image_only[ChannelShuffle-params4]", "tests/test_transforms.py::test_additional_targets_for_image_only[ColorJitter-params5]", "tests/test_transforms.py::test_additional_targets_for_image_only[Defocus-params6]", "tests/test_transforms.py::test_additional_targets_for_image_only[Downscale-params7]", "tests/test_transforms.py::test_additional_targets_for_image_only[Emboss-params8]", "tests/test_transforms.py::test_additional_targets_for_image_only[Equalize-params9]", "tests/test_transforms.py::test_additional_targets_for_image_only[FDA-params10]", "tests/test_transforms.py::test_additional_targets_for_image_only[FancyPCA-params11]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussNoise-params13]", "tests/test_transforms.py::test_additional_targets_for_image_only[GaussianBlur-params14]", "tests/test_transforms.py::test_additional_targets_for_image_only[GlassBlur-params15]", "tests/test_transforms.py::test_additional_targets_for_image_only[HistogramMatching-params16]", "tests/test_transforms.py::test_additional_targets_for_image_only[HueSaturationValue-params17]", "tests/test_transforms.py::test_additional_targets_for_image_only[ISONoise-params18]", "tests/test_transforms.py::test_additional_targets_for_image_only[ImageCompression-params19]", "tests/test_transforms.py::test_additional_targets_for_image_only[InvertImg-params20]", "tests/test_transforms.py::test_additional_targets_for_image_only[MedianBlur-params21]", "tests/test_transforms.py::test_additional_targets_for_image_only[MotionBlur-params22]", "tests/test_transforms.py::test_additional_targets_for_image_only[MultiplicativeNoise-params23]", "tests/test_transforms.py::test_additional_targets_for_image_only[Normalize-params24]", "tests/test_transforms.py::test_additional_targets_for_image_only[PixelDistributionAdaptation-params25]", "tests/test_transforms.py::test_additional_targets_for_image_only[Posterize-params26]", "tests/test_transforms.py::test_additional_targets_for_image_only[RGBShift-params27]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomBrightnessContrast-params28]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomFog-params29]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomGamma-params30]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomRain-params31]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomShadow-params32]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSnow-params33]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomSunFlare-params34]", "tests/test_transforms.py::test_additional_targets_for_image_only[RandomToneCurve-params35]", "tests/test_transforms.py::test_additional_targets_for_image_only[RingingOvershoot-params36]", "tests/test_transforms.py::test_additional_targets_for_image_only[Sharpen-params37]", "tests/test_transforms.py::test_additional_targets_for_image_only[Solarize-params38]", "tests/test_transforms.py::test_additional_targets_for_image_only[Spatter-params39]", "tests/test_transforms.py::test_additional_targets_for_image_only[Superpixels-params40]", "tests/test_transforms.py::test_additional_targets_for_image_only[TemplateTransform-params41]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToFloat-params42]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToGray-params43]", "tests/test_transforms.py::test_additional_targets_for_image_only[ToSepia-params44]", "tests/test_transforms.py::test_additional_targets_for_image_only[UnsharpMask-params45]", "tests/test_transforms.py::test_additional_targets_for_image_only[ZoomBlur-params46]", "tests/test_transforms.py::test_image_invert", "tests/test_transforms.py::test_lambda_transform", "tests/test_transforms.py::test_channel_droput", "tests/test_transforms.py::test_equalize", "tests/test_transforms.py::test_crop_non_empty_mask", "tests/test_transforms.py::test_downscale[0]", "tests/test_transforms.py::test_downscale[1]", "tests/test_transforms.py::test_downscale[2]", "tests/test_transforms.py::test_crop_keypoints", "tests/test_transforms.py::test_longest_max_size_keypoints", "tests/test_transforms.py::test_smallest_max_size_keypoints", "tests/test_transforms.py::test_resize_keypoints", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image0]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image1]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image2]", "tests/test_transforms.py::test_multiplicative_noise_grayscale[image3]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image0]", "tests/test_transforms.py::test_multiplicative_noise_rgb[image1]", "tests/test_transforms.py::test_mask_dropout", "tests/test_transforms.py::test_grid_dropout_mask[image0]", "tests/test_transforms.py::test_grid_dropout_mask[image1]", "tests/test_transforms.py::test_grid_dropout_params[1e-05-10-10-100-100-50-50]", "tests/test_transforms.py::test_grid_dropout_params[0.9-100-None-200-None-0-0]", "tests/test_transforms.py::test_grid_dropout_params[0.4556-10-20-None-200-0-0]", "tests/test_transforms.py::test_grid_dropout_params[4e-05-None-None-2-100-None-None]", "tests/test_transforms.py::test_gauss_noise_incorrect_var_limit_type", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit3-sigma3-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit4-sigma4-3-0]", "tests/test_transforms.py::test_gaus_blur_limits[blur_limit5-sigma5-3-0.1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit0-sigma0-0-1]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit1-sigma1-1-0]", "tests/test_transforms.py::test_unsharp_mask_limits[blur_limit2-sigma2-1-1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_unsharp_mask_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[0.123-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1.321-1-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-0.234-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1.432-1-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-0.345-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1.543-0]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1-0.456]", "tests/test_transforms.py::test_color_jitter_float_uint8_equal[1-1-1--0.432]", "tests/test_transforms.py::test_shift_scale_separate_shift_x_shift_y", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_glass_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_perspective_keep_size", "tests/test_transforms.py::test_longest_max_size_list", "tests/test_transforms.py::test_smallest_max_size_list", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform0-image_size0-template_size0]", "tests/test_transforms.py::test_template_transform[0.3-0.5-template_transform1-image_size1-template_size1]", "tests/test_transforms.py::test_template_transform[1.0-0.5-template_transform2-image_size2-template_size2]", "tests/test_transforms.py::test_template_transform[0.5-0.8-template_transform3-image_size3-template_size3]", "tests/test_transforms.py::test_template_transform[0.5-0.2-template_transform4-image_size4-template_size4]", "tests/test_transforms.py::test_template_transform[0.5-0.9-template_transform5-image_size5-template_size5]", "tests/test_transforms.py::test_template_transform[0.5-0.5-None-image_size6-template_size6]", "tests/test_transforms.py::test_template_transform[0.8-0.7-None-image_size7-template_size7]", "tests/test_transforms.py::test_template_transform[0.5-0.5-template_transform8-image_size8-template_size8]", "tests/test_transforms.py::test_template_transform_incorrect_size", "tests/test_transforms.py::test_template_transform_incorrect_channels[1-3]", "tests/test_transforms.py::test_template_transform_incorrect_channels[6-3]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[0]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[1]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[128]", "tests/test_transforms.py::test_advanced_blur_float_uint8_diff_less_than_two[255]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params0]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params1]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params2]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params3]", "tests/test_transforms.py::test_advanced_blur_raises_on_incorrect_params[params4]", "tests/test_transforms.py::test_affine_scale_ratio[params0]", "tests/test_transforms.py::test_affine_scale_ratio[params1]", "tests/test_transforms.py::test_affine_scale_ratio[params2]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params0]", "tests/test_transforms.py::test_affine_incorrect_scale_range[params1]", "tests/test_transforms.py::test_safe_rotate[-10-targets0-expected0]", "tests/test_transforms.py::test_safe_rotate[10-targets1-expected1]", "tests/test_transforms.py::test_rotate_equal[-360-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-360-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-360-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-360-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-345-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-345-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-330-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-330-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-315-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-315-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-300-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-300-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-285-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-285-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-270-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-270-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-255-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-255-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-240-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-240-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-225-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-225-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-210-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-210-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-195-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-195-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-180-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-180-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-165-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-165-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-150-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-150-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-135-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-135-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-120-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-120-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-105-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-105-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-90-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-90-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-75-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-75-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-60-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-60-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-45-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-45-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-30-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-30-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[-15-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[-15-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[0-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[0-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[15-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[15-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[30-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[30-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[45-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[45-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[60-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[60-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[75-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[75-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[90-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[90-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[105-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[105-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[120-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[120-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[135-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[135-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[150-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[150-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[165-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[165-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[180-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[180-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[195-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[195-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[210-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[210-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[225-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[225-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[240-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[240-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[255-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[255-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[270-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[270-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[285-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[285-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[300-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[300-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[315-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[315-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[330-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[330-img2-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img0-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img0-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img1-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img1-<lambda>1]", "tests/test_transforms.py::test_rotate_equal[345-img2-<lambda>0]", "tests/test_transforms.py::test_rotate_equal[345-img2-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes0-expected0-0.9--1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes0-expected0-0.9--1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes1-expected1-0.6--1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes1-expected1-0.6--1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes2-expected2-0.9-1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes2-expected2-0.9-1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping[bboxes3-expected3-0.6-1-<lambda>0]", "tests/test_transforms.py::test_bbox_clipping[bboxes3-expected3-0.6-1-<lambda>1]", "tests/test_transforms.py::test_bbox_clipping_perspective", "tests/test_transforms.py::test_motion_blur_allow_shifted[0]", "tests/test_transforms.py::test_motion_blur_allow_shifted[1]", "tests/test_transforms.py::test_motion_blur_allow_shifted[2]", "tests/test_transforms.py::test_motion_blur_allow_shifted[3]", "tests/test_transforms.py::test_motion_blur_allow_shifted[4]", "tests/test_transforms.py::test_motion_blur_allow_shifted[5]", "tests/test_transforms.py::test_motion_blur_allow_shifted[6]", "tests/test_transforms.py::test_motion_blur_allow_shifted[7]", "tests/test_transforms.py::test_motion_blur_allow_shifted[8]", "tests/test_transforms.py::test_motion_blur_allow_shifted[9]", "tests/test_transforms.py::test_non_rgb_transform_warning[1-augmentation0]", "tests/test_transforms.py::test_non_rgb_transform_warning[1-augmentation1]", "tests/test_transforms.py::test_non_rgb_transform_warning[1-augmentation2]", "tests/test_transforms.py::test_non_rgb_transform_warning[1-augmentation3]", "tests/test_transforms.py::test_non_rgb_transform_warning[1-augmentation4]", "tests/test_transforms.py::test_non_rgb_transform_warning[1-augmentation5]", "tests/test_transforms.py::test_non_rgb_transform_warning[6-augmentation0]", "tests/test_transforms.py::test_non_rgb_transform_warning[6-augmentation1]", "tests/test_transforms.py::test_non_rgb_transform_warning[6-augmentation2]", "tests/test_transforms.py::test_non_rgb_transform_warning[6-augmentation3]", "tests/test_transforms.py::test_non_rgb_transform_warning[6-augmentation4]", "tests/test_transforms.py::test_non_rgb_transform_warning[6-augmentation5]", "tests/test_transforms.py::test_spatter_incorrect_mode" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2022-10-07 16:51:04+00:00
mit
1,012
albumentations-team__albumentations-1310
diff --git a/albumentations/core/composition.py b/albumentations/core/composition.py index dbc78ca..9662afb 100644 --- a/albumentations/core/composition.py +++ b/albumentations/core/composition.py @@ -128,6 +128,8 @@ class Compose(BaseCompose): keypoint_params (KeypointParams): Parameters for keypoints transforms additional_targets (dict): Dict with keys - new target name, values - old target name. ex: {'image2': 'image'} p (float): probability of applying all list of transforms. Default: 1.0. + is_check_shapes (bool): If True shapes consistency of images/mask/masks would be checked on each call. If you + would like to disable this check - pass False (do it only if you are sure in your data consistency). """ def __init__( @@ -137,6 +139,7 @@ class Compose(BaseCompose): keypoint_params: typing.Optional[typing.Union[dict, "KeypointParams"]] = None, additional_targets: typing.Optional[typing.Dict[str, str]] = None, p: float = 1.0, + is_check_shapes: bool = True, ): super(Compose, self).__init__(transforms, p) @@ -172,6 +175,8 @@ class Compose(BaseCompose): self.is_check_args = True self._disable_check_args_for_transforms(self.transforms) + self.is_check_shapes = is_check_shapes + @staticmethod def _disable_check_args_for_transforms(transforms: TransformsSeqType) -> None: for transform in transforms: @@ -235,6 +240,7 @@ class Compose(BaseCompose): if keypoints_processor else None, "additional_targets": self.additional_targets, + "is_check_shapes": self.is_check_shapes, } ) return dictionary @@ -251,6 +257,7 @@ class Compose(BaseCompose): else None, "additional_targets": self.additional_targets, "params": None, + "is_check_shapes": self.is_check_shapes, } ) return dictionary @@ -260,18 +267,28 @@ class Compose(BaseCompose): checked_multi = ["masks"] check_bbox_param = ["bboxes"] # ["bboxes", "keypoints"] could be almost any type, no need to check them + shapes = [] for data_name, data in kwargs.items(): internal_data_name = self.additional_targets.get(data_name, data_name) if internal_data_name in checked_single: if not isinstance(data, np.ndarray): raise TypeError("{} must be numpy array type".format(data_name)) + shapes.append(data.shape[:2]) if internal_data_name in checked_multi: if data: if not isinstance(data[0], np.ndarray): raise TypeError("{} must be list of numpy arrays".format(data_name)) + shapes.append(data[0].shape[:2]) if internal_data_name in check_bbox_param and self.processors.get("bboxes") is None: raise ValueError("bbox_params must be specified for bbox transformations") + if self.is_check_shapes and shapes and shapes.count(shapes[0]) != len(shapes): + raise ValueError( + "Height and Width of image, mask or masks should be equal. You can disable shapes check " + "by calling disable_shapes_check method of Compose class (do it only if you are sure " + "about your data consistency)." + ) + @staticmethod def _make_targets_contiguous(data: typing.Dict[str, typing.Any]) -> typing.Dict[str, typing.Any]: result = {} @@ -423,9 +440,12 @@ class ReplayCompose(Compose): keypoint_params: typing.Optional[typing.Union[dict, "KeypointParams"]] = None, additional_targets: typing.Optional[typing.Dict[str, str]] = None, p: float = 1.0, + is_check_shapes: bool = True, save_key: str = "replay", ): - super(ReplayCompose, self).__init__(transforms, bbox_params, keypoint_params, additional_targets, p) + super(ReplayCompose, self).__init__( + transforms, bbox_params, keypoint_params, additional_targets, p, is_check_shapes + ) self.set_deterministic(True, save_key=save_key) self.save_key = save_key
albumentations-team/albumentations
7029e802f15d7c21ed8690ba8812dde6cf16de01
diff --git a/tests/test_core.py b/tests/test_core.py index 7c784c4..7fbcff6 100644 --- a/tests/test_core.py +++ b/tests/test_core.py @@ -412,3 +412,26 @@ def test_contiguous_output(transforms): # confirm output contiguous assert data["image"].flags["C_CONTIGUOUS"] assert data["mask"].flags["C_CONTIGUOUS"] + + [email protected]( + "targets", + [ + {"image": np.ones((20, 20, 3), dtype=np.uint8), "mask": np.ones((30, 20))}, + {"image": np.ones((20, 20, 3), dtype=np.uint8), "masks": [np.ones((30, 20))]}, + ], +) +def test_compose_image_mask_equal_size(targets): + transforms = Compose([]) + + with pytest.raises(ValueError) as exc_info: + transforms(**targets) + + assert str(exc_info.value).startswith( + "Height and Width of image, mask or masks should be equal. " + "You can disable shapes check by calling disable_shapes_check method " + "of Compose class (do it only if you are sure about your data consistency)." + ) + # test after disabling shapes check + transforms = Compose([], is_check_shapes=False) + transforms(**targets) diff --git a/tests/test_serialization.py b/tests/test_serialization.py index e3eb9a4..5bfb4ab 100644 --- a/tests/test_serialization.py +++ b/tests/test_serialization.py @@ -761,6 +761,7 @@ def test_serialization_v2_to_dict(): "bbox_params": None, "keypoint_params": None, "additional_targets": {}, + "is_check_shapes": True, }
Add check that masks and image have the same height and width This needed to avoid problems inside spatial-level transforms when params generated based on image shapes, for example pad and crop augs.
0.0
7029e802f15d7c21ed8690ba8812dde6cf16de01
[ "tests/test_core.py::test_compose_image_mask_equal_size[targets0]", "tests/test_core.py::test_compose_image_mask_equal_size[targets1]", "tests/test_serialization.py::test_serialization_v2_to_dict" ]
[ "tests/test_core.py::test_one_or_other", "tests/test_core.py::test_compose", "tests/test_core.py::test_always_apply", "tests/test_core.py::test_one_of", "tests/test_core.py::test_n_of[True-1]", "tests/test_core.py::test_n_of[True-2]", "tests/test_core.py::test_n_of[True-5]", "tests/test_core.py::test_n_of[True-10]", "tests/test_core.py::test_n_of[False-1]", "tests/test_core.py::test_n_of[False-2]", "tests/test_core.py::test_n_of[False-5]", "tests/test_core.py::test_n_of[False-10]", "tests/test_core.py::test_sequential", "tests/test_core.py::test_to_tuple", "tests/test_core.py::test_image_only_transform", "tests/test_core.py::test_compose_doesnt_pass_force_apply", "tests/test_core.py::test_dual_transform", "tests/test_core.py::test_additional_targets", "tests/test_core.py::test_check_bboxes_with_correct_values", "tests/test_core.py::test_check_bboxes_with_values_less_than_zero", "tests/test_core.py::test_check_bboxes_with_values_greater_than_one", "tests/test_core.py::test_check_bboxes_with_end_greater_that_start", "tests/test_core.py::test_per_channel_mono", "tests/test_core.py::test_per_channel_multi", "tests/test_core.py::test_deterministic_oneof", "tests/test_core.py::test_deterministic_one_or_other", "tests/test_core.py::test_deterministic_sequential", "tests/test_core.py::test_named_args", "tests/test_core.py::test_targets_type_check[targets0-None-image", "tests/test_core.py::test_targets_type_check[targets1-None-mask", "tests/test_core.py::test_targets_type_check[targets2-additional_targets2-image1", "tests/test_core.py::test_targets_type_check[targets3-additional_targets3-mask1", "tests/test_core.py::test_check_each_transform[targets0-None-keypoint_params0-expected0]", "tests/test_core.py::test_check_each_transform[targets1-None-keypoint_params1-expected1]", "tests/test_core.py::test_check_each_transform[targets2-bbox_params2-None-expected2]", "tests/test_core.py::test_check_each_transform[targets3-bbox_params3-None-expected3]", "tests/test_core.py::test_check_each_transform[targets4-bbox_params4-keypoint_params4-expected4]", "tests/test_core.py::test_check_each_transform[targets5-bbox_params5-keypoint_params5-expected5]", "tests/test_core.py::test_check_each_transform[targets6-bbox_params6-keypoint_params6-expected6]", "tests/test_core.py::test_check_each_transform[targets7-bbox_params7-keypoint_params7-expected7]", "tests/test_core.py::test_bbox_params_is_not_set", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform5]", "tests/test_core.py::test_choice_inner_compositions[transforms0]", "tests/test_core.py::test_choice_inner_compositions[transforms1]", "tests/test_core.py::test_contiguous_output[transforms0]", "tests/test_core.py::test_contiguous_output[transforms1]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-FromFloat-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomGridShuffle-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-0-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-0-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-1-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-1-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-FromFloat-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomGridShuffle-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-42-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-42-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-FromFloat-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomGridShuffle-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-111-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-111-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-FromFloat-params19]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomGridShuffle-params49]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[False-9999-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-0-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-0-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-1-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-1-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-42-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-42-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-111-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-111-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-0.5-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CoarseDropout-params7]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-CropNonEmptyMaskIfExists-params11]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Defocus-params12]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Downscale-params13]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ElasticTransform-params14]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Emboss-params15]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Equalize-params16]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-FancyPCA-params17]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Flip-params18]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GaussNoise-params20]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GaussianBlur-params21]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GlassBlur-params22]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GridDistortion-params23]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-GridDropout-params24]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-HorizontalFlip-params25]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-HueSaturationValue-params26]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ISONoise-params27]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ImageCompression-params28]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-InvertImg-params29]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-LongestMaxSize-params30]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MaskDropout-params31]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MedianBlur-params32]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MotionBlur-params33]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-MultiplicativeNoise-params34]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-NoOp-params35]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Normalize-params36]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-OpticalDistortion-params37]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-PadIfNeeded-params38]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Perspective-params39]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-PiecewiseAffine-params40]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-PixelDropout-params41]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RGBShift-params43]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomBrightnessContrast-params44]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomCrop-params45]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomCropFromBorders-params46]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomFog-params47]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomGamma-params48]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomRain-params50]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomResizedCrop-params51]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomRotate90-params52]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomScale-params53]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomShadow-params54]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomSizedCrop-params55]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomSnow-params56]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomSunFlare-params57]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RandomToneCurve-params58]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Resize-params59]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-RingingOvershoot-params60]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Rotate-params61]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-SafeRotate-params62]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Sharpen-params63]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ShiftScaleRotate-params64]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-SmallestMaxSize-params65]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Solarize-params66]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Spatter-params67]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Superpixels-params68]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ToFloat-params69]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ToGray-params70]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ToSepia-params71]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-Transpose-params72]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-VerticalFlip-params74]", "tests/test_serialization.py::test_augmentations_serialization[True-9999-1-ZoomBlur-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-0-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-1-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-42-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-111-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[False-9999-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-0-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-1-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-42-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-111-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_with_custom_parameters[True-9999-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-0-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-1-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-42-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-111-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomGridShuffle-params40]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-False-9999-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-0-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-1-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-42-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-111-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-0.5-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ImageCompression-params0]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-JpegCompression-params1]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-HueSaturationValue-params2]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RGBShift-params3]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomBrightnessContrast-params4]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Blur-params5]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MotionBlur-params6]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MedianBlur-params7]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-GaussianBlur-params8]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-GaussNoise-params9]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CLAHE-params10]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomGamma-params11]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Cutout-params12]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CoarseDropout-params13]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomSnow-params14]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomRain-params15]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomFog-params16]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomSunFlare-params17]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomShadow-params18]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PadIfNeeded-params19]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Rotate-params20]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-SafeRotate-params21]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ShiftScaleRotate-params22]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ShiftScaleRotate-params23]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-OpticalDistortion-params24]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-GridDistortion-params25]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ElasticTransform-params26]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CenterCrop-params27]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomCrop-params28]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CropNonEmptyMaskIfExists-params29]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomSizedCrop-params30]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Crop-params31]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ToFloat-params32]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Normalize-params33]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomBrightness-params34]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomContrast-params35]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomScale-params36]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Resize-params37]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-SmallestMaxSize-params38]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-LongestMaxSize-params39]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Solarize-params41]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Posterize-params42]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Equalize-params43]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MultiplicativeNoise-params44]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ColorJitter-params45]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Perspective-params46]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Sharpen-params47]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Emboss-params48]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomToneCurve-params49]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-CropAndPad-params50]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Superpixels-params51]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Affine-params52]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Affine-params53]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PiecewiseAffine-params54]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ChannelDropout-params55]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ChannelShuffle-params56]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Downscale-params57]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Flip-params58]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-FromFloat-params59]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-HorizontalFlip-params60]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ISONoise-params61]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-InvertImg-params62]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-MaskDropout-params63]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-NoOp-params64]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomResizedCrop-params65]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-FancyPCA-params66]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomRotate90-params67]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ToGray-params68]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ToSepia-params69]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Transpose-params70]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-VerticalFlip-params71]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RingingOvershoot-params72]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-UnsharpMask-params73]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-AdvancedBlur-params74]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PixelDropout-params75]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-PixelDropout-params76]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-RandomCropFromBorders-params77]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Spatter-params78]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-Defocus-params79]", "tests/test_serialization.py::test_augmentations_serialization_to_file_with_custom_parameters[yaml-True-9999-1-ZoomBlur-params80]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-FromFloat-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-0-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-1-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-FromFloat-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-42-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-FromFloat-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-111-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-FromFloat-params17]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[False-9999-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-0-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-1-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-42-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-111-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-0.5-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-BBoxSafeRandomCrop-params2]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Blur-params3]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-CLAHE-params4]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-CenterCrop-params5]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ChannelDropout-params6]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ChannelShuffle-params7]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ColorJitter-params8]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Crop-params9]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-CropAndPad-params10]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Defocus-params11]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Downscale-params12]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Emboss-params13]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Equalize-params14]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-FancyPCA-params15]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Flip-params16]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-GaussNoise-params18]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-GaussianBlur-params19]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-GlassBlur-params20]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-HorizontalFlip-params21]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-HueSaturationValue-params22]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ISONoise-params23]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ImageCompression-params24]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-InvertImg-params25]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-LongestMaxSize-params26]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-MedianBlur-params27]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-MotionBlur-params28]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-MultiplicativeNoise-params29]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-NoOp-params30]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Normalize-params31]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-PadIfNeeded-params32]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Perspective-params33]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-PiecewiseAffine-params34]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-PixelDropout-params35]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Posterize-params36]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RGBShift-params37]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomBrightnessContrast-params38]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomCrop-params39]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomCropFromBorders-params40]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomFog-params41]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomGamma-params42]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomRain-params43]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomResizedCrop-params44]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomRotate90-params45]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomScale-params46]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomShadow-params47]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSizedBBoxSafeCrop-params48]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSizedCrop-params49]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSnow-params50]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomSunFlare-params51]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RandomToneCurve-params52]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Resize-params53]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-RingingOvershoot-params54]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Rotate-params55]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-SafeRotate-params56]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Sharpen-params57]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ShiftScaleRotate-params58]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-SmallestMaxSize-params59]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Solarize-params60]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Spatter-params61]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Superpixels-params62]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ToFloat-params63]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ToGray-params64]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ToSepia-params65]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-Transpose-params66]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-UnsharpMask-params67]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-VerticalFlip-params68]", "tests/test_serialization.py::test_augmentations_for_bboxes_serialization[True-9999-1-ZoomBlur-params69]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-FromFloat-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-0-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-1-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-FromFloat-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-42-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-FromFloat-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-111-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-FromFloat-params16]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[False-9999-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-0-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-1-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-42-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-111-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-0.5-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-AdvancedBlur-params0]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Affine-params1]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Blur-params2]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-CLAHE-params3]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-CenterCrop-params4]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ChannelDropout-params5]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ChannelShuffle-params6]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ColorJitter-params7]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Crop-params8]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-CropAndPad-params9]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Defocus-params10]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Downscale-params11]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Emboss-params12]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Equalize-params13]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-FancyPCA-params14]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Flip-params15]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-GaussNoise-params17]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-GaussianBlur-params18]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-GlassBlur-params19]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-HorizontalFlip-params20]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-HueSaturationValue-params21]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ISONoise-params22]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ImageCompression-params23]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-InvertImg-params24]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-LongestMaxSize-params25]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-MedianBlur-params26]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-MotionBlur-params27]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-MultiplicativeNoise-params28]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-NoOp-params29]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Normalize-params30]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-PadIfNeeded-params31]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Perspective-params32]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-PiecewiseAffine-params33]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-PixelDropout-params34]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Posterize-params35]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RGBShift-params36]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomBrightnessContrast-params37]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomCrop-params38]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomCropFromBorders-params39]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomFog-params40]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomGamma-params41]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomRain-params42]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomResizedCrop-params43]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomRotate90-params44]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomScale-params45]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomShadow-params46]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomSizedCrop-params47]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomSnow-params48]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomSunFlare-params49]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RandomToneCurve-params50]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Resize-params51]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-RingingOvershoot-params52]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Rotate-params53]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-SafeRotate-params54]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Sharpen-params55]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ShiftScaleRotate-params56]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-SmallestMaxSize-params57]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Solarize-params58]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Spatter-params59]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Superpixels-params60]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ToFloat-params61]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ToGray-params62]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ToSepia-params63]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-Transpose-params64]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-UnsharpMask-params65]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-VerticalFlip-params66]", "tests/test_serialization.py::test_augmentations_for_keypoints_serialization[True-9999-1-ZoomBlur-params67]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-0-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-0-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-1-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-1-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-42-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-42-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-111-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-111-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-9999-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[False-9999-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-0-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-0-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-1-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-1-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-42-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-42-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-111-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-111-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-9999-0.5-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_augmentations_serialization_with_call_params[True-9999-1-RandomCropNearBBox-params0-call_params0]", "tests/test_serialization.py::test_from_float_serialization", "tests/test_serialization.py::test_transform_pipeline_serialization[0]", "tests/test_serialization.py::test_transform_pipeline_serialization[1]", "tests/test_serialization.py::test_transform_pipeline_serialization[42]", "tests/test_serialization.py::test_transform_pipeline_serialization[111]", "tests/test_serialization.py::test_transform_pipeline_serialization[9999]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[0-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[1-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[42-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[111-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes0-coco-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes1-coco-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes2-pascal_voc-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes3-pascal_voc-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes4-yolo-labels4]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_bboxes[9999-bboxes5-yolo-labels5]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[0-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[1-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[42-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[111-keypoints3-xys-labels3]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints0-xyas-labels0]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints1-xy-labels1]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints2-yx-labels2]", "tests/test_serialization.py::test_transform_pipeline_serialization_with_keypoints[9999-keypoints3-xys-labels3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Defocus-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Downscale-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Emboss-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Equalize-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-FancyPCA-params10]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-GaussNoise-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-GaussianBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-GlassBlur-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-HueSaturationValue-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ISONoise-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ImageCompression-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-InvertImg-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-MedianBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-MotionBlur-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-MultiplicativeNoise-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Normalize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Posterize-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RGBShift-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomBrightnessContrast-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomFog-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomGamma-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomRain-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomShadow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomSnow-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomSunFlare-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RandomToneCurve-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-RingingOvershoot-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Sharpen-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Solarize-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Spatter-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-Superpixels-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ToFloat-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ToGray-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ToSepia-params40]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-UnsharpMask-params41]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[0-ZoomBlur-params42]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Defocus-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Downscale-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Emboss-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Equalize-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-FancyPCA-params10]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-GaussNoise-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-GaussianBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-GlassBlur-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-HueSaturationValue-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ISONoise-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ImageCompression-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-InvertImg-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-MedianBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-MotionBlur-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-MultiplicativeNoise-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Normalize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Posterize-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RGBShift-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomBrightnessContrast-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomFog-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomGamma-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomRain-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomShadow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomSnow-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomSunFlare-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RandomToneCurve-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-RingingOvershoot-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Sharpen-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Solarize-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Spatter-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-Superpixels-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ToFloat-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ToGray-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ToSepia-params40]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-UnsharpMask-params41]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[1-ZoomBlur-params42]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Defocus-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Downscale-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Emboss-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Equalize-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-FancyPCA-params10]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-GaussNoise-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-GaussianBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-GlassBlur-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-HueSaturationValue-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ISONoise-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ImageCompression-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-InvertImg-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-MedianBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-MotionBlur-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-MultiplicativeNoise-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Normalize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Posterize-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RGBShift-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomBrightnessContrast-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomFog-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomGamma-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomRain-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomShadow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomSnow-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomSunFlare-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RandomToneCurve-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-RingingOvershoot-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Sharpen-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Solarize-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Spatter-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-Superpixels-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ToFloat-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ToGray-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ToSepia-params40]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-UnsharpMask-params41]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[42-ZoomBlur-params42]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Defocus-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Downscale-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Emboss-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Equalize-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-FancyPCA-params10]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-GaussNoise-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-GaussianBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-GlassBlur-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-HueSaturationValue-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ISONoise-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ImageCompression-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-InvertImg-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-MedianBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-MotionBlur-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-MultiplicativeNoise-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Normalize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Posterize-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RGBShift-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomBrightnessContrast-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomFog-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomGamma-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomRain-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomShadow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomSnow-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomSunFlare-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RandomToneCurve-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-RingingOvershoot-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Sharpen-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Solarize-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Spatter-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-Superpixels-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ToFloat-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ToGray-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ToSepia-params40]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-UnsharpMask-params41]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[111-ZoomBlur-params42]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-AdvancedBlur-params0]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Blur-params1]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-CLAHE-params2]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ChannelDropout-params3]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ChannelShuffle-params4]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ColorJitter-params5]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Defocus-params6]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Downscale-params7]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Emboss-params8]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Equalize-params9]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-FancyPCA-params10]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-GaussNoise-params12]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-GaussianBlur-params13]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-GlassBlur-params14]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-HueSaturationValue-params15]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ISONoise-params16]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ImageCompression-params17]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-InvertImg-params18]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-MedianBlur-params19]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-MotionBlur-params20]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-MultiplicativeNoise-params21]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Normalize-params22]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Posterize-params23]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RGBShift-params24]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomBrightnessContrast-params25]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomFog-params26]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomGamma-params27]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomRain-params28]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomShadow-params29]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomSnow-params30]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomSunFlare-params31]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RandomToneCurve-params32]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-RingingOvershoot-params33]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Sharpen-params34]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Solarize-params35]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Spatter-params36]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-Superpixels-params37]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ToFloat-params38]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ToGray-params39]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ToSepia-params40]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-UnsharpMask-params41]", "tests/test_serialization.py::test_additional_targets_for_image_only_serialization[9999-ZoomBlur-params42]", "tests/test_serialization.py::test_lambda_serialization[1-0]", "tests/test_serialization.py::test_lambda_serialization[1-1]", "tests/test_serialization.py::test_lambda_serialization[1-42]", "tests/test_serialization.py::test_lambda_serialization[1-111]", "tests/test_serialization.py::test_lambda_serialization[1-9999]", "tests/test_serialization.py::test_custom_transform_with_overlapping_name", "tests/test_serialization.py::test_shorten_class_name[albumentations.augmentations.transforms.HorizontalFlip-HorizontalFlip]", "tests/test_serialization.py::test_shorten_class_name[HorizontalFlip-HorizontalFlip]", "tests/test_serialization.py::test_shorten_class_name[some_module.HorizontalFlip-some_module.HorizontalFlip]", "tests/test_serialization.py::test_template_transform_serialization[1-0]", "tests/test_serialization.py::test_template_transform_serialization[1-1]", "tests/test_serialization.py::test_template_transform_serialization[1-42]", "tests/test_serialization.py::test_template_transform_serialization[1-111]", "tests/test_serialization.py::test_template_transform_serialization[1-9999]" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2022-10-11 12:42:47+00:00
mit
1,013
albumentations-team__albumentations-1379
diff --git a/albumentations/core/composition.py b/albumentations/core/composition.py index 54f596c..dfc5e86 100644 --- a/albumentations/core/composition.py +++ b/albumentations/core/composition.py @@ -285,7 +285,7 @@ class Compose(BaseCompose): if self.is_check_shapes and shapes and shapes.count(shapes[0]) != len(shapes): raise ValueError( "Height and Width of image, mask or masks should be equal. You can disable shapes check " - "by calling disable_shapes_check method of Compose class (do it only if you are sure " + "by setting a parameter is_check_shapes=False of Compose class (do it only if you are sure " "about your data consistency)." )
albumentations-team/albumentations
1eceb794ccbf52a02b09e630833f61366bef1149
diff --git a/tests/test_core.py b/tests/test_core.py index 7fbcff6..5297304 100644 --- a/tests/test_core.py +++ b/tests/test_core.py @@ -429,7 +429,7 @@ def test_compose_image_mask_equal_size(targets): assert str(exc_info.value).startswith( "Height and Width of image, mask or masks should be equal. " - "You can disable shapes check by calling disable_shapes_check method " + "You can disable shapes check by setting a parameter is_check_shapes=False " "of Compose class (do it only if you are sure about your data consistency)." ) # test after disabling shapes check
No disable_shapes_check method of Compose class ## 🐛 Bug The error message says "You can disable shapes check by calling disable_shapes_check method of Compose class.": https://github.com/albumentations-team/albumentations/blob/57988c2091b72e67f37de0332b75d1772d28c651/albumentations/core/composition.py#L285-L290 But there's no ```disable_shapes_check``` method of Compose class.
0.0
1eceb794ccbf52a02b09e630833f61366bef1149
[ "tests/test_core.py::test_compose_image_mask_equal_size[targets0]", "tests/test_core.py::test_compose_image_mask_equal_size[targets1]" ]
[ "tests/test_core.py::test_one_or_other", "tests/test_core.py::test_compose", "tests/test_core.py::test_always_apply", "tests/test_core.py::test_one_of", "tests/test_core.py::test_n_of[True-1]", "tests/test_core.py::test_n_of[True-2]", "tests/test_core.py::test_n_of[True-5]", "tests/test_core.py::test_n_of[True-10]", "tests/test_core.py::test_n_of[False-1]", "tests/test_core.py::test_n_of[False-2]", "tests/test_core.py::test_n_of[False-5]", "tests/test_core.py::test_n_of[False-10]", "tests/test_core.py::test_sequential", "tests/test_core.py::test_to_tuple", "tests/test_core.py::test_image_only_transform", "tests/test_core.py::test_compose_doesnt_pass_force_apply", "tests/test_core.py::test_dual_transform", "tests/test_core.py::test_additional_targets", "tests/test_core.py::test_check_bboxes_with_correct_values", "tests/test_core.py::test_check_bboxes_with_values_less_than_zero", "tests/test_core.py::test_check_bboxes_with_values_greater_than_one", "tests/test_core.py::test_check_bboxes_with_end_greater_that_start", "tests/test_core.py::test_per_channel_mono", "tests/test_core.py::test_per_channel_multi", "tests/test_core.py::test_deterministic_oneof", "tests/test_core.py::test_deterministic_one_or_other", "tests/test_core.py::test_deterministic_sequential", "tests/test_core.py::test_named_args", "tests/test_core.py::test_targets_type_check[targets0-None-image", "tests/test_core.py::test_targets_type_check[targets1-None-mask", "tests/test_core.py::test_targets_type_check[targets2-additional_targets2-image1", "tests/test_core.py::test_targets_type_check[targets3-additional_targets3-mask1", "tests/test_core.py::test_check_each_transform[targets0-None-keypoint_params0-expected0]", "tests/test_core.py::test_check_each_transform[targets1-None-keypoint_params1-expected1]", "tests/test_core.py::test_check_each_transform[targets2-bbox_params2-None-expected2]", "tests/test_core.py::test_check_each_transform[targets3-bbox_params3-None-expected3]", "tests/test_core.py::test_check_each_transform[targets4-bbox_params4-keypoint_params4-expected4]", "tests/test_core.py::test_check_each_transform[targets5-bbox_params5-keypoint_params5-expected5]", "tests/test_core.py::test_check_each_transform[targets6-bbox_params6-keypoint_params6-expected6]", "tests/test_core.py::test_check_each_transform[targets7-bbox_params7-keypoint_params7-expected7]", "tests/test_core.py::test_bbox_params_is_not_set", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform0-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform1-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform2-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform3-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform4-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform5-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform6-compose_transform5]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform0]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform1]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform2]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform3]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform4]", "tests/test_core.py::test_single_transform_compose[inner_transform7-compose_transform5]", "tests/test_core.py::test_choice_inner_compositions[transforms0]", "tests/test_core.py::test_choice_inner_compositions[transforms1]", "tests/test_core.py::test_contiguous_output[transforms0]", "tests/test_core.py::test_contiguous_output[transforms1]" ]
{ "failed_lite_validators": [ "has_short_problem_statement" ], "has_test_patch": true, "is_lite": false }
2023-01-06 10:54:06+00:00
mit
1,014
albumentations-team__albumentations-616
diff --git a/albumentations/augmentations/dropout/channel_dropout.py b/albumentations/augmentations/dropout/channel_dropout.py index 45d42c7..48b4707 100644 --- a/albumentations/augmentations/dropout/channel_dropout.py +++ b/albumentations/augmentations/dropout/channel_dropout.py @@ -1,11 +1,10 @@ import random -from typing import Union, Tuple, Any, Mapping +from typing import Any, Mapping, Tuple, Union import numpy as np -from albumentations.core.transforms_interface import ( - ImageOnlyTransform, -) +from albumentations.core.transforms_interface import ImageOnlyTransform + from .functional import channel_dropout __all__ = ["ChannelDropout"] diff --git a/albumentations/augmentations/dropout/cutout.py b/albumentations/augmentations/dropout/cutout.py index 206f171..c781c97 100644 --- a/albumentations/augmentations/dropout/cutout.py +++ b/albumentations/augmentations/dropout/cutout.py @@ -1,12 +1,11 @@ import random import warnings -from typing import Union, Any, Dict, Tuple +from typing import Any, Dict, Tuple, Union import numpy as np -from albumentations.core.transforms_interface import ( - ImageOnlyTransform, -) +from albumentations.core.transforms_interface import ImageOnlyTransform + from .functional import cutout __all__ = ["Cutout"] diff --git a/albumentations/augmentations/dropout/functional.py b/albumentations/augmentations/dropout/functional.py index 759bc4d..d40b516 100644 --- a/albumentations/augmentations/dropout/functional.py +++ b/albumentations/augmentations/dropout/functional.py @@ -1,6 +1,7 @@ -from typing import List, Tuple, Union, Iterable +from typing import Iterable, List, Tuple, Union import numpy as np + from ..functional import preserve_shape __all__ = ["cutout", "channel_dropout"] diff --git a/albumentations/augmentations/dropout/grid_dropout.py b/albumentations/augmentations/dropout/grid_dropout.py index f5e7f93..96bb1e0 100644 --- a/albumentations/augmentations/dropout/grid_dropout.py +++ b/albumentations/augmentations/dropout/grid_dropout.py @@ -1,10 +1,10 @@ import random -from typing import Tuple, Iterable +from typing import Iterable, Tuple import numpy as np -from . import functional as F from ...core.transforms_interface import DualTransform +from . import functional as F __all__ = ["GridDropout"] diff --git a/albumentations/core/bbox_utils.py b/albumentations/core/bbox_utils.py index d3b9790..152ef6a 100644 --- a/albumentations/core/bbox_utils.py +++ b/albumentations/core/bbox_utils.py @@ -458,13 +458,12 @@ def filter_bboxes( transformed_box_area = calculate_bbox_area(bbox, rows, cols) bbox, tail = tuple(np.clip(bbox[:4], 0, 1.0)), tuple(bbox[4:]) clipped_box_area = calculate_bbox_area(bbox, rows, cols) - if not transformed_box_area or clipped_box_area / transformed_box_area <= min_visibility: - continue - else: - bbox = tuple(np.clip(bbox[:4], 0, 1.0)) - if calculate_bbox_area(bbox, rows, cols) <= min_area: - continue - resulting_boxes.append(bbox + tail) + if ( + clipped_box_area != 0 # to ensure transformed_box_area!=0 and to handle min_area=0 or min_visibility=0 + and clipped_box_area >= min_area + and clipped_box_area / transformed_box_area >= min_visibility + ): + resulting_boxes.append(bbox + tail) return resulting_boxes
albumentations-team/albumentations
85c3c0bbf39b62aec666b9c95cd204a5cdd73803
diff --git a/tests/test_bbox.py b/tests/test_bbox.py index ba981d6..67c30e6 100644 --- a/tests/test_bbox.py +++ b/tests/test_bbox.py @@ -1,7 +1,7 @@ import numpy as np import pytest -from albumentations import RandomCrop, RandomResizedCrop, RandomSizedCrop, Rotate +from albumentations import Crop, RandomCrop, RandomResizedCrop, RandomSizedCrop, Rotate from albumentations.core.bbox_utils import ( calculate_bbox_area, convert_bbox_from_albumentations, @@ -267,3 +267,18 @@ def test_crop_boxes_replay_compose(): transformed2 = ReplayCompose.replay(transformed["replay"], **input_data) np.testing.assert_almost_equal(transformed["bboxes"], transformed2["bboxes"]) + + [email protected]( + ["transforms", "bboxes", "result_bboxes", "min_area", "min_visibility"], + [ + [[Crop(10, 10, 20, 20)], [[0, 0, 10, 10, 0]], [], 0, 0], + [[Crop(0, 0, 90, 90)], [[0, 0, 91, 91, 0], [0, 0, 90, 90, 0]], [[0, 0, 90, 90, 0]], 0, 1], + [[Crop(0, 0, 90, 90)], [[0, 0, 1, 10, 0], [0, 0, 1, 11, 0]], [[0, 0, 1, 10, 0], [0, 0, 1, 11, 0]], 10, 0], + ], +) +def test_bbox_params_edges(transforms, bboxes, result_bboxes, min_area, min_visibility): + image = np.empty([100, 100, 3], dtype=np.uint8) + aug = Compose(transforms, bbox_params=BboxParams("pascal_voc", min_area=min_area, min_visibility=min_visibility)) + res = aug(image=image, bboxes=bboxes)["bboxes"] + assert np.allclose(res, result_bboxes)
bboxes with min_visibility are excluded `min_visibility` bbox parameter works as non-strict limit to exclude bboxes. I.e. bboxes with visibility ratio == min_visibility are excluded. It not only contradicts to documentation ('min_visibility (float): Minimum fraction of area for a bounding box to remain this box in list.') but causes the problem that if I want to retain only not clipped bboxes, setting `min_visibility=1.0` results in all bboxes are filtered
0.0
85c3c0bbf39b62aec666b9c95cd204a5cdd73803
[ "tests/test_bbox.py::test_bbox_params_edges[transforms1-bboxes1-result_bboxes1-0-1]", "tests/test_bbox.py::test_bbox_params_edges[transforms2-bboxes2-result_bboxes2-10-0]" ]
[ "tests/test_bbox.py::test_normalize_bbox[bbox0-expected0]", "tests/test_bbox.py::test_normalize_bbox[bbox1-expected1]", "tests/test_bbox.py::test_denormalize_bbox[bbox0-expected0]", "tests/test_bbox.py::test_denormalize_bbox[bbox1-expected1]", "tests/test_bbox.py::test_normalize_denormalize_bbox[bbox0]", "tests/test_bbox.py::test_normalize_denormalize_bbox[bbox1]", "tests/test_bbox.py::test_denormalize_normalize_bbox[bbox0]", "tests/test_bbox.py::test_denormalize_normalize_bbox[bbox1]", "tests/test_bbox.py::test_normalize_bboxes", "tests/test_bbox.py::test_denormalize_bboxes", "tests/test_bbox.py::test_calculate_bbox_area[bbox0-50-100-5000]", "tests/test_bbox.py::test_calculate_bbox_area[bbox1-50-50-1600]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox0-coco-expected0]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox1-coco-expected1]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox2-pascal_voc-expected2]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox3-pascal_voc-expected3]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox4-yolo-expected4]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox5-yolo-expected5]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox6-yolo-expected6]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox7-yolo-expected7]", "tests/test_bbox.py::test_convert_bbox_to_albumentations[bbox8-yolo-expected8]", "tests/test_bbox.py::test_convert_bbox_from_albumentations[bbox0-coco-expected0]", "tests/test_bbox.py::test_convert_bbox_from_albumentations[bbox1-coco-expected1]", "tests/test_bbox.py::test_convert_bbox_from_albumentations[bbox2-pascal_voc-expected2]", "tests/test_bbox.py::test_convert_bbox_from_albumentations[bbox3-pascal_voc-expected3]", "tests/test_bbox.py::test_convert_bbox_from_albumentations[bbox4-yolo-expected4]", "tests/test_bbox.py::test_convert_bbox_from_albumentations[bbox5-yolo-expected5]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox0-coco]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox1-coco]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox2-coco]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox3-coco]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox4-coco]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox5-pascal_voc]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox6-pascal_voc]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox7-pascal_voc]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox8-pascal_voc]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox9-pascal_voc]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox10-yolo]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox11-yolo]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox12-yolo]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox13-yolo]", "tests/test_bbox.py::test_convert_bbox_to_albumentations_and_back[bbox14-yolo]", "tests/test_bbox.py::test_convert_bboxes_to_albumentations", "tests/test_bbox.py::test_convert_bboxes_from_albumentations", "tests/test_bbox.py::test_compose_with_bbox_noop[bboxes0-coco-labels0]", "tests/test_bbox.py::test_compose_with_bbox_noop[bboxes1-coco-None]", "tests/test_bbox.py::test_compose_with_bbox_noop[bboxes2-pascal_voc-labels2]", "tests/test_bbox.py::test_compose_with_bbox_noop[bboxes3-pascal_voc-None]", "tests/test_bbox.py::test_compose_with_bbox_noop[bboxes4-yolo-labels4]", "tests/test_bbox.py::test_compose_with_bbox_noop[bboxes5-yolo-None]", "tests/test_bbox.py::test_compose_with_bbox_noop_error_label_fields[bboxes0-coco]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes0-pascal_voc-labels0]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes1-pascal_voc-labels1]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes2-pascal_voc-labels2]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes3-pascal_voc-labels3]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes4-pascal_voc-labels4]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes5-pascal_voc-labels5]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes6-pascal_voc-labels6]", "tests/test_bbox.py::test_compose_with_bbox_noop_label_outside[bboxes7-pascal_voc-labels7]", "tests/test_bbox.py::test_random_sized_crop_size", "tests/test_bbox.py::test_random_resized_crop_size", "tests/test_bbox.py::test_random_rotate", "tests/test_bbox.py::test_crop_boxes_replay_compose", "tests/test_bbox.py::test_bbox_params_edges[transforms0-bboxes0-result_bboxes0-0-0]" ]
{ "failed_lite_validators": [ "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2020-05-04 09:10:24+00:00
mit
1,015
alecthomas__voluptuous-507
diff --git a/voluptuous/schema_builder.py b/voluptuous/schema_builder.py index 6ad8758..f7427f8 100644 --- a/voluptuous/schema_builder.py +++ b/voluptuous/schema_builder.py @@ -1020,7 +1020,11 @@ class VirtualPathComponent(str): class Marker(object): - """Mark nodes for special treatment.""" + """Mark nodes for special treatment. + + `description` is an optional field, unused by Voluptuous itself, but can be used + introspected by any external tool, for example to generate schema documentation. + """ def __init__( self, diff --git a/voluptuous/validators.py b/voluptuous/validators.py index a372afe..9951738 100644 --- a/voluptuous/validators.py +++ b/voluptuous/validators.py @@ -821,9 +821,15 @@ class In(object): except TypeError: check = True if check: - raise InInvalid( - self.msg or 'value must be one of {}'.format(sorted(self.container)) - ) + try: + raise InInvalid( + self.msg or f'value must be one of {sorted(self.container)}' + ) + except TypeError: + raise InInvalid( + self.msg + or f'value must be one of {sorted(self.container, key=str)}' + ) return v def __repr__(self): @@ -845,9 +851,15 @@ class NotIn(object): except TypeError: check = True if check: - raise NotInInvalid( - self.msg or 'value must not be one of {}'.format(sorted(self.container)) - ) + try: + raise NotInInvalid( + self.msg or f'value must not be one of {sorted(self.container)}' + ) + except TypeError: + raise NotInInvalid( + self.msg + or f'value must not be one of {sorted(self.container, key=str)}' + ) return v def __repr__(self):
alecthomas/voluptuous
09d0f066a5f7b80973996c90c54a7bb00f62c905
diff --git a/voluptuous/tests/tests.py b/voluptuous/tests/tests.py index 05b7e8e..7286b31 100644 --- a/voluptuous/tests/tests.py +++ b/voluptuous/tests/tests.py @@ -79,19 +79,54 @@ def test_in(): assert isinstance(ctx.value.errors[0], InInvalid) +def test_in_unsortable_container(): + """Verify that In works with unsortable container.""" + schema = Schema({"type": In((int, str, float))}) + schema({"type": float}) + with pytest.raises( + MultipleInvalid, + match=( + r"value must be one of \[<class 'float'>, <class 'int'>, <class 'str'>\] for dictionary value " + r"@ data\['type'\]" + ), + ) as ctx: + schema({"type": 42}) + assert len(ctx.value.errors) == 1 + assert isinstance(ctx.value.errors[0], InInvalid) + + def test_not_in(): """Verify that NotIn works.""" schema = Schema({"color": NotIn(frozenset(["red", "blue", "yellow"]))}) schema({"color": "orange"}) with pytest.raises( MultipleInvalid, - match=r"value must not be one of \['blue', 'red', 'yellow'\] for dictionary value @ data\['color'\]", + match=( + r"value must not be one of \['blue', 'red', 'yellow'\] for dictionary " + r"value @ data\['color'\]" + ), ) as ctx: schema({"color": "blue"}) assert len(ctx.value.errors) == 1 assert isinstance(ctx.value.errors[0], NotInInvalid) +def test_not_in_unsortable_container(): + """Verify that NotIn works with unsortable container.""" + schema = Schema({"type": NotIn((int, str, float))}) + schema({"type": 42}) + with pytest.raises( + MultipleInvalid, + match=( + r"value must not be one of \[<class 'float'>, <class 'int'>, " + r"<class 'str'>\] for dictionary value @ data\['type'\]" + ), + ) as ctx: + schema({"type": str}) + assert len(ctx.value.errors) == 1 + assert isinstance(ctx.value.errors[0], NotInInvalid) + + def test_contains(): """Verify contains validation method.""" schema = Schema({'color': Contains('red')})
Description argument not documented The `description` argument for the `Marker` class (or any subclass) is not documented anywhere, so it's unclear what's allowed and how it affects the schema.
0.0
09d0f066a5f7b80973996c90c54a7bb00f62c905
[ "voluptuous/tests/tests.py::test_in_unsortable_container", "voluptuous/tests/tests.py::test_not_in_unsortable_container" ]
[ "voluptuous/tests/tests.py::test_new_required_test", "voluptuous/tests/tests.py::test_exact_sequence", "voluptuous/tests/tests.py::test_required", "voluptuous/tests/tests.py::test_extra_with_required", "voluptuous/tests/tests.py::test_iterate_candidates", "voluptuous/tests/tests.py::test_in", "voluptuous/tests/tests.py::test_not_in", "voluptuous/tests/tests.py::test_contains", "voluptuous/tests/tests.py::test_remove", "voluptuous/tests/tests.py::test_extra_empty_errors", "voluptuous/tests/tests.py::test_literal", "voluptuous/tests/tests.py::test_class", "voluptuous/tests/tests.py::test_email_validation", "voluptuous/tests/tests.py::test_email_validation_with_none", "voluptuous/tests/tests.py::test_email_validation_with_empty_string", "voluptuous/tests/tests.py::test_email_validation_without_host", "voluptuous/tests/tests.py::test_email_validation_with_bad_data[[email protected]>]", "voluptuous/tests/tests.py::test_email_validation_with_bad_data[[email protected]!@($*!]", "voluptuous/tests/tests.py::test_fqdn_url_validation", "voluptuous/tests/tests.py::test_fqdn_url_validation_with_bad_data[without", "voluptuous/tests/tests.py::test_fqdn_url_validation_with_bad_data[None]", "voluptuous/tests/tests.py::test_fqdn_url_validation_with_bad_data[empty", "voluptuous/tests/tests.py::test_url_validation", "voluptuous/tests/tests.py::test_url_validation_with_bad_data[None]", "voluptuous/tests/tests.py::test_url_validation_with_bad_data[empty", "voluptuous/tests/tests.py::test_copy_dict_undefined", "voluptuous/tests/tests.py::test_sorting", "voluptuous/tests/tests.py::test_schema_extend", "voluptuous/tests/tests.py::test_schema_extend_overrides", "voluptuous/tests/tests.py::test_schema_extend_key_swap", "voluptuous/tests/tests.py::test_subschema_extension", "voluptuous/tests/tests.py::test_schema_extend_handles_schema_subclass", "voluptuous/tests/tests.py::test_equality", "voluptuous/tests/tests.py::test_equality_negative", "voluptuous/tests/tests.py::test_inequality", "voluptuous/tests/tests.py::test_inequality_negative", "voluptuous/tests/tests.py::test_repr", "voluptuous/tests/tests.py::test_list_validation_messages", "voluptuous/tests/tests.py::test_nested_multiple_validation_errors", "voluptuous/tests/tests.py::test_humanize_error", "voluptuous/tests/tests.py::test_fix_157", "voluptuous/tests/tests.py::test_range_inside", "voluptuous/tests/tests.py::test_range_outside", "voluptuous/tests/tests.py::test_range_no_upper_limit", "voluptuous/tests/tests.py::test_range_no_lower_limit", "voluptuous/tests/tests.py::test_range_excludes_nan", "voluptuous/tests/tests.py::test_range_excludes_none", "voluptuous/tests/tests.py::test_range_excludes_string", "voluptuous/tests/tests.py::test_range_excludes_unordered_object", "voluptuous/tests/tests.py::test_clamp_inside", "voluptuous/tests/tests.py::test_clamp_above", "voluptuous/tests/tests.py::test_clamp_below", "voluptuous/tests/tests.py::test_clamp_invalid", "voluptuous/tests/tests.py::test_length_ok", "voluptuous/tests/tests.py::test_length_too_short", "voluptuous/tests/tests.py::test_length_too_long", "voluptuous/tests/tests.py::test_length_invalid", "voluptuous/tests/tests.py::test_equal", "voluptuous/tests/tests.py::test_unordered", "voluptuous/tests/tests.py::test_maybe", "voluptuous/tests/tests.py::test_maybe_accepts_msg", "voluptuous/tests/tests.py::test_maybe_returns_default_error", "voluptuous/tests/tests.py::test_schema_empty_list", "voluptuous/tests/tests.py::test_schema_empty_dict", "voluptuous/tests/tests.py::test_schema_empty_dict_key", "voluptuous/tests/tests.py::test_schema_decorator_match_with_args", "voluptuous/tests/tests.py::test_schema_decorator_unmatch_with_args", "voluptuous/tests/tests.py::test_schema_decorator_match_with_kwargs", "voluptuous/tests/tests.py::test_schema_decorator_unmatch_with_kwargs", "voluptuous/tests/tests.py::test_schema_decorator_match_return_with_args", "voluptuous/tests/tests.py::test_schema_decorator_unmatch_return_with_args", "voluptuous/tests/tests.py::test_schema_decorator_match_return_with_kwargs", "voluptuous/tests/tests.py::test_schema_decorator_unmatch_return_with_kwargs", "voluptuous/tests/tests.py::test_schema_decorator_return_only_match", "voluptuous/tests/tests.py::test_schema_decorator_return_only_unmatch", "voluptuous/tests/tests.py::test_schema_decorator_partial_match_called_with_args", "voluptuous/tests/tests.py::test_schema_decorator_partial_unmatch_called_with_args", "voluptuous/tests/tests.py::test_schema_decorator_partial_match_called_with_kwargs", "voluptuous/tests/tests.py::test_schema_decorator_partial_unmatch_called_with_kwargs", "voluptuous/tests/tests.py::test_number_validation_with_string", "voluptuous/tests/tests.py::test_number_validation_with_invalid_precision_invalid_scale", "voluptuous/tests/tests.py::test_number_validation_with_valid_precision_scale_yield_decimal_true", "voluptuous/tests/tests.py::test_number_when_precision_scale_none_yield_decimal_true", "voluptuous/tests/tests.py::test_number_when_precision_none_n_valid_scale_case1_yield_decimal_true", "voluptuous/tests/tests.py::test_number_when_precision_none_n_valid_scale_case2_yield_decimal_true", "voluptuous/tests/tests.py::test_number_when_precision_none_n_invalid_scale_yield_decimal_true", "voluptuous/tests/tests.py::test_number_when_valid_precision_n_scale_none_yield_decimal_true", "voluptuous/tests/tests.py::test_number_when_invalid_precision_n_scale_none_yield_decimal_true", "voluptuous/tests/tests.py::test_number_validation_with_valid_precision_scale_yield_decimal_false", "voluptuous/tests/tests.py::test_named_tuples_validate_as_tuples", "voluptuous/tests/tests.py::test_datetime", "voluptuous/tests/tests.py::test_date", "voluptuous/tests/tests.py::test_date_custom_format", "voluptuous/tests/tests.py::test_ordered_dict", "voluptuous/tests/tests.py::test_marker_hashable", "voluptuous/tests/tests.py::test_schema_infer", "voluptuous/tests/tests.py::test_schema_infer_dict", "voluptuous/tests/tests.py::test_schema_infer_list", "voluptuous/tests/tests.py::test_schema_infer_scalar", "voluptuous/tests/tests.py::test_schema_infer_accepts_kwargs", "voluptuous/tests/tests.py::test_validation_performance", "voluptuous/tests/tests.py::test_IsDir", "voluptuous/tests/tests.py::test_IsFile", "voluptuous/tests/tests.py::test_PathExists", "voluptuous/tests/tests.py::test_description", "voluptuous/tests/tests.py::test_SomeOf_min_validation", "voluptuous/tests/tests.py::test_SomeOf_max_validation", "voluptuous/tests/tests.py::test_self_validation", "voluptuous/tests/tests.py::test_any_error_has_path", "voluptuous/tests/tests.py::test_all_error_has_path", "voluptuous/tests/tests.py::test_match_error_has_path", "voluptuous/tests/tests.py::test_path_with_string", "voluptuous/tests/tests.py::test_path_with_list_index", "voluptuous/tests/tests.py::test_path_with_tuple_index", "voluptuous/tests/tests.py::test_path_with_integer_dict_key", "voluptuous/tests/tests.py::test_path_with_float_dict_key", "voluptuous/tests/tests.py::test_path_with_tuple_dict_key", "voluptuous/tests/tests.py::test_path_with_arbitrary_hashable_dict_key", "voluptuous/tests/tests.py::test_self_any", "voluptuous/tests/tests.py::test_self_all", "voluptuous/tests/tests.py::test_SomeOf_on_bounds_assertion", "voluptuous/tests/tests.py::test_comparing_voluptuous_object_to_str", "voluptuous/tests/tests.py::test_set_of_integers", "voluptuous/tests/tests.py::test_frozenset_of_integers", "voluptuous/tests/tests.py::test_set_of_integers_and_strings", "voluptuous/tests/tests.py::test_frozenset_of_integers_and_strings", "voluptuous/tests/tests.py::test_lower_util_handles_various_inputs", "voluptuous/tests/tests.py::test_upper_util_handles_various_inputs", "voluptuous/tests/tests.py::test_capitalize_util_handles_various_inputs", "voluptuous/tests/tests.py::test_title_util_handles_various_inputs", "voluptuous/tests/tests.py::test_strip_util_handles_various_inputs", "voluptuous/tests/tests.py::test_any_required", "voluptuous/tests/tests.py::test_any_required_with_subschema", "voluptuous/tests/tests.py::test_inclusive", "voluptuous/tests/tests.py::test_inclusive_defaults", "voluptuous/tests/tests.py::test_exclusive", "voluptuous/tests/tests.py::test_any_with_discriminant", "voluptuous/tests/tests.py::test_key1", "voluptuous/tests/tests.py::test_key2", "voluptuous/tests/tests.py::test_coerce_enum", "voluptuous/tests/tests.py::test_object", "voluptuous/tests/tests.py::test_exception" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_modified_files", "has_pytest_match_arg" ], "has_test_patch": true, "is_lite": false }
2024-02-01 17:23:42+00:00
bsd-3-clause
1,016
alephdata__followthemoney-871
diff --git a/followthemoney/types/email.py b/followthemoney/types/email.py index 51052f28..275980a1 100644 --- a/followthemoney/types/email.py +++ b/followthemoney/types/email.py @@ -68,7 +68,10 @@ class EmailType(PropertyType): domain = domain.lower() domain = domain.rstrip(".") # handle unicode - domain = domain.encode("idna").decode("ascii") + try: + domain = domain.encode("idna").decode("ascii") + except UnicodeError: + return None if domain is not None and mailbox is not None: return "@".join((mailbox, domain)) return None
alephdata/followthemoney
4b102568a3b3d13a8c4b34de4b7dc0f856a08b9c
diff --git a/tests/types/test_emails.py b/tests/types/test_emails.py index 0c233e81..57d798b0 100644 --- a/tests/types/test_emails.py +++ b/tests/types/test_emails.py @@ -16,6 +16,18 @@ class EmailsTest(unittest.TestCase): self.assertEqual(emails.clean(5), None) self.assertEqual(emails.clean("[email protected]"), "[email protected]") self.assertEqual(emails.clean("[email protected]"), "[email protected]") + self.assertEqual( + emails.clean( + "foo@0123456789012345678901234567890123456789012345678901234567890.example.com" + ), + "foo@0123456789012345678901234567890123456789012345678901234567890.example.com", + ) + self.assertEqual( + emails.clean( + "foo@0123456789012345678901234567890123456789012345678901234567890123.example.com" + ), + None, + ) def test_domain_validity(self): self.assertTrue(emails.validate("[email protected]"))
Better error handling regarding invalid domains in e-mail cleanup I believe https://github.com/alephdata/ingest-file/issues/253 should be fixed here in `followthemoney`, because https://github.com/alephdata/followthemoney/blob/4b102568a3b3d13a8c4b34de4b7dc0f856a08b9c/followthemoney/types/email.py#L71 might [raise a UnicodeError](https://docs.python.org/3/library/stdtypes.html?highlight=encode#str.encode). The suggested change: return `None` if a `UnicodeError` is raised.
0.0
4b102568a3b3d13a8c4b34de4b7dc0f856a08b9c
[ "tests/types/test_emails.py::EmailsTest::test_parse" ]
[ "tests/types/test_emails.py::EmailsTest::test_domain_validity", "tests/types/test_emails.py::EmailsTest::test_specificity" ]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_hyperlinks" ], "has_test_patch": true, "is_lite": false }
2022-11-02 09:13:37+00:00
mit
1,017
alephdata__servicelayer-60
diff --git a/servicelayer/worker.py b/servicelayer/worker.py index 939a3a3..f2a45b3 100644 --- a/servicelayer/worker.py +++ b/servicelayer/worker.py @@ -1,5 +1,6 @@ import signal import logging +import sys from threading import Thread from banal import ensure_list from abc import ABC, abstractmethod @@ -10,7 +11,13 @@ from servicelayer.cache import get_redis from servicelayer.util import unpack_int log = logging.getLogger(__name__) + +# When a worker thread is not blocking, it has to exit if no task is available. +# `TASK_FETCH_RETRY`` determines how many times the worker thread will try to fetch +# a task before quitting. +# `INTERVAL`` determines the interval in seconds between each retry. INTERVAL = 2 +TASK_FETCH_RETRY = 60 / INTERVAL class Worker(ABC): @@ -23,8 +30,10 @@ class Worker(ABC): self.exit_code = 0 def _handle_signal(self, signal, frame): - log.warning("Shutting down worker (signal %s)", signal) + log.warning(f"Shutting down worker (signal {signal})") self.exit_code = int(signal) + # Exit eagerly without waiting for current task to finish running + sys.exit(self.exit_code) def handle_safe(self, task): try: @@ -56,16 +65,25 @@ class Worker(ABC): task.stage.queue(task.payload, task.context) def process(self, blocking=True, interval=INTERVAL): - while True: + retries = 0 + while retries <= TASK_FETCH_RETRY: if self.exit_code > 0: + log.info("Worker thread is exiting") return self.exit_code self.periodic() stages = self.get_stages() task = Stage.get_task(self.conn, stages, timeout=interval) if task is None: if not blocking: - return self.exit_code + # If we get a null task, retry to fetch a task a bunch of times before quitting + if retries >= TASK_FETCH_RETRY: + log.info("Worker thread is exiting") + return self.exit_code + else: + retries += 1 continue + # when we get a good task, reset retry count + retries = 0 self.handle_safe(task) def sync(self): diff --git a/setup.py b/setup.py index 88a915d..79b586f 100644 --- a/setup.py +++ b/setup.py @@ -30,7 +30,7 @@ setup( install_requires=[ "banal >= 1.0.1, <2.0.0", "normality >= 2.1.1, <3.0.0", - "fakeredis == 1.7.0", + "fakeredis == 1.7.1", "sqlalchemy >= 1.3", "structlog >= 20.2.0, < 22.0.0", "colorama >= 0.4.4, < 1.0.0", @@ -39,7 +39,7 @@ setup( "amazon": ["boto3 >= 1.11.9, <2.0.0"], "google": [ "grpcio >= 1.32.0, <2.0.0", - "google-cloud-storage >= 1.31.0, <2.0.0", + "google-cloud-storage >= 1.31.0, < 3.0.0", ], "dev": [ "twine",
alephdata/servicelayer
ebde2a96658c9ecda9a7f9048cd106ef580dda5b
diff --git a/tests/test_worker.py b/tests/test_worker.py index 60e14a9..f4af193 100644 --- a/tests/test_worker.py +++ b/tests/test_worker.py @@ -1,4 +1,5 @@ from unittest import TestCase +import pytest from servicelayer.cache import get_fakeredis from servicelayer.jobs import Job @@ -34,8 +35,6 @@ class WorkerTest(TestCase): assert job.is_done() assert worker.exit_code == 0, worker.exit_code assert worker.test_done == 1, worker.test_done - worker._handle_signal(5, None) - assert worker.exit_code == 5, worker.exit_code worker.retry(task) worker.run(blocking=False) assert job.is_done() @@ -45,3 +44,9 @@ class WorkerTest(TestCase): worker.run(blocking=False) assert job.is_done() assert worker.exit_code == 0, worker.exit_code + try: + worker._handle_signal(5, None) + except SystemExit as exc: + assert exc.code == 5, exc.code + with pytest.raises(SystemExit) as exc: # noqa + worker._handle_signal(5, None)
Worker doesn't exit on KeyboardInterrupt when running in multi-threaded mode
0.0
ebde2a96658c9ecda9a7f9048cd106ef580dda5b
[ "tests/test_worker.py::WorkerTest::test_run" ]
[]
{ "failed_lite_validators": [ "has_short_problem_statement", "has_many_modified_files", "has_many_hunks" ], "has_test_patch": true, "is_lite": false }
2022-02-17 11:13:08+00:00
mit
1,018
alerta__python-alerta-client-205
diff --git a/alertaclient/commands/cmd_heartbeats.py b/alertaclient/commands/cmd_heartbeats.py index b9964ff..5776b2a 100644 --- a/alertaclient/commands/cmd_heartbeats.py +++ b/alertaclient/commands/cmd_heartbeats.py @@ -58,7 +58,7 @@ def cli(obj, alert, severity, timeout, purge): text='Heartbeat not received in {} seconds'.format(b.timeout), tags=b.tags, attributes=b.attributes, - origin=origin, + origin=origin(), type='heartbeatAlert', timeout=timeout, customer=b.customer @@ -76,7 +76,7 @@ def cli(obj, alert, severity, timeout, purge): text='Heartbeat took more than {}ms to be processed'.format(b.max_latency), tags=b.tags, attributes=b.attributes, - origin=origin, + origin=origin(), type='heartbeatAlert', timeout=timeout, customer=b.customer @@ -94,7 +94,7 @@ def cli(obj, alert, severity, timeout, purge): text='Heartbeat OK', tags=b.tags, attributes=b.attributes, - origin=origin, + origin=origin(), type='heartbeatAlert', timeout=timeout, customer=b.customer
alerta/python-alerta-client
a1df91891c9c92ede91513b3caccc8b722b743ca
diff --git a/tests/test_commands.py b/tests/test_commands.py index c0de243..40ed1b2 100644 --- a/tests/test_commands.py +++ b/tests/test_commands.py @@ -6,6 +6,7 @@ from click.testing import CliRunner from alertaclient.api import Client from alertaclient.commands.cmd_heartbeat import cli as heartbeat_cmd +from alertaclient.commands.cmd_heartbeats import cli as heartbeats_cmd from alertaclient.commands.cmd_whoami import cli as whoami_cmd from alertaclient.config import Config @@ -22,14 +23,14 @@ class CommandsTestCase(unittest.TestCase): self.runner = CliRunner(echo_stdin=True) @requests_mock.mock() - def test_send_cmd(self, m): + def test_heartbeat_cmd(self, m): config_response = """ {} """ m.get('/config', text=config_response) - send_response = """ + heartbeat_response = """ { "heartbeat": { "attributes": { @@ -58,11 +59,111 @@ class CommandsTestCase(unittest.TestCase): } """ - m.post('/heartbeat', text=send_response) + m.post('/heartbeat', text=heartbeat_response) result = self.runner.invoke(heartbeat_cmd, ['-E', 'Production', '-S', 'Web', '-s', 'major'], obj=self.obj) UUID(result.output.strip()) self.assertEqual(result.exit_code, 0) + @requests_mock.mock() + def test_heartbeats_cmd(self, m): + + config_response = """ + {} + """ + m.get('/config', text=config_response) + + heartbeats_response = """ + { + "heartbeats": [ + { + "attributes": { + "environment": "infrastructure" + }, + "createTime": "2020-03-10T20:25:54.541Z", + "customer": null, + "href": "http://127.0.0.1/heartbeat/52c202e8-d949-45ed-91e0-cdad4f37de73", + "id": "52c202e8-d949-45ed-91e0-cdad4f37de73", + "latency": 0, + "maxLatency": 2000, + "origin": "monitoring-01", + "receiveTime": "2020-03-10T20:25:54.541Z", + "since": 204, + "status": "expired", + "tags": [], + "timeout": 90, + "type": "Heartbeat" + } + ], + "status": "ok", + "total": 1 + } + """ + + heartbeat_alert_response = """ + { + "alert": { + "attributes": { + "environment": "infrastructure" + }, + "correlate": [ + "HeartbeatFail", + "HeartbeatSlow", + "HeartbeatOK" + ], + "createTime": "2020-03-10T21:55:07.884Z", + "customer": null, + "duplicateCount": 0, + "environment": "infrastructure", + "event": "HeartbeatSlow", + "group": "System", + "history": [ + { + "event": "HeartbeatSlow", + "href": "http://api.local.alerta.io:8080/alert/6cfbc30f-c2d6-4edf-b672-841070995206", + "id": "6cfbc30f-c2d6-4edf-b672-841070995206", + "severity": "High", + "status": "open", + "text": "new alert", + "type": "new", + "updateTime": "2020-03-10T21:55:07.884Z", + "user": null, + "value": "22ms" + } + ], + "href": "http://api.local.alerta.io:8080/alert/6cfbc30f-c2d6-4edf-b672-841070995206", + "id": "6cfbc30f-c2d6-4edf-b672-841070995206", + "lastReceiveId": "6cfbc30f-c2d6-4edf-b672-841070995206", + "lastReceiveTime": "2020-03-10T21:55:07.916Z", + "origin": "alerta/macbook.lan", + "previousSeverity": "Not classified", + "rawData": null, + "receiveTime": "2020-03-10T21:55:07.916Z", + "repeat": false, + "resource": "monitoring-01", + "service": [ + "Alerta" + ], + "severity": "High", + "status": "open", + "tags": [], + "text": "Heartbeat took more than 2ms to be processed", + "timeout": 86000, + "trendIndication": "moreSevere", + "type": "heartbeatAlert", + "updateTime": "2020-03-10T21:55:07.916Z", + "value": "22ms" + }, + "id": "6cfbc30f-c2d6-4edf-b672-841070995206", + "status": "ok" + } + """ + + m.get('/heartbeats', text=heartbeats_response) + m.post('/alert', text=heartbeat_alert_response) + result = self.runner.invoke(heartbeats_cmd, ['--alert'], obj=self.obj) + self.assertEqual(result.exit_code, 0, result.exception) + self.assertIn('monitoring-01', result.output) + @requests_mock.mock() def test_whoami_cmd(self, m):
`alerta heartbeats --alert` broken **Issue Summary** after last update got exception on alerta heartbeats --alert **Environment** - OS: linux ubuntu 16.04 - API version: 7.4.4 - Deployment: self-hosted - For self-hosted, WSGI environment: nginx/uwsgi - Database: postgresql - Server config: Auth enabled? Yes Auth provider? Basic Customer views? No **To Reproduce** Steps to reproduce the behavior: 1. pip install alerta==7.4.4 2. ALERTA_ENDPOINT=http://localhost/api ALERTA_API_KEY=<skipped> alerta heartbeats --timeout 600 --alert ``` Traceback (most recent call last): File "/srv/projects/venv3/bin/alerta", line 11, in <module> sys.exit(cli()) File "/srv/projects/venv3/lib/python3.5/site-packages/click/core.py", line 829, in __call__ return self.main(*args, **kwargs) File "/srv/projects/venv3/lib/python3.5/site-packages/click/core.py", line 782, in main rv = self.invoke(ctx) File "/srv/projects/venv3/lib/python3.5/site-packages/click/core.py", line 1259, in invoke return _process_result(sub_ctx.command.invoke(sub_ctx)) File "/srv/projects/venv3/lib/python3.5/site-packages/click/core.py", line 1066, in invoke return ctx.invoke(self.callback, **ctx.params) File "/srv/projects/venv3/lib/python3.5/site-packages/click/core.py", line 610, in invoke return callback(*args, **kwargs) File "/srv/projects/venv3/lib/python3.5/site-packages/click/decorators.py", line 33, in new_func return f(get_current_context().obj, *args, **kwargs) File "/srv/projects/venv3/lib/python3.5/site-packages/alertaclient/commands/cmd_heartbeats.py", line 100, in cli customer=b.customer File "/srv/projects/venv3/lib/python3.5/site-packages/alertaclient/api.py", line 65, in send_alert r = self.http.post('/alert', data) File "/srv/projects/venv3/lib/python3.5/site-packages/alertaclient/api.py", line 519, in post response = self.session.post(url, data=json.dumps(data, cls=CustomJsonEncoder), File "/usr/lib/python3.5/json/__init__.py", line 237, in dumps **kw).encode(obj) File "/usr/lib/python3.5/json/encoder.py", line 198, in encode chunks = self.iterencode(o, _one_shot=True) File "/usr/lib/python3.5/json/encoder.py", line 256, in iterencode return _iterencode(o, 0) File "/srv/projects/venv3/lib/python3.5/site-packages/alertaclient/utils.py", line 18, in default return json.JSONEncoder.default(self, o) File "/usr/lib/python3.5/json/encoder.py", line 179, in default raise TypeError(repr(o) + " is not JSON serializable") TypeError: <function origin at 0x7f5cba65ad90> is not JSON serializable ``` **Expected behavior** ``` Alerting heartbeats [####################################] 100% ``` **Additional context** temporary workaround: 1. pip install alerta==7.4.0
0.0
a1df91891c9c92ede91513b3caccc8b722b743ca
[ "tests/test_commands.py::CommandsTestCase::test_heartbeats_cmd" ]
[ "tests/test_commands.py::CommandsTestCase::test_whoami_cmd", "tests/test_commands.py::CommandsTestCase::test_heartbeat_cmd" ]
{ "failed_lite_validators": [ "has_hyperlinks" ], "has_test_patch": true, "is_lite": false }
2020-03-10 22:11:08+00:00
apache-2.0
1,019