Prefect 2.10.5 is here! With workers for each major cloud provider, automations for building deployments, and more!
You're viewing the docs for Prefect 2.10.5. Click here to view the latest docs.
logo
Prefect Docs
Guides
Initializing search
    GitHub
    GitHub
    • Getting Started
      • Installation
      • Cloud Quickstart
    • Tutorials
      • Flows & Tasks
      • Configuration
      • Execution
      • Orchestration
      • Projects
      • Deployments
      • Storage & Infrastructure
    • Concepts
        • Flows
        • Tasks
        • Results
        • Artifacts
        • States
        • Blocks
        • Variables
        • Task Runners
        • Runtime Context
        • Profiles & Configuration
        • Deployments
        • Projects
        • Work Pools, Workers & Agents
        • Storage
        • Filesystems
        • Infrastructure
        • Schedules
        • Logging
    • Cloud
      • Cloud Quickstart
      • Workspaces
      • Organizations
      • Users
        • Roles (RBAC)
        • API Keys
        • Service Accounts
        • Single Sign-on (SSO)
        • Audit Log
      • Events
      • Automations
      • API Rate Limits
      • Connecting & Troubleshooting
    • Host
    • Guides
      • Testing
      • Dask & Ray
        • Docker
        • Azure Container Instance
      • Recipes
      • Migration Guide
    • Integrations
      • Using Integrations
      • Contributing Integrations
    • API References
        • prefect.agent
        • prefect.artifacts
        • prefect.context
        • prefect.deployments
        • prefect.engine
        • prefect.exceptions
        • prefect.filesystems
        • prefect.flows
        • prefect.futures
        • prefect.infrastructure
        • prefect.logging
          • prefect.projects.base
          • prefect.projects.steps.core
          • prefect.projects.steps.pull
          • prefect.runtime.flow_run
          • prefect.runtime.deployment
          • prefect.runtime.task_run
        • prefect.serializers
        • prefect.settings
        • prefect.states
        • prefect.task_runners
        • prefect.tasks
          • prefect.blocks.core
          • prefect.blocks.kubernetes
          • prefect.blocks.notifications
          • prefect.blocks.system
          • prefect.blocks.webhook
          • prefect.client.base
          • prefect.client.cloud
          • prefect.client.orchestration
          • prefect.client.schemas
          • prefect.client.utilities
          • prefect.cli.agent
          • prefect.cli.cloud
          • prefect.cli.concurrency_limit
          • prefect.cli.config
          • prefect.cli.dev
          • prefect.cli.profile
          • prefect.cli.project
          • prefect.cli.work_queue
          • prefect.cli.root
          • prefect.cli.deployment
          • prefect.cli.flow_run
          • prefect.cli.server
          • prefect.utilities.annotations
          • prefect.utilities.asyncutils
          • prefect.utilities.processutils
          • prefect.utilities.callables
          • prefect.utilities.collections
          • prefect.utilities.filesystem
          • prefect.utilities.hashing
          • server.api.admin
          • server.api.dependencies
          • server.api.deployments
          • server.api.flows
          • server.api.flow_runs
          • server.api.flow_run_states
          • server.api.run_history
          • server.api.saved_searches
          • server.api.server
          • server.api.task_runs
          • server.api.task_run_states
          • server.models.flows
          • server.models.flow_runs
          • server.models.flow_run_states
          • server.models.task_runs
          • server.models.task_run_states
          • server.models.deployments
          • server.models.saved_searches
          • server.orchestration.rules
          • server.orchestration.policies
          • server.orchestration.core_policy
          • server.orchestration.global_policy
          • server.schemas.actions
          • server.schemas.core
          • server.schemas.filters
          • server.schemas.responses
          • server.schemas.schedules
          • server.schemas.sorting
          • server.schemas.states
          • server.services.late_runs
          • server.services.loop_service
          • server.services.scheduler
          • server.utilities.database
          • server.utilities.schemas
          • server.utilities.server
        • Prefect REST API Overview
        • Prefect REST API Reference
    • Community
      • Contributing
      • Style
      • Versioning
      • Troubleshooting

    Guides

    • Learn how Prefect makes testing your workflows a breeze.
    • See how to parallelize your code with Dask and Ray.
    • Learn how to use Docker with your Deployments.
    • See how to deploy your workflows with Docker Container Instances.
    • Check out many common workflows with Prefect Recipes.
    • Learn how to migrate from Prefect 1 to Prefect 2 with the Migration Guide.
    Made with Material for MkDocs Insiders