George Shishorin
06/30/2022, 10:52 AMmodule not found
. Could you please help with it?
---> threadAnna Geller
06/30/2022, 11:22 AMJehan Abduljabbar
06/30/2022, 2:21 PMJoshua Greenhalgh
06/30/2022, 2:51 PMValueError: the greenlet library is required to use this function. No module named 'greenlet'
Any ideas?JK
06/30/2022, 3:01 PMIsara Ovin
06/30/2022, 3:04 PMfor col in date_columns:
if col in df_columns:
df[col] = df[col].str.replace('/', '-')
with mp.Pool(mp.cpu_count()) as pool:
df[col] = pool.map(get_parsed_date, df[col])
Jessica Smith
06/30/2022, 5:05 PMPagerDutyNotificationAction
(24dfaasdfe-93dd-4b11-8dddc-4xxxxxx3d23
) has failed with 'HTTPError: 202 Accepted 'PagerDuty did not provide error details.' while contacting service API. Check your action configuration. See the Pagerduty docs for more details on error handling.' during execution triggered by FlowSLAFailedEvent
event from hook b625xx8-d3x-4xxe-bxx6-1xxxxxx67f2
.Muhammad Usman Ghani
06/30/2022, 5:12 PMSushma Adari
06/30/2022, 7:37 PMTypeError: Object of type DataFrame is not JSON serializable
Madison Schott
06/30/2022, 8:30 PMFlowRenameTask
File "/Users/madisonschott/dbt_snowflake/data_pipeline_test_new_account.py", line 5, in <module>
from prefect.tasks.prefect.flow_rename import FlowRenameTask
ModuleNotFoundError: No module named 'prefect.tasks.prefect.flow_rename'
JK
06/30/2022, 9:11 PMKeyError: 'xxx'
Emil Ordoñez
06/30/2022, 10:04 PMyu zeng
07/01/2022, 3:32 AMOliver Mannion
07/01/2022, 8:02 AMCamilo Fernandez
07/01/2022, 8:56 AMIuliia Volkova
07/01/2022, 12:47 PMCarlos Cueto
07/01/2022, 1:28 PMPrefectSecret
explicitly but make use of secrets in other ways, such as Git
storage git_clone_url_secret_name=<secret_key>
.
The error is the following:
ClientError([{'path': ['secret_value'], 'message': 'An unknown error occurred.', 'extensions': {'code': 'INTERNAL_SERVER_ERROR'}}])
The error is very vague and it's very difficult to understand what the error is exactly. Any help is appreciated, this is affecting our production workflows that sometimes take hours to run.Sergey Goncharov
07/01/2022, 2:41 PMTim Enders
07/01/2022, 2:59 PMGCSResult
for my Task results. Does anybody know if there is a way to catch exceptions with it? We are seeing occasional failures on the GCS side and I don't want my flows failing because of it.Wieger Opmeer
07/01/2022, 4:40 PMhaven
07/01/2022, 4:46 PMClusterNotFound
but haven't gotten anywhere. i'd immensely appreciate it if anyone would have any insights! details in threadhaven
07/02/2022, 6:34 AMFaheem Khan
07/02/2022, 9:50 AMjars
07/03/2022, 6:16 AMWilliam Jamir
07/03/2022, 7:46 AMTask A
to do an upload and Task B
to monitor if everything went fine after the upload from Task A.
I noticed that using LocalDaskExecutor, only 10 tasks are processed at a time
It’s possible to run more than 10 mapped tasks in parallel?
Using LocalDaskExecutor with Prefect 1.2.2Isara Ovin
07/03/2022, 2:53 PMDenis Sh
07/03/2022, 8:56 PMDenis Sh
07/03/2022, 8:59 PMRajvir Jhawar
07/03/2022, 11:36 PMFaheem Khan
07/03/2022, 11:40 PMFaheem Khan
07/03/2022, 11:40 PMAnna Geller
07/04/2022, 11:33 AMprefect version
2. Some code to reproduce the issue
3. The exception traceback?from prefect import flow, task
from prefect import get_run_logger
from prefect.task_runners import DaskTaskRunner
from prefect.flow_runners import DockerFlowRunner
from prefect.deployments import DeploymentSpec
import time
@task
def compute_something(x):
logger = get_run_logger()
<http://logger.info|logger.info>("Computing: %d x 2 = %d", x, x * 2)
time.sleep(2)
@flow(task_runner=DaskTaskRunner())
def dask_flow():
for i in range(50):
compute_something(i)
DeploymentSpec(name="staging", flow=dask_flow, flow_runner=DockerFlowRunner())
Faheem Khan
07/05/2022, 1:20 AM@task
def compute_something(x):
logger = get_run_logger()
<http://logger.info|logger.info>("Computing: %d x 2 = %d", x, x * 2)
time.sleep(2)
@flow(task_runner=DaskTaskRunner())
def dask_flow():
list(map(compute_something, range(50))) #worked
if __name__ == '__main__':
#list(map(dask_flow, range(50))) #didn't work
dask_flow()
DeploymentSpec(name="staging", flow=dask_flow, flow_runner=DockerFlowRunner())
Anna Geller
07/05/2022, 11:11 AM