Skip to content

Releases: apache/airflow

Apache Airflow Helm Chart 1.4.0

10 Jan 18:26
helm-chart/1.4.0
Compare
Choose a tag to compare

New Features

  • Add type to extra secrets param (#20599)
  • Support elasticsearch connection scheme (#20564)
  • Allows to disable built-in secret variables individually (#18974)
  • Add support for securityContext (#18249)
  • Add extra containers, volumes and volume mounts for jobs (#18808)
  • Allow ingress multiple hostnames w/diff secrets (#18542)
  • PgBouncer extra volumes, volume mounts, and sslmode (#19749)
  • Allow specifying kerberos keytab (#19054)
  • Allow disabling the Helm hooks (#18776, #20018)
  • Add migration-wait-timeout (#20069)

Improvements

  • Increase default livenessProbe timeout (#20698)
  • Strict schema for k8s objects for values.yaml (#19181)
  • Remove unnecessary pod_template_file defaults (#19690)
  • Use built-in check-migrations command for Airflow>=2 (#19676)

Bug Fixes

  • Fix precedence of affinity, nodeSelector, and tolerations (#20641)
  • Fix chart elasticsearch default port 80 to 9200. (#20616)
  • Fix network policy issue for webserver and flowerui (#20199)
  • Use local definitions for k8s schema validation (#20544)
  • Add custom labels for ingresses/PVCs (#20535)
  • Fix extra secrets/configmaps labels (#20464)
  • Fix flower restarts on update (#20316)
  • Properly quote namespace names (#20266)

Doc only changes

  • Add helm dependency update step to chart INSTALL (#20702)
  • Reword section covering the envvar secrets (#20566)
  • Add "Customizing Workers" page (#20331)
  • Include Datadog example in production guide (#17996)
  • Update production Helm guide database section to use k8s secret (#19892)
  • Fix multiNamespaceMode docs to also cover KPO (#19879)
  • Clarify Helm behaviour when it comes to loading default connections (#19708)

Misc

  • Use 2.2.3 as default Airflow version (#20450)
  • Add ArtifactHUB annotations for docs and screenshots (#20558)
  • Add kubernetes 1.21 support (#19557)

Apache Airflow 2.2.3

21 Dec 17:25
2.2.3
Compare
Choose a tag to compare

Bug Fixes

  • Lazy Jinja2 context (#20217)
  • Exclude snowflake-sqlalchemy v1.2.5 (#20245)
  • Move away from legacy importlib.resources API (#19091)
  • Move setgid as the first command executed in forked task runner (#20040)
  • Fix race condition when starting DagProcessorAgent (#19935)
  • Limit httpx to <0.20.0 (#20218)
  • Log provider import errors as debug warnings (#20172)
  • Bump minimum required alembic version (#20153)
  • Fix log link in gantt view (#20121)
  • fixing #19028 by moving chown to use sudo (#20114)
  • Lift off upper bound for MarkupSafe (#20113)
  • Fix infinite recursion on redact log (#20039)
  • Fix db downgrades (#19994)
  • Context class handles deprecation (#19886)
  • Fix possible reference to undeclared variable (#19933)
  • Validate DagRun state is valid on assignment (#19898)
  • Workaround occasional deadlocks with MSSQL (#19856)
  • Enable task run setting to be able reinitialise (#19845)
  • Fix log endpoint for same task (#19672)
  • Cast macro datetime string inputs explicitly (#19592)
  • Do not crash with stacktrace when task instance is missing (#19478)
  • Fix log timezone in task log view (#19342) (#19401)
  • Fix: Add taskgroup tooltip to graph view (#19083)
  • Rename execution date in forms and tables (#19063)
  • Simplify "invalid TI state" message (#19029)
  • Handle case of nonexistent file when preparing file path queue (#18998)
  • Do not create dagruns for DAGs with import errors (#19367)
  • Fix field relabeling when switching between conn types (#19411)
  • KubernetesExecutor should default to template image if used (#19484)
  • Fix task instance api cannot list task instances with None state (#19487)
  • Fix IntegrityError in DagFileProcessor.manage_slas (#19553)
  • Declare data interval fields as serializable (#19616)
  • Relax timetable class validation (#19878)
  • Fix labels used to find queued KubernetesExecutor pods (#19904)
  • Fix moved data migration check for MySQL when replcation is used (#19999)

Doc only changes

  • Warn without tracebacks when example_dags are missing deps (#20295)
  • Deferrable operators doc clarification (#20150)
  • Ensure the example DAGs are all working (#19355)
  • Updating core example DAGs to use TaskFlow API where applicable (#18562)
  • Add xcom clearing behaviour on task retries (#19968)
  • Add a short chapter focusing on adapting secret format for connections (#19859)
  • Add information about supported OS-es for Apache Airflow (#19855)
  • Update docs to reflect that changes to the base_log_folder require updating other configs (#19793)
  • Disclaimer in KubernetesExecutor pod template docs (#19686)
  • Add upgrade note on execution_date -> run_id (#19593)
  • Expanding .output operator property information in TaskFlow tutorial doc (#19214)
  • Add example SLA DAG (#19563)
  • Add a proper example to patch DAG (#19465)
  • Add DAG file processing description to Scheduler Concepts (#18954)
  • Updating explicit arg example in TaskFlow API tutorial doc (#18907)
  • Adds back documentation about context usage in Python/@task (#18868)
  • Add release date for when an endpoint/field is added in the REST API (#19203)
  • Better pod_template_file examples (#19691)
  • Add decription on how you can customize image entrypoint (#18915)
  • Dags-in-image pod template example should not have dag mounts (#19337)

Apache Airflow Helm Chart 1.3.0

09 Nov 14:50
helm-chart/1.3.0
Compare
Choose a tag to compare

New Features

  • Chart: Add resources for cleanup and createuser jobs (#19263)
  • Chart: Add labels to jobs created by cleanup pods (#19225)
  • Add migration job resources (#19175)
  • Allow custom pod annotations to all components (#18481)
  • Chart: Make PgBouncer cmd/args configurable (#18910)
  • Chart: Use python 3.7 by default; support disabling triggerer (#18920)

Improvements

  • Chart: Increase default liveness probe timeout (#19003)
  • Chart: Mount DAGs in triggerer (#18753)

Bug Fixes

  • Allow Airflow UI to create worker pod via Clear > Run (#18272)
  • Allow airflow standard images to run in openshift utilising the official helm chart #18136 (#18147)

Doc only changes

  • Chart: Fix extraEnvFrom examples (#19144)
  • Chart docs: Update webserver secret key reference configuration (#18595)
  • Fix helm chart links in source install guide (#18588)

Misc

  • Chart: Update default Airflow version to 2.2.1 (#19326)
  • Modernize dockerfiles builds (#19327)
  • Chart: Use strict k8s schemas for template validation (#19379)

Apache Airflow 2.2.2

15 Nov 18:37
2.2.2
Compare
Choose a tag to compare

Bug Fixes

  • Fix bug when checking for existence of a Variable (#19395)
  • Fix Serialization whenrelativedelta is passed as schedule_interval (#19418)
  • Fix moving of dangling TaskInstance rows for SQL Server (#19425)
  • Fix task instance modal in gantt view (#19258)
  • Fix serialization of Params with set data type (#19267)
  • Check if job object is None before calling .is_alive() (#19380)
  • Task should fail immediately when pod is unprocessable (#19359)
  • Fix downgrade for a DB Migration (#19390)
  • Only mark SchedulerJobs as failed, not any jobs (#19375)
  • Fix message on "Mark as" confirmation page (#19363)
  • Bugfix: Check next run exists before reading data interval (#19307)
  • Fix MySQL db migration with default encoding/collation (#19268)
  • Fix hidden tooltip position (#19261)
  • sqlite_default Connection has been hard-coded to /tmp, use gettempdir instead (#19255)
  • Fix Toggle Wrap on DAG code page (#19211)
  • Clarify "dag not found" error message in CLI (#19338)
  • Add Note to SLA regarding schedule_interval (#19173)
  • Use execution_date to check for existing DagRun for TriggerDagRunOperator (#18968)
  • Add explicit session parameter in PoolSlotsAvailableDep (#18875)
  • FAB still requires WTForms<3.0 (#19466)
  • Fix missing dagruns when catchup=True (#19528)

Doc only changes

  • Add missing parameter documentation for "timetable" (#19282)
  • Improve Kubernetes Executor docs (#19339)
  • Update image tag used in docker docs

Apache Airflow 2.2.1

30 Oct 05:32
2.2.1
Compare
Choose a tag to compare

Bug Fixes

  • Fix Unexpected commit error in schedulerjob (#19213)
  • Add DagRun.logical_date as a property (#19198)
  • Clear ti.next_method and ti.next_kwargs on task finish (#19183)
  • Faster PostgreSQL db migration to Airflow 2.2 (#19166)
  • Remove incorrect type comment in Swagger2Specification._set_defaults classmethod (#19065)
  • Add TriggererJob to jobs check command (#19179, #19185)
  • Hide tooltip when next run is None (#19112)
  • Crerate TI context with data interval compat layer (#19148)
  • Fix queued dag runs changes catchup=False behaviour (#19130, #19145)
  • add detailed information to logging when a dag or a task finishes. (#19097)
  • Warn about unsupported Python 3.10 (#19060)
  • Fix catchup by limiting queued dagrun creation using max_active_runs (#18897)
  • Prevent scheduler crash when serialized dag is missing (#19113)
  • Don't install SQLAlchemy/Pendulum adapters for other DBs (#18745)
  • Workaround libstdcpp TLS error (#19010)
  • Change ds, ts, etc. back to use logical date (#19088)
  • Ensure task state doesn't change when marked as failed/success/skipped (#19095)
  • Relax packaging requirement (#19087)
  • Rename trigger page label to Logical Date (#19061)
  • Allow Param to support a default value of None (#19034)
  • Upgrade old DAG/task param format when deserializing from the DB (#18986)
  • Don't bake ENV and _cmd into tmp config for non-sudo (#18772)
  • CLI: Fail backfill command before loading DAGs if missing args (#18994)
  • BugFix: Null execution date on insert to task_fail violating NOT NULL (#18979)
  • Try to move "dangling" rows in upgradedb (#18953)
  • Row lock TI query in SchedulerJob._process_executor_events (#18975)
  • Sentry before send fallback (#18980)
  • Fix XCom.delete error in Airflow 2.2.0 (#18956)
  • Check python version before starting triggerer (#18926)

Doc only changes

  • Update access control documentation for TaskInstances and DagRuns (#18644)
  • Add information about keepalives for managed Postgres (#18850)
  • Doc: Add Callbacks Section to Logging & Monitoring (#18842)
  • Group PATCH DAGrun together with other DAGRun endpoints (#18885)

Apache Airflow 2.2.0

11 Oct 17:48
2.2.0
Compare
Choose a tag to compare

New Features

Improvements

  • Small improvements for Airflow UI (#18715, #18795)
  • Rename processor_poll_interval to scheduler_idle_sleep_time (#18704)
  • Check the allowed values for the logging level (#18651)
  • Fix error on triggering a dag that doesn't exist using dagrun_conf (#18655)
  • Add muldelete action to TaskInstanceModelView (#18438)
  • Avoid importing DAGs during clean DB installation (#18450)
  • Require can_edit on DAG privileges to modify TaskInstances and DagRuns (#16634)
  • Make Kubernetes job description fit on one log line (#18377)
  • Always draw borders if task instance state is null or undefined (#18033)
  • Inclusive Language (#18349)
  • Improved log handling for zombie tasks (#18277)
  • Adding Variable.update method and improving detection of variable key collisions (#18159)
  • Add note about params on trigger DAG page (#18166)
  • Change TaskInstance and TaskReschedule PK from execution_date to run_id (#17719)
  • Adding TaskGroup support in BaseOperator.chain() (#17456)
  • Advises the kernel to not cache log files generated by Airflow (#18054)
  • Allow filtering DAGS by tags in the REST API (#18090)
  • Optimize imports of Providers Manager (#18052)
  • Adds capability of Warnings for incompatible community providers (#18020)
  • Serialize the template_ext attribute to show it in UI (#17985)
  • Add robots.txt and X-Robots-Tag header (#17946)
  • Refactor BranchDayOfWeekOperator, DayOfWeekSensor (#17940)
  • Update error message to guide the user into self-help mostly (#17929)
  • Update to Celery 5 (#17397)
  • Avoid redirect loop for users with no permissions (#17838)
  • Improve graph view load time for dags with open groups (#17821)
  • Add links to provider's documentation (#17736)
  • Remove Marshmallow schema warnings (#17753)
  • Rename none_failed_or_skipped by none_failed_min_one_success trigger rule (#17683)
  • Remove [core] store_dag_code & use DB to get Dag Code (#16342)
  • Rename task_concurrency to max_active_tis_per_dag (#17708)
  • Import Hooks lazily individually in providers manager (#17682)
  • Adding support for multiple task-ids in the external task sensor (#17339)
  • Replace execution_date with run_id in airflow tasks run command (#16666)
  • Avoid endless redirect loop when user has no roles (#17613)
  • Make output from users cli command more consistent (#17642)
  • Open relative extra links in place (#17477)
  • Move worker_log_server_port option to the logging section (#17621)
  • Use gunicorn to serve logs generated by worker (#17591)
  • Improve validation of Group id (#17578)
  • Simplify 404 page (#17501)
  • Add XCom.clear so it's hookable in custom XCom backend (#17405)
  • Add deprecation notice for SubDagOperator (#17488)
  • Support DAGS folder being in different location on scheduler and runners (#16860)
  • Remove /dagrun/create and disable edit form generated by F.A.B (#17376)
  • Enable specifying dictionary paths in template_fields_renderers (#17321)
  • error early if virtualenv is missing (#15788)
  • Handle connection parameters added to Extra and custom fields (#17269)
  • Fix airflow celery stop to accept the pid file. (#17278)
  • Remove DAG refresh buttons (#17263)
  • Deprecate dummy trigger rule in favor of always (#17144)
  • Be verbose about failure to import airflow_local_settings (#17195)
  • Include exit code in AirflowException str when BashOperator fails. (#17151)
  • Adding EdgeModifier support for chain() (#17099)
  • Only allows supported field types to be used in custom connections (#17194)
  • Secrets backend failover (#16404)
  • Warn on Webserver when using SQLite or SequentialExecutor (#17133)
  • Extend init_containers defined in pod_override (#17537)
  • Client-side filter dag dependencies (#16253)
  • Improve executor validation in CLI (#17071)
  • Prevent running airflow db init/upgrade migrations and setup in parallel. (#17078)
  • Update chain() and cross_downstream() to support XComArgs (#16732)
  • Improve graph view refresh (#16696)
  • When a task instance fails with exception, log it (#16805)
  • Set process title for serve-logs and LocalExecutor (#16644)
  • Rename test_cycle to check_cycle (#16617)
  • Set process title for Worker when using LocalExecutor (#16623)
  • Add schema as DbApiHook instance attribute (#16521, #17423)
  • Improve compatibility with MSSQL (#9973)
  • Add transparency for unsupported connection type (#16220)
  • Call resource based fab methods (#16190)
  • Format more dates with timezone (#16129)
  • Replace deprecated dag.sub_dag with dag.partial_subset (#16179)
  • Treat AirflowSensorTimeout as immediate failure without retrying (#12058)
  • Marking success/failed automatically clears failed downstream tasks (#13037)
  • Add close/open indicator for import dag errors (#16073)
  • Add collapsible import errors (#16072)
  • Always return a response in TI's action_clear view (#15980)
  • Add cli command to delete user by email (#15873)
  • Use resource and action names for FAB permissions (#16410)
  • Rename DAG concurrency ([core] dag_concurrency) settings for easier understanding (#16267, #18730)
  • Calendar UI improvements (#16226)
  • Refactor: SKIPPED should not be logged again as SUCCESS (#14822)
  • Remove version limits for dnspython (#18046, #18162)
  • Accept custom run ID in TriggerDagRunOperator (#18788)

Bug Fixes

  • Make REST API patch user endpoint work the same way as the UI (#18757)
  • Properly set start_date for cleared tasks (#18708)
  • Ensure task_instance exists before running update on its state(REST API) (#18642)
  • Make AirflowDateTimePickerWidget a required field (#18602)
  • Retry deadlocked transactions on deleting old rendered task fields (#18616)
  • Fix retry_exponential_backoff divide by zero error when retry delay is zero (#17003)
  • Improve how UI handles datetimes (#18611, #18700)
  • Bugfix: dag_bag.get_dag should return None, not raise exception (#18554)
  • Only show the task modal if it is a valid instance (#18570)
  • Fix accessing rendered {{ task.x }} attributes from within templates (#18516)
  • Add missing email type of connection (#18502)
  • Don't use flash for "same-page" UI messages. (#18462)
  • Fix task group tooltip (#18406)
  • Properly fix dagrun update state endpoint (#18370)
  • Properly handle ti state difference between executor and scheduler (#17819)
  • Fix stuck "queued" tasks in KubernetesExecutor (#18152)
  • Don't permanently add zip DAGs to sys.path (#18384)
  • Fix random deadlocks in MSSQL database (#18362)
  • Deactivating DAGs which have been removed from files (#17121)
  • When syncing dags to db remove dag_tag rows that are now unused (#8231)
  • Graceful scheduler shutdown on error (#18092)
  • Fix mini scheduler not respecting wait_for_downstream dep (#18338)
  • Pass exception to run_finished_callback for Debug Executor (#17983)
  • Make XCom.get_one return full, not abbreviated values (#18274)
  • Use try/except when closing temporary file in task_runner (#18269)
  • show next run if not none (#18273)
  • Fix DB session handling in XCom.set (#18240)
  • Sort adopted tasks in _check_for_stalled_adopted_tasks method (#18208)
  • Fix external_executor_id not being set for manually run jobs (#17207)
  • Fix deleting of zipped Dags in Serialized Dag Table (#18243)
  • Return explicit error on user-add for duplicated email (#18224)
  • Remove loading dots even when last run data is empty (#18230)
  • Swap dag import error dropdown icons (#18207)
  • Automatically create section when migrating config (#16814)
  • Set encoding to utf-8 by default while reading task logs (#17965)
  • Set task state to failed when pod is DELETED while running (#18095)
  • Apply parent dag permissions to subdags (#1816...
Read more

Apache Airflow Helm Chart 1.2.0

28 Sep 18:42
helm-chart/1.2.0
Compare
Choose a tag to compare

New Features

  • Add Triggerer to Helm Chart (#17743)
  • Chart: warn when webserver secret key isn't set (#18306)
  • add extraContainers for migrateDatabaseJob (#18379)
  • Labels on job templates (#18403)
  • Chart: Allow running and waiting for DB Migrations using default image (#18218)
  • Chart: Make cleanup cronjob cmd/args configuable (#17970)
  • Chart: configurable number of retention days for log groomers (#17764)
  • Chart: Add loadBalancerSourceRanges in webserver and flower services (#17666)
  • Chart: Support extraContainers in k8s workers (#17562)

Improvements

  • Switch to latest version of PGBouncer-Exporter (#18429)
  • Chart: Ability to access http k8s via multiple hostnames (#18257)
  • Chart: Use stable API versions where available (#17211)
  • Chart: Allow podTemplate to be templated (#17560)

Bug Fixes

  • Chart: Fix applying labels on Triggerer (#18299)
  • Fixes warm shutdown for celery worker. (#18068)
  • Chart: Fix minor Triggerer issues (#18105)
  • Chart: fix webserver secret key update (#18079)
  • Chart: fix running with uid 0 (#17688)
  • Chart: use serviceaccount template for log reader rolebinding (#17645)
  • Chart: Fix elasticsearch-secret template port default function (#17428)
  • KEDA task count query should ignore k8s queue (#17433)

Doc only changes

  • Chart Doc: Delete extra space in adding connections doc (#18424)
  • Improves installing from sources pages for all components (#18251)
  • Chart docs: Format loadBalancerSourceRanges using code-block (#17763)
  • Doc: Fix a broken link in an ssh-related warning message (#17294)
  • Chart: Add instructions to Update Helm Repo before upgrade (#17282)
  • Chart docs: better note for logs existing pvc permissions (#17177)

Misc

  • Chart: Update the default Airflow version to 2.1.4 (#18354)

Apache Airflow 2.1.4

18 Sep 22:00
2.1.4
Compare
Choose a tag to compare

Bug Fixes

  • Fix deprecation error message rather than silencing it (#18126)
  • Limit the number of queued dagruns created by the Scheduler (#18065)
  • Fix DagRun execution order from queued to running not being properly followed (#18061)
  • Fix max_active_runs not allowing moving of queued dagruns to running (#17945)
  • Avoid redirect loop for users with no permissions (#17838)
  • Avoid endless redirect loop when user has no roles (#17613)
  • Fix log links on graph TI modal (#17862)
  • Hide variable import form if user lacks permission (#18000)
  • Improve dag/task concurrency check (#17786)
  • Fix Clear task instances endpoint resets all DAG runs bug (#17961)
  • Fixes incorrect parameter passed to views (#18083) (#18085)
  • Fix Sentry handler from LocalTaskJob causing error (#18119)
  • Limit colorlog version (6.x is incompatible) (#18099)
  • Only show Pause/Unpause tooltip on hover (#17957)
  • Improve graph view load time for dags with open groups (#17821)
  • Increase width for Run column (#17817)
  • Fix wrong query on running tis (#17631)
  • Add root to tree refresh url (#17633)
  • Do not delete running DAG from the UI (#17630)
  • Improve discoverability of Provider packages' functionality
  • Do not let create_dagrun overwrite explicit run_id (#17728)
  • BugFix: Regression on pid reset to allow task start after heartbeat (#17333)
  • Set task state to failed when pod is DELETED while running (#18095)
  • Advises the kernel to not cache log files generated by Airflow (#18054)
  • Sort adopted tasks in _check_for_stalled_adopted_tasks method (#18208)
  • Fix DagRunState enum query for MySQLdb driver (#17886)

Doc only changes

  • Update version added fields in airflow/config_templates/config.yml (#18128)
  • Improve the description of how to handle dynamic task generation (#17963)
  • Improve cross-links to operators and hooks references (#17622)
  • Doc: Fix replacing Airflow version for Docker stack (#17711)
  • Make the providers operators/hooks reference much more usable (#17768)
  • Update description about the new connection-types provider meta-data
  • Suggest to use secrets backend for variable when it contains sensitive data (#17319)
  • Improves quick-start docker-compose warnings and documentation (#18164)
  • Separate Installing from sources section and add more details (#18171)
  • Doc: Use closer.lua script for downloading sources (#18179)
  • Doc: Improve installing from sources (#18194)
  • Improves installing from sources pages for all components (#18251)

Apache Airflow 2.1.3

11 Sep 21:53
2.1.3
Compare
Choose a tag to compare

Bug Fixes

  • Fix task retries when they receive sigkill and have retries and properly handle sigterm (#16301)
  • Fix redacting secrets in context exceptions. (#17618)
  • Fix race condition with dagrun callbacks (#16741)
  • Add 'queued' to DagRunState (#16854)
  • Add 'queued' state to DagRun (#16401)
  • Fix external elasticsearch logs link (#16357)
  • Add proper warning message when recorded PID is different from current PID (#17411)
  • Fix running tasks with default_impersonation config (#17229)
  • Rescue if a DagRun's DAG was removed from db (#17544)
  • Fixed broken json_client (#17529)
  • Handle and log exceptions raised during task callback (#17347)
  • Fix CLI kubernetes cleanup-pods which fails on invalid label key (#17298)
  • Show serialization exceptions in DAG parsing log (#17277)
  • Fix: TaskInstance does not show queued_by_job_id & external_executor_id (#17179)
  • Adds more explanatory message when SecretsMasker is not configured (#17101)
  • Enable the use of __init_subclass__ in subclasses of BaseOperator (#17027)
  • Fix task instance retrieval in XCom view (#16923)
  • Validate type of priority_weight during parsing (#16765)
  • Correctly handle custom deps` and task_group`` during DAG Serialization (#16734)
  • Fix slow (cleared) tasks being be adopted by Celery worker. (#16718)
  • Fix calculating duration in tree view (#16695)
  • Fix AttributeError: datetime.timezone object has no attribute name (#16599)
  • Redact conn secrets in webserver logs (#16579)
  • Change graph focus to top of view instead of center (#16484)
  • Fail tasks in scheduler when executor reports they failed (#15929)
  • fix(smart_sensor): Unbound variable errors (#14774)
  • Add back missing permissions to UserModelView controls. (#17431)
  • Better diagnostics and self-healing of docker-compose (#17484)
  • Improve diagnostics message when users have secret_key mis-configured (#17410)
  • Stop checking execution_date in task_instance.refresh_from_db (#16809)

Improvements

  • Run mini scheduler in LocalTaskJob during task exit (#16289)
  • Remove SQLAlchemy<1.4 constraint (#16630)
  • Bump Jinja2 upper-bound from 2.12.0 to 4.0.0 (#16595)
  • Bump dnspython (#16698)
  • Updates to FlaskAppBuilder 3.3.2+ (#17208)
  • Add State types for tasks and DAGs (#15285)
  • Set Process title for Worker when using LocalExecutor (#16623)
  • Move DagFileProcessor and DagFileProcessorProcess out of scheduler_job.py (#16581)

Doc-only changes

  • Fix inconsistencies in configuration docs (#17317)
  • Fix docs link for using SQLite as Metadata DB (#17308)

Misc

  • Switch back http provider after requests removes LGPL dependency (#16974)

Apache Airflow Helm Chart 1.1.0

28 Jul 20:37
c7ed265
Compare
Choose a tag to compare

New Features

  • Chart: Allow using krb5.conf with CeleryExecutor (#16822)
  • Chart: Refactor webserver and flower networkpolicy (#16619)
  • Chart: Apply worker's node assigning settings to Pod Template File (#16663)
  • Chart: Support for overriding webserver and flower service ports (#16572)
  • Chart: Support extraContainers and extraVolumes in flower (#16515)
  • Chart: Allow configuration of pod resources in helm chart (#16425)
  • Chart: Support job level annotations; fix jobs scheduling config (#16331)
  • feat: Helm chart adding minReplicaCount to the Keda worker-kedaautoscaler.yaml (#16262)
  • Chart: Adds support for custom command and args (#16153)
  • Chart: Add extra ini config to pgbouncer (#16120)
  • Chart: Add extraInitContainers to scheduler/webserver/workers (#16098)
  • Configurable resources for git-sync sidecar (#16080)
  • Chart: Template airflowLocalSettings and webserver.webserverConfig (#16074)
  • Support strategy/updateStrategy on scheduler (#16069)
  • Chart: Add both airflow and extra annotations to jobs (#16058)
  • loadBalancerIP and annotations for both Flower and Webserver (#15972)

Improvements

  • Chart: Update Postgres subchart to 10.5.3 (#17041)
  • Chart: Update the default Airflow version to 2.1.2 (#17013)
  • Update default image as 2.1.1 for Helm Chart (#16785)
  • Chart: warn when using default logging with KubernetesExecutor (#16784)
  • Drop support for Helm 2 (#16575)
  • Chart: podAntiAffinity for scheduler, webserver, and workers (#16315)
  • Chart: Update the default Airflow Version to 2.1.0 (#16273)
  • Chart: Only mount DAGs in webserver when required (#16229)
  • Chart: Remove git-sync: root and dest params (#15955)
  • Chart: Add warning about missing knownHosts (#15950)

Bug Fixes

  • Chart: Create a random secret for Webserver's flask secret key (#17142)
  • Chart: fix labels on cleanup serviceaccount (#16722)
  • Chart: Fix overriding node assigning settings on Worker Deployment (#16670)
  • Chart: Always deploy a gitsync init container (#16339)
  • Chart: Fix updating from KubernetesExecutor to CeleryExecutor (#16242)
  • Chart: Adds labels to Kubernetes worker pods (#16203)
  • Chart: Allow webserver.base_url to be templated (#16126)
  • Chart: Fix PgBouncer exporter sidecar (#16099)
  • Remove dags.gitSync.excludeWebserver from chart values.schema.json (#16070)
  • Chart: Fix Elasticsearch secret created without Elasticsearch enabled (#16015)
  • Handle special characters in password sfor Helm Chart (#16004)
  • Fix flower serviceAccount created without flower enable (#16011)
  • Chart: gitsync Clean Up for KubernetesExecutor (#15925)
  • Mount DAGs read only when using gitsync (#15953)

Doc only changes

  • Chart docs: note uid write permissions for existing pvc (#17170)
  • Chart Docs: Add single-line description for multiNamespaceMode (#17147)
  • Chart: Update description for Helm chart to include 'official' (#17040)
  • Chart: Better comment and example for podTemplate (#16859)
  • Chart: Add more clear docs for setting pod_template_file.yaml (#16632)
  • Fix description on scheduler.livenessprobe.periodSeconds (#16486)
  • Chart docs: Fix extrasecrets example (#16305)
  • Small improvements for README.md files (#16244)

Misc

  • Removes pylint from our toolchain (#16682)
  • Update link to match what is in pre-commit (#16408)
  • Chart: Update the appVersion to 2.1.0 in Chart.yaml (#16337)
  • Rename the main branch of the Airflow repo to be main (#16149)
  • Update Chart version to 1.1.0-rc1 (#16124)