Skip to content

Releases: apache/airflow

Airflow 1.10.14, 2020-12-10

10 Dec 15:11
1.10.14
Compare
Choose a tag to compare

Bug Fixes

  • BugFix: Tasks with depends_on_past or task_concurrency are stuck (#12663)
  • Fix issue with empty Resources in executor_config (#12633)
  • Fix: Deprecated config force_log_out_after was not used (#12661)
  • Fix empty asctime field in JSON formatted logs (#10515)
  • [AIRFLOW-2809] Fix security issue regarding Flask SECRET_KEY (#3651)
  • [AIRFLOW-2884] Fix Flask SECRET_KEY security issue in www_rbac (#3729)
  • [AIRFLOW-2886] Generate random Flask SECRET_KEY in default config (#3738)
  • Add missing comma in setup.py (#12790)
  • Bugfix: Unable to import Airflow plugins on Python 3.8 (#12859)
  • Fix setup.py missing comma in setup_requires (#12880)
  • Don't emit first_task_scheduling_delay metric for only-once dags (#12835)

Improvements

  • Update setup.py to get non-conflicting set of dependencies (#12636)
  • Rename [scheduler] max_threads to [scheduler] parsing_processes (#12605)
  • Add metric for scheduling delay between first run task & expected start time (#9544)
  • Add new-style 2.0 command names for Airflow 1.10.x (#12725)
  • Add Kubernetes cleanup-pods CLI command for Helm Chart (#11802)
  • Don't let webserver run with dangerous config (#12747)
  • Replace pkg_resources with importlib.metadata to avoid VersionConflict errors (#12694)

Doc only changes

  • Clarified information about supported Databases

apache-airflow-upgrade-check 1.0.0

02 Dec 12:19
deb7fc0
Compare
Choose a tag to compare

The first release of apache-airflow-upgrade-check module.

Release based off the v1-10-stable branch.

📦 https://pypi.org/project/apache-airflow-upgrade-check/

Airflow 1.10.13, 2020-11-25

25 Nov 14:03
Compare
Choose a tag to compare

New Features

  • Add "already checked" to failed pods in K8sPodOperator (#11368)
  • Pass SQLAlchemy engine options to FAB based UI (#11395)
  • [AIRFLOW-4438] Add Gzip compression to S3_hook (#8571)
  • Add permission "extra_links" for Viewer role and above (#10719)
  • Add generate_yaml command to easily test KubernetesExecutor before deploying pods (#10677)
  • Add Secrets backend for Microsoft Azure Key Vault (#10898)

Bug Fixes

  • SkipMixin: Handle empty branches (#11120)
  • [AIRFLOW-5274] dag loading duration metric name too long (#5890)
  • Handle no Dagrun in DagrunIdDep (#8389) (#11343)
  • Fix Kubernetes Executor logs for long dag names (#10942)
  • Add on_kill support for the KubernetesPodOperator (#10666)
  • KubernetesPodOperator template fix (#10963)
  • Fix displaying of add serialized_dag table migration
  • Fix Start Date tooltip on DAGs page (#10637)
  • URL encode execution date in the Last Run link (#10595)
  • Fixes issue with affinity backcompat in Airflow 1.10
  • Fix KubernetesExecutor import in views.py
  • Fix issues with Gantt View (#12419)
  • Fix Entrypoint and _CMD config variables (#12411)
  • Fix operator field update for SerializedBaseOperator (#10924)
  • Limited cryptography to < 3.2 for python 2.7
  • Install cattr on Python 3.7 - Fix docs build on RTD (#12045)
  • Limit version of marshmallow-sqlalchemy
  • Pin kubernetes to a max version of 11.0.0 (#11974)
  • Use snakebite-py3 for HDFS dependency for Python3 (#12340)
  • Removes snakebite kerberos dependency (#10865)
  • Fix failing dependencies for FAB and Celery (#10828)
  • Fix pod_mutation_hook for 1.10.13 (#10850)
  • Fix formatting of Host information
  • Fix Logout Google Auth issue in Non-RBAC UI (#11890)
  • Add missing imports to app.py (#10650)
  • Show Generic Error for Charts & Query View in old UI (#12495)
  • TimeSensor should respect the default_timezone config (#9699)
  • TimeSensor should respect DAG timezone (#9882)
  • Unify user session lifetime configuration (#11970)
  • Handle outdated webserver session timeout gracefully. (#12332)

Improvements

  • Add XCom.deserialize_value to Airflow 1.10.13 (#12328)
  • Mount airflow.cfg to pod_template_file (#12311)
  • All k8s object must comply with JSON Schema (#12003)
  • Validate airflow chart values.yaml & values.schema.json (#11990)
  • Pod template file uses custom custom env variable (#11480)
  • Bump attrs and cattrs dependencies (#11969)
  • Bump attrs to > 20.0 (#11799)
  • [AIRFLOW-3607] Only query DB once per DAG run for TriggerRuleDep (#4751)
  • Rename task with duplicate task_id
  • Manage Flask AppBuilder Tables using Alembic Migrations (#12352)
  • airflow test only works for tasks in 1.10, not whole dags (#11191)
  • Improve warning messaging for duplicate task_ids in a DAG (#11126)
  • Pins moto to 1.3.14 (#10986)
  • DbApiHook: Support kwargs in get_pandas_df (#9730)
  • Make grace_period_seconds option on K8sPodOperator (#10727)
  • Fix syntax error in Dockerfile 'maintainer' Label (#10899)
  • The entrypoints in Docker Image should be owned by Airflow (#10853)
  • Make dockerfiles Google Shell Guide Compliant (#10734)
  • clean-logs script for Dockerfile: trim logs before sleep (#10685)
  • When sending tasks to celery from a sub-process, reset signal handlers (#11278)
  • SkipMixin: Add missing session.commit() and test (#10421)
  • Webserver: Further Sanitize values passed to origin param (#12459)
  • Security upgrade lodash from 4.17.19 to 4.17.20 (#11095)
  • Log instead of raise an Error for unregistered OperatorLinks (#11959)
  • Mask Password in Log table when using the CLI (#11468)
  • [AIRFLOW-3607] Optimize dep checking when depends on past set and concurrency limit
  • Execute job cancel HTTPRequest in Dataproc Hook (#10361)
  • Use rst lexer to format airflow upgrade check output (#11259)
  • Remove deprecation warning from contrib/kubernetes/pod.py
  • adding body as templated field for CloudSqlImportOperator (#10510)
  • Change log level for User's session to DEBUG (#12414)

Deprecations

  • Deprecate importing Hooks from plugin-created module (#12133)
  • Deprecate adding Operators and Sensors via plugins (#12069)

Doc only changes

  • [Doc] Correct description for macro task_instance_key_str (#11062)
  • Checks if all the libraries in setup.py are listed in installation.rst file (#12023)
  • Revise "Project Focus" copy (#12011)
  • Move Project focus and Principles higher in the README (#11973)
  • Remove archived link from README.md (#11945)
  • Update download url for Airflow Version (#11800)
  • Add Project URLs for PyPI page (#11801)
  • Move Backport Providers docs to our docsite (#11136)
  • Refactor rebase copy (#11030)
  • Add missing images for kubernetes executor docs (#11083)
  • Fix identation in executor_config example (#10467)
  • Enhanced the Kubernetes Executor doc (#10433)
  • Refactor content to a markdown table (#10863)
  • Rename "Beyond the Horizon" section and refactor content (#10802)
  • Refactor official source section to use bullets (#10801)
  • Add section for official source code (#10678)
  • Add redbubble link to Airflow merchandise (#10359)
  • README Doc: Link to Airflow directory in ASF Directory (#11137)
  • Fix the default value for VaultBackend's config_path (#12518)

Airflow 2.0.0b3

20 Nov 11:01
94ba200
Compare
Choose a tag to compare
Airflow 2.0.0b3 Pre-release
Pre-release

Major features since beta2:

New features:

  • Add description field to connection (#10873)
  • Use different deserialization method in XCom init_on_load (#12327)
  • Make nav fully accessible y keyboard, fix mobile nav menus (#12351)
  • Add metric for scheduling delay between first run task & expected start time (#9544)
  • Create DAG-level cluster policy (#12184)

Improvements:

  • UI: Improve the layout of TI modal when browser at narrower widths (#12456)
  • PR to add 'files' to template-fields in EmailOperator class (#12428)
  • JSON Response is returned for invalid API requests (#12305)
  • Make K8sPodOperator backwards compatible (#12384)
  • Don't display DAG docs when None (#12415)
  • Simplify using XComArg in jinja template string (#12405)
  • Remove inapplicable configuration section [ldap] (since 2.0.0) (#12386)
  • Add info log message about duration taken to load plugins (#12308)
  • Manage Flask AppBuilder Tables using Alembic Migrations (#12352)
  • UI: Improve presentation of DAG Docs (#12330)
  • Wait option for dagrun operator (#12126)
  • Use default view in TriggerDagRunLink (#11778)
  • Handle naive datetimes in REST APIi (#12248)
  • Unify user session lifetime configuration for webserver (#11970)

Bug fixes:

  • Fix typo in migrations: RESOURCE_DAGS to RESOURCE_DAG. (#12460)
  • UI: Fix bug in server timezone indicator (#12447)
  • Fix issues with Gantt View (#12419)
  • Proper exit status for failed CLI requests (#12375)
  • Check for TaskGroup in _PythonDecoratedOperator (#12312)
  • Reject 'connections add' CLI request if URI provided is invalid (#12370)
  • Reorder Database Migrations (#12362)
  • Refactor root logger handling in task run (#12342)
  • Bugfix: REST API Variables update endpoint returns 204 No Content (#12321)
  • UI: Fix/Enhancement: Disable forms and communicate to user when no DAG Runs (#12320)
  • UI: Get all "tags" parameters not just one (#12324)
  • Make dag_id, task_id, and execution_date nullable in event log schema (#12287)
  • Don't wrap warrning messages when stderr is not a TTY (#12285)
  • Don't treat warning message as rich formatting codes. (#12283)
  • UI: Fix pause/unpause toggle to display failed state when unsuccessful (#12267)
  • UI: Conditionally update button URL only when it is present (#12268)

Docs:

  • Cleanup requirements in README a bit (#12446)
  • Synchronization of supported K8S version (#12443)
  • Show all Providers in Docs (#12363)
  • Restructure documentation for releasing Airflow/Providers (#12350)
  • Fix Sample CLI commands for upgrading to 2.0 (#12349)
  • Docs installation improvements (#12304)
  • Remove providers imports from core examples (#12252)

Misc/Internal:

  • Move setup properties out of setup.py in to setup.cfg (#12417)
  • Change log level for User's session to DEBUG (#12414)
  • Adds mechanism for provider package discovery. (#12383)
  • Add success/failed sets to State class (#12359)
  • Enable protection for v1-10-stable branch (#12343)
  • Fix prod image build (#12314)
  • Remove deprecated Elasticsearch Configs (#12296)
  • Remove deprecated BashTaskRunner (#12295)
  • Added k9s as integrated tool to help with kubernetes testing (#12163)
  • Providers in extras are properly configured and verified (#12265)

Airflow 2.0.0b2

02 Dec 12:21
1521965
Compare
Choose a tag to compare
Airflow 2.0.0b2 Pre-release
Pre-release
  • Update versions in UPDATING.md for 2.0.0b1 release (#12244)
  • Remove Unnecessary comprehension (#12221)
  • Sign release files with an apache.org key by default (#12241)
  • Add back missing api_connextion/init.py file (#12240)
  • Fixes automated provider installation with extras (#12233)
  • Enable markdownlint rule - MD031/blanks-around-fences (#12238)
  • Fix spelling in Python files (#12230)
  • Add docs about security on GCP (#12187)
  • Enable Markdownlint rule - MD022/blanks-around-headings (#12225)
  • CSS Changes to adjust content width as per screen size and responsive table with multiline td. (#12227)

Airflow 1.10.12, 2020-08-25

25 Aug 19:02
Compare
Choose a tag to compare

New Features

  • Add DateTimeSensor (#9697)
  • Add ClusterPolicyViolation support to airflow local settings (#10282)
  • Get Airflow configs with sensitive data from Secret Backends (#9645)
  • [AIRFLOW-4734] Upsert functionality for PostgresHook.insert_rows() (#8625)
  • Allow defining custom XCom class (#8560)

Bug Fixes

  • Add pre 1.10.11 Kubernetes Paths back with Deprecation Warning (#10067)
  • Fixes PodMutationHook for backwards compatibility (#9903)
  • Fix bug in executor_config when defining resources (#9935)
  • Respect DAG Serialization setting when running sync_perm (#10321)
  • Show correct duration on graph view for running task (#8311) (#8675)
  • Fix regression in SQLThresholdCheckOperator (#9312)
  • [AIRFLOW-6931] Fixed migrations to find all dependencies for MSSQL (#9891)
  • Avoid sharing session with RenderedTaskInstanceFields write and delete (#9993)
  • Fix clear future recursive when ExternalTaskMarker is used (#9515)
  • Handle IntegrityError while creating TIs (#10136)
  • Fix airflow-webserver startup errors when using Kerberos Auth (#10047)
  • Fixes treatment of open slots in scheduler (#9316) (#9505)
  • Fix KubernetesPodOperator reattachment (#10230)
  • Fix more PodMutationHook issues for backwards compatibility (#10084)
  • [AIRFLOW-5391] Do not re-run skipped tasks when they are cleared (#7276)
  • Fix task_instance_mutation_hook (#9910)
  • Fixes failing formatting of DAG file containing {} in docstring (#9779)
  • Fix is_terminal_support_colors function (#9734)
  • Fix PythonVirtualenvOperator when using provide_context=True (#8256)
  • Fix issue with mounting volumes from secrets (#10366)
  • BugFix: K8s Executor Multinamespace mode is evaluated to true by default (#10410)
  • Make KubernetesExecutor recognize kubernetes_labels (#10412)
  • Fix broken Kubernetes PodRuntimeInfoEnv (#10478)

Improvements

  • Use Hash of Serialized DAG to determine DAG is changed or not (#10227)
  • Update Serialized DAGs in Webserver when DAGs are Updated (#9851)
  • Do not Update Serialized DAGs in DB if DAG did not change (#9850)
  • Add repr to SerializedDagModel (#9862)
  • Update JS packages to latest versions (#9811) (#9921)
  • UI Graph View: Focus upstream / downstream task dependencies on mouseover (#9303)
  • Allow image in KubernetesPodOperator to be templated (#10068)
  • [AIRFLOW-6843] Add delete_option_kwargs to delete_namespaced_pod (#7523)
  • Improve process terminating in scheduler_job (#8064)
  • Replace deprecated base classes used in bigquery_check_operator (#10272)
  • [AIRFLOW-5897] Allow setting -1 as pool slots value in webserver (#6550)
  • Limit all google-cloud api to <2.0.0 (#10317)
  • [AIRFLOW-6706] Lazy load operator extra links (#7327) (#10318)
  • Add Snowflake support to SQL operator and sensor (#9843)
  • Makes multi-namespace mode optional (#9570)
  • Pin Pyarrow < 1.0
  • Pin pymongo version to <3.11.0
  • Pin google-cloud-container to <2 (#9901)
  • Dockerfile: Remove package.json and yarn.lock from the prod image (#9814)
  • Dockerfile: The group of embedded DAGs should be root to be OpenShift compatible (#9794)
  • Update upper limit of flask-swagger, gunicorn & jinja2 (#9684)
  • Webserver: Sanitize values passed to origin param (#10334)
  • Sort connection type list in add/edit page alphabetically (#8692)

Doc only changes

  • Add new committers: Ry Walker & Leah Cole to project.rst (#9892)
  • Add Qingping Hou to committers list (#9725)
  • Updated link to official documentation (#9629)
  • Create a short-link for Airflow Slack Invites (#10034)
  • Fix docstrings in BigQueryGetDataOperator (#10042)
  • Set language on code-block on docs/howto/email-config.rst (#10238)
  • Remove duplicate line from 1.10.10 CHANGELOG (#10289)
  • Improve heading on Email Configuration page (#10175)
  • Fix link for the Jinja Project in docs/tutorial.rst (#10245)
  • Create separate section for Cron Presets (#10247)
  • Add Syntax Highlights to code-blocks in docs/best-practices.rst (#10258)
  • Fix docstrings in BigQueryGetDataOperator (#10042)
  • Fix typo in Task Lifecycle section (#9867)
  • Make Secret Backend docs clearer about Variable & Connection View (#8913)

Airflow 1.10.11, 2020-07-10

10 Jul 15:22
Compare
Choose a tag to compare

New Features

  • Add task instance mutation hook (#8852)
  • Allow changing Task States Colors (#9520)
  • Add support for AWS Secrets Manager as Secrets Backend (#8186)
  • Add airflow info command to the CLI (#8704)
  • Add Local Filesystem Secret Backend (#8596)
  • Add Airflow config CLI command (#8694)
  • Add Support for Python 3.8 (#8836)(#8823)
  • Allow K8S worker pod to be configured from JSON/YAML file (#6230)
  • Add quarterly to crontab presets (#6873)
  • Add support for ephemeral storage on KubernetesPodOperator (#6337)
  • Add AirflowFailException to fail without any retry (#7133)
  • Add SQL Branch Operator (#8942)

Bug Fixes

  • Use NULL as dag.description default value (#7593)
  • BugFix: DAG trigger via UI error in RBAC UI (#8411)
  • Fix logging issue when running tasks (#9363)
  • Fix JSON encoding error in DockerOperator (#8287)
  • Fix alembic crash due to typing import (#6547)
  • Correctly restore upstream_task_ids when deserializing Operators (#8775)
  • Correctly store non-default Nones in serialized tasks/dags (#8772)
  • Correctly deserialize dagrun_timeout field on DAGs (#8735)
  • Fix tree view if config contains " (#9250)
  • Fix Dag Run UI execution date with timezone cannot be saved issue (#8902)
  • Fix Migration for MSSQL (#8385)
  • RBAC ui: Fix missing Y-axis labels with units in plots (#8252)
  • RBAC ui: Fix missing task runs being rendered as circles instead (#8253)
  • Fix: DagRuns page renders the state column with artifacts in old UI (#9612)
  • Fix task and dag stats on home page (#8865)
  • Fix the trigger_dag api in the case of nested subdags (#8081)
  • UX Fix: Prevent undesired text selection with DAG title selection in Chrome (#8912)
  • Fix connection add/edit for spark (#8685)
  • Fix retries causing constraint violation on MySQL with DAG Serialization (#9336)
  • [AIRFLOW-4472] Use json.dumps/loads for templating lineage data (#5253)
  • Restrict google-cloud-texttospeach to <v2 (#9137)
  • Fix pickling failure when spawning processes (#8671)
  • Pin Version of Azure Cosmos to <4 (#8956)
  • Azure storage 0.37.0 is not installable any more (#8833)
  • Fix modal_backdrop z-index in the UI (#7313)
  • Fix Extra Links in Gannt View (#8308)
  • Bug fix for EmrAddStepOperator init with cluster_name error (#9235)
  • Fix KubernetesPodOperator pod name length validation (#8829)
  • Fix non updating DAG code by checking against last modification time (#8266)
  • BugFix: Unpausing a DAG with catchup=False creates an extra DAG run (#8776)

Improvements

  • Improve add_dag_code_table migration (#8176)
  • Persistent display/filtering of DAG status (#8106)
  • Set unique logger names (#7330)
  • Update the version of cattrs from 0.9 to 1.0 to support Python 3.8 (#7100)
  • Reduce response payload size of /dag_stats and /task_stats (#8655)
  • Add authenticator parameter to snowflake_hook (#8642)
  • Show "Task Reschedule" table in Airflow Webserver (#9521)
  • Change worker_refresh_interval fallback to default of 30 (#9588)
  • Use pfromat instead of str to render arguments in WebUI (#9587)
  • Simplify DagFileProcessorManager (#7521)
  • Reload gunicorn when plugins has beeen changed (#8997)
  • Fix the default value for store_dag_code (#9554)
  • Add support for fetching logs from running pods (#8626)
  • Persist start/end date and duration for DummyOperator Task Instance (#8663)
  • Ensure "started"/"ended" in tooltips are not shown if job not started (#8667)
  • Add context to execution_date_fn in ExternalTaskSensor (#8702)
  • Avoid color info in response of /dag_stats & /task_stats (#8742)
  • Make loading plugins from entrypoint fault-tolerant (#8732)
  • Refactor Kubernetes worker config (#7114)
  • Add default conf parameter to Spark JDBC Hook (#8787)
  • Allow passing backend_kwargs to AWS SSM client (#8802)
  • Filter dags by clicking on tag (#8897)
  • Support k8s auth method in Vault Secrets provider (#8640)
  • Monitor pods by labels instead of names (#6377)
  • Optimize count query on /home (#8729)
  • Fix json string escape in tree view (#8551)
  • Add TaskInstance state to TI Tooltip to be colour-blind friendlier (#8910)
  • Add a tip to trigger DAG screen (#9049)
  • Use Markup for htmlcontent for landing_times (#9242)
  • Pinning max pandas version to 2.0 (lesser than) to allow pandas 1.0 (#7954)
  • Update example webserver_config.py to show correct CSRF config (#8944)
  • Fix displaying Executor Class Name in "Base Job" table (#8679)
  • Use existing DagBag for 'dag_details' & 'trigger' Endpoints (#8501)
  • Flush pending Sentry exceptions before exiting (#7232)
  • Display DAG run conf in the list view (#6794)
  • Fix performance degradation when updating dagrun state (#8435)
  • Don't use the |safe filter in code, it's risky (#9180)
  • Validate only task commands are run by executors (#9178)
  • Show Deprecation warning on duplicate Task ids (#8728)
  • Move DAG._schedule_interval logic out of DAG.__init__ (#8225)
  • Make retrieving Paused Dag ids a separate method (#7587)
  • Bulk fetch paused_dag_ids (#7476)
  • Add a configurable DAGs volume mount path for Kubernetes (#8147)
  • Add schedulername option for KubernetesPodOperator (#6088)
  • Support running git sync container as root (#6312)
  • Add extra options for Slack Webhook operator and Slack hook (#9409)
  • Monkey patch greenlet celery pools (#8559)
  • Decrypt secrets from SystemsManagerParameterStoreBackend (#9214)
  • Prevent clickable sorting on non sortable columns in TI view (#8681)
  • Make hive macros py3 compatible (#8598)
  • Fix SVG tooltip positioning with custom scripting (#8269)
  • Avoid unnecessary sleep to maintain local task job heart rate (#6553)
  • Include some missing RBAC roles on User and Viewer roles (#9133)
  • Show Dag's Markdown docs on Tree View (#9448)
  • Improved compatibility with Python 3.5+ - Convert signal.SIGTERM to int (#9207)
  • Add 'main' param to template_fields in DataprocSubmitPySparkJobOperator (#9154)
  • Make it possible to silence warnings from Airflow (#9208)
  • Remove redundant count query in BaseOperator.clear() (#9362)
  • Fix DB migration message (#8988)
  • Fix awkward log info in dbapi_hook (#8482)
  • Fix Celery default to no longer allow pickle (#7205)
  • Further validation that only task commands are run by executors (#9240)
  • Remove vendored nvd3 and slugify libraries (#9136)
  • Enable configurable git sync depth (#9094)
  • Reduce the required resources for the Kubernetes's sidecar (#6062)
  • Refactor K8S codebase with k8s API models (#5481)
  • Move k8sexecutor out of contrib to closer match master (#8904)
  • Allow filtering using "event" and "owner" in "Log" view (#4881)
  • Add Yandex.Cloud custom connection to 1.10 (#8791)
  • Add table-hover css class to DAGs table (#5033)
  • Show un/pause errors in dags view. (#7669)
  • Restructure database queries on /home (#4872)
  • Add Cross Site Scripting defence (#6913)
  • Make Gantt tooltip the same as Tree and Graph view (#8220)
  • Add config to only delete worker pod on task failure (#7507)(#8312)
  • Remove duplicate error message on chart connection failure (#8476)
  • Remove default value spark_binary (#8508)
  • Expose Airflow Webserver Port in Production Docker Image (#8228)
  • Commit after each alembic migration (#4797)
  • KubernetesPodOperator fixes and test (#6524)
  • Docker Image: Add ADDITIONAL_AIRFLOW_EXTRAS (#9032)
  • Docker Image: Add ADDITIONAL_PYTHON_DEPS (#9031)
  • Remove httplib2 from Google requirements (#9194)
  • Merging multiple sql operators (#9124)
  • Adds hive as extra in pyhive dependency (#9075)
  • Change default auth for experimental backend to deny_all (#9611)
  • Restrict changing XCom values from the Webserver (#9614)
  • Add repr for DagTag so tags display properly in /dagmodel/show (#8719)
  • Functionality to shuffle HMS connections used by HiveMetastoreHook facilitating load balancing (#9280)
  • Expose SQLAlchemy's connect_args and make it configurable (#6478)

Doc only changes

  • Add docs on using DAGRun.conf (#9578)
  • Enforce code-block directives in doc (#9443)
  • Carefully parse warning messages when building documentation (#8693)
  • Make KubernetesPodOperator clear in docs (#8444)
  • Improve language in Pod Mutation Hook docs (#8445)
  • Fix formatting of Pool docs in concepts.rst (#8443)
  • Make doc clearer about Airflow Variables using Environment Variables (#8427)
  • Fix pools doc for LocalExecutor (#7643)
  • Add Local and Sequential Executors to Doc (#8084)
  • Add documentation for CLI command airflow dags test (#8251)
  • Fix typo in DAG Serialization documentation (#8317)
  • Add scheduler in production section (#7351)
  • Add a structural dag validation example (#6727)
  • Adding Task re-run documentation (#6295)
  • Fix outdated doc on settings.policy (#7532)
  • Add docs about reload_on_plugin_change opiton (#9575)
  • Add copy button to Code Blocks in Airflow Docs (#9450)
  • Update commands in docs for v1.10+ (#9585)
  • Add more info on dry-run CLI option (#9582)
  • Document default timeout value for SSHOperator (#8744)
  • Fix docs on creating CustomOperator (#8678)
  • Enhanced documentation around Cluster Policy (#8661)
  • Use sphinx syntax in concepts.rst (#7729)
  • Update README to remove Py 3.8 limitation for Master (#9451)
  • Add note about using dag_run.conf in BashOperator (#9143)
  • Improve tutorial - Include all imports statements (#8670)
  • Added more precise Python requirements to README.md (#8455)
  • Fix Airflow Stable version in README.md (#9360)
  • Update AWS connection example to show how to set from env var (#9191)
  • Fix list formatting of plugins doc. (#8873)
  • Add 'Version Added' on Secrets Backend docs (#8264)
  • Simplify language re roll-your-own secrets backend (#8257)
  • Add installation description for repeatable PyPi installation (#8513)
  • Add note extra links only render on when using RBAC webserver (#8788)
  • Remove unused airflow import from docs (#9274)
  • Add PR/issue note in Contribution Workflow Example (#9177)
  • Don't use the term "whitelist" - lan...
Read more

Airflow 1.10.10, 2020-04-09

09 Apr 20:10
Compare
Choose a tag to compare

New Features

  • [AIRFLOW-7048] Allow user to chose timezone to use in UI (#8046)
  • Add Production Docker image support (#7832)
  • Get Airflow Variables from Environment Variables (#7923)
  • Get Airflow Variables from Hashicorp Vault (#7944)
  • Get Airflow Variables from AWS Systems Manager Parameter Store (#7945)
  • Get Airflow Variables from GCP Secrets Manager (#7946)
  • [AIRFLOW-5705] Add secrets backend and support for AWS SSM / Get Airflow Connections from AWS Parameter Store(#6376)
  • [AIRFLOW-7104] Add Secret backend for GCP Secrets Manager / Get Airflow Connections from GCP Secrets Manager (#7795)
  • [AIRFLOW-7076] Add support for HashiCorp Vault as Secrets Backend / Get Airflow Connections from Hashicorp Vault (#7741)
  • [AIRFLOW-6685] Add ThresholdCheckOperator (#7353)
  • [AIRFLOW-7080] Add API endpoint to return a DAG's paused state (#7737)

Improvements

Bug Fixes

Misc/Internal

Doc only changes

  • Fix typo for store_serialized_dags config (#7952)
  • Fix broken link in README.md (#7893)
  • Separate supported Postgres versions with comma (#7892)
  • Fix grammar in setup.py (#7877)
  • Add Jiajie Zhong to committers list (#8047)
  • Update Security doc for 1.10.* for auth backends (#8072)
  • Fix Example in config_templates for Secrets Backend (#8074)
  • Add backticks in IMAGES.rst command description (#8075)
  • Change version_added for store_dag_code config (#8076)
  • [AIRFLOW-XXXX] Remove duplicate docs
  • [AIRFLOW-XXXX] Remove the defunct limitation of Dag Serialization (#7716)
  • [AIRFLOW-XXXX] Add prerequisite tasks for ...
Read more

Airflow 1.10.9, 2020-02-07

19 Feb 22:47
Compare
Choose a tag to compare

Bug Fixes

  • [AIRFLOW-6751] Pin Werkzeug (dependency of a number of our dependencies) to < 1.0.0 (#7377)

Airflow 1.10.8, 2020-02-07

07 Feb 04:04
Compare
Choose a tag to compare

New Features

Improvements

Bug Fixes

Misc/Internal

Doc only changes

  • [AIRFLOW-XXXX] Consistency fixes in new documentation (#7207)
  • [AIRFLOW-XXXX] Improve grammar and structure in FAQ doc (#7291)
  • [AIRFLOW-XXXX] Fix email configuration link in CONTRIBUTING.rst (#7311)
  • [AIRFLOW-XXXX] Update docs with new BranchPythonOperator behaviour (#4682)
  • [AIRFLOW-XXXX] Fix Typo in scripts/ci/ci_run_airflow_testing.sh (#7235)
  • [AIRFLOW-XXXX] Screenshot showing disk space configuration for OSX (#7226)
  • [AIRFLOW-XXXX] Add mentoring information to contributing docs (#7202)
  • [AIRFLOW-XXXX] Add rebase info to contributing (#7201)
  • [AIRFLOW-XXXX] Increase verbosity of static checks in CI (#7200)
  • [AIRFLOW-XXXX] Adds branching strategy to documentation (#7193)
  • [AIRFLOW-XXXX] Move email configuration from the concept page (#7189)
  • [AIRFLOW-XXXX] Update task lifecycle diagram (#7161)
  • [AIRFLOW-XXXX] Fix reference in concepts doc (#7135)
  • [AIRFLOW-XXXX] Clear debug docs (#7104)
  • [AIRFLOW-XXXX] Fix typos and broken links in development docs (#7086)
  • [AIRFLOW-XXXX] Clarify wait_for_downstream and execution_date (#6999)
  • [AIRFLOW-XXXX] Add airflow dags show command guide (#7014)
  • [AIRFLOW-XXXX] Update operation chaining documentation (#7018)
  • [AIRFLOW-XXXX] Add .autoenv_leave.zsh to .gitignore (#6986)
  • [AIRFLOW-XXXX] Fix development packages installation instructions (#6942)
  • [AIRFLOW-XXXX] Update committers list (#7212)
  • [AIRFLOW-XXXX] Move UPDATING changes into correct versions (#7166)
  • [AIRFLOW-XXXX] Add Documentation for check_slas flag (#6974)
  • [AIRFLOW-XXXX] Fix gcp keyfile_d...
Read more