Arthur Shi
07/09/2025, 11:27 PMMarvin
07/09/2025, 11:27 PMMarvin
07/09/2025, 11:28 PMpython
from prefect import flow, task
from prefect.tasks import task_input_hash
@task(cache_key_fn=task_input_hash)
def expensive_task(x):
    # This task will only run if the inputs change
    # or if the cache expires
    return x * 2
@flow
def my_flow(x):
    result = expensive_task(x)
    # ... rest of your flowpython
from prefect import flow, task
from prefect.context import get_run_context
@task
def check_previous_state(task_name):
    context = get_run_context()
    # You can implement logic here to check if the task
    # was successful in a previous run
    return should_skip
@flow
def my_flow():
    if not check_previous_state("task_1"):
        task_1_result = task_1()
    if not check_previous_state("task_2"):
        task_2_result = task_2()python
from prefect import flow
from prefect.flow_runs import resume_flow_run
@flow
def my_flow():
    try:
        # Your flow logic here
        pass
    except Exception as e:
        # Capture state and handle resumption
        current_state = capture_current_state()
        resume_flow_run(flow_run_id=get_run_context().flow_run.id, 
                       run_input={"previous_state": current_state})