schedules
in prefect.yaml
by @zzstoatzz in #16867run_flow_in_subprocess
utility by @desertaxle in #16802prefect.runtime.task_run
by @zzstoatzz in #16879python -m prefect
by @sky-code in #16790validation_alias
to SnowflakeConnector
by @desertaxle in #16854prefect-dask
usage docs by @zzstoatzz in #16872site-packages
from scanned dirs in prefect deploy
by @zzstoatzz in #16885Task.__call__
by @desertaxle in #16891kubernetes-asyncio
version by @jeanluciano in #16841<0.14.0,>=0.12.0
to >=0.12.0
,!=0.12.2,<0.16.0
by @dependabot in #16205prefect_aws
tasks by @desertaxle in #16851PrefectDbtSettings
to prefect-dbt
by @kevingrismore in #16834Flow.ato_deployment
, Flow.afrom_source
, and Runner.afrom_storage
by @desertaxle in #16897pyright
checks to CI by @desertaxle in #16843schedule
key by @zzstoatzz in #16847run_flow_in_subprocess
by @desertaxle in #16883[@sync](https://github.com/sync)_compatible
from prefect.artifacts
by @desertaxle in #16877Service
base class to cover loop and other services by @chrisguidry in #16898PREFECT_SERVER_LOGGING_LEVEL
in prefect server start
by @zzstoatzz in #16765prefect dashboard open
by @zzstoatzz in #16768Inputs
cache policies are consolidated when used in a CompoundCachePolicy
by @zzstoatzz in #16785FlowRunContext
for flow runs kicked off from a deployment by @desertaxle in #16831cli.deploy
by @zzstoatzz in #16767prefect.runner.runner
by @desertaxle in #16797TaskRunRecorder
by @zzstoatzz in #16829pendulum
consolidation by @zzstoatzz in #16808prefect-redis
to the Prefect image by @chrisguidry in #16818Schedule a flow
tutorial by @kevingrismore in #16796prefect
is now 100% type complete! 🎉 Every public interface in the library now includes comprehensive type annotations, bringing significant improvements to the developer experience. This means you’ll enjoy:
mypy
and pyright
, catching potential issues before runtimeprefect server services
CLI commands by @zzstoatzz in #16706SendgridEmail
code example by @jakekaplan in #16677wait_for
by @chrisguidry in #16709drain_all
call to be called from new thread instead of global loop thread by @jeanluciano in #16739QueueService
instances are unique within types by @chrisguidry in #16751_on_start
by @cicdw in #16687prefect.server.events
by @desertaxle in #16692prefect.server.services
by @desertaxle in #16701prefect.results
by @desertaxle in #16714prefect.settings
by @desertaxle in #16719prefect.inputs
to 100% by @desertaxle in #16740prefect.server
to 100% by @desertaxle in #16729CoiledPushProvisioner
by @desertaxle in #16745JsonPatch
implementation by @desertaxle in #16743gcloud
example command by @cicdw in #16738sync_compatible
from automations SDK by @zzstoatzz in #16584enforce_parameter_schema
in prefect.yaml
by @zzstoatzz in #16607FlowRunContext.model_rebuild()
in hydrate_context
by @zzstoatzz in #16628<6.0.0,>=1.0.12
to >=1.0.12,<7.0.0
by @dependabot in #16431prefect.blocks
by @desertaxle in #16630otel
extras in docker image and remove experimental flag setting by @bunchesofdonald in #16412flow_run_name
by @zzstoatzz in #16517GitRepository
by @jakekaplan in #16518NO_PROXY
for websocket connections by @jbw-vtl in #16538Path
interpreting .
in deployment names as the beginning of a file extension by @zzstoatzz in #16553TypeError
in SnowflakeConnector.fetch_all
by @zzstoatzz in #16511fetch_one
and fetch_many
in prefect-snowflake
by @zzstoatzz in #16554redis-streams
by @zzstoatzz in #16432prefect.cli
part 1 by @desertaxle in #16546wait_for
and return_state
in Task.__call__
by @zzstoatzz in #16547getattr
by @zzstoatzz in #16498prefect.futures
by @zzstoatzz in #16381serve
docs by @zzstoatzz in #16475prefect.flow
decorator by @mjpieters in #16405enforce_parameter_schema
in prefect deploy
by @zzstoatzz in #16418from_source
safe to use concurrently by @zzstoatzz in #16458/csrf
by @aaazzam in #16464MattermostWebhook
tests by @zzstoatzz in #16433OTLPLogExporter
and OTLPSpanExporter
in a QueueService
to pull them out of the main thread by @bunchesofdonald in #16439PREFECT_RUNNER_HEARTBEAT_FREQUENCY
(requires Prefect 3.1.8+)Runner
to send heartbeat events for flow runs by @desertaxle in #16410prefect-redis
by @zzstoatzz in #16417[@task](https://github.com/task)
decorator by @zzstoatzz in #16386websocket_connect
utility in Subscriptions
by @jakekaplan in #16388Block.aload
method and remove [@sync](https://github.com/sync)_compatible
from Block.load
by @desertaxle in #16341sync_compatible
from git_clone
by @zzstoatzz in #16340prefect.serializers
by @desertaxle in #16331sync_compatible
from prefect.variables
by @zzstoatzz in #16349DateTime
to prefect.types
by @zzstoatzz in #16356Dockerfile
build time and add CI to catch future slow downs by @zzstoatzz in #16348prefect.tasks
and prefect.task_worker
by @zzstoatzz in #16332entrypoint.sh
to use uv
for EXTRA_PIP_PACKAGES
by @zzstoatzz in #16291prefect work-pool inspect
by @zzstoatzz in #16378RunTelemetry
class by @jeanluciano in #16233job_variables
in runtime.flow_run
by @zzstoatzz in #16124aserve
utility for serving multiple flows from an asynchronous context by @GitAlexxx in #15972sync_compatible
from build_server
by @zzstoatzz in #16314__getattr__
conflict in prefect.docker.__init__
by @zzstoatzz in #16172from_profiles_yml
to dbt TargetConfigs
by @kevingrismore in #16178prefect.server.database.migrations
to prefect.server.database._migrations
by @desertaxle in #16214blocks.abstract
and concurrency
by @zzstoatzz in #16212husky
to pre-commit
by @desertaxle in #16246flow
and task
decorators pass strict typing by @zzstoatzz in #16251uv
to install dependencies in the Dockerfile
by @zzstoatzz in #16235NODE_VERSION
to .nvmrc
by @desertaxle in #16282prefect.main
by @zzstoatzz in #16288debug.mdx
tutorial by @zzstoatzz in #16296any_
by @zzstoatzz in #16072prefect_aws.s3
async tasks to async_dispatch
by @zzstoatzz in #16096prefect_aws.client_waiter
off sync_compatible
by @zzstoatzz in #16082prefect_aws.lambda_function
off sync_compatible
by @zzstoatzz in #16083pydantic==2.10.0
workaround given upstream fix by @zzstoatzz in #16087prefect_aws.secrets_manager
off sync_compatible
by @zzstoatzz in #16169labels
field on Flow, Deployment, FlowRun, and TaskRun by @bunchesofdonald in #16050BaseFlowRunEngine
and AsyncFlowRunEngine
shell by @desertaxle in #16091incidents
by @aaazzam in #16139RunnerDeployment
by @zzstoatzz in #16075None -> {}
in KeyValueLabels
by @zzstoatzz in #16067pydantic==2.10
compatibility by @zzstoatzz in #16076prefect
pin to >=3.1.3
in prefect-aws
by @zzstoatzz in #16064AzureBlobStorageCredentials
to close default credentials when used as a context manager by @desertaxle in #16071/docs/3.0
by @daniel-prefect in #16058new
action to OpsGenieWebhook
for apprise==1.9.0
compatibility by @kevingrismore in #16030prefect_redis
use of async
by @teocns in #15967<5.0.0,>=1.0.12
to >=1.0.12,<6.0.0
by @dependabot in #15856async_dispatch
to enable forcing behavior for instance methods by @zzstoatzz in #15996prefect.yaml
by @discdiver in #15812prefect_aws.batch
off sync_compatible
by @zzstoatzz in #16053list
and set
settings values when marshaling to environment variables by @GalLadislav in #15979.env
files load only Prefect environment variables by @desertaxle in #15975url_for
by @sam-phinizy in #15974async_dispatch
for slack collection by @zzstoatzz in #15973None
value by @zzstoatzz in #15966asyncio_default_fixture_loop_scope
in all collections by @zzstoatzz in #15976prefect-kubernetes
into setting framework by @desertaxle in #15888wait_for
for DaskTaskRunner
by @zzstoatzz in #15909prefect config view
not showing .env file settings by @GalLadislav in #15922<0.13.0,>=0.12.0
to >=0.12.0
,!=0.12.2,<0.14.0
by @dependabot in #15949async_dispatch
util by @zzstoatzz in #15813COVERAGE_CORE=sysmon
to speed up test on 3.12 by @desertaxle in #15905pydantic-settings
for enhanced organization and clarity. You can now define your settings in either a dedicated prefect.toml
file or your existing pyproject.toml
file, streamlining the configuration experience and making it more portable across environments.
To learn more about new settings capabilities, check out the updated settings documentation or watch @zzstoatzz’s instructional demo on YouTube.
New Features 🎉
prefect.toml
file by @desertaxle in #15788pyproject.toml
file by @desertaxle in #15875run_shell_process
by @zzstoatzz in #15817jit="off"
setting for Postgres DBs by @desertaxle in #15854Settings.copy_with_update
to ignore sources when restoring default settings by @desertaxle in #15884prefect-dbt
Dependencies
<4.0.0,>=1.0.12
to >=1.0.12,<5.0.0
by @dependabot in #15839prefect.toml
to .gitignore
by @zzstoatzz in #15846soft_wrap
link in prefect block register
by @zzstoatzz in #15876experimental_warn
setting to experiments
model and removes async_fetch_state_result
by @desertaxle in #15885prefect.toml
support by @desertaxle in #15847max_active_runs
and catchup
fields by @zzstoatzz in #15810pytest-markdown-docs
by @bunchesofdonald in #15808