# Prefect Tasks
Tasks for interacting with the Prefect API
# StartFlowRun
class
prefect.tasks.prefect.flow_run.StartFlowRun
(flow_name=None, project_name=None, parameters=None, run_config=None, wait=False, new_flow_context=None, run_name=None, scheduled_start_time=None, poll_interval=datetime.timedelta(seconds=10), **kwargs)[source]Task used to kick off a flow run using Prefect Core's server or Prefect Cloud. If multiple versions of the flow are found, this task will kick off the most recent unarchived version.
Args:
flow_name (str, optional)
: the name of the flow to schedule; this value may also be provided at run timeproject_name (str, optional)
: if running with Cloud as a backend, this is the project in which the flow is located; this value may also be provided at runtime. If running with Prefect Core's server as the backend, this should not be provided.parameters (dict, optional)
: the parameters to pass to the flow run being scheduled; this value may also be provided at run timerun_config (RunConfig, optional)
: a run-config to use for this flow run, overriding any existing flow settings.wait (bool, optional)
: whether to wait the triggered flow run's state; if True, this task will wait until the flow run is complete, and then reflect the corresponding state as the state of this task. Defaults toFalse
.new_flow_context (dict, optional)
: the optional run context for the new flow runrun_name (str, optional)
: name to be set for the flow runscheduled_start_time (datetime, optional)
: the time to schedule the execution for; if not provided, defaults to nowpoll_interval (timedelta)
: the time to wait between each check if the flow is finished. Has to be >= 3 seconds. Used only ifwait=True
. Defaults to 10 seconds.**kwargs (dict, optional)
: additional keyword arguments to pass to the Task constructor
methods: |
---|
prefect.tasks.prefect.flow_run.StartFlowRun.run (flow_name=None, project_name=None, parameters=None, run_config=None, new_flow_context=None, run_name=None, idempotency_key=None, scheduled_start_time=None)[source] |
Run method for the task; responsible for scheduling the specified flow run.
|
# RenameFlowRun
class
prefect.tasks.prefect.flow_run_rename.RenameFlowRun
(flow_run_id=None, flow_run_name=None, **kwargs)[source]Task used to rename a running flow.
Args:
flow_run_id (str, optional)
: The ID of the flow run to rename.flow_run_name (str, optional)
: The new flow run name.**kwargs (dict, optional)
: additional keyword arguments to pass to the Task constructor
methods: |
---|
prefect.tasks.prefect.flow_run_rename.RenameFlowRun.run (flow_run_id, flow_run_name)[source] |
Args:
|
# CancelFlowRun
Task to cancel a flow run. If flow_run_id
is not provided, flow_run_id
from prefect.context
will be used by default
Args:
flow_run_id (str, optional)
: The ID of the flow run to cancel**kwargs (dict, optional)
: additional keyword arguments to pass to the Task constructor
methods: |
---|
prefect.tasks.prefect.flow_run_cancel.CancelFlowRun.run (flow_run_id=None)[source] |
Args:
|
This documentation was auto-generated from commit n/a
on July 1, 2021 at 18:35 UTC