Airflow 2 to 3 auto migration rules
Description
Why
As we're introducing breaking changes to the main branch, it would be better to begin recording the things we could use migration tools to help our users migrate from Airflow 2 to 3.
The breaking changes can be found at https://github.com/apache/airflow/pulls?q=is%3Apr+label%3Aairflow3.0%3Abreaking and through newsfragments/(\d{5}).significant.rst
What
- List down all the change needed based on newsfragments/(\d{5}).significant.rst
- Organize them into the following issues for tracking the implementation part
- [ ] #44556
- [x] #44555
List of significant news fragments and rules after #44080
The following rules has been reorganized and merged into #44556 and #44555
List of significant news fragments and rules before #44080
List of significant news fragments and rules (by Nov 27)
- [x] #24842
- ❓ I guess we don't need to do something for it based on the reason why we changed it.
- [x] #40029
- Remove config
allow_raw_html_descriptions
- Remove config
- [x] #40931
- ❌ Model related change
- [x] #41096
- config
scheduler.processor_poll_interval→scheduler.scheduler_idle_sleep_time
- config
- [x] #41348
- module
airflow.datasets→airflow.sdk.definitions.asset- class
DatasetAlias→AssetAlias - class
DatasetAll→AssetAll - class
DatasetAny→AssetAny - function
expand_alias_to_datasets→expand_alias_to_assets - class
DatasetAliasEvent→AssetAliasEvent- attribute
dest_dataset_uri→BaseAsset
- attribute
- class
BaseDataset→BaseAsset- method
iter_datasets→iter_assets - method
iter_dataset_aliases→iter_asset_aliases
- method
- class
Dataset→Asset- method
iter_datasets→iter_assets - method
iter_dataset_aliases→iter_asset_aliases
- method
- class
_DatasetBooleanCondition→_AssetBooleanCondition- method
iter_datasets→iter_assets - method
iter_dataset_aliases→iter_asset_aliases
- method
- class
- module
airflow.datasets.manager→airflow.assets.manager- variable
dataset_manager→asset_manager - function
resolve_dataset_manager→resolve_asset_manager - class
DatasetManager→AssetManager- method
register_dataset_change→register_asset_change - method
create_datasets→create_assets - method
register_dataset_change→notify_asset_created - method
notify_dataset_changed→notify_asset_changed - method
notify_dataset_alias_created→notify_asset_alias_created
- method
- variable
- module
airflow.listeners.spec.dataset→airflow.listeners.spec.asset- function
on_dataset_created→on_asset_created - function
on_dataset_changed→on_asset_changed
- function
- module
airflow.timetables.datasets→airflow.timetables.assets- class
DatasetOrTimeSchedule→AssetOrTimeSchedule
- class
- module
airflow.datasets.metadata→airflow.sdk.definitions.asset.metadata - module
airflow.listeners.spec.dataset→airflow.listeners.spec.asset- function
on_dataset_created→on_asset_created - function
on_dataset_changed→on_asset_changed
- function
- class
airflow.timetables.datasets.DatasetOrTimeSchedule→airflow.timetables.assets.AssetOrTimeSchedule - decorator
airflow.api_connexion.security.requires_access_dataset→airflow.api_connexion.security.requires_access_dataset.requires_access_asset - class
airflow.auth.managers.models.resource_details.DatasetDetails→airflow.auth.managers.models.resource_details.AssetDetails - function
airflow.auth.managers.base_auth_manager.is_authorized_dataset→airflow.auth.managers.base_auth_manager.is_authorized_asset - class
airflow.timetables.simple.DatasetTriggeredTimetable→airflow.timetables.simple.AssetTriggeredTimetable - in class
airflow.providers_manager.ProvidersManager- method
initialize_providers_dataset_uri_resources→initialize_providers_asset_uri_resources - property
dataset_factories→asset_factories - property
dataset_uri_handlers→asset_uri_handlers - property
dataset_to_openlineage_converters→asset_to_openlineage_converters
- method
- constant
airflow.security.permissions.RESOURCE_DATASET→airflow.security.permissions.RESOURCE_ASSET - function
airflow.www.auth.has_access_dataset→airflow.www.auth.has_access_dataset.has_access_asset - class
airflow.lineage.hook.DatasetLineageInfo→airflow.lineage.hook.AssetLineageInfo- attribute
dataset→asset
- attribute
- In class
airflow.lineage.hook.HookLineageCollector- method
create_dataset→create_asset - method
add_input_dataset→add_input_asset - method
add_output_dataset→add_output_asset - method
collected_datasets→collected_assets
- method
- context key
triggering_dataset_events→triggering_asset_events - resource key
dataset-uris→asset-uris(for providers amazon, common.io, mysql, fab, postgres, trino) - In amazon provider
- package
airflow.providers.amazon.aws.datasets→airflow.providers.amazon.aws.assets- in module
s3- method
create_dataset→create_asset - method
convert_dataset_to_openlineage→convert_asset_to_openlineage
- method
- in module
- attribute
airflow.providers.amazon.auth_manager.avp.entities.AvpEntities.DATASET→airflow.providers.amazon.auth_manager.avp.entities.AvpEntities.ASSET airflow.providers.amazon.auth_manager.aws_auth_manager.AwsAuthManager.is_authorized_dataset→airflow.providers.amazon.auth_manager.aws_auth_manager.AwsAuthManager.is_authorized_asset
- package
- In Common IO Provider
- package
airflow.providers.common.io.datasets→airflow.providers.common.io.assets- in module
file- method
create_dataset→create_asset - method
convert_dataset_to_openlineage→convert_asset_to_openlineage
- method
- in module
- package
- In fab provider
- function
airflow.providers.fab.auth_manager.fab_auth_manager.is_authorized_dataset→airflow.providers.fab.auth_manager.fab_auth_manager.is_authorized_asset
- function
- In openlineage provider
- in module
airflow.providers.openlineage.utils.utils- class
DatasetInfo→AssetInfo - function
translate_airflow_dataset→translate_airflow_asset
- class
- in module
- In postgres provider
- package
airflow.providers.postgres.datasets→airflow.providers.postgres.assets
- package
- In mysql provider
- package
airflow.providers.mysql.datasets→airflow.providers.mysql.assets
- package
- In trino provider
- package
airflow.providers.trino.datasets→airflow.providers.trino.assets
- package
- ❌ ignored
airflow.api_connexion.schemas.dataset_schemaairflow.api_ui.views.datasetsairflow.serialization.pydantic.datasetairflow.serialization.pydantic.taskinstanceairflow.serialization.enums.DagAttributeTypesairflow.serialization.serialized_objectsairflow.utils.context- models
- DagDependency names
- private methods
- module
- [x] #41366
- #44385
- [x] #41367
airflow.models.ImportError→airflow.models.errors.ParseImportError
- [x] #41368
- Remove
airflow.executors.* - Remove
airflow.hooks.* - Remove
airflow.macros.* - Remove
airflow.operators.* - Remove
airflow.sensors.*
- Remove
- [x] #41390
- Remove package
airflow.operators.subdag
- Remove package
- [x] #41391
airflow.sensors.external_task.ExternalTaskSensorLink→airflow.sensors.external_task.ExternalDagLin
- [x] #41393
- in
DayOfWeekSensor- parameter
use_task_execution_day→use_task_logical_date
- parameter
- in
- [x] #41394
airflow.models.taskMixin.TaskMixin→airflow.models.taskMixin.DependencyMixin
- [x] #41395
- Remove
airflow.executors.executor_loader.UNPICKLEABLE_EXECUTORS - Remove
airflow.utils.dag_cycle_tester.test_cycle - Remove
airflow.utils.file.TemporaryDirectory - Remove
airflow.utils.file.mkdirs - Remove
airflow.utils.state.SHUTDOWN - Remove
airflow.utils.state.terminating_states
- Remove
- [x] #41420
- ❌ Internal change
- [x] #41434
- ❌ REST APIchange
- [x] #41440
- ❌ Model change
- [x] #41453
- in
DAG- Remove argument
schedule_interval - Remove argument
timetable
- Remove argument
- in
- [x] #41496
- Remove
airflow.utils.dates.date_range - Remove
airflow.utils.dates.days_ago→ ❓ do we need to change it topendulum.today('UTC').add(days=-N, ...)
- Remove
- [x] #41520
airflow.utils.helpers.chain→airflow.models.baseoperator.chainairflow.utils.helpers.chain→airflow.models.baseoperator.cross_downstream
- [x] #41533
airflow.secrets.local_filesystem.load_connections→airflow.secrets.local_filesystem.load_connections_dictairflow.secrets.local_filesystem.get_connection→airflow.secrets.local_filesystem.load_connections_dict
- [x] #41539
- Remove config
smtp.smtp_user - Remove config
smtp.smtp_password
- Remove config
- [x] #41550
- Remove config
webserver.session_lifetime_days→ usewebserver.session_lifetime_minutes - Remove config
webserver.force_log_out_after→ usewebserver.session_lifetime_minutes - config section
policy→task_policy
- Remove config
- [x] #41552
- In
airflow.utils.log.file_task_handler.FileTaskHandler- Remove parameter
filename_template
- Remove parameter
- In
- [x] #41579
- Remove function
airflow.utils.decorators.apply_defaults
- Remove function
- [x] #41609
- Remove config
scheduler.dependency_detector
- Remove config
- [x] #41635
- ❌ CLI changes
- [x] #41642
airflow.secrets.base_secrets.BaseSecretsBackend.get_conn_uri→airflow.secrets.base_secrets.BaseSecretsBackend.get_conn_valueairflow.secrets.base_secrets.BaseSecretsBackend.get_connections→airflow.secrets.base_secrets.BaseSecretsBackend.get_connection
- [x] #41663
airflow.api.auth.backend.basic_auth→airflow.providers.fab.auth_manager.api.auth.backend.basic_auth
- [x] #41693
airflow.api.auth.backend.kerberos_auth→airflow.providers.fab.auth_manager.api.auth.backend.kerberos_authairflow.auth.managers.fab.api.auth.backend.kerberos_auth→airflow.providers.fab.auth_manager.api.auth.backend.kerberos_auth
- [x] #41708
airflow.auth.managers.fab.fab_auth_manager→airflow.providers.fab.auth_manager.security_manager.overrideairflow.auth.managers.fab.security_manager.override→airflow.providers.fab.auth_manager.security_manager.override
- [x] #41733
- Remove
airflow.hooks.base.BaseHook.get_connections(❓ related to 41642)
- Remove
- [x] #41735
- Remove
airflow.kubernetes
- Remove
- [x] #41736
- in
airflow.operators.datetime.BranchDateTimeOperator- parameter
use_task_execution_day→use_task_logical_date
- parameter
- in
airflow.operators.trigger_dagrun.TriggerDagRunOperator- remove parameter
execution_date
- remove parameter
- in
airflow.operators.weekday.BranchDayOfWeekOperator- parameter
use_task_execution_day→use_task_logical_date
- parameter
- in
- [x] #41737
- Remove
airflow.triggers.external_task.TaskStateTrigger
- Remove
- [x] #41739
- ❌ CLI changes
- [x] #41748
airflow.hooks.dbapi→airflow.providers.common.sql.hooks.sql
- [x] #41758
- Remove
airflow.www.auth.has_access→ useairflow.www.auth.has_access_* - module
airflow.www.security→airflow.providers.fab.auth_manager.security_manager.override.FabAirflowSecurityManagerOverride airflow.www.utils.get_sensitive_variables_fields→airflow.utils.log.secrets_masker.get_sensitive_variables_fieldsairflow.www.utils.should_hide_value_for_key→airflow.utils.log.secrets_masker.should_hide_value_for_key
- Remove
- [x] #41761
- in
BaseOperator- paramter
task_concurrency→max_active_tis_per_daghttps://github.com/astral-sh/ruff/pull/14616 - remove trigger_rule
dummy - remove trigger_rule
none_failed_or_skipped
- paramter
- remove config
operators.ALLOW_ILLEGAL_ARGUMENTS airflow.models.baseoperator.BaseOperatorLink→airflow.models.baseoperatorlink.BaseOperatorLink
- in
- [x] #41762
- Remove
airflow.models.connection.parse_netloc_to_hostname - Remove
airflow.models.connection.Connection.parse_from_uri - Remove
airflow.models.connection.Connection.log_info - Remove
airflow.models.connection.Connection.debug_info
- Remove
- [x] #41774
- ❌ Model change
- [x] #41776
- ❌ Model change
- [x] #41778
- ❌ Model change
- [x] #41779
- ❌ Model change
- [x] #41780
- ❌ Model change
- [x] #41784
- ❌ Model change
- [x] #41808
- ❌ Model change
- [x] #41814
- ❌ overwritten by 43915
- [x] #41857
- ❌ Package dependency change
- [x] #41910
- Remove
airflow.api_connexion.security.requires_access→ userequires_access_*
- Remove
- [x] #41964
- ❌ CLI changed
- ❌ Model change
- [x] #41975
- Remove config
metrics.metrics_use_pattern_match - Remove
airflow.metrics.validators.AllowListValidator→ suggest usingairflow.metrics.validators.PatternAllowListValidator(not direct mapping) - Remove
airflow.metrics.validators.BlockListValidator→ suggest usingairflow.metrics.validators.PatternBlockListValidator(not direct mapping)
- Remove config
- [x] #42023
- ❌ Model change
- [x] #42042
- ~~ Remove property
airflow.auth.managers.models.base_user.is_active~~ ❌ Users are not likely to use it
- ~~ Remove property
- [x] #42054
- ❓ not sure what we can do
- [x] #42060
- Remove config
celery.stalled_task_timeout - config
kubernetes_executor.worker_pods_pending_timeout→scheduler.task_queued_timeout
- Remove config
- [x] #42088
- config
metrics.statsd_allow_list→metrics.metrics_allow_list - config
metrics.statsd_block_list→metrics.metrics_block_list - config
scheduler.statsd_on→metrics.statsd_on - config
scheduler.statsd_host→metrics.statsd_host - config
scheduler.statsd_port→metrics.statsd_port - config
scheduler.statsd_prefix→metrics.statsd_prefix - config
scheduler.statsd_allow_list→metrics.statsd_allow_list - config
scheduler.stat_name_handler→metrics.stat_name_handler - config
scheduler.statsd_datadog_enabled→metrics.statsd_datadog_enabled - config
scheduler.statsd_datadog_tags→metrics.statsd_datadog_tags - config
scheduler.statsd_datadog_metrics_tags→metrics.statsd_datadog_metrics_tags - config
scheduler.statsd_custom_client_path→metrics.statsd_custom_client_path
- config
- [x] #42100
- config
core.interleave_timestamp_parser→logging.interleave_timestamp_parser - config
core.base_log_folder→logging.base_log_folder - config
core.remote_logging→logging.remote_logging - config
core.remote_log_conn_id→logging.remote_log_conn_id - config
core.remote_base_log_folder→logging.remote_base_log_folder - config
core.encrypt_s3_logs→logging.encrypt_s3_logs - config
core.logging_level→logging.logging_level - config
core.fab_logging_level→logging.fab_logging_level - config
core.logging_config_class→logging.logging_config_class - config
core.colored_console_log→logging.colored_console_log - config
core.colored_log_format→logging.colored_log_format - config
core.colored_formatter_class→logging.colored_formatter_class - config
core.log_format→logging.log_format - config
core.simple_log_format→logging.simple_log_format - config
core.task_log_prefix_template→logging.task_log_prefix_template - config
core.log_filename_template→logging.log_filename_template - config
core.log_processor_filename_template→logging.log_processor_filename_template - config
core.dag_processor_manager_log_location→logging.dag_processor_manager_log_location - config
core.task_log_reader→logging.task_log_reader
- config
- [x] #42126
- config
core.sql_alchemy_conn→database.sql_alchemy_conn - config
core.sql_engine_encoding→database.sql_engine_encoding - config
core.sql_engine_collation_for_ids→database.sql_engine_collation_for_ids - config
core.sql_alchemy_pool_enabled→database.sql_alchemy_pool_enabled - config
core.sql_alchemy_pool_size→database.sql_alchemy_pool_size - config
core.sql_alchemy_max_overflow→database.sql_alchemy_max_overflow - config
core.sql_alchemy_pool_recycle→database.sql_alchemy_pool_recycle - config
core.sql_alchemy_pool_pre_ping→database.sql_alchemy_pool_pre_ping - config
core.sql_alchemy_schema→database.sql_alchemy_schema - config
core.sql_alchemy_connect_args→database.sql_alchemy_connect_args - config
core.load_default_connections→database.load_default_connections - config
core.max_db_retries→database.max_db_retries
- config
- [x] #42129
- config
core.worker_precheck→celery.worker_precheck - config
scheduler.max_threads→scheduler.parsing_processes - config
celery.default_queue→operators.default_queue - config
admin.hide_sensitive_variable_fields→core.hide_sensitive_var_conn_fields - config
admin.sensitive_variable_fields→core.sensitive_var_conn_names - config
core.non_pooled_task_slot_count→core.default_pool_task_slot_count - config
core.dag_concurrency→core.max_active_tasks_per_dag - config
api.access_control_allow_origin→api.access_control_allow_origins - config
api.auth_backend→api.auth_backends - config
scheduler.deactivate_stale_dags_interval→scheduler.parsing_cleanup_interval - config
kubernetes_executor.worker_pods_pending_timeout_check_interval→scheduler.task_queued_timeout_check_interval - config
webserver.update_fab_perms→fab.update_fab_perms - config
webserver.auth_rate_limited→fab.auth_rate_limited - config
webserver.auth_rate_limit→fab.auth_rate_limit - config section
kubernetes→kubernetes_executor
- config
- [x] #42137
- ❌ package dependency change
- [x] #42280
- ❌ REST APIchange
- [x] #42285
- Remove config
core.check_slas - In
DAG- Remove argument
sla_miss_callback
- Remove argument
- In
BaseOperator- Remove argument
sla
- Remove argument
- Remove config
- [x] #42343
- ❌ Internal change
- [x] #42436
- ❓ Should we raise a warning if that
dag_ignore_file_syntaxhas changed
- ❓ Should we raise a warning if that
- #42548
- ❌ Model change
- [x] #42579
- ❌ REST APIchange
- [x] #42640
- ❌ Test change
- [x] #42647
- ❌ Build change
- [x] #42658
- ❌ REST API change
- [x] #42660
- ❌ REST API change
- [x] #42739
- ❌ Model change
- [x] #42776
- ❌ Model change
- [x] #42953
- ❓ Should we warn that
DAG.max_active_runsbehavior has been changed
- ❓ Should we warn that
- [x] #43067
- ❌ Model change
- [x] #43073
- ❌ UI change
- [x] #43096
airflow.api.auth.backend.default→airflow.providers.fab.auth_manager.api.auth.backend.session
- [x] #43102
- ❌ REST API change
- [x] #43183
- Remove config
logging.enable_task_context_logger
- Remove config
- [x] #43289
- ❌ Remove
airflow.executors.*
- ❌ Remove
- [x] #43291
- Remove
airflow.hook.*
- Remove
- [x] #43368
trigger_rule=TriggerRule.ALWAYSis blocked in a dynamic mapped task
- [x] #43490
- ❌ Model change
- [x] #43530
- function
airflow.config.get→airflow.config.conf.get - function
airflow.config.getboolean→airflow.config.conf.getboolean - function
airflow.config.getfloat→airflow.config.conf.getfloat - function
airflow.config.getint→airflow.config.conf.getint - function
airflow.config.has_option→airflow.config.conf.has_option - function
airflow.config.remove_option→airflow.config.conf.remove_option - function
airflow.config.as_dict→airflow.config.conf.as_dict - function
airflow.config.set→airflow.config.conf.set - function
airflow.config.→airflow.config.conf.
- function
- [x] #43533
- Remove function
airflow.utils.dates.parse_execution_date - Remove function
airflow.utils.dates.round_time - Remove function
airflow.utils.dates.scale_time_units - Remove function
airflow.utils.dates.infer_time_unit
- Remove function
- [x] #43562
airflow.PY36→if sys.version_info >== (3, 6)airflow.PY37→if sys.version_info >== (3, 7)
- [x] #43568
- ❌ don't think we need to do anything
- [x] #43611
- ❌ don't think we can do anything
- [x] #43612
- ❌ More like a new feature. Change behavior but probably don't need to do something for it
- [x] #43902
- https://github.com/apache/airflow/issues/44409
- [x] #43915
- Remove config
core.strict_dataset_uri_validation
- Remove config
- [x] #43943
- Remove config
traces.otel_task_log_event
- Remove config
- [x] #43975
- Remove config
metrics.timer_unit_consistency
- Remove config
- [x] #44080
- ❌ DB version change
- aip-72.significant.rst
Related issues
No response
Are you willing to submit a PR?
- [X] Yes I am willing to submit a PR!
Code of Conduct
- [X] I agree to follow this project's Code of Conduct
The Rules now is an example of how these changes can be recorded. I will check the existing breaking changes and update the rules. It would be great if folks could help update this list if you know there are breaking changes.
I pinned the issue - this way it will show up at the top of "Issues" list in the repo
Thanks!
We can just go over all the significant newsfragments and create a rule for them or keep some reasoning why it doesn't require one
We should add something for the public API change too. API v1 won't work anymore. Those are being changed as part of AIP-84 to a new FastApi based app. GitHub project for it: https://github.com/orgs/apache/projects/414
Issue here to regroup Rest API breaking changes https://github.com/apache/airflow/issues/43378
I have started prototyping a small package based on LibCST to build a Python 2to3 like tool for Airflow 2to3 that does simple and straight forward replacements. My main motivation was around lot of our users in our Airflow instance using schedule_interval in Airflow 2 that was deprecated and renamed to schedule in Airflow 3. It would require updating thousands of dags manually and some automation could help. This could also help in places with import statements changes .E.g. Task SDK need to be updated from from airflow import DAG to from airflow.sdk import DAG. Something like this could eventually become part of Airflow cli so that users can run airflow migrate /airflow/dags for migration or serve as a starter point for migration. It can update the file in place or show diff. Currently it does the following changes :
Dags
- schedule_interval -> schedule
- timetable -> schedule
- concurrency -> max_active_tasks
- Removal of unused full_filepath parameter
- default_view (tree -> grid)
Operators
- task_concurrency -> max_active_tis_per_dag
- trigger_rule (none_failed_or_skipped -> none_failed_min_one_success)
Sample file
import datetime
from airflow import DAG
from airflow.decorators import dag, task
from airflow.operators.empty import EmptyOperator
from airflow.timetables.events import EventsTimetable
with DAG(
dag_id="my_dag_name",
default_view="tree",
start_date=datetime.datetime(2021, 1, 1),
schedule_interval="@daily",
concurrency=2,
):
op = EmptyOperator(
task_id="task", task_concurrency=1, trigger_rule="none_failed_or_skipped"
)
@dag(
default_view="graph",
start_date=datetime.datetime(2021, 1, 1),
schedule_interval=EventsTimetable(event_dates=[datetime.datetime(2022, 4, 5)]),
max_active_tasks=2,
full_filepath="/tmp/test_dag.py"
)
def my_decorated_dag():
op = EmptyOperator(task_id="task")
my_decorated_dag()
Sample usage
python -m libcst.tool codemod dag_fixer.DagFixerCommand -u 1 tests/test_dag.py
Calculating full-repo metadata...
Executing codemod...
reformatted -
All done! ✨ 🍰 ✨
1 file reformatted.
--- /home/karthikeyan/stuff/python/libcst-tut/tests/test_dag.py
+++ /home/karthikeyan/stuff/python/libcst-tut/tests/test_dag.py
@@ -10,6 +10,6 @@
dag_id="my_dag_name",
- default_view="tree",
+ default_view="grid",
start_date=datetime.datetime(2021, 1, 1),
- schedule_interval="@daily",
- concurrency=2,
+ schedule="@daily",
+ max_active_tasks=2,
):
@@ -23,5 +23,4 @@
start_date=datetime.datetime(2021, 1, 1),
- schedule_interval=EventsTimetable(event_dates=[datetime.datetime(2022, 4, 5)]),
+ schedule=EventsTimetable(event_dates=[datetime.datetime(2022, 4, 5)]),
max_active_tasks=2,
- full_filepath="/tmp/test_dag.py"
)
Finished codemodding 1 files!
- Transformed 1 files successfully.
- Skipped 0 files.
- Failed to codemod 0 files.
- 0 warnings were generated.
Repo : https://github.com/tirkarthi/Airflow-2to3
NICE! @tirkarthi -> you should start a thread about it at devlist and propose adding it to the repo. The sooner we start working on it and let poeple test it, the better it will be. And we can already start adding not only the newsfragments but also rules to the migration tools (cc: @vikramkoka @kaxil ) - we can even think about keeping a database of old-way-dags and running such migration tool on them and letting airflow scheduler from Airflow 3 process them (and maybe even execute) as part of our CI. This would tremendously help with maintaining and updating such a tool if we will make it a part of our CI pipeline.
BTW. I like it a lot how simple it is with libCST - we previously used quite a bit more complex tool from Facebook that allowed to do refactoring at scale in parallell (https://github.com/facebookincubator/Bowler) , but it was rather brittle to develop rules for it and it had some weird problems and missing features. One thing that was vere useful - is that it had a nice "parallelism" features - which allowed to refactor 1000s of files in seconds (but also made it difficult to debug).
I think if we get it working with libCST - it will be way more generic and maintainable, also we can easily add parallelism later on when/if we see it is slow.
One small watchout though - such a tool should have a way to isolate rules - so that they are not in a single big method - some abstraction that will allow us to easily develop and selectively apply (or skip) different rules - see https://github.com/apache/airflow/tree/v1-10-test/airflow/upgrade where we have documentation and information about the upgrade check we've done in Airflow 1 -> 2 migration.
Also we have to discuss, whether it should be a separate repo or whether it should be in airflow's monorepo. Both have pros and cons - in 1.10 we chose to keep it 1.10 branch of airflow, because it imported some of the airflow code and it was easier, but we could likely create a new repo for it, add CI there and keep it there.
We even have this archived repo https://github.com/apache/airflow-upgrade-check which we never used and archived, we could re-open it. We also have https://pypi.org/project/apache-airflow-upgrade-check/ - package in PyPI - and we could release new upgrade check versions (2.* ?) with "apache-airflow>=2.11.0" as dependency.
All that should likely be discussed at devlist :)
Thanks @potiuk for the details. I will start a discussion on this at the devlist and continue there. Bowler looks interesting. Using libcst.tool from cli parallelizes the process. Right now this needs python -m libcst.tool to execute it as a codemod. Initially I had designed them as standalone Transformer for each category like (dag, operator) where the updated AST from one transformer can be passed to another. The codemod looked like a recommended abstraction for running it and changed it that way to later find cli accepts only one codemod at a time. I need to check how composable they are.
python -m libcst.tool codemod --help | grep -i -A 1 'jobs JOBS'
-j JOBS, --jobs JOBS Number of jobs to use when processing files. Defaults to number of cores
time python -m libcst.tool codemod dag_fixer.DagFixerCommand -u 1 ~/airflow/dags > /dev/null 2>&1
python -m libcst.tool codemod dag_fixer.DagFixerCommand -u 1 ~/airflow/dags >
6.95s user 0.61s system 410% cpu 1.843 total
# Single core
time python -m libcst.tool codemod dag_fixer.DagFixerCommand -u 1 -j 1 ~/airflow/dags > /dev/null 2>&1
python -m libcst.tool codemod dag_fixer.DagFixerCommand -u 1 -j 1 >
/dev/nul 4.66s user 0.38s system 99% cpu 5.035 total
# 4 core
python -m libcst.tool codemod dag_fixer.DagFixerCommand -u 1 -j 4 ~/airflow/dags > /dev/null 2>&1
python -m libcst.tool codemod dag_fixer.DagFixerCommand -u 1 -j 4 >
/dev/nul 5.45s user 0.54s system 253% cpu 2.358 total
Bowler looks interesting.
Don't be deceived by it :).
It was helpful for Provider's migration at some point in time, but I had many rough edges - like debugging a problem was a nightmare until we learned how to do it properly, also it had some annoying limitations - you had to learn a completely new non-standard abstractions (an SQLAlchemy-like DSL to perform modifications) - which did not cover all the refactorings we wanted to do. We had to really dig-deep into the code an find some workarounds for things we wanted to do, when authors of Bowler have not thoght about them. And sometimes those were nasty workarounds.
query = (
Query(<paths to modify>)
.select_function("old_name")
.rename("new_name")
.diff(interactive=True)
)
Example that I remember above is that we could not rename some of the object types easily because it was not "foreseen" (can't remember exactly) - we had a few surprises there.
Also Bowler seems to be not maintained for > 3 years and it means that it's unlikely to handle some constructs even in 3.9+ Airflow.
What I like about libcst is that it is really "low-level" interface that you have to program in Python rather than in abstract DSL - similar to "ast". You write actual python code to perform what you want to perform rather than rely on incomplete abstractions, even if you have to copy&paste rename code between different "rules" (for example) (which you can then abstract away as 'common` util if you need, so no big deal).
BTW. Codemod .... is also 5 years not maintained. Not that it is disqualification - but they list python2 as their dependency ... so .....
I tried to use libcst in airflow as a tiny POC of this issue here https://github.com/apache/airflow/blob/5b7977a149492168688e6f013a7dcd4fe3561a49/scripts/ci/pre_commit/check_deferrable_default.py#L34. It mostly works great except for its speed. I was also thinking about whether to add these migrations thing info ruff airflow linter but not yet explore much on the rust/ruff side.
:eyes: :eyes: rust project :) ...
Me :heart: it (but I doubt we want to invest in it as it might be difficult to maintain, unless we find quite a few committers who are somewhat ruff profficient to at least be able to review the code) . But it's tempting I must admit.
But to be honest - while I'd love to finally get a serious rust project, it's not worth it I think we are talking of one-time migration for even a 10.000 dags it will take at most single minutes and we can turn it maybe in under one minute with rust - so not a big gain for a lot of pain :) . Or at lest this is what my intuition tells me.
I think parallelism will do the job nicely. My intuition tells me (but this is just intuition and understanding on some limits ans speed of certain operation) - that we will get from multiple 10s of minutes (when running such migration sequentially) to single minutes when we allow to run migration in parallel using multiple processors and processes - even with Python and libcst. This task is really suitable for such parallelisation because each file is complete, independent task that can be run in complete isolation from all other tasks - so spawning multiple paralllel interpreters, ideally forking them right after all the imports and common code is loaded so that they use shared memory for those - this should do the job nicely (at least intuitively).
Using RUST for that might be classic premature optimisation - we might likely not need it :). But would be worth to make some calculations and get some "numbers" for big installation - i.e. how many dags of what size are out there, and how long it will be to parse them all with libcst and write back (even unmodified or with a simple modification). I presume that parsing and writing back will be the bulk of the job - and modifications will add very little overhead as they will be mostly operating on in memory data structures.
Me ❤️ it (but I doubt we want to invest in it as it might be difficult to maintain, unless we find quite a few committers who are somewhat ruff profficient to at least be able to review the code) . But it's tempting I must admit.
But to be honest - while I'd love to finally get a serious rust project, it's not worth it I think we are talking of one-time migration for even a 10.000 dags it will take at most single minutes and we can turn it maybe in under one minute with rust - so not a big gain for a lot of pain :) . Or at lest this is what my intuition tells me.
Yep, totally agree. I just want to raise this idea which might be interesting. 👀
I presume that parsing and writing back will be the bulk of the job - and modifications will add very little overhead as they will be mostly operating on in memory data structures.
Yep, I think you're right. My previous default deferrable script took around 10 sec to process ~400 operators. Using ast for checking took around 1 sec
Mostly as curiosity: One option we might consider is https://github.com/alexpovel/srgn - I've heard about it recently, it's a "grep that understands code" with capabilities of running different actions. Written in rust, and allows to add extensions apparently where you can define your own "scopes" of search and modification.
But I am not too convinced - this is mostly a command line tool so we would have to have a sequence of "script commands" to run - seems that plugging in our own rules and AST parsing should also be more flexible, even if slower.
Mostly as curiosity: One option we might consider is https://github.com/alexpovel/srgn - I've heard about it recently, it's a "grep that understands code" with capabilities of running different actions. Written in rust, and allows to add extensions apparently where you can define your own "scopes" of search and modification.
But I am not too convinced - this is mostly a command line tool so we would have to have a sequence of "script commands" to run - seems that plugging in our own rules and AST parsing should also be more flexible, even if slower.
Yep, not that convinced either. but it is always good to have an alternative we could consider 🤔
My best idea right now is to split this into two tools. We don’t really want to invest too much time into building a very rich CLI tool to show users what need to be changed—we’ll effectively be rebuilding the error reporting interface in ruff (or flake8). Those squiggle lines, colors, error codes, and code context things are not easy to build.
It is probably easiest to tack the linter part on Ruff—it is Rust, but the code to implement a lint rule isn’t that hard if you know Python AST and just a general idea about C-like languages. The rewrite part is a lot more difficult, so it’s probably better to implement this as a different tool in Python with libcst. I’m thinking something like
$ ruff check --select AIR
This spits out lint errors with codes like AIR005 AIR123...
$ airflow2to3 --select AIR005 -- path/to/dag/file.py
This fixes the given error(s) in given file(s) in-place with a minimal CLI...
I plan to start experiementing some rules in Ruff to see how easy the first part actually is. We should be able to save a lot of effort if it is viable.
I tried to change the format a bit and list the rules in the following format.
* [ ] link to the pr with breaking change
* [ ] things to do
Once the things to do have been listed, we can check the root pr. After implementing the rule, we can mark the things to do as done.
I also updated the format for #41366, #41367, #41368, #41391, #41393
If anyone has anything to add but do not have permission to update the description. Please just tag me and I'll take a look
It is probably easiest to tack the linter part on Ruff—it is Rust, but the code to implement a lint rule isn’t that hard if you know Python AST and just a general idea about C-like languages. The rewrite part is a lot more difficult, so it’s probably better to implement this as a different tool in Python with libcst. I’m thinking something like
Actually I am convinced too - I quite like this one after a bit of thought. This is not something that might be maintained by a lot of people and a number of contributors, and even for them, this is so far from the main "airflow code" - it's really a "one-time" tool - that it might be worth treating it as our first "rust experiment". And I quite agree that, the AST code on it's own is not really that "pythonic" and if you know what you want, and have already existing examples, adding a new rule in RUST, should not be difficult even if you do not know it (and AI driven development here might be even pretty cool exercise). I'd myself be happy to add a few rules at some point of time and maybe even take part in implementing the tooling for rust for our CI environment.
The things we'll need to migrate for 41348
- [ ] https://github.com/apache/airflow/pull/41348
- [ ] module
airflow.datasets->airflow.sdk.definitions.asset- [ ] class
DatasetAlias->AssetAlias - [ ] class
DatasetAll->AssetAll - [ ] class
DatasetAny->AssetAny - [ ] function
expand_alias_to_datasets->expand_alias_to_assets - [ ] class
DatasetAliasEvent->AssetAliasEvent- [ ] attribute
dest_dataset_uri->BaseAsset
- [ ] attribute
- [ ] class
BaseDataset->BaseAsset- [ ] method
iter_datasets->iter_assets - [ ] method
iter_dataset_aliases->iter_asset_aliases
- [ ] method
- [ ] class
Dataset->Asset- [ ] method
iter_datasets->iter_assets - [ ] method
iter_dataset_aliases->iter_asset_aliases
- [ ] method
- [ ] class
_DatasetBooleanCondition->_AssetBooleanCondition- [ ] method
iter_datasets->iter_assets - [ ] method
iter_dataset_aliases->iter_asset_aliases
- [ ] method
- [ ] class
- [ ] module
airflow.datasets.manager→airflow.assets.manager- [ ] variable
dataset_manager→asset_manager - [ ] function
resolve_dataset_manager→resolve_asset_manager - [ ] class
DatasetManager→AssetManager- [ ] method
register_dataset_change→register_asset_change - [ ] method
create_datasets→create_assets - [ ] method
register_dataset_change→notify_asset_created - [ ] method
notify_dataset_changed→notify_asset_changed - [ ] method
notify_dataset_alias_created→notify_asset_alias_created
- [ ] method
- [ ] variable
- [ ] module
airflow.listeners.spec.dataset→airflow.listeners.spec.asset- [ ] function
on_dataset_created→on_asset_created - [ ] function
on_dataset_changed→on_asset_changed
- [ ] function
- [ ] module
airflow.timetables.datasets→airflow.timetables.assets- [ ] class
DatasetOrTimeSchedule→AssetOrTimeSchedule
- [ ] class
- [ ] module
airflow.datasets.metadata→airflow.sdk.definitions.asset.metadata - [ ] module
airflow.listeners.spec.dataset→airflow.listeners.spec.asset- [ ] function
on_dataset_created→on_asset_created - [ ] function
on_dataset_changed→on_asset_changed
- [ ] function
- [ ] class
airflow.timetables.datasets.DatasetOrTimeSchedule→airflow.timetables.assets.AssetOrTimeSchedule - [ ] decorator
airflow.api_connexion.security.requires_access_dataset→airflow.api_connexion.security.requires_access_dataset.requires_access_asset - [ ] class
airflow.auth.managers.models.resource_details.DatasetDetails→ `airflow.auth.managers.models.resource_details.AssetDetails - [ ] function
airflow.auth.managers.base_auth_manager.is_authorized_dataset→airflow.auth.managers.base_auth_manager.is_authorized_asset - [ ] class
airflow.timetables.simple.DatasetTriggeredTimetable→airflow.timetables.simple.AssetTriggeredTimetable - in class
airflow.providers_manager.ProvidersManager- [ ] method
initialize_providers_dataset_uri_resources→initialize_providers_asset_uri_resources - [ ] property
dataset_factories→asset_factories - [ ] property
dataset_uri_handlers→asset_uri_handlers - [ ] property
dataset_to_openlineage_converters→asset_to_openlineage_converters
- [ ] method
- [ ] constant
airflow.security.permissions.RESOURCE_DATASET→airflow.security.permissions.RESOURCE_ASSET - [ ] function
airflow.www.auth.has_access_dataset→airflow.www.auth.has_access_dataset.has_access_asset - [ ] class
airflow.lineage.hook.DatasetLineageInfo→airflow.lineage.hook.AssetLineageInfo- [ ] attribute
dataset→asset
- [ ] attribute
- In class
airflow.lineage.hook.HookLineageCollector- [ ] method
create_dataset→create_asset - [ ] method
add_input_dataset→add_input_asset - [ ] method
add_output_dataset→add_output_asset - [ ] method
collected_datasets→collected_assets
- [ ] method
- [ ] context key
triggering_dataset_events→triggering_asset_events - In amazon provider
- package
airflow.providers.amazon.aws.datasets→airflow.providers.amazon.aws.assets- in module
s3- [ ] method
create_dataset→create_asset - [ ] method
convert_dataset_to_openlineage→convert_asset_to_openlineage
- [ ] method
- in module
- [ ] attribute
airflow.providers.amazon.auth_manager.avp.entities.AvpEntities.DATASET→airflow.providers.amazon.auth_manager.avp.entities.AvpEntities.ASSET - [ ] method
airflow.providers.amazon.auth_manager.aws_auth_manager.AwsAuthManager.is_authorized_dataset→airflow.providers.amazon.auth_manager.aws_auth_manager.AwsAuthManager.is_authorized_asset - [ ] resource key
dataset-uris→asset-uris
- package
- In Common IO Provider
- [ ] package
airflow.providers.common.io.datasets→airflow.providers.common.io.assets- in module
file- [ ] method
create_dataset→create_asset - [ ] method
convert_dataset_to_openlineage→convert_asset_to_openlineage
- [ ] method
- in module
- [ ] resource key
dataset-uris→asset-uris
- [ ] package
- In fab provider
- [ ] function
airflow.providers.fab.auth_manager.fab_auth_manager.is_authorized_dataset→airflow.providers.fab.auth_manager.fab_auth_manager.is_authorized_asset
- [ ] function
- In openlineage provider
- in module
airflow.providers.openlineage.utils.utils- [ ] class
DatasetInfo→AssetInfo - [ ] function
translate_airflow_dataset→translate_airflow_asset
- [ ] class
- in module
- In postgres provider
- [ ] package
airflow.providers.postgres.datasets→airflow.providers.postgres.assets - [ ] resource key
dataset-uris→asset-uris
- [ ] package
- In mysql provider
- [ ] package
airflow.providers.mysql.datasets→airflow.providers.mysql.assets - [ ] resource key
dataset-uris→asset-uris
- [ ] package
- In trino provider
- [ ] package
airflow.providers.trino.datasets→airflow.providers.trino.assets - [ ] resource key
dataset-uris→asset-uris
- [ ] package
- ❌ ignored
airflow.api_connexion.schemas.dataset_schemaairflow.api_ui.views.datasetsairflow.serialization.pydantic.datasetairflow.serialization.pydantic.taskinstanceairflow.serialization.enums.DagAttributeTypesairflow.serialization.serialized_objectsairflow.utils.context- models
- DagDependency names
- private methods
- [ ] module
Hi all, I'm trying to read through the significant news fragment and compile a list of rules we should migrate. It would be nice if you could take a look and check if I missed anything.
- @jscheffl
- [x] https://github.com/apache/airflow/pull/40029
- [x] https://github.com/apache/airflow/pull/41733
- [x] https://github.com/apache/airflow/pull/41735
- [x] https://github.com/apache/airflow/pull/41736
- [x] https://github.com/apache/airflow/pull/41737
- [x] https://github.com/apache/airflow/pull/41739
- [x] https://github.com/apache/airflow/pull/41761
- [x] https://github.com/apache/airflow/pull/41762
- [x] https://github.com/apache/airflow/pull/41774
- [x] https://github.com/apache/airflow/pull/41776
- [x] https://github.com/apache/airflow/pull/41778
- [x] https://github.com/apache/airflow/pull/41779
- [x] https://github.com/apache/airflow/pull/41780
- [x] https://github.com/apache/airflow/pull/41808
- @dirrao
- [ ] https://github.com/apache/airflow/pull/40931
- [ ] https://github.com/apache/airflow/pull/41096
- [ ] https://github.com/apache/airflow/pull/41539
- [ ] https://github.com/apache/airflow/pull/41496
- [ ] https://github.com/apache/airflow/pull/41550
- [ ] https://github.com/apache/airflow/pull/41552
- [ ] https://github.com/apache/airflow/pull/41579
- [ ] https://github.com/apache/airflow/pull/41609
- [ ] https://github.com/apache/airflow/pull/41635
- [ ] https://github.com/apache/airflow/pull/41642
- [ ] https://github.com/apache/airflow/pull/41663
- [ ] https://github.com/apache/airflow/pull/41693
- [ ] https://github.com/apache/airflow/pull/41708
- [ ] https://github.com/apache/airflow/pull/41748
- [ ] https://github.com/apache/airflow/pull/41784
- [ ] https://github.com/apache/airflow/pull/41910
- [ ] https://github.com/apache/airflow/pull/42060
- [ ] https://github.com/apache/airflow/pull/42088
- [ ] https://github.com/apache/airflow/pull/42100
- [ ] https://github.com/apache/airflow/pull/42126
- [ ] https://github.com/apache/airflow/pull/42129
- @kaxil
- [ ] https://github.com/apache/airflow/pull/41390
- [ ] https://github.com/apache/airflow/pull/41393
- @dstandish
- [ ] https://github.com/apache/airflow/pull/41440
- @pierrejeambrun
- [ ] https://github.com/apache/airflow/pull/41857
- @jedcunningham
- [ ] https://github.com/apache/airflow/pull/41964
- @uranusjr
- [ ] https://github.com/apache/airflow/pull/42054
@kaxil @ashb would also like to confirm whether we're still allowing users to use models in airflow 3.0? If not, should we just skip all the changes related to models. Thanks
I tried my hands on implementing a rule in Ruff. This one checks if a DAG uses the schedule argument explicitly, and errors if there’s no such argument (i.e. user is relying on the implicit default, which changes in 3.0), or a deprecated argument is used.
Does this look reasonable enough for people to build on? I’ll produce a more detailed writeup of what to do if we feel this is the way to go.
https://github.com/uranusjr/ruff/pull/1/files
@kaxil @ashb would also like to confirm whether we're still allowing users to use models in airflow 3.0? If not, should we just skip all the changes related to models. Thanks
Which models? But no, the plan is to not have/"allow" users to import anything from airflow.models at all. Exact details and new names are to be determined yet though
@kaxil https://github.com/apache/airflow/pull/41390 https://github.com/apache/airflow/pull/41393 https://github.com/apache/airflow/pull/41390
Duplicate entries for SubDAGs
@kaxil #41390 #41393 #41390
Duplicate entries for SubDAGs
oops, just fixed!
@kaxil @ashb would also like to confirm whether we're still allowing users to use models in airflow 3.0? If not, should we just skip all the changes related to models. Thanks
Which models? But no, the plan is to not have/"allow" users to import anything from airflow.models at all. Exact details and new names are to be determined yet though
Pretty much every model 👀 Sounds good. Just want to confirm I'm not misunderstanding anything. I'll just mark it as model change and not going to migrate for now till we have anything decided