Airflow 2 to 3 auto migration rules - airflow config #44555
Labels
area:dev-tools
area:upgrade
Facilitating migration to a newer version of Airflow
kind:feature
Feature Requests
Description
airflow config
Removal
smtp
smtp_user
(from smtp email user and password deprecated config removal #41539)smtp_password
(from smtp email user and password deprecated config removal #41539)webserver
allow_raw_html_descriptions
(from Remove RAW HTML support from Trigger Form UI #40029)session_lifetime_days
(from airflow deprecated settings session_lifetime_days, force_log_out_after and policy removal #41550) → usesession_lifetime_minutes
force_log_out_after
(from airflow deprecated settings session_lifetime_days, force_log_out_after and policy removal #41550) → usesession_lifetime_minutes
scheduler
dependency_detector
(from custom dependency detector removal #41609)operators
ALLOW_ILLEGAL_ARGUMENTS
(from Remove deprecations in BaseOperator for Airflow 3 #41761)metrics
metrics_use_pattern_match
(from Metrics basic deprecated validators removed in favor of pattern matching #41975)timer_unit_consistency
(from Standardize timer metrics to milliseconds and remove config #43975)celery
stalled_task_timeout
(from Deprecated configuration stalled_task_timeout, task_adoption_timeout and worker_pods_pending_timeout removed #42060)core
check_slas
(from Purge existing SLA implementation #42285)strict_dataset_uri_validation
(from Remove strict_asset_uri_validation #43915)logging
enable_task_context_logger
(from Remove TaskContextLogger #43183)traces
otel_task_log_event
(from Remove sending of task logs in otel traces inside the Scheduler #43943)Rename
scheduler
processor_poll_interval
→cheduler_idle_sleep_time
(from Airflow 3: processor_poll_interval deprecated parameter usage removal #41096)metrics
statsd_allow_list
→metrics_allow_list
(from Deprecated metrics configuration removed #42088)statsd_block_list
→metrics_block_list
(from Deprecated metrics configuration removed #42088)scheduler.statsd_on
→metrics.statsd_on
(from Deprecated metrics configuration removed #42088)scheduler.statsd_host
→metrics.statsd_host
(from Deprecated metrics configuration removed #42088)scheduler.statsd_port
→metrics.statsd_port
(from Deprecated metrics configuration removed #42088)scheduler.statsd_prefix
→metrics.statsd_prefix
(from Deprecated metrics configuration removed #42088)scheduler.statsd_allow_list
→metrics.statsd_allow_list
(from Deprecated metrics configuration removed #42088)scheduler.stat_name_handler
→metrics.stat_name_handler
(from Deprecated metrics configuration removed #42088)scheduler.statsd_datadog_enabled
→metrics.statsd_datadog_enabled
(from Deprecated metrics configuration removed #42088)scheduler.statsd_datadog_tags
→metrics.statsd_datadog_tags
(from Deprecated metrics configuration removed #42088)scheduler.statsd_datadog_metrics_tags
→metrics.statsd_datadog_metrics_tags
(from Deprecated metrics configuration removed #42088)scheduler.statsd_custom_client_path
→core.sql_alchemy_conn
→database.sql_alchemy_conn
(from Deprecated database configuration removed #42126)core.sql_engine_encoding
→database.sql_engine_encoding
(from Deprecated database configuration removed #42126)core.sql_engine_collation_for_ids
→database.sql_engine_collation_for_ids
(from Deprecated database configuration removed #42126)core.sql_alchemy_pool_enabled
→database.sql_alchemy_pool_enabled
(from Deprecated database configuration removed #42126)core.sql_alchemy_pool_size
→database.sql_alchemy_pool_size
(from Deprecated database configuration removed #42126)core.sql_alchemy_max_overflow
→database.sql_alchemy_max_overflow
(from Deprecated database configuration removed #42126)core.sql_alchemy_pool_recycle
→database.sql_alchemy_pool_recycle
(from Deprecated database configuration removed #42126)core.sql_alchemy_pool_pre_ping
→database.sql_alchemy_pool_pre_ping
(from Deprecated database configuration removed #42126)core.sql_alchemy_schema
→database.sql_alchemy_schema
(from Deprecated database configuration removed #42126)core.sql_alchemy_connect_args
→database.sql_alchemy_connect_args
(from Deprecated database configuration removed #42126)core.load_default_connections
→database.load_default_connections
(from Deprecated database configuration removed #42126)core.max_db_retries
→database.max_db_retries
(from Deprecated database configuration removed #42126)core.worker_precheck
→celery.worker_precheck
(from Deprecated configuration removed #42129)scheduler.max_threads
→scheduler.parsing_processes
(from Deprecated configuration removed #42129)celery.default_queue
→operators.default_queue
(from Deprecated configuration removed #42129)admin.hide_sensitive_variable_fields
→core.hide_sensitive_var_conn_fields
(from Deprecated configuration removed #42129)admin.sensitive_variable_fields
→core.sensitive_var_conn_names
(from Deprecated configuration removed #42129)core.non_pooled_task_slot_count
→core.default_pool_task_slot_count
(from Deprecated configuration removed #42129)core.dag_concurrency
→core.max_active_tasks_per_dag
(from Deprecated configuration removed #42129)api.access_control_allow_origin
→api.access_control_allow_origins
(from Deprecated configuration removed #42129)api.auth_backend
→api.auth_backends
(from Deprecated configuration removed #42129)scheduler.deactivate_stale_dags_interval
→scheduler.parsing_cleanup_interval
(from Deprecated configuration removed #42129)kubernetes_executor.worker_pods_pending_timeout_check_interval
→scheduler.task_queued_timeout_check_interval
(from Deprecated configuration removed #42129)webserver.update_fab_perms
→fab.update_fab_perms
(from Deprecated configuration removed #42129)webserver.auth_rate_limited
→fab.auth_rate_limited
(from Deprecated configuration removed #42129)webserver.auth_rate_limit
→fab.auth_rate_limit
(from Deprecated configuration removed #42129)policy
→task_policy
(from airflow deprecated settings session_lifetime_days, force_log_out_after and policy removal #41550)kubernetes
→kubernetes_executor
(from Deprecated configuration removed #42129)Use case/motivation
No response
Related issues
#41641
Are you willing to submit a PR?
Code of Conduct
The text was updated successfully, but these errors were encountered: