Kyle McEntush
12/24/2022, 7:19 PMdef f():
Kyle McEntush
12/24/2022, 7:20 PMnout
as a task arg, but I can't find the equivalent in the docs...Shubham Wani
12/24/2022, 7:39 PMcursor.executemany(query, values),
I run the
connection.commit()
to to transfer all data from buffer to the table in dataset.
Error faced in the following command:
connection.commit()
Error:
00:12:33.556 | ERROR | Task run 'load_records-41eb504c-0' - Encountered exception during execution:
Traceback (most recent call last):
File "/home/shubhamwani/nice/edilitics-server/edilitics-env/lib/python3.8/site-packages/prefect/engine.py", line 1346, in orchestrate_task_run
result = await run_sync(task.fn, *args, **kwargs)
File "/home/shubhamwani/nice/edilitics-server/edilitics-env/lib/python3.8/site-packages/prefect/utilities/asyncutils.py", line 69, in run_sync_in_worker_thread
return await anyio.to_thread.run_sync(call, cancellable=True)
File "/home/shubhamwani/nice/edilitics-server/edilitics-env/lib/python3.8/site-packages/anyio/to_thread.py", line 31, in run_sync
return await get_asynclib().run_sync_in_worker_thread(
File "/home/shubhamwani/nice/edilitics-server/edilitics-env/lib/python3.8/site-packages/anyio/_backends/_asyncio.py", line 937, in run_sync_in_worker_thread
return await future
File "/home/shubhamwani/nice/edilitics-server/edilitics-env/lib/python3.8/site-packages/anyio/_backends/_asyncio.py", line 867, in run
result = context.run(func, *args)
File "/home/shubhamwani/nice/edilitics-server/prefect_flows/load/prefect2_tasks.py", line 166, in load_records
(
TypeError: cannot unpack non-iterable NoneType object
I've tried using different sql connectors(mysqlclient, mysql-connector, pymysql), but the error persists.
is this somehow related to prefect?
anyone else facing this issue?
Any help is welcomed, Thanks.Shruti Hande
12/26/2022, 4:40 AMprefect.exceptions.PrefectHTTPStatusError: Server error '500 Internal Server Error' for url '<https://api.prefect.cloud/api/accounts/2f48cb6f->
0049-4569-879d-7123d9113e31/workspaces/9da885d9-9d9f-4ee9-9b42-84bfb4a3d9aa/work_queues/name/queue_5'
Response: {'exception_message': 'Internal Server Error'}
Aditya Sharma
12/26/2022, 8:03 AMAditya Sharma
12/26/2022, 8:03 AMAditya Sharma
12/26/2022, 8:04 AMJelle Vegter
12/26/2022, 1:32 PMKelvin DeCosta
12/26/2022, 1:50 PMprefect
blocks not being registered.
The hosted agent must run something that looks like this:
prefect block register -m prefect_azure.container_instance
Ollie Sellers
12/26/2022, 9:33 PMRikimaru Yamaguchi
12/27/2022, 12:58 AMDavid Cheedie
12/27/2022, 2:54 PMDavid Cheedie
12/27/2022, 3:03 PMDec 24 22:04:58 linux prefect[279492]: 22:04:58.602 | ERROR | prefect.agent - Server error '500 Internal Server Error' for url
The service failed, tried to restart a few times, was unsuccessful, and then our scheduled jobs on prefect cloud switched to state=Late
I'd like to rule out that this was an error on the prefect cloud side, does anyone know anything about prefect cloud issues around 12/24 22:04 UTC?Michael Levenson
12/27/2022, 4:41 PMPrefect Core Version: 1.2.4
I trigger a flow run from a github actions step and it just hangs (happened yesterday and the run state was still in progress for 2 days) even though the job does not exist
I know the flow did not finish because I see that my ml model tracking service did not register a new model
I triggered the flow manually and it successfully completed.
This flow is also scheduled and completes.
What could be causing this issue?PKay
12/27/2022, 5:14 PMChris Whatley
12/27/2022, 5:54 PMJohn-Craig Borman
12/27/2022, 7:35 PMSebastian Steele
12/27/2022, 8:57 PMMatt Morris
12/27/2022, 9:06 PMConcurrentTaskRunner
! However, I am noticing that the speed of using prefect_dask.DaskTaskRunner
is slower than using prefect.executors.DaskExecutor
(prefect 1). In both cases I was using processes rather than threads. Speed depends on the task, but some tasks that read from s3 are taking a little over twice as long with the DaskTaskRunner
. Has anyone faced something or similar, or any pointers as to why I may be experiencing this? Thanks!Rikimaru Yamaguchi
12/28/2022, 5:30 AMMohit Singhal
12/28/2022, 11:45 AMAbosede Oladipo
12/28/2022, 12:59 PMAbosede Oladipo
12/28/2022, 1:47 PMprefect block ls
, but I can't seem to find anything in the docks using python code.Tadej Svetina
12/28/2022, 6:00 PMDalin Stone
12/28/2022, 7:25 PMKen Nguyen
12/28/2022, 7:53 PMimport prefect
from prefect import task, Flow
from prefect.storage import GitHub
from prefect.run_configs import ECSRun
from prefect.client import Secret
However, when I run my code now (Prefect 2.7.4), I get a ModuleNotFoundError: No module named 'prefect.storage'
error (same goes for prefect.run_configs
and prefect.client
). Was there a recent update to the way we should import these modules?CA Lee
12/29/2022, 8:39 AMPaco Ibañez
12/29/2022, 3:03 PM@flow
def hello():
"""
Is there a way to get the text in here to be formatted in the awesome prefect UI?
"""
pass
Chris Gunderson
12/29/2022, 3:57 PMDalin Stone
12/29/2022, 4:20 PMDalin Stone
12/29/2022, 4:20 PMAnna Geller
12/29/2022, 4:44 PMDalin Stone
12/29/2022, 5:27 PMAnna Geller
12/30/2022, 12:58 AMDalin Stone
12/30/2022, 3:12 PM