1. Packages
  2. Prefect Provider
  3. API Docs
  4. DeploymentSchedule
prefect 2.22.4 published on Wednesday, Mar 26, 2025 by prefecthq

prefect.DeploymentSchedule

Explore with Pulumi AI

prefect logo
prefect 2.22.4 published on Wednesday, Mar 26, 2025 by prefecthq

    The resource ‘deployment_schedule’ represents a schedule for a deployment.
    For more information, see schedule flow runs.

    This feature is available in the following product plan(s): Prefect OSS, Prefect Cloud (Free), Prefect Cloud (Pro), Prefect Cloud (Enterprise).

    Example Usage

    import * as pulumi from "@pulumi/pulumi";
    import * as prefect from "@pulumi/prefect";
    
    const testWorkspace = prefect.getWorkspace({
        handle: "my-workspace",
    });
    const testFlow = new prefect.Flow("testFlow", {
        workspaceId: testWorkspace.then(testWorkspace => testWorkspace.id),
        tags: ["test"],
    });
    const testDeployment = new prefect.Deployment("testDeployment", {
        workspaceId: testWorkspace.then(testWorkspace => testWorkspace.id),
        flowId: testFlow.id,
    });
    const testInterval = new prefect.DeploymentSchedule("testInterval", {
        workspaceId: testWorkspace.then(testWorkspace => testWorkspace.id),
        deploymentId: testDeployment.id,
        active: true,
        catchup: false,
        maxActiveRuns: 10,
        timezone: "America/New_York",
        interval: 30,
        anchorDate: "2024-01-01T00:00:00Z",
    });
    const testCron = new prefect.DeploymentSchedule("testCron", {
        workspaceId: testWorkspace.then(testWorkspace => testWorkspace.id),
        deploymentId: testDeployment.id,
        active: true,
        catchup: false,
        maxActiveRuns: 10,
        timezone: "America/New_York",
        cron: "0 0 * * *",
        dayOr: true,
    });
    const testRrule = new prefect.DeploymentSchedule("testRrule", {
        workspaceId: testWorkspace.then(testWorkspace => testWorkspace.id),
        deploymentId: testDeployment.id,
        active: true,
        catchup: false,
        maxActiveRuns: 10,
        timezone: "America/New_York",
        rrule: "FREQ=DAILY;INTERVAL=1",
    });
    
    import pulumi
    import pulumi_prefect as prefect
    
    test_workspace = prefect.get_workspace(handle="my-workspace")
    test_flow = prefect.Flow("testFlow",
        workspace_id=test_workspace.id,
        tags=["test"])
    test_deployment = prefect.Deployment("testDeployment",
        workspace_id=test_workspace.id,
        flow_id=test_flow.id)
    test_interval = prefect.DeploymentSchedule("testInterval",
        workspace_id=test_workspace.id,
        deployment_id=test_deployment.id,
        active=True,
        catchup=False,
        max_active_runs=10,
        timezone="America/New_York",
        interval=30,
        anchor_date="2024-01-01T00:00:00Z")
    test_cron = prefect.DeploymentSchedule("testCron",
        workspace_id=test_workspace.id,
        deployment_id=test_deployment.id,
        active=True,
        catchup=False,
        max_active_runs=10,
        timezone="America/New_York",
        cron="0 0 * * *",
        day_or=True)
    test_rrule = prefect.DeploymentSchedule("testRrule",
        workspace_id=test_workspace.id,
        deployment_id=test_deployment.id,
        active=True,
        catchup=False,
        max_active_runs=10,
        timezone="America/New_York",
        rrule="FREQ=DAILY;INTERVAL=1")
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-terraform-provider/sdks/go/prefect/v2/prefect"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		testWorkspace, err := prefect.LookupWorkspace(ctx, &prefect.LookupWorkspaceArgs{
    			Handle: pulumi.StringRef("my-workspace"),
    		}, nil)
    		if err != nil {
    			return err
    		}
    		testFlow, err := prefect.NewFlow(ctx, "testFlow", &prefect.FlowArgs{
    			WorkspaceId: pulumi.String(testWorkspace.Id),
    			Tags: pulumi.StringArray{
    				pulumi.String("test"),
    			},
    		})
    		if err != nil {
    			return err
    		}
    		testDeployment, err := prefect.NewDeployment(ctx, "testDeployment", &prefect.DeploymentArgs{
    			WorkspaceId: pulumi.String(testWorkspace.Id),
    			FlowId:      testFlow.ID(),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = prefect.NewDeploymentSchedule(ctx, "testInterval", &prefect.DeploymentScheduleArgs{
    			WorkspaceId:   pulumi.String(testWorkspace.Id),
    			DeploymentId:  testDeployment.ID(),
    			Active:        pulumi.Bool(true),
    			Catchup:       pulumi.Bool(false),
    			MaxActiveRuns: pulumi.Float64(10),
    			Timezone:      pulumi.String("America/New_York"),
    			Interval:      pulumi.Float64(30),
    			AnchorDate:    pulumi.String("2024-01-01T00:00:00Z"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = prefect.NewDeploymentSchedule(ctx, "testCron", &prefect.DeploymentScheduleArgs{
    			WorkspaceId:   pulumi.String(testWorkspace.Id),
    			DeploymentId:  testDeployment.ID(),
    			Active:        pulumi.Bool(true),
    			Catchup:       pulumi.Bool(false),
    			MaxActiveRuns: pulumi.Float64(10),
    			Timezone:      pulumi.String("America/New_York"),
    			Cron:          pulumi.String("0 0 * * *"),
    			DayOr:         pulumi.Bool(true),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = prefect.NewDeploymentSchedule(ctx, "testRrule", &prefect.DeploymentScheduleArgs{
    			WorkspaceId:   pulumi.String(testWorkspace.Id),
    			DeploymentId:  testDeployment.ID(),
    			Active:        pulumi.Bool(true),
    			Catchup:       pulumi.Bool(false),
    			MaxActiveRuns: pulumi.Float64(10),
    			Timezone:      pulumi.String("America/New_York"),
    			Rrule:         pulumi.String("FREQ=DAILY;INTERVAL=1"),
    		})
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Prefect = Pulumi.Prefect;
    
    return await Deployment.RunAsync(() => 
    {
        var testWorkspace = Prefect.GetWorkspace.Invoke(new()
        {
            Handle = "my-workspace",
        });
    
        var testFlow = new Prefect.Flow("testFlow", new()
        {
            WorkspaceId = testWorkspace.Apply(getWorkspaceResult => getWorkspaceResult.Id),
            Tags = new[]
            {
                "test",
            },
        });
    
        var testDeployment = new Prefect.Deployment("testDeployment", new()
        {
            WorkspaceId = testWorkspace.Apply(getWorkspaceResult => getWorkspaceResult.Id),
            FlowId = testFlow.Id,
        });
    
        var testInterval = new Prefect.DeploymentSchedule("testInterval", new()
        {
            WorkspaceId = testWorkspace.Apply(getWorkspaceResult => getWorkspaceResult.Id),
            DeploymentId = testDeployment.Id,
            Active = true,
            Catchup = false,
            MaxActiveRuns = 10,
            Timezone = "America/New_York",
            Interval = 30,
            AnchorDate = "2024-01-01T00:00:00Z",
        });
    
        var testCron = new Prefect.DeploymentSchedule("testCron", new()
        {
            WorkspaceId = testWorkspace.Apply(getWorkspaceResult => getWorkspaceResult.Id),
            DeploymentId = testDeployment.Id,
            Active = true,
            Catchup = false,
            MaxActiveRuns = 10,
            Timezone = "America/New_York",
            Cron = "0 0 * * *",
            DayOr = true,
        });
    
        var testRrule = new Prefect.DeploymentSchedule("testRrule", new()
        {
            WorkspaceId = testWorkspace.Apply(getWorkspaceResult => getWorkspaceResult.Id),
            DeploymentId = testDeployment.Id,
            Active = true,
            Catchup = false,
            MaxActiveRuns = 10,
            Timezone = "America/New_York",
            Rrule = "FREQ=DAILY;INTERVAL=1",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.prefect.PrefectFunctions;
    import com.pulumi.prefect.inputs.GetWorkspaceArgs;
    import com.pulumi.prefect.Flow;
    import com.pulumi.prefect.FlowArgs;
    import com.pulumi.prefect.Deployment;
    import com.pulumi.prefect.DeploymentArgs;
    import com.pulumi.prefect.DeploymentSchedule;
    import com.pulumi.prefect.DeploymentScheduleArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            final var testWorkspace = PrefectFunctions.getWorkspace(GetWorkspaceArgs.builder()
                .handle("my-workspace")
                .build());
    
            var testFlow = new Flow("testFlow", FlowArgs.builder()
                .workspaceId(testWorkspace.applyValue(getWorkspaceResult -> getWorkspaceResult.id()))
                .tags("test")
                .build());
    
            var testDeployment = new Deployment("testDeployment", DeploymentArgs.builder()
                .workspaceId(testWorkspace.applyValue(getWorkspaceResult -> getWorkspaceResult.id()))
                .flowId(testFlow.id())
                .build());
    
            var testInterval = new DeploymentSchedule("testInterval", DeploymentScheduleArgs.builder()
                .workspaceId(testWorkspace.applyValue(getWorkspaceResult -> getWorkspaceResult.id()))
                .deploymentId(testDeployment.id())
                .active(true)
                .catchup(false)
                .maxActiveRuns(10)
                .timezone("America/New_York")
                .interval(30)
                .anchorDate("2024-01-01T00:00:00Z")
                .build());
    
            var testCron = new DeploymentSchedule("testCron", DeploymentScheduleArgs.builder()
                .workspaceId(testWorkspace.applyValue(getWorkspaceResult -> getWorkspaceResult.id()))
                .deploymentId(testDeployment.id())
                .active(true)
                .catchup(false)
                .maxActiveRuns(10)
                .timezone("America/New_York")
                .cron("0 0 * * *")
                .dayOr(true)
                .build());
    
            var testRrule = new DeploymentSchedule("testRrule", DeploymentScheduleArgs.builder()
                .workspaceId(testWorkspace.applyValue(getWorkspaceResult -> getWorkspaceResult.id()))
                .deploymentId(testDeployment.id())
                .active(true)
                .catchup(false)
                .maxActiveRuns(10)
                .timezone("America/New_York")
                .rrule("FREQ=DAILY;INTERVAL=1")
                .build());
    
        }
    }
    
    resources:
      testFlow:
        type: prefect:Flow
        properties:
          workspaceId: ${testWorkspace.id}
          tags:
            - test
      testDeployment:
        type: prefect:Deployment
        properties:
          workspaceId: ${testWorkspace.id}
          flowId: ${testFlow.id}
      testInterval:
        type: prefect:DeploymentSchedule
        properties:
          workspaceId: ${testWorkspace.id}
          deploymentId: ${testDeployment.id}
          active: true
          catchup: false
          maxActiveRuns: 10
          timezone: America/New_York
          # Interval-specific fields
          interval: 30
          anchorDate: 2024-01-01T00:00:00Z
      testCron:
        type: prefect:DeploymentSchedule
        properties:
          workspaceId: ${testWorkspace.id}
          deploymentId: ${testDeployment.id}
          active: true
          catchup: false
          maxActiveRuns: 10
          timezone: America/New_York
          # Cron-specific fields
          cron: 0 0 * * *
          dayOr: true
      testRrule:
        type: prefect:DeploymentSchedule
        properties:
          workspaceId: ${testWorkspace.id}
          deploymentId: ${testDeployment.id}
          active: true
          catchup: false
          maxActiveRuns: 10
          timezone: America/New_York
          # RRule-specific fields
          rrule: FREQ=DAILY;INTERVAL=1
    variables:
      testWorkspace:
        fn::invoke:
          function: prefect:getWorkspace
          arguments:
            handle: my-workspace
    

    Create DeploymentSchedule Resource

    Resources are created with functions called constructors. To learn more about declaring and configuring resources, see Resources.

    Constructor syntax

    new DeploymentSchedule(name: string, args: DeploymentScheduleArgs, opts?: CustomResourceOptions);
    @overload
    def DeploymentSchedule(resource_name: str,
                           args: DeploymentScheduleArgs,
                           opts: Optional[ResourceOptions] = None)
    
    @overload
    def DeploymentSchedule(resource_name: str,
                           opts: Optional[ResourceOptions] = None,
                           deployment_id: Optional[str] = None,
                           catchup: Optional[bool] = None,
                           anchor_date: Optional[str] = None,
                           account_id: Optional[str] = None,
                           cron: Optional[str] = None,
                           day_or: Optional[bool] = None,
                           active: Optional[bool] = None,
                           deployment_schedule_id: Optional[str] = None,
                           interval: Optional[float] = None,
                           max_active_runs: Optional[float] = None,
                           max_scheduled_runs: Optional[float] = None,
                           rrule: Optional[str] = None,
                           timezone: Optional[str] = None,
                           workspace_id: Optional[str] = None)
    func NewDeploymentSchedule(ctx *Context, name string, args DeploymentScheduleArgs, opts ...ResourceOption) (*DeploymentSchedule, error)
    public DeploymentSchedule(string name, DeploymentScheduleArgs args, CustomResourceOptions? opts = null)
    public DeploymentSchedule(String name, DeploymentScheduleArgs args)
    public DeploymentSchedule(String name, DeploymentScheduleArgs args, CustomResourceOptions options)
    
    type: prefect:DeploymentSchedule
    properties: # The arguments to resource properties.
    options: # Bag of options to control resource's behavior.
    
    

    Parameters

    name string
    The unique name of the resource.
    args DeploymentScheduleArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    resource_name str
    The unique name of the resource.
    args DeploymentScheduleArgs
    The arguments to resource properties.
    opts ResourceOptions
    Bag of options to control resource's behavior.
    ctx Context
    Context object for the current deployment.
    name string
    The unique name of the resource.
    args DeploymentScheduleArgs
    The arguments to resource properties.
    opts ResourceOption
    Bag of options to control resource's behavior.
    name string
    The unique name of the resource.
    args DeploymentScheduleArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    name String
    The unique name of the resource.
    args DeploymentScheduleArgs
    The arguments to resource properties.
    options CustomResourceOptions
    Bag of options to control resource's behavior.

    Constructor example

    The following reference example uses placeholder values for all input properties.

    var deploymentScheduleResource = new Prefect.DeploymentSchedule("deploymentScheduleResource", new()
    {
        DeploymentId = "string",
        Catchup = false,
        AnchorDate = "string",
        AccountId = "string",
        Cron = "string",
        DayOr = false,
        Active = false,
        DeploymentScheduleId = "string",
        Interval = 0,
        MaxActiveRuns = 0,
        MaxScheduledRuns = 0,
        Rrule = "string",
        Timezone = "string",
        WorkspaceId = "string",
    });
    
    example, err := prefect.NewDeploymentSchedule(ctx, "deploymentScheduleResource", &prefect.DeploymentScheduleArgs{
    DeploymentId: pulumi.String("string"),
    Catchup: pulumi.Bool(false),
    AnchorDate: pulumi.String("string"),
    AccountId: pulumi.String("string"),
    Cron: pulumi.String("string"),
    DayOr: pulumi.Bool(false),
    Active: pulumi.Bool(false),
    DeploymentScheduleId: pulumi.String("string"),
    Interval: pulumi.Float64(0),
    MaxActiveRuns: pulumi.Float64(0),
    MaxScheduledRuns: pulumi.Float64(0),
    Rrule: pulumi.String("string"),
    Timezone: pulumi.String("string"),
    WorkspaceId: pulumi.String("string"),
    })
    
    var deploymentScheduleResource = new DeploymentSchedule("deploymentScheduleResource", DeploymentScheduleArgs.builder()
        .deploymentId("string")
        .catchup(false)
        .anchorDate("string")
        .accountId("string")
        .cron("string")
        .dayOr(false)
        .active(false)
        .deploymentScheduleId("string")
        .interval(0)
        .maxActiveRuns(0)
        .maxScheduledRuns(0)
        .rrule("string")
        .timezone("string")
        .workspaceId("string")
        .build());
    
    deployment_schedule_resource = prefect.DeploymentSchedule("deploymentScheduleResource",
        deployment_id="string",
        catchup=False,
        anchor_date="string",
        account_id="string",
        cron="string",
        day_or=False,
        active=False,
        deployment_schedule_id="string",
        interval=0,
        max_active_runs=0,
        max_scheduled_runs=0,
        rrule="string",
        timezone="string",
        workspace_id="string")
    
    const deploymentScheduleResource = new prefect.DeploymentSchedule("deploymentScheduleResource", {
        deploymentId: "string",
        catchup: false,
        anchorDate: "string",
        accountId: "string",
        cron: "string",
        dayOr: false,
        active: false,
        deploymentScheduleId: "string",
        interval: 0,
        maxActiveRuns: 0,
        maxScheduledRuns: 0,
        rrule: "string",
        timezone: "string",
        workspaceId: "string",
    });
    
    type: prefect:DeploymentSchedule
    properties:
        accountId: string
        active: false
        anchorDate: string
        catchup: false
        cron: string
        dayOr: false
        deploymentId: string
        deploymentScheduleId: string
        interval: 0
        maxActiveRuns: 0
        maxScheduledRuns: 0
        rrule: string
        timezone: string
        workspaceId: string
    

    DeploymentSchedule Resource Properties

    To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.

    Inputs

    In Python, inputs that are objects can be passed either as argument classes or as dictionary literals.

    The DeploymentSchedule resource accepts the following input properties:

    DeploymentId string
    Deployment ID (UUID)
    AccountId string
    Account ID (UUID)
    Active bool
    Whether or not the schedule is active.
    AnchorDate string
    The anchor date of the schedule.
    Catchup bool
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    Cron string
    The cron expression of the schedule.
    DayOr bool
    Control croniter behavior for handling day and dayofweek entries.
    DeploymentScheduleId string
    Deployment Schedule ID (UUID)
    Interval double
    The interval of the schedule.
    MaxActiveRuns double
    (Cloud only) The maximum number of active runs for the schedule.
    MaxScheduledRuns double
    The maximum number of scheduled runs for the schedule.
    Rrule string
    The rrule expression of the schedule.
    Timezone string
    The timezone of the schedule.
    WorkspaceId string
    Workspace ID (UUID)
    DeploymentId string
    Deployment ID (UUID)
    AccountId string
    Account ID (UUID)
    Active bool
    Whether or not the schedule is active.
    AnchorDate string
    The anchor date of the schedule.
    Catchup bool
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    Cron string
    The cron expression of the schedule.
    DayOr bool
    Control croniter behavior for handling day and dayofweek entries.
    DeploymentScheduleId string
    Deployment Schedule ID (UUID)
    Interval float64
    The interval of the schedule.
    MaxActiveRuns float64
    (Cloud only) The maximum number of active runs for the schedule.
    MaxScheduledRuns float64
    The maximum number of scheduled runs for the schedule.
    Rrule string
    The rrule expression of the schedule.
    Timezone string
    The timezone of the schedule.
    WorkspaceId string
    Workspace ID (UUID)
    deploymentId String
    Deployment ID (UUID)
    accountId String
    Account ID (UUID)
    active Boolean
    Whether or not the schedule is active.
    anchorDate String
    The anchor date of the schedule.
    catchup Boolean
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    cron String
    The cron expression of the schedule.
    dayOr Boolean
    Control croniter behavior for handling day and dayofweek entries.
    deploymentScheduleId String
    Deployment Schedule ID (UUID)
    interval Double
    The interval of the schedule.
    maxActiveRuns Double
    (Cloud only) The maximum number of active runs for the schedule.
    maxScheduledRuns Double
    The maximum number of scheduled runs for the schedule.
    rrule String
    The rrule expression of the schedule.
    timezone String
    The timezone of the schedule.
    workspaceId String
    Workspace ID (UUID)
    deploymentId string
    Deployment ID (UUID)
    accountId string
    Account ID (UUID)
    active boolean
    Whether or not the schedule is active.
    anchorDate string
    The anchor date of the schedule.
    catchup boolean
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    cron string
    The cron expression of the schedule.
    dayOr boolean
    Control croniter behavior for handling day and dayofweek entries.
    deploymentScheduleId string
    Deployment Schedule ID (UUID)
    interval number
    The interval of the schedule.
    maxActiveRuns number
    (Cloud only) The maximum number of active runs for the schedule.
    maxScheduledRuns number
    The maximum number of scheduled runs for the schedule.
    rrule string
    The rrule expression of the schedule.
    timezone string
    The timezone of the schedule.
    workspaceId string
    Workspace ID (UUID)
    deployment_id str
    Deployment ID (UUID)
    account_id str
    Account ID (UUID)
    active bool
    Whether or not the schedule is active.
    anchor_date str
    The anchor date of the schedule.
    catchup bool
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    cron str
    The cron expression of the schedule.
    day_or bool
    Control croniter behavior for handling day and dayofweek entries.
    deployment_schedule_id str
    Deployment Schedule ID (UUID)
    interval float
    The interval of the schedule.
    max_active_runs float
    (Cloud only) The maximum number of active runs for the schedule.
    max_scheduled_runs float
    The maximum number of scheduled runs for the schedule.
    rrule str
    The rrule expression of the schedule.
    timezone str
    The timezone of the schedule.
    workspace_id str
    Workspace ID (UUID)
    deploymentId String
    Deployment ID (UUID)
    accountId String
    Account ID (UUID)
    active Boolean
    Whether or not the schedule is active.
    anchorDate String
    The anchor date of the schedule.
    catchup Boolean
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    cron String
    The cron expression of the schedule.
    dayOr Boolean
    Control croniter behavior for handling day and dayofweek entries.
    deploymentScheduleId String
    Deployment Schedule ID (UUID)
    interval Number
    The interval of the schedule.
    maxActiveRuns Number
    (Cloud only) The maximum number of active runs for the schedule.
    maxScheduledRuns Number
    The maximum number of scheduled runs for the schedule.
    rrule String
    The rrule expression of the schedule.
    timezone String
    The timezone of the schedule.
    workspaceId String
    Workspace ID (UUID)

    Outputs

    All input properties are implicitly available as output properties. Additionally, the DeploymentSchedule resource produces the following output properties:

    Created string
    Timestamp of when the resource was created (RFC3339)
    Id string
    The provider-assigned unique ID for this managed resource.
    Updated string
    Timestamp of when the resource was updated (RFC3339)
    Created string
    Timestamp of when the resource was created (RFC3339)
    Id string
    The provider-assigned unique ID for this managed resource.
    Updated string
    Timestamp of when the resource was updated (RFC3339)
    created String
    Timestamp of when the resource was created (RFC3339)
    id String
    The provider-assigned unique ID for this managed resource.
    updated String
    Timestamp of when the resource was updated (RFC3339)
    created string
    Timestamp of when the resource was created (RFC3339)
    id string
    The provider-assigned unique ID for this managed resource.
    updated string
    Timestamp of when the resource was updated (RFC3339)
    created str
    Timestamp of when the resource was created (RFC3339)
    id str
    The provider-assigned unique ID for this managed resource.
    updated str
    Timestamp of when the resource was updated (RFC3339)
    created String
    Timestamp of when the resource was created (RFC3339)
    id String
    The provider-assigned unique ID for this managed resource.
    updated String
    Timestamp of when the resource was updated (RFC3339)

    Look up Existing DeploymentSchedule Resource

    Get an existing DeploymentSchedule resource’s state with the given name, ID, and optional extra properties used to qualify the lookup.

    public static get(name: string, id: Input<ID>, state?: DeploymentScheduleState, opts?: CustomResourceOptions): DeploymentSchedule
    @staticmethod
    def get(resource_name: str,
            id: str,
            opts: Optional[ResourceOptions] = None,
            account_id: Optional[str] = None,
            active: Optional[bool] = None,
            anchor_date: Optional[str] = None,
            catchup: Optional[bool] = None,
            created: Optional[str] = None,
            cron: Optional[str] = None,
            day_or: Optional[bool] = None,
            deployment_id: Optional[str] = None,
            deployment_schedule_id: Optional[str] = None,
            interval: Optional[float] = None,
            max_active_runs: Optional[float] = None,
            max_scheduled_runs: Optional[float] = None,
            rrule: Optional[str] = None,
            timezone: Optional[str] = None,
            updated: Optional[str] = None,
            workspace_id: Optional[str] = None) -> DeploymentSchedule
    func GetDeploymentSchedule(ctx *Context, name string, id IDInput, state *DeploymentScheduleState, opts ...ResourceOption) (*DeploymentSchedule, error)
    public static DeploymentSchedule Get(string name, Input<string> id, DeploymentScheduleState? state, CustomResourceOptions? opts = null)
    public static DeploymentSchedule get(String name, Output<String> id, DeploymentScheduleState state, CustomResourceOptions options)
    resources:  _:    type: prefect:DeploymentSchedule    get:      id: ${id}
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    resource_name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    The following state arguments are supported:
    AccountId string
    Account ID (UUID)
    Active bool
    Whether or not the schedule is active.
    AnchorDate string
    The anchor date of the schedule.
    Catchup bool
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    Created string
    Timestamp of when the resource was created (RFC3339)
    Cron string
    The cron expression of the schedule.
    DayOr bool
    Control croniter behavior for handling day and dayofweek entries.
    DeploymentId string
    Deployment ID (UUID)
    DeploymentScheduleId string
    Deployment Schedule ID (UUID)
    Interval double
    The interval of the schedule.
    MaxActiveRuns double
    (Cloud only) The maximum number of active runs for the schedule.
    MaxScheduledRuns double
    The maximum number of scheduled runs for the schedule.
    Rrule string
    The rrule expression of the schedule.
    Timezone string
    The timezone of the schedule.
    Updated string
    Timestamp of when the resource was updated (RFC3339)
    WorkspaceId string
    Workspace ID (UUID)
    AccountId string
    Account ID (UUID)
    Active bool
    Whether or not the schedule is active.
    AnchorDate string
    The anchor date of the schedule.
    Catchup bool
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    Created string
    Timestamp of when the resource was created (RFC3339)
    Cron string
    The cron expression of the schedule.
    DayOr bool
    Control croniter behavior for handling day and dayofweek entries.
    DeploymentId string
    Deployment ID (UUID)
    DeploymentScheduleId string
    Deployment Schedule ID (UUID)
    Interval float64
    The interval of the schedule.
    MaxActiveRuns float64
    (Cloud only) The maximum number of active runs for the schedule.
    MaxScheduledRuns float64
    The maximum number of scheduled runs for the schedule.
    Rrule string
    The rrule expression of the schedule.
    Timezone string
    The timezone of the schedule.
    Updated string
    Timestamp of when the resource was updated (RFC3339)
    WorkspaceId string
    Workspace ID (UUID)
    accountId String
    Account ID (UUID)
    active Boolean
    Whether or not the schedule is active.
    anchorDate String
    The anchor date of the schedule.
    catchup Boolean
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    created String
    Timestamp of when the resource was created (RFC3339)
    cron String
    The cron expression of the schedule.
    dayOr Boolean
    Control croniter behavior for handling day and dayofweek entries.
    deploymentId String
    Deployment ID (UUID)
    deploymentScheduleId String
    Deployment Schedule ID (UUID)
    interval Double
    The interval of the schedule.
    maxActiveRuns Double
    (Cloud only) The maximum number of active runs for the schedule.
    maxScheduledRuns Double
    The maximum number of scheduled runs for the schedule.
    rrule String
    The rrule expression of the schedule.
    timezone String
    The timezone of the schedule.
    updated String
    Timestamp of when the resource was updated (RFC3339)
    workspaceId String
    Workspace ID (UUID)
    accountId string
    Account ID (UUID)
    active boolean
    Whether or not the schedule is active.
    anchorDate string
    The anchor date of the schedule.
    catchup boolean
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    created string
    Timestamp of when the resource was created (RFC3339)
    cron string
    The cron expression of the schedule.
    dayOr boolean
    Control croniter behavior for handling day and dayofweek entries.
    deploymentId string
    Deployment ID (UUID)
    deploymentScheduleId string
    Deployment Schedule ID (UUID)
    interval number
    The interval of the schedule.
    maxActiveRuns number
    (Cloud only) The maximum number of active runs for the schedule.
    maxScheduledRuns number
    The maximum number of scheduled runs for the schedule.
    rrule string
    The rrule expression of the schedule.
    timezone string
    The timezone of the schedule.
    updated string
    Timestamp of when the resource was updated (RFC3339)
    workspaceId string
    Workspace ID (UUID)
    account_id str
    Account ID (UUID)
    active bool
    Whether or not the schedule is active.
    anchor_date str
    The anchor date of the schedule.
    catchup bool
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    created str
    Timestamp of when the resource was created (RFC3339)
    cron str
    The cron expression of the schedule.
    day_or bool
    Control croniter behavior for handling day and dayofweek entries.
    deployment_id str
    Deployment ID (UUID)
    deployment_schedule_id str
    Deployment Schedule ID (UUID)
    interval float
    The interval of the schedule.
    max_active_runs float
    (Cloud only) The maximum number of active runs for the schedule.
    max_scheduled_runs float
    The maximum number of scheduled runs for the schedule.
    rrule str
    The rrule expression of the schedule.
    timezone str
    The timezone of the schedule.
    updated str
    Timestamp of when the resource was updated (RFC3339)
    workspace_id str
    Workspace ID (UUID)
    accountId String
    Account ID (UUID)
    active Boolean
    Whether or not the schedule is active.
    anchorDate String
    The anchor date of the schedule.
    catchup Boolean
    (Cloud only) Whether or not a worker should catch up on Late runs for the schedule.
    created String
    Timestamp of when the resource was created (RFC3339)
    cron String
    The cron expression of the schedule.
    dayOr Boolean
    Control croniter behavior for handling day and dayofweek entries.
    deploymentId String
    Deployment ID (UUID)
    deploymentScheduleId String
    Deployment Schedule ID (UUID)
    interval Number
    The interval of the schedule.
    maxActiveRuns Number
    (Cloud only) The maximum number of active runs for the schedule.
    maxScheduledRuns Number
    The maximum number of scheduled runs for the schedule.
    rrule String
    The rrule expression of the schedule.
    timezone String
    The timezone of the schedule.
    updated String
    Timestamp of when the resource was updated (RFC3339)
    workspaceId String
    Workspace ID (UUID)

    Package Details

    Repository
    prefect prefecthq/terraform-provider-prefect
    License
    Notes
    This Pulumi package is based on the prefect Terraform Provider.
    prefect logo
    prefect 2.22.4 published on Wednesday, Mar 26, 2025 by prefecthq