11:50:54.464 | INFO | prefect.infrastructure.process - Opening process 'tuscan-catfish'... 11:50:54.468 | INFO | prefect.agent - Completed submission of flow run '04a25570-e849-4c8a-8d3a-dfc2c1fe0b96' 11:50:58.416 | INFO | Flow run 'tuscan-catfish' - Starting 'ConcurrentTaskRunner'; submitted tasks will be run concurrently... 11:50:58.632 | INFO | Flow run 'tuscan-catfish' - Created task run 'trigger_sync-6dd98a16-0' for task 'trigger_sync' 11:50:58.632 | INFO | Flow run 'tuscan-catfish' - Executing 'trigger_sync-6dd98a16-0' immediately... 11:50:58.669 | INFO | prefect - Getting Airbyte Connection 828224ea-4052-41a5-85ba-7b5708214088, poll interval 3 seconds, airbyte_base_url http://localhost:8000/api/v1 11:50:59.118 | INFO | prefect - running 11:51:02.144 | INFO | prefect - running 11:51:05.167 | INFO | prefect - running 11:51:08.205 | INFO | prefect - running 11:51:11.285 | INFO | prefect - running 11:51:14.328 | INFO | prefect - running 11:51:17.369 | INFO | prefect - running 11:51:20.406 | INFO | prefect - running 11:51:23.453 | INFO | prefect - running 11:51:26.511 | INFO | prefect - running 11:51:29.550 | INFO | prefect - running 11:51:32.593 | INFO | prefect - Job 6 succeeded. 11:51:32.629 | INFO | Task run 'trigger_sync-6dd98a16-0' - Finished in state Completed() 11:51:32.667 | INFO | Flow run 'tuscan-catfish' - Created task run 'trigger_dbt_cli_command-321ca940-0' for task 'trigger_dbt_cli_command' 11:51:32.668 | INFO | Flow run 'tuscan-catfish' - Executing 'trigger_dbt_cli_command-321ca940-0' immediately... 11:51:32.711 | INFO | Task run 'trigger_dbt_cli_command-321ca940-0' - Running dbt command: dbt run --profiles-dir C:\Users\micka\.dbt --project-dir C:\Users\micka\Projects\article_1 11:51:32.809 | ERROR | Task run 'trigger_dbt_cli_command-321ca940-0' - 11:51:32.809 | ERROR | Task run 'trigger_dbt_cli_command-321ca940-0' - Encountered exception during execution: Traceback (most recent call last): File "C:\tools\python3\lib\site-packages\prefect\engine.py", line 1039, in orchestrate_task_run result = await task.fn(*args, **kwargs) File "C:\tools\python3\lib\site-packages\prefect_dbt\cli\commands.py", line 152, in trigger_dbt_cli_command result = await shell_run_command.fn(command=command, **shell_run_command_kwargs) File "C:\tools\python3\lib\site-packages\prefect_shell\commands.py", line 56, in shell_run_command result = await utils_run_command( File "C:\tools\python3\lib\site-packages\prefect_shell\utils.py", line 81, in shell_run_command raise RuntimeError(msg) RuntimeError: Command failed with exit code 1 11:51:32.847 | ERROR | Task run 'trigger_dbt_cli_command-321ca940-0' - Finished in state Failed('Task run encountered an exception.') 11:51:32.847 | ERROR | Flow run 'tuscan-catfish' - Encountered exception during execution: Traceback (most recent call last): File "C:\tools\python3\lib\site-packages\prefect\engine.py", line 559, in orchestrate_flow_run result = await run_sync(flow_call) File "C:\tools\python3\lib\site-packages\prefect\utilities\asyncutils.py", line 56, in run_sync_in_worker_thread return await anyio.to_thread.run_sync(call, cancellable=True) File "C:\tools\python3\lib\site-packages\anyio\to_thread.py", line 31, in run_sync return await get_asynclib().run_sync_in_worker_thread( File "C:\tools\python3\lib\site-packages\anyio\_backends\_asyncio.py", line 937, in run_sync_in_worker_thread return await future File "C:\tools\python3\lib\site-packages\anyio\_backends\_asyncio.py", line 867, in run result = context.run(func, *args) File "C:\Users\micka\AppData\Local\Temp\tmp9rkfcxul\main_flow.py", line 16, in airbyte_dbt_flow File "C:\tools\python3\lib\site-packages\prefect\tasks.py", line 282, in __call__ return enter_task_run_engine( File "C:\tools\python3\lib\site-packages\prefect\engine.py", line 688, in enter_task_run_engine return run_async_from_worker_thread(begin_run) File "C:\tools\python3\lib\site-packages\prefect\utilities\asyncutils.py", line 136, in run_async_from_worker_thread return anyio.from_thread.run(call) File "C:\tools\python3\lib\site-packages\anyio\from_thread.py", line 49, in run return asynclib.run_async_from_thread(func, *args) File "C:\tools\python3\lib\site-packages\anyio\_backends\_asyncio.py", line 970, in run_async_from_thread return f.result() File "C:\tools\python3\lib\concurrent\futures\_base.py", line 440, in result return self.__get_result() File "C:\tools\python3\lib\concurrent\futures\_base.py", line 389, in __get_result raise self._exception File "C:\tools\python3\lib\site-packages\prefect\engine.py", line 803, in create_task_run_then_submit return await future._result() File "C:\tools\python3\lib\site-packages\prefect\futures.py", line 220, in _result return final_state.result(raise_on_failure=raise_on_failure) File "C:\tools\python3\lib\site-packages\prefect\orion\schemas\states.py", line 145, in result raise data File "C:\tools\python3\lib\site-packages\prefect\engine.py", line 1039, in orchestrate_task_run result = await task.fn(*args, **kwargs) File "C:\tools\python3\lib\site-packages\prefect_dbt\cli\commands.py", line 152, in trigger_dbt_cli_command result = await shell_run_command.fn(command=command, **shell_run_command_kwargs) File "C:\tools\python3\lib\site-packages\prefect_shell\commands.py", line 56, in shell_run_command result = await utils_run_command( File "C:\tools\python3\lib\site-packages\prefect_shell\utils.py", line 81, in shell_run_command raise RuntimeError(msg) RuntimeError: Command failed with exit code 1 11:51:32.896 | ERROR | Flow run 'tuscan-catfish' - Finished in state Failed('Flow run encountered an exception.') Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed {'job': {'id': 6, 'configType': 'sync', 'configId': '828224ea-4052-41a5-85ba-7b5708214088', 'createdAt': 1658829058, 'updatedAt': 1658829058, 'status': 'running'}, 'attempts': [{'attempt': {'id': 0, 'status': 'running', 'createdAt': 1658829058, 'updatedAt': 1658829058, 'streamStats': []}, 'logs': {'logLines': ['2022-07-26 09:50:59 \x1b[32mINFO\x1b[m i.a.w.t.TemporalAttemptExecution(get):108 - Docker volume job log path: /tmp/workspace/6/0/logs.log', '2022-07-26 09:50:59 \x1b[32mINFO\x1b[m i.a.w.t.TemporalAttemptExecution(get):113 - Executing worker wrapper. Airbyte version: 0.39.37-alpha']}}]} Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed Exception ignored in: Traceback (most recent call last): File "C:\tools\python3\lib\asyncio\proactor_events.py", line 116, in __del__ self.close() File "C:\tools\python3\lib\asyncio\proactor_events.py", line 108, in close self._loop.call_soon(self._call_connection_lost, None) File "C:\tools\python3\lib\asyncio\base_events.py", line 746, in call_soon self._check_closed() File "C:\tools\python3\lib\asyncio\base_events.py", line 510, in _check_closed raise RuntimeError('Event loop is closed') RuntimeError: Event loop is closed 11:51:33.219 | INFO | prefect.infrastructure.process - Process 'tuscan-catfish' exited cleanly.