Luis Henrique Dallelaste Bernartt
03/25/2025, 5:46 PMsadath
03/26/2025, 5:25 AMVlad
03/26/2025, 9:31 AMSam Greenwood
03/26/2025, 11:46 AMprefect deploy
issue which was reliably producing badly built images for ECR which EKS then refused to run (EKS reported on bad hash on image pull, imagePullErr).
I had had this issue for over a week and tried everything with installing/re-installing Docker, different package manager venvs, different project layouts for prefect.yaml, etc.
In the end, the solution was to disable the containerd image store in Docker Desktop.
With that checkbox unticked, the prefect deploy
worked first time, with it checked it would reliably not work.
This is Prefect 3.2 with Python 3.12.Abdul Raheem Siddiqui
06/27/2025, 10:26 PMMartin Klefas
06/27/2025, 11:15 PMBen Epstein
06/29/2025, 12:34 AMMohammad Nassar
06/29/2025, 10:22 AMMohammed Noureldin
06/29/2025, 5:40 PM.deploy
, as Prefect does not output anything but the very latest error, which is mostly missing the context and the text of the real fatal error. While building (in the deploy step) a custom image, it only shows building, without the steps, and if an error happens, show the "error" message, while a the real message, when using docker build, is in the fatal message, which prefect just does not show. Can we make prefect show all of the building steps, just like docker build?Royzac
06/29/2025, 10:54 PMMohammed Noureldin
06/29/2025, 11:48 PM.deploy
to build the whole image again.
I already tried
image=DockerImage(
name="myworkflow",
tag="latest",
dockerfile="Dockerfile",
build_kwargs={"nocache": True},
But for some reason the build_kwargs is not recognized (I am getting an error)Tobias Bjormyr
06/30/2025, 11:26 AMLegacy Free Tier
to Starter Tier
, but when we try to initiate the process by clicking on "Upgrade" we get this error.
I've already emailed <mailto:help@prefect.io|help@prefect.io>
early on Friday - still waiting for answers.
Does anyone know the normal response time? I haven't received a notification that the support case has been received.
Is this a normal bug people have seen before?Robin
06/30/2025, 1:11 PMPav Staz
06/30/2025, 5:00 PM@task
async def check_logs():
async with get_client() as client:
# Ensure any pending logs are sent
await APILogHandler.aflush()
logs = await client.read_logs(
LogFilter(flow_run_id={"any_": [runtime.flow_run.id]})
)
records = []
for log in logs:
# Gets task run and flow run info
if log.task_run_id is not None:
task_runs = await client.read_task_runs(
task_run_filter=TaskRunFilter(id=TaskRunFilterId(any_=[log.task_run_id]))
)
task_run = task_runs[0]
task_run_name = task_run.name
print("-------------------- Task Run Details ----------------------------")
print(task_run)
print("------------------------------------------------------------------")
if task_run.flow_run_id is not None:
flow_runs = await client.read_flow_runs(
flow_run_filter=FlowRunFilter(id=FlowRunFilterId(any_=[task_run.flow_run_id]))
)
flow_run = flow_runs[0]
print("-------------------- Flow Run Details ----------------------------")
print(flow_run)
print("------------------------------------------------------------------")
if flow_run.flow_id is not None:
flow = await client.read_flow(flow_run.flow_id)
print(f"Flow name is {flow.name}")
print(log)
@flow(log_prints=True)
def daily_flow():
## A subflow
some_subflow()
## A task
some_task()
check_logs.submit()
# only logs of the some_task are printed by the check_logs function, not the some_subflow function
Thomas Cobban
07/01/2025, 4:41 AMkrishnaprasad k
07/01/2025, 7:04 AMdt = <http://self.tz|self.tz>.convert(dt)
AttributeError: 'NoneType' object has no attribute 'convert'
Giacomo Chiarella
07/01/2025, 11:04 AMLina Carmona
07/01/2025, 11:30 AM...
@flow(
name="Scrapers sub-flow",
task_runner=DaskTaskRunner(
cluster_kwargs={"n_workers": 1, "processes": False, "threads_per_worker": 20}
),
)
def scraper(splitted_files: list[str], run_timestamp: str, success_threshold: float):
logger = get_run_logger()
...
walter
07/01/2025, 5:32 PMGiacomo Chiarella
07/01/2025, 6:46 PMDemid
07/02/2025, 7:00 AMIdan Elhalwani
07/02/2025, 9:41 AMNils Birth-Sickel
07/02/2025, 11:43 AMSrikar Kolukuluri
07/02/2025, 1:05 PMRussell Brooks
07/02/2025, 2:11 PMGiacomo Chiarella
07/02/2025, 2:20 PMtask_filter = TaskRunFilter(
tags=TaskRunFilterTags(all_=[tag]),
state_type=TaskRunFilterStateType(
any_=[
StateType.RUNNING.value,
StateType.PENDING.value,
StateType.CANCELLING.value,
StateType.SCHEDULED.value,
StateType.PAUSED.value
]
)
)
but despite in the class doc it is written that it returns task runs meeting all conditions, it looks like it is an OR. Does it happen to you also?Nick Torba
07/02/2025, 8:45 PMprefect server start --port 4201
as I have before, but I get this message in the bottom right of the browser:
Can't connect to Server API at <http://localhost:4200/api>. Check that it's accessible from your machine.
and nothing shows up in the UI when I run flows. Can anyone help me figure out what is wrong?
I have tried on each of 3.4.4, 3.4.5, 3.4.6, and 3.4.7. I can't get this working on any of themDavid Martin Calalang
07/03/2025, 2:23 PMArthur Ren
07/03/2025, 3:27 PM{
"type": "event",
"match": {},
"match_related": {},
"after": [
"some.event.completed"
],
"expect": [
"some.event.completed"
],
"for_each": [],
"posture": "Reactive",
"threshold": 1,
"within": 3600
}
And here’s an event I sent and confirmed the engine received, does anyone know why won’t this event trigger the automation?datamongus
07/03/2025, 11:19 PM