Solomon Negusse
07/17/2025, 10:01 PMutils.pydef common(a):
    return a * 2prefect_common.pyfrom prefect import task
from utils import common
@task
def common_task(a):
    return common(a)flow_a.pyfrom prefect import task
from prefect_common import common_task
@task
def task_one():
    pass
@flow
def flow():
    prefect_common(3)
    task_one()flow_b.pyfrom prefect import task
from prefect_common import common_task
@task
def task_two():
    pass
@flow
def flow():
    prefect_common(5)
    task_two()flow_a.pyfrom prefect import task
from util import common
@task
def task_one():
    pass
@task
def common_task(a):
    return common(a)
@flow
def flow():
    common_task(3)
    task_one()flow_b.pyfrom prefect import task
from util import common
@task
def task_two():
    pass
@task
def common_task(a):
    return common(a)
@flow
def flow():
    common_task(5)
    task_two()Marvin
07/17/2025, 10:01 PMMarvin
07/17/2025, 10:02 PMprefect_common.pypython
# utils.py
def common(a):
    return a * 2
# prefect_common.py
from prefect import task
from utils import common
@task(name="common_multiplication_task", 
      description="Multiplies input by 2",
      retries=2)  # Adding some task configuration as an example
def common_task(a: int) -> int:
    return common(a)
# flow_a.py
from prefect import flow, task
from prefect_common import common_task
@task
def task_one():
    pass
@flow
def flow_a():
    result = common_task(3)
    task_one()
# flow_b.py
from prefect import flow, task
from prefect_common import common_task
@task
def task_two():
    pass
@flow
def flow_b():
    result = common_task(5)
    task_two()prefect_common(3)common_task(3)Solomon Negusse
07/17/2025, 10:04 PMMarvin
07/17/2025, 10:04 PMMarvin
07/17/2025, 10:05 PMMarvin
07/17/2025, 10:05 PMpython
# prefect_common.py
from prefect import task
from utils import common
def create_common_task(timeout_seconds=None, retries=None):
    @task(
        name="common_multiplication_task",
        timeout_seconds=timeout_seconds,
        retries=retries
    )
    def common_task(a):
        return common(a)
    
    return common_task
# flow_a.py - needs more retries and longer timeout
from prefect import flow, task
from prefect_common import create_common_task
@task
def task_one():
    pass
@flow
def flow_a():
    # Create task with specific settings for this flow
    common_task = create_common_task(timeout_seconds=600, retries=5)
    result = common_task(3)
    task_one()
# flow_b.py - needs fewer retries and shorter timeout
from prefect import flow, task
from prefect_common import create_common_task
@task
def task_two():
    pass
@flow
def flow_b():
    # Create task with different settings for this flow
    common_task = create_common_task(timeout_seconds=300, retries=2)
    result = common_task(5)
    task_two()python
# prefect_common.py
from prefect import task
from utils import common
@task(
    name="common_multiplication_task_standard",
    timeout_seconds=300,
    retries=2
)
def common_task_standard(a):
    return common(a)
@task(
    name="common_multiplication_task_extended",
    timeout_seconds=600,
    retries=5
)
def common_task_extended(a):
    return common(a)
# flow_a.py - needs more robust settings
from prefect import flow, task
from prefect_common import common_task_extended
@flow
def flow_a():
    result = common_task_extended(3)
    # ...
# flow_b.py - needs standard settings
from prefect import flow, task
from prefect_common import common_task_standard
@flow
def flow_b():
    result = common_task_standard(5)
    # ...Marvin
07/17/2025, 10:06 PMpython
# prefect_common.py
from prefect import task
from typing import Optional
from utils import common
def create_common_task(
    timeout_seconds: Optional[int] = None,
    retries: Optional[int] = None,
    name: Optional[str] = None
):
    @task(
        timeout_seconds=timeout_seconds,
        retries=retries,
        name=name or "common_multiplication_task"
    )
    def common_task(a: int) -> int:
        return common(a)
    
    return common_task
# flow_a.py
from prefect import flow, task
from prefect_common import create_common_task
@task
def task_one():
    pass
@flow
def flow_a():
    # Create task with specific configuration for this flow
    common_task = create_common_task(timeout_seconds=300, retries=5)
    result = common_task(3)
    task_one()
# flow_b.py
from prefect import flow, task
from prefect_common import create_common_task
@task
def task_two():
    pass
@flow
def flow_b():
    # Different configuration for this flow
    common_task = create_common_task(timeout_seconds=60, retries=2)
    result = common_task(5)
    task_two()python
# prefect_common.py
from prefect import task
from utils import common
@task(timeout_seconds=300, retries=5, name="common_task_long")
def common_task_long_running(a: int) -> int:
    return common(a)
@task(timeout_seconds=60, retries=2, name="common_task_standard")
def common_task_standard(a: int) -> int:
    return common(a)
# Then use the appropriate variant in each flowretry_condition_fn