All Versions
22
Latest Version
Avg Release Cycle
7 days
Latest Release
525 days ago
Changelog History
Page 1
Changelog History
Page 1
-
v0.13.19 Changes
December 08, 2020๐ Changelog
0.13.19
๐ Released on December 8, 2020.
โจ Enhancements
- ๐ป Use explicit exception chaining - #3306
- ๐ Support Bitbucket as storage option - #3711
- ๐ Surface pod failures and container errors in jobs deployed with the Kubernetes Agent - 3747
- ๐ Support timeout option in GCS tasks - #3732
- โ Added storage option for AWS CodeCommit - #3733
- โ Add the image used for a flow-run to the flow run environment as
prefect.context.image
- #3746 - โ Add
UniversalRun
run-config that works with all agents - #3750 - ๐ Support flows that have no run-config or environment - #3750
- ๐ Allow Docker storage environment vars to be used in commands - #3755
- Add
service_account_name
andimage_pull_secrets
options toKubernetesRun
andKubernetesAgent
- #3778 - โ Add a new Client function
delete_project
- #3728
Task Library
- โ Add task to fetch data from Dremio - #3734
- โ Add
RunGreatExpectationsValidation
task - #3753 - โ Add the option to post markdown artifacts from the
RunGreatExpectationsValidation
task - #3753
๐ Fixes
- ๐ Fix state attempting to read result from absent upstream result - #3618
- Replace deprecated download_as_string method with download_as_bytes method - #3741
- ๐ Fix default image whenever working on a non-tagged commit - #3748
- ๐ Fix type-casting for task timeout defaults loaded from config - #3761
- ๐ Fix the
ref
default on GitHub storage - #3764 - ๐ Fix rare cancellation bug when running with external Dask cluster - #3770
๐ Deprecations
- ๐ Deprecated the
RunGreatExpectationsCheckpoint
task in favor ofRunGreatExpectationsValidation
- #3766
Contributors
-
v0.13.18 Changes
November 30, 2020๐ Changelog
0.13.18
๐ Released on November 30, 2020.
โจ Enhancements
- Display formatted graphql errors on client request failure - #3632
- ๐ Refactor Core Client API calls for performance - #3730
Task Library
- ๐จ Refactor execute query code for
PostgresExecute
,PostgresExecuteMany
, andPostgresFetch
tasks - #3714 - ๐ Fix
PicklingError
inBigQueryLoadFile
andBigQueryLoadGoogleCloudStorage
- #3724 - ๐ Allow custom exporter for
ExecuteNotebook
task - #3725 - Properly forward
location
parameter in bigquery tasks - #3726 - ๐ Support passing
helper_script
toShellTask
/DBTShellTask
at runtime - #3729
๐ Fixes
- ๐ Fix bug with docker storage throwing exception while trying to display output - #3717
Contributors
-
v0.13.17 Changes
November 24, 2020๐ Changelog
0.13.17
๐ Released on November 24, 2020.
๐ Features
- ๐ Improved support for Tasks returning multiple results - #3697
โจ Enhancements
- ๐ Allow chaining of
Task
imperative dependency calls - #3696 - Add
task_definition_arn
toECSRun
run-config - #3681 - Rerun
resource_manager
tasks when restarting flows from failed - #3689 - โ Raise nice warning if user passes
Task
instance toTask
constructor, rather than when calling theTask
(or usingTask.map
/Task.set_dependencies
) - #3691 - Always use tenant slug in output of Client
get_cloud_url
function - #3692
Task Library
- โ Add enhancement to
StartFlowRun
task to create link artifact for started flow run - #3692 - โ Add a new postgres task
PostgresExecuteMany
- #3703 - โ Add debug logging for Docker tasks
PullImage
andBuildImage
- #3672 ShellTask
returns output on failure - #3649ShellTask
allows streaming of output independently of the number of lines returned - #3649
๐ Fixes
- ๐ Make
serialized_hash
handle unordered task sets correctly - #3682 - ๐ Docker storage build error logs were not always displayed - #3693
- ๐ Fix automatic quoting of Docker storage environment variable values - #3694
- ๐ Use
exist_ok
flag inos.makedirs
to avoid race condition in local storage class - #3679
Contributors
-
v0.13.16 Changes
November 18, 2020๐ Changelog
๐ Released on November 17, 2020.
โจ Enhancements
- ๐ Experimental support for Python 3.9 - #3411
๐ Fixes
- ๐ Fixes Flow.replace freezing reference tasks - #3655
- ๐ Fixed bug where
flow.serialized_hash()
could return inconsistent values across new python instances - #3654
Contributors
-
v0.13.15 Changes
November 11, 2020๐ Changelog
0.13.15
๐ Released on November 11, 2020.
๐ Features
- โ Add API for storing task run artifacts in the backend - #3581
โจ Enhancements
- ๐ Allow for setting
Client
headers before loading tenant when running with Prefect Server - #3515 - Checkpoint all iterations of Looped tasks - #3619
- โ Add
ref
option to GitHub storage for specifying branches other than master - #3638 - โ Added
ExecuteNotebook
task for running Jupyter notebooks - #3599 - โฑ Pass
day_or
croniter argument to CronClock and CronSchedule - #3612 Client.create_project
andprefect create project
will skip creating the project if the project already exists - #3630- ๐ Update deployments extension to AppsV1Api - #3637
PrefectSecret
andEnvVarSecret
tasks no longer require secret names be provided at flow creation time - #3641
๐ Fixes
- ๐ Fix issue with retrying mapped pipelines on dask - #3519
- โ Task arguments take precedence when generating
task_run_name
- #3605 - ๐ Fix breaking change in flow registration with old server versions - #3642
- Task arguments take precedence when generating templated targets and locations - #3627
๐ฅ Breaking Changes
- ๐ Environment variable config values now parse without requiring escaping backslashes - #3603
Contributors
-
v0.13.14 Changes
November 05, 2020๐ Changelog
0.13.14
๐ Released on November 5, 2020.
๐ Features
flow.register
accepts an idempotency key to prevent excessive flow versions from being created - #3590- โ Added
flow.serialized_hash()
for easy generation of hash keys from the serialized flow - #3590
โจ Enhancements
- โ Add option to select
cursor_type
for MySQLFetch task - #3574 - โ Add new
ECSAgent
andECSRun
run config - #3585 - ๐ป Display exception information on
prefect create project
failure - #3589 - 0๏ธโฃ
prefect diagnostics
no longer displays keys that have values matching the default config - #3593 - ๐ Allow use of multiple image pull secrets in
KubernetesAgent
,DaskKubernetesEnvironment
- #3596 - โ Added FROM to explicitly chain exceptions in src/prefect/tasks/twitter - #3602
- โ Add UTC offset to default logging.datefmt; logging timestamp converter now follows Python default behavior - #3607
- ๐ Improve error message when API responds with 400 status code - #3615
๐ Deprecations
- ๐ Deprecate
prefect agent start <kind>
in favor ofprefect agent <kind> start
- #3610 - ๐ Deprecate
prefect agent install <kind>
in favor ofprefect agent <kind> install
- #3610
Contributors
-
v0.13.13 Changes
October 27, 2020๐ Changelog
0.13.13
๐ Released on October 27, 2020.
โจ Enhancements
- Don't stop execution if the task runner fails to load a cached result - #3378
- โ Add option to specify
networkMode
for tasks created by the Fargate Agent - #3546 - ๐ Allows to schedule flow runs at an arbitrary time with StartFlowRun - #3573
๐ Fixes
- ๐ Use
BlobServiceClient
instead ofBlockBlobService
to connect to azure blob in azure tasks - #3562 - Tasks with
log_stdout=True
work with non-utf8 output - #3563
Contributors
-
v0.13.12 Changes
October 20, 2020๐ Changelog
0.13.12
๐ Released on October 20, 2020.
โจ Enhancements
- โฑ Agents now submit flow runs in order of scheduled start times - #3165
- ๐ Updating k8s tutorial docs to include instructions on how to provide access to S3 from kubernetes deployments on AWS - #3200
- โ Adds option to specify default values for GetItem and GetAttr tasks - #3489
- ๐ Allow disabling default storage labels for the
LocalAgent
- #3503 - ๐ Improve overall functionality of docs search, full list of changes here - #3504
- โ Add
LocalRun
implementation forrun_config
based flows - #3527 - โ Add
DockerRun
implementation forrun_config
based flows - #3537 - โฑ Raise a better error message when trying to register a flow with a schedule using custom filter functions - #3450
- โ
RenameFlowRunTask
: use defaultflow_run_id
value from context - #3548 - 0๏ธโฃ Raise a better error message when trying to register a flow with parameters with JSON-incompatible defaults - #3549
Task Library
- Extended
GCSUpload
task to allow uploading of bytes/gzip data - #3507 - Allow setting runtime
webook_secret
onSlackTask
and kwarg forwebhook_secret
retrieved fromPrefectSecret
task - #3522
๐ Fixes
- ๐ Fix
get flow-runs
anddescribe flow-runs
CLI commands querying of removedduration
field - #3517 - ๐ Fix multiprocess based timeout handler on linux - #3526
- ๐ Fix API doc generation incorrectly compiling mocked imports - #3504
- ๐ Fix multiprocessing scheduler failure while running tasks with timeouts - #3511
- โก๏ธ Update Fargate task definition validation - #3514
- ๐ Fix bug in k8s where the resource-manager would sometimes silently crash on errors - #3521
- โ Add labels from
flow.storage
forrun_config
based flows - #3527 - ๐ Fix LocalAgent PYTHONPATH construction on Windows - #3551
๐ Deprecations
FlowRunTask
,RenameFlowRunTask
, andCancelFlowRunTask
have been renamed toStartFlowRun
,RenameFlowRun
, andCancelFlowRun
respectively - #3539
Contributors
-
v0.13.11 Changes
October 14, 2020๐ Changelog
0.13.11
๐ Released on October 14, 2020.
๐ Features
- ๐ Allow for schedules that emit custom Flow Run labels - #3483
โจ Enhancements
- ๐ป Use explicit exception chaining - #3306
- S3List filtering using the LastModified value - #3460
- โ Add Gitlab storage - #3461
- Extend module storage capabilities - #3463
- ๐ Support adding additional flow labels in
prefect register flow
- #3465 - 0๏ธโฃ Strict Type for default value of a Parameter - #3466
- Enable automatic script upload for file-based storage when using S3 and GCS - #3482
- Allow for passing labels to
client.create_flow_run
- #3483 - ๐ป Display flow group ID in registration output URL instead of flow ID to avoid redirect in UI - #3500
- โ Add informative error log when local storage fails to load flow - #3475
Task Library
- โ Add cancel flow run task - #3484
- โ Add new
BatchSubmit
task for submitting jobs to AWS batch - #3366 - โ Add new
AWSClientWait
task for waiting on long-running AWS jobs - #3366 - โ Add GetAttr task - #3481
๐ Fixes
- ๐ Fix default profile directory creation behavior - #3037
- ๐ Fix
DaskKubernetesEnvironment
overwriting log attributes for custom specs - #3231 - ๐ Fix default behavior for
dbt_kwargs
in the dbt task to provide an empty string - #3280 - ๐ Fix containerDefinitions environment validation - #3452
- ๐ Raise a better error when calling
flow.register()
from within aFlow
context - #3467 - ๐ Fix task cancellation on Python 3.8 to properly interrupt long blocking calls - #3474
Contributors
-
v0.13.10 Changes
October 06, 2020๐ Changelog
0.13.10
๐ Released on October 6, 2020.
โจ Enhancements
- โ Add option to template task run name at runtime when using backend API - #2100
- Add
set_task_run_name
Client function - #2100 - ๐ Use
from
to explicitly chain exceptions - #3306 - โก๏ธ Update error message when registering flow to non-existant project - #3418
- Add
flow.run_config
, an experimental design for configuring deployed flows - #3333 - ๐ Allow python path in Local storage - #3351
- Enable agent registration for server users - #3385
Task Library
- โ Add keypair auth for snowflake - #3404
- โ Add new
RenameFlowRunTask
for renaming a currently running flow - #3285.
๐ Fixes
- ๐ Fix mypy typing for
target
kwarg on base Task class - #2100 - ๐ Fix Fargate Agent not parsing cpu and memory provided as integers - #3423
- ๐ Fix MySQL Tasks breaking on opening a context - #3426
Contributors