Deepanshu Aggarwal
11/15/2022, 6:12 AMShruti Hande
11/15/2022, 6:55 AM11:13:27.904 | ERROR | Flow run 'pink-pogona' - Crash detected! Request to <prefect cloud url >/task_runs/ failed: Traceback (most recent call last):
File "/home/<my_username>/<my_venv_name>/lib/python3.8/site-packages/anyio/streams/tls.py", line 108, in _call_sslobject_method
result = func(*args)
File "/usr/lib/python3.8/ssl.py", line 944, in do_handshake
self._sslobj.do_handshake()
ssl.SSLSyscallError: Some I/O error occurred (_ssl.c:1131)
#prefect-community #prefect-cloudAndreas Nigg
11/15/2022, 6:57 AMAndreas Nigg
11/15/2022, 6:59 AMVadym Dytyniak
11/15/2022, 8:53 AMmax
11/15/2022, 10:32 AMprefect work-queue set-concurrency-limit
?Simon Macklin
11/15/2022, 11:25 AMFuETL
11/15/2022, 3:17 PMBlake Hamm
11/15/2022, 3:26 PMredsquare
11/15/2022, 3:48 PMKalise Richmond
11/15/2022, 4:47 PMvholmer
11/15/2022, 5:00 PMCrash detected! Request to <https://api.prefect.cloud/api/accounts/CENSORED/workspaces/CENSORED/flow_runs/CENSORED/set_state> failed: Traceback (most recent call last):
File "/usr/local/lib/python3.8/site-packages/httpcore/backends/asyncio.py", line 33, in read
return await self._stream.receive(max_bytes=max_bytes)
File "/usr/local/lib/python3.8/site-packages/anyio/streams/tls.py", line 195, in receive
data = await self._call_sslobject_method(self._ssl_object.read, max_bytes)
File "/usr/local/lib/python3.8/site-packages/anyio/streams/tls.py", line 137, in _call_sslobject_method
data = await self.transport_stream.receive()
File "/usr/local/lib/python3.8/site-packages/anyio/_backends/_asyncio.py", line 1265, in receive
await self._protocol.read_event.wait()
File "/usr/local/lib/python3.8/asyncio/locks.py", line 309, in wait
await fut
asyncio.exceptions.CancelledError
The URL points to the flow's own id. What's going on here? Did anyone else experience this?Luca Schneider
11/15/2022, 5:21 PMSowmiya Anand
11/15/2022, 5:48 PMMadison Schott
11/15/2022, 5:55 PMfrom prefect_fivetran.connectors import fivetran_sync_flow
ImportError: cannot import name 'fivetran_sync_flow' from 'prefect_fivetran.connectors' (/usr/local/lib/python3.9/site-packages/prefect_fivetran/connectors.py)
Amey Desai
11/15/2022, 6:40 PMSam Garvis
11/15/2022, 6:50 PMwhile true:
in the flow, but that has always shut down in the past after a few hours on 2.0Nathaniel Russell
11/15/2022, 8:04 PMIf this isn't clear:
flow run A is running
flow run A has list of info on flow runs B -> G
flow run A picks out flow run D
I want flow run A to wait until flow run D is done before continuing, how do I do this step?
Jeff Rose
11/15/2022, 8:33 PMSegmentation fault (core dumped)
. I have run this using different version of pandas (1.5.1 and 1.3.5) and still get the same error. I am able to import pandas and run a command such as pd.show_versions()
without issues but whenever I try to run anything that would create a dataframe I get the segfault error.
Including my currently installed versions and the flow I am trying to run below. Thanks in advance!Anders Smedegaard Pedersen
11/15/2022, 8:42 PMSamuel Kohlleffel
11/15/2022, 8:47 PMIlya Galperin
11/15/2022, 9:23 PMsync_task
will never start and the flow just seems to hang. The intention here is to run some asynchronous tasks, gather the results, then send those results to a synchronous or blocking task that can be executed sequentially (or submitted to a concurrent task runner).
The equivalent code works in a standard Python script if we remove our Prefect decorators.
from prefect import flow, task
import asyncio, time
@task
async def async_task(n):
await asyncio.sleep(1)
return n
@task
def sync_task(res):
time.sleep(1)
print(res)
@flow
async def async_flow():
res = await asyncio.gather(*(async_task(n) for n in range(0, 3, 1)))
sync_task(res)
if __name__ == "__main__":
asyncio.run(async_flow())
See output in replies.Madison Schott
11/15/2022, 9:23 PMawait
from the function, any ideas?
A 'sync_compatible' method was called from a context that was previously async but is now sync. The sync call must be changed to run in a worker thread to support sending the coroutine for 'load' to the main thread.
Blake Stefansen
11/15/2022, 10:00 PMFailed to submit flow run to infrastructure
https://prefect-community.slack.com/archives/CL09KU1K7/p1663166587656539
Details in threadBoggdan Barrientos
11/15/2022, 11:19 PMInvalid input ConnectionInputs.RECV_PING in state ConnectionState.CLOSED
complete logs in the thread.Ben Muller
11/16/2022, 1:09 AMState message: Submission failed. RuntimeError: Timed out after 120.81494164466858s while watching task for status {until_status or 'STOPPED'}
Can I handle this somehow? is this handled by the task_start_timeout_seconds
?Tom Klein
11/16/2022, 7:40 AMSunjay
11/16/2022, 9:35 AMLuca Schneider
11/16/2022, 10:44 AM@flow
def flow():
f1 = subflow1()
f2 = subflow2()
data1 = task1.submit(wait_for=[f1, f2])
data2 = task2().submit()
data3 = task3.submit(data1, data2, wait_for=[data1, data2])
if data3.result():
data4 = task4.submit(data3, wait_for=[data3])
task5.submit(data4, wait_for=[data4])
else:
pass
Shruti Hande
11/16/2022, 10:57 AM12:41:52.823 | ERROR | Task run 'flow-3aa4322b-126' - Crash detected! Execution was cancelled by the runtime environment
.
12:46:59.458 | ERROR | Flow run 'eminent-heron' - Crash detected! Request to <https://api.prefect.cloud/api/accounts/2f48>
cb6f-0049-4569-879d-7123d9113e31/workspaces/9da885d9-9d9f-4ee9-9b42-84bfb4a3d9aa/task_runs/ failed: Traceback (most recent
call last):
File "/home/shrutihande/python_venv/lib/python3.8/site-packages/httpcore/backends/asyncio.py", line 33, in read
return await self._stream.receive(max_bytes=max_bytes)
File "/home/shrutihande/python_venv/lib/python3.8/site-packages/anyio/streams/tls.py", line 171, in receive
data = await self._call_sslobject_method(self._ssl_object.read, max_bytes)
File "/home/shrutihande/python_venv/lib/python3.8/site-packages/anyio/streams/tls.py", line 115, in _call_sslobject_meth
od
data = await self.transport_stream.receive()
File "/home/shrutihande/python_venv/lib/python3.8/site-packages/anyio/_backends/_asyncio.py", line 1105, in receive
await self._protocol.read_event.wait()
File "/usr/lib/python3.8/asyncio/locks.py", line 309, in wait
await fut
asyncio.exceptions.CancelledError