-
Notifications
You must be signed in to change notification settings - Fork 16.3k
Description
Apache Airflow version
3.1.2
If "Other Airflow 2/3 version" selected, which one?
No response
What happened?
Hello! We are experimenting with upgrading from AIrflow 3.1.1 (working environment) to Airflow 3.1.2, but once we deployed it we started receiving errors from the DAG processor and the DAG triggerer.
DAG processor error log:
/home/airflow/.local/lib/python3.10/site-packages/google/api_core/_python_version_support.py:266 FutureWarning: You are using a Python version (3.10.19) which Google will stop supporting in new releases of google.api_core once it reaches its end of life (2026-10-04). Please upgrade to the latest Python version, or at least Python 3.11, to continue receiving updates for google.api_core past that date.
/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/cli_config.py:647 DeprecationWarning: The access_logfile option in [api] has been renamed to log_config - the old setting has been used, but please update your config.
/home/airflow/.local/lib/python3.10/site-packages/airflow/providers/fab/auth_manager/fab_auth_manager.py:108 RemovedInAirflow4Warning: The airflow.security.permissions module is deprecated; please see https://airflow.apache.org/docs/apache-airflow/stable/security/deprecated_permissions.html
/opt/airflow/src/datahub/common/helpers/curated_data_table.py:7 DeprecatedImportWarning: The `airflow.utils.trigger_rule.TriggerRule` attribute is deprecated. Please use `'airflow.task.trigger_rule.TriggerRule'`.
/opt/airflow/src/datahub/operators/bigquery/bigquery_job_link.py:2 DeprecatedImportWarning: The `airflow.models.baseoperator.BaseOperator` attribute is deprecated. Please use `'airflow.sdk.bases.operator.BaseOperator'`.
2025-11-06T15:38:46.738651Z [info [] Starting the Dag Processor Job [airflow.jobs.dag_processor_job_runner.DagProcessorJobRunner] loc=dag_processor_job_runner.py:59
2025-11-06T15:38:46.739901Z [info [] Processing files using up to 2 processes at a time [airflow.dag_processing.manager.DagFileProcessorManager] loc=manager.py:265
2025-11-06T15:38:46.740085Z [info [] Process each file at most once every 300 seconds [airflow.dag_processing.manager.DagFileProcessorManager] loc=manager.py:266
2025-11-06T15:38:46.741977Z [info [] DAG bundles loaded: dags-folder [airflow.dag_processing.bundles.manager.DagBundlesManager] loc=manager.py:179
2025-11-06T15:38:46.775236Z [info [] DAG bundles loaded: dags-folder [airflow.dag_processing.bundles.manager.DagBundlesManager] loc=manager.py:179
2025-11-06T15:38:46.775644Z [info [] Checking for new files in bundle dags-folder every 300 seconds [airflow.dag_processing.manager.DagFileProcessorManager] loc=manager.py:276
2025-11-06T15:38:46.836520Z [info [] Refreshing bundle dags-folder [airflow.dag_processing.manager.DagFileProcessorManager] loc=manager.py:553
2025-11-06T15:38:46.843288Z [info [] Searching for files in dags-folder at /opt/airflow/dags/glovo [airflow.dag_processing.manager.DagFileProcessorManager] loc=manager.py:604
2025-11-06T15:38:46.968011Z [info [] Found 13 files for bundle dags-folder [airflow.dag_processing.manager.DagFileProcessorManager] loc=manager.py:606
2025-11-06T15:38:47.058903Z [error [] Exception when executing DagProcessorJob [airflow.jobs.dag_processor_job_runner.DagProcessorJobRunner] loc=dag_processor_job_runner.py:63
Traceback (most recent call last):
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/dag_processor_job_runner.py", line 61, in _execute
self.processor.run()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 282, in run
return self._run_parsing_loop()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 367, in _run_parsing_loop
self._start_new_processes()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 939, in _start_new_processes
processor = self._create_process(file)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 918, in _create_process
logger, logger_filehandle = self._get_logger_for_dag_file(dag_file)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 897, in _get_logger_for_dag_file
log_file = init_log_file(log_filename)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/log.py", line 145, in init_log_file
from airflow.sdk._shared.logging import init_log_file
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/__init__.py", line 27, in <module>
from .structlog import configure_logging, init_log_file, init_log_folder
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/structlog.py", line 38, in <module>
from .percent_formatter import PercentFormatRender
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/percent_formatter.py", line 29, in <module>
from structlog.dev import ConsoleRenderer, Styles
ImportError: cannot import name 'Styles' from 'structlog.dev' (/home/airflow/.local/lib/python3.10/site-packages/structlog/dev.py)
Traceback (most recent call last):
File "/home/airflow/.local/bin/airflow", line 7, in <module>
sys.exit(main())
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/__main__.py", line 55, in main
args.func(args)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/cli_config.py", line 49, in command
return func(*args, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/utils/cli.py", line 114, in wrapper
return f(*args, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/utils/providers_configuration_loader.py", line 54, in wrapped_function
return func(*args, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/commands/dag_processor_command.py", line 53, in dag_processor
run_command_with_daemon_option(
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/commands/daemon_utils.py", line 86, in run_command_with_daemon_option
callback()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/commands/dag_processor_command.py", line 56, in <lambda>
callback=lambda: run_job(job=job_runner.job, execute_callable=job_runner._execute),
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/utils/session.py", line 100, in wrapper
return func(*args, session=session, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/job.py", line 368, in run_job
return execute_job(job, execute_callable=execute_callable)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/job.py", line 397, in execute_job
ret = execute_callable()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/dag_processor_job_runner.py", line 61, in _execute
self.processor.run()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 282, in run
return self._run_parsing_loop()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 367, in _run_parsing_loop
self._start_new_processes()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 939, in _start_new_processes
processor = self._create_process(file)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 918, in _create_process
logger, logger_filehandle = self._get_logger_for_dag_file(dag_file)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/dag_processing/manager.py", line 897, in _get_logger_for_dag_file
log_file = init_log_file(log_filename)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/log.py", line 145, in init_log_file
from airflow.sdk._shared.logging import init_log_file
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/__init__.py", line 27, in <module>
from .structlog import configure_logging, init_log_file, init_log_folder
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/structlog.py", line 38, in <module>
from .percent_formatter import PercentFormatRender
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/percent_formatter.py", line 29, in <module>
from structlog.dev import ConsoleRenderer, Styles
ImportError: cannot import name 'Styles' from 'structlog.dev' (/home/airflow/.local/lib/python3.10/site-packages/structlog/dev.py)
Similar issue with DAG triggerer, error log:
2025-11-06T15:40:55.477087Z [info [] Starting log server on http://[::[]:8794 [airflow.utils.serve_logs.core] loc=core.py:50
WARNING: ASGI app factory detected. Using it, but please consider setting the --factory flag explicitly.
INFO: Started server process [27]
INFO: Waiting for application startup.
INFO: Application startup complete.
INFO: Uvicorn running on http://:8794 (Press CTRL+C to quit)
/opt/airflow/src/datahub/common/helpers/curated_data_table.py:7 DeprecatedImportWarning: The `airflow.utils.trigger_rule.TriggerRule` attribute is deprecated. Please use `'airflow.task.trigger_rule.TriggerRule'`.
/opt/airflow/src/datahub/operators/bigquery/bigquery_job_link.py:2 DeprecatedImportWarning: The `airflow.models.baseoperator.BaseOperator` attribute is deprecated. Please use `'airflow.sdk.bases.operator.BaseOperator'`.
2025-11-06T15:40:57.991369Z [info [] Starting the triggerer [airflow.jobs.triggerer_job_runner.TriggererJobRunner] loc=triggerer_job_runner.py:162
Exception in _fork_main, exiting with code 124
Traceback (most recent call last):
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/execution_time/supervisor.py", line 487, in start
_fork_main(child_requests, child_stdout, child_stderr, child_logs.fileno(), target)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/execution_time/supervisor.py", line 352, in _fork_main
_configure_logs_over_json_channel(log_fd)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/execution_time/supervisor.py", line 222, in _configure_logs_over_json_channel
reset_logging()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/log.py", line 248, in reset_logging
from airflow.sdk._shared.logging.structlog import structlog_processors
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/__init__.py", line 27, in <module>
from .structlog import configure_logging, init_log_file, init_log_folder
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/structlog.py", line 38, in <module>
from .percent_formatter import PercentFormatRender
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/percent_formatter.py", line 29, in <module>
from structlog.dev import ConsoleRenderer, Styles
ImportError: cannot import name 'Styles' from 'structlog.dev' (/home/airflow/.local/lib/python3.10/site-packages/structlog/dev.py)
2025-11-06T15:40:58.013100Z [error [] Exception when executing TriggerRunnerSupervisor.run [airflow.jobs.triggerer_job_runner.TriggererJobRunner] loc=triggerer_job_runner.py:173
Traceback (most recent call last):
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/triggerer_job_runner.py", line 165, in _execute
self.trigger_runner = TriggerRunnerSupervisor.start(
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/triggerer_job_runner.py", line 373, in start
proc = super().start(id=job.id, job=job, target=cls.run_in_process, logger=logger, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/execution_time/supervisor.py", line 514, in start
proc._register_pipe_readers(
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/triggerer_job_runner.py", line 680, in _register_pipe_readers
super()._register_pipe_readers(stdout, stderr, requests, logs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/execution_time/supervisor.py", line 540, in _register_pipe_readers
from airflow.sdk._shared.logging.structlog import logger_without_processor_of_type
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/__init__.py", line 27, in <module>
from .structlog import configure_logging, init_log_file, init_log_folder
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/structlog.py", line 38, in <module>
from .percent_formatter import PercentFormatRender
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/percent_formatter.py", line 29, in <module>
from structlog.dev import ConsoleRenderer, Styles
ImportError: cannot import name 'Styles' from 'structlog.dev' (/home/airflow/.local/lib/python3.10/site-packages/structlog/dev.py)
2025-11-06T15:40:58.018992Z [info [] Waiting for triggers to clean up [airflow.jobs.triggerer_job_runner.TriggererJobRunner] loc=triggerer_job_runner.py:176
Traceback (most recent call last):
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/triggerer_job_runner.py", line 165, in _execute
self.trigger_runner = TriggerRunnerSupervisor.start(
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/triggerer_job_runner.py", line 373, in start
proc = super().start(id=job.id, job=job, target=cls.run_in_process, logger=logger, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/execution_time/supervisor.py", line 514, in start
proc._register_pipe_readers(
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/triggerer_job_runner.py", line 680, in _register_pipe_readers
super()._register_pipe_readers(stdout, stderr, requests, logs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/execution_time/supervisor.py", line 540, in _register_pipe_readers
from airflow.sdk._shared.logging.structlog import logger_without_processor_of_type
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/__init__.py", line 27, in <module>
from .structlog import configure_logging, init_log_file, init_log_folder
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/structlog.py", line 38, in <module>
from .percent_formatter import PercentFormatRender
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/sdk/_shared/logging/percent_formatter.py", line 29, in <module>
from structlog.dev import ConsoleRenderer, Styles
ImportError: cannot import name 'Styles' from 'structlog.dev' (/home/airflow/.local/lib/python3.10/site-packages/structlog/dev.py)
During handling of the above exception, another exception occurred:
Traceback (most recent call last):
File "/home/airflow/.local/bin/airflow", line 7, in <module>
sys.exit(main())
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/__main__.py", line 55, in main
args.func(args)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/cli_config.py", line 49, in command
return func(*args, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/utils/cli.py", line 114, in wrapper
return f(*args, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/utils/providers_configuration_loader.py", line 54, in wrapped_function
return func(*args, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/commands/triggerer_command.py", line 69, in triggerer
run_command_with_daemon_option(
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/commands/daemon_utils.py", line 86, in run_command_with_daemon_option
callback()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/commands/triggerer_command.py", line 72, in <lambda>
callback=lambda: triggerer_run(args.skip_serve_logs, args.capacity, triggerer_heartrate),
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/cli/commands/triggerer_command.py", line 55, in triggerer_run
run_job(job=triggerer_job_runner.job, execute_callable=triggerer_job_runner._execute)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/utils/session.py", line 100, in wrapper
return func(*args, session=session, **kwargs)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/job.py", line 368, in run_job
return execute_job(job, execute_callable=execute_callable)
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/job.py", line 397, in execute_job
ret = execute_callable()
File "/home/airflow/.local/lib/python3.10/site-packages/airflow/jobs/triggerer_job_runner.py", line 180, in _execute
self.trigger_runner.kill(escalation_delay=10, force=True)
AttributeError: 'TriggererJobRunner' object has no attribute 'trigger_runner'
INFO: Shutting down
INFO: Waiting for application shutdown.
INFO: Application shutdown complete.
INFO: Finished server process [27]
We are installing with the https://raw.githubusercontent.com/apache/airflow/constraints-3.1.2/constraints-3.10.txt constraints I'm able to verify that the version of Airflow is 3.1.2 (airflow version in working components). I'm also able to verify structlog==25.5.0 is installed.
Because of this issue we are unable to use Airflow 3.1.2. structlog==25.5.0 is apparently not working, different from what we read in the release notes.
What you think should happen instead?
Components should work correctly given right constraints and dependency installation.
How to reproduce
pip freeze from API server:
a2wsgi==1.10.10
adal==1.2.7
adlfs==2025.8.0
aiofiles==24.1.0
aiohappyeyeballs==2.6.1
aiohttp==3.13.2
aiohttp-cors==0.8.1
aiomysql==0.3.2
aiosignal==1.4.0
aiosmtplib==5.0.0
aiosqlite==0.21.0
alembic==1.17.1
altair==4.2.2
amqp==5.3.1
annotated-types==0.7.0
anyio==4.11.0
apache-airflow==3.1.2
apache-airflow-client==3.0.2
apache-airflow-core==3.1.2
apache-airflow-providers-amazon==9.16.0
apache-airflow-providers-atlassian-jira==3.2.0
apache-airflow-providers-celery==3.13.0
apache-airflow-providers-cncf-kubernetes==10.9.0
apache-airflow-providers-common-compat==1.8.0
apache-airflow-providers-common-io==1.6.4
apache-airflow-providers-common-sql==1.28.2
apache-airflow-providers-databricks==7.7.4
apache-airflow-providers-datadog==3.9.2
apache-airflow-providers-docker==4.4.4
apache-airflow-providers-elasticsearch==6.3.4
apache-airflow-providers-fab==3.0.1
apache-airflow-providers-ftp==3.13.2
apache-airflow-providers-google==18.1.0
apache-airflow-providers-grpc==3.8.2
apache-airflow-providers-hashicorp==4.3.3
apache-airflow-providers-http==5.4.0
apache-airflow-providers-imap==3.9.3
apache-airflow-providers-jira==3.1.0
apache-airflow-providers-microsoft-azure==12.8.0
apache-airflow-providers-mongo==5.2.2
apache-airflow-providers-mysql==6.3.4
apache-airflow-providers-odbc==4.10.2
apache-airflow-providers-openlineage==2.7.3
apache-airflow-providers-opsgenie==5.9.2
apache-airflow-providers-postgres==6.4.0
apache-airflow-providers-redis==4.3.2
apache-airflow-providers-salesforce==5.11.3
apache-airflow-providers-sendgrid==4.1.4
apache-airflow-providers-sftp==5.4.1
apache-airflow-providers-slack==9.4.0
apache-airflow-providers-smtp==2.3.1
apache-airflow-providers-snowflake==6.6.0
apache-airflow-providers-sqlite==4.1.2
apache-airflow-providers-ssh==4.1.5
apache-airflow-providers-standard==1.9.1
apache-airflow-providers-tableau==5.2.1
apache-airflow-task-sdk==1.1.1
apispec==6.8.4
argcomplete==3.6.3
asgiref==3.10.0
asn1crypto==1.5.1
async-timeout==4.0.3
asyncpg==0.30.0
asyncssh==2.21.1
atlassian-python-api==4.0.7
attrs==25.4.0
Authlib==1.6.5
azure-batch==14.2.0
azure-common==1.1.28
azure-core==1.36.0
azure-cosmos==4.14.0
azure-datalake-store==0.0.53
azure-identity==1.25.1
azure-keyvault-secrets==4.10.0
azure-kusto-data==5.0.5
azure-mgmt-containerinstance==10.1.0
azure-mgmt-containerregistry==14.0.0
azure-mgmt-core==1.6.0
azure-mgmt-cosmosdb==9.8.0
azure-mgmt-datafactory==9.2.0
azure-mgmt-datalake-nspkg==3.0.1
azure-mgmt-datalake-store==0.5.0
azure-mgmt-nspkg==3.0.2
azure-mgmt-resource==24.0.0
azure-mgmt-storage==24.0.0
azure-nspkg==3.0.2
azure-servicebus==7.14.3
azure-storage-blob==12.27.1
azure-storage-file-datalake==12.22.0
azure-storage-file-share==12.23.1
azure-synapse-artifacts==0.21.0
azure-synapse-spark==0.7.0
babel==2.17.0
backoff==2.2.1
backports.strenum==1.3.1
bcrypt==5.0.0
beautifulsoup4==4.14.2
billiard==4.2.2
bleach==6.3.0
blinker==1.9.0
boto3==1.40.61
botocore==1.40.61
build==1.3.0
cachelib==0.13.0
cachetools==6.2.1
cadwyn==5.4.5
cattrs==25.3.0
celery==5.5.3
Cerberus==1.3.4
certifi==2025.10.5
cffi==1.17.1
chardet==5.2.0
charset-normalizer==3.4.4
click==8.2.1
click-didyoumean==0.3.1
click-plugins==1.1.1.2
click-repl==0.3.0
clickclick==20.10.2
cloud-sql-python-connector==1.2.1
cloudpickle==3.1.1
colorama==0.4.6
colorful==0.5.8
colorlog==6.10.1
confluent-kafka==2.12.1
connexion==2.14.2
contourpy==1.3.2
coverage==7.6.0
cron_descriptor==2.0.6
croniter==6.0.0
cryptography==42.0.8
cycler==0.12.1
databricks-sql-connector==4.1.4
databricks-sqlalchemy==1.0.2
datadog==0.52.1
datahub-airflow @ file:///home/airflow/airflow3
datahub-airflow-workload-optimiser==0.10.1
db-dtypes==1.4.3
DBUtils==3.0.2
decorator==5.2.1
defusedxml==0.7.1
dependency-injector==4.48.2
Deprecated==1.3.1
dh-feature-store-materialization==2.0.0.dev202511061534+g032a77a
dill==0.4.0
distlib==0.4.0
distro==1.9.0
dnspython==2.8.0
docker==7.1.0
docstring_parser==0.17.0
durationpy==0.10
ecdsa==0.19.1
elastic-transport==8.17.1
elasticsearch==8.19.2
email-validator==2.3.0
entrypoints==0.4
et_xmlfile==2.0.0
exceptiongroup==1.3.0
execnet==2.1.1
fastapi==0.117.1
fastapi-cli==0.0.14
fastdiff==0.3.0
fastuuid==0.14.0
filelock==3.20.0
flake8==6.0.0
Flask==2.2.5
Flask-AppBuilder==5.0.0
flask-babel==4.0.0
Flask-JWT-Extended==4.7.1
Flask-Limiter==3.12
Flask-Login==0.6.3
Flask-Session==0.8.0
Flask-SQLAlchemy==3.0.5
Flask-WTF==1.2.2
flower==2.0.1
fonttools==4.60.0
freezegun==1.5.2
frozenlist==1.8.0
fsspec==2025.10.0
gcloud-aio-auth==5.4.2
gcloud-aio-bigquery==7.1.0
gcloud-aio-storage==9.6.0
gcsfs==2025.10.0
ghp-import==2.1.0
# Editable install with no version control (glovo==0.1.0)
-e /home/airflow/dags/glovo
google-ads==28.3.0
google-analytics-admin==0.26.0
google-api-core==2.28.1
google-api-python-client==2.186.0
google-auth==2.41.1
google-auth-httplib2==0.2.1
google-auth-oauthlib==1.2.3
google-cloud-aiplatform==1.124.0
google-cloud-alloydb==0.6.0
google-cloud-appengine-logging==1.7.0
google-cloud-audit-log==0.4.0
google-cloud-automl==2.17.0
google-cloud-batch==0.18.0
google-cloud-bigquery==3.38.0
google-cloud-bigquery-datatransfer==3.20.0
google-cloud-bigquery-reservation==1.3.0
google-cloud-bigquery-storage==2.34.0
google-cloud-bigtable==2.34.0
google-cloud-build==3.33.0
google-cloud-compute==1.40.0
google-cloud-container==2.61.0
google-cloud-core==2.5.0
google-cloud-datacatalog==3.28.0
google-cloud-dataflow-client==0.10.0
google-cloud-dataform==0.7.0
google-cloud-dataplex==2.14.0
google-cloud-dataproc==5.23.0
google-cloud-dataproc-metastore==1.20.0
google-cloud-dlp==3.33.0
google-cloud-firestore==2.21.0
google-cloud-kms==3.7.0
google-cloud-language==2.18.0
google-cloud-logging==3.12.1
google-cloud-managedkafka==0.2.0
google-cloud-memcache==1.13.0
google-cloud-monitoring==2.28.0
google-cloud-orchestration-airflow==1.18.0
google-cloud-os-login==2.18.0
google-cloud-pubsub==2.33.0
google-cloud-redis==2.19.0
google-cloud-resource-manager==1.15.0
google-cloud-run==0.12.0
google-cloud-secret-manager==2.25.0
google-cloud-spanner==3.59.0
google-cloud-speech==2.34.0
google-cloud-storage==3.4.1
google-cloud-storage-transfer==1.18.0
google-cloud-tasks==2.20.0
google-cloud-texttospeech==2.33.0
google-cloud-translate==3.22.0
google-cloud-videointelligence==2.17.0
google-cloud-vision==3.11.0
google-cloud-workflows==1.19.0
google-crc32c==1.7.1
google-genai==1.47.0
google-resumable-media==2.7.2
googleapis-common-protos==1.71.0
great_expectations==1.5.8
greenback==1.2.1
greenlet==3.2.4
grpc-google-iam-v1==0.14.3
grpc-interceptor==0.15.4
grpcio==1.65.5
grpcio-gcp==0.2.2
grpcio-status==1.62.3
h11==0.16.0
h2==4.3.0
hf-xet==1.2.0
HiYaPyCo==0.7.0
hpack==4.1.0
httpcore==1.0.9
httplib2==0.22.0
httptools==0.7.1
httpx==0.28.1
huggingface-hub==1.0.1
humanize==4.14.0
hvac==2.4.0
hyperframe==6.1.0
idna==3.11
ijson==3.4.0.post0
immutabledict==4.2.2
importlib_metadata==8.4.0
inflection==0.5.1
iniconfig==2.0.0
iso8601==2.1.0
isodate==0.7.2
itsdangerous==2.2.0
Jinja2==3.1.6
jira==3.5.0
jiter==0.11.1
jmespath==0.10.0
joblib==1.5.2
JSON-log-formatter==1.1.1
jsonpath-ng==1.7.0
jsonpickle==3.4.2
jsonschema==4.25.1
jsonschema-specifications==2025.9.1
kiwisolver==1.4.9
kombu==5.5.4
kopf==1.38.0
kubernetes==33.1.0
kubernetes_asyncio==33.3.0
lazy-object-proxy==1.12.0
libcst==1.8.5
limits==5.6.0
linkify-it-py==2.0.3
litellm==1.76.3
littleutils==0.2.4
lockfile==0.12.2
looker-sdk==25.18.0
lxml==6.0.2
lz4==4.4.5
Mako==1.3.10
Markdown==3.9
markdown-it-py==4.0.0
MarkupSafe==3.0.3
marshmallow==3.26.1
marshmallow-sqlalchemy==1.4.2
matplotlib==3.10.6
mccabe==0.7.0
mdurl==0.1.2
mergedeep==1.3.4
methodtools==0.4.7
microsoft-kiota-abstractions==1.9.7
microsoft-kiota-authentication-azure==1.9.7
microsoft-kiota-http==1.9.7
microsoft-kiota-serialization-json==1.9.7
microsoft-kiota-serialization-text==1.9.7
mistune==3.1.4
mkdocs==1.6.0
mkdocs-get-deps==0.2.0
more-itertools==10.8.0
msal==1.34.0
msal-extensions==1.3.1
msgpack==1.1.2
msgraph-core==1.3.8
msgraphfs==0.4
msgspec==0.19.0
msrest==0.7.1
msrestazure==0.6.4.post1
multidict==6.7.0
mysql-connector-python==9.5.0
mysqlclient==2.2.7
natsort==8.4.0
networkx==3.4.2
numpy==1.26.4
oauthlib==3.3.1
openai==2.6.1
opencensus==0.11.4
opencensus-context==0.1.3
openlineage-integration-common==1.39.0
openlineage-python==1.39.0
openlineage_sql==1.39.0
openpyxl==3.1.5
opentelemetry-api==1.27.0
opentelemetry-exporter-otlp==1.27.0
opentelemetry-exporter-otlp-proto-common==1.27.0
opentelemetry-exporter-otlp-proto-grpc==1.27.0
opentelemetry-exporter-otlp-proto-http==1.27.0
opentelemetry-exporter-prometheus==0.48b0
opentelemetry-proto==1.27.0
opentelemetry-sdk==1.27.0
opentelemetry-semantic-conventions==0.48b0
opsgenie-sdk==2.1.5
ordered-set==4.1.0
outcome==1.3.0.post0
outdated==0.2.2
packaging==25.0
pandas==2.1.4
pandas-gbq==0.29.2
pandas_flavor==0.7.0
paramiko==3.5.1
pathspec==0.12.1
patsy==1.0.1
pendulum==3.1.0
pg8000==1.29.4
pillow==11.3.0
pingouin==0.5.3
platformdirs==4.5.0
pluggy==1.6.0
ply==3.11
plyvel==1.5.1
posthog==6.7.7
pretty-html-table==0.9.16
prison==0.2.1
prometheus_client==0.23.1
prompt_toolkit==3.0.52
propcache==0.4.1
proto-plus==1.26.1
protobuf==4.25.8
psutil==7.1.3
psycopg2-binary==2.9.11
py-kit==3.8.6
py-spy==0.4.1
pyarrow==18.1.0
pyasn1==0.6.1
pyasn1_modules==0.4.1
PyAthena==3.19.0
pycodestyle==2.10.0
pycparser==2.23
pydantic==2.12.3
pydantic_core==2.41.4
pydata-google-auth==1.9.1
pyflakes==3.0.1
Pygments==2.19.2
pygtrie==2.5.0
PyJWT==2.10.1
pymongo==4.15.3
PyMySQL==1.1.2
PyNaCl==1.6.0
pyodbc==5.3.0
pyOpenSSL==25.1.0
pyparsing==3.2.5
pyproject_hooks==1.2.0
pysftp==0.2.9
pytest==8.4.1
pytest-cov==6.2.1
pytest-mock==3.14.1
pytest-xdist==3.8.0
python-daemon==3.1.2
python-dateutil==2.9.0.post0
python-dotenv==1.2.1
python-http-client==3.3.7
python-json-logger==3.3.0
python-multipart==0.0.20
python-slugify==8.0.4
pytz==2025.2
PyYAML==6.0.3
pyyaml_env_tag==1.1
ray==2.47.1
redis==5.2.1
redshift-connector==2.1.7
referencing==0.37.0
regex==2025.10.23
requests==2.32.5
requests-file==3.0.1
requests-oauthlib==2.0.0
requests-toolbelt==1.0.0
retryhttp==1.4.0
rich==13.9.4
rich-argparse==1.7.2
rich-toolkit==0.15.1
rpds-py==0.28.0
rsa==4.9.1
ruamel.yaml==0.18.16
ruamel.yaml.clib==0.2.14
s3transfer==0.14.0
sagemaker_studio==1.0.22
scikit-learn==1.5.2
scipy==1.15.3
scramp==1.4.6
seaborn==0.13.2
sendgrid==6.12.4
setproctitle==1.3.7
shapely==2.1.2
shellingham==1.5.4
simple-salesforce==1.12.9
six==1.17.0
slack_sdk==3.37.0
smart_open==7.4.3
snapshottest==0.6.0
sniffio==1.3.1
snowflake-connector-python==3.18.0
snowflake-snowpark-python==1.42.0
snowflake-sqlalchemy==1.7.7
sortedcontainers==2.4.0
soupsieve==2.8
SQLAlchemy==1.4.54
sqlalchemy-bigquery==1.15.0
SQLAlchemy-JSONField==1.0.2
sqlalchemy-spanner==1.17.1
SQLAlchemy-Utils==0.42.0
sqlparse==0.5.3
sshtunnel==0.4.0
starlette==0.48.0
statsd==4.0.1
statsmodels==0.14.5
std-uritemplate==2.0.8
structlog==25.5.0
svcs==25.1.0
tableau-api-lib==0.1.50
tableauserverclient==0.38
tabulate==0.9.0
tenacity==9.1.2
termcolor==3.2.0
text-unidecode==1.3
threadpoolctl==3.6.0
thrift==0.16.0
tiktoken==0.12.0
tokenizers==0.22.1
toml==0.10.2
tomli==2.3.0
tomlkit==0.13.3
toolz==1.0.0
tornado==6.5.2
tqdm==4.67.1
twilio==7.17.0
typeguard==4.4.2
typer==0.20.0
typer-slim==0.20.0
types-protobuf==6.32.1.20250918
types-requests==2.32.4.20250913
typing-inspection==0.4.2
typing_extensions==4.15.0
tzdata==2025.2
tzlocal==5.3.1
uc-micro-py==1.0.3
unicodecsv==0.14.1
universal_pathlib==0.2.6
uritemplate==4.2.0
urllib3==2.5.0
uuid6==2025.0.1
uv==0.9.7
uvicorn==0.38.0
uvloop==0.22.1
vine==5.1.0
virtualenv==20.35.4
wasmer==1.1.0
wasmer_compiler_cranelift==1.1.0
watchdog==6.0.0
watchfiles==1.1.1
watchtower==3.4.0
wcwidth==0.2.14
webencodings==0.5.1
websocket-client==1.9.0
websockets==15.0.1
Werkzeug==2.2.3
wirerope==1.0.0
wrapt==1.17.3
WTForms==3.2.1
xarray==2025.6.1
xmltodict==1.0.2
yamllint==1.37.1
yarl==1.22.0
zeep==4.3.2
zipp==3.23.0
Operating System
PRETTY_NAME="Debian GNU/Linux 12 (bookworm)" NAME="Debian GNU/Linux" VERSION_ID="12" VERSION="12 (bookworm)" VERSION_CODENAME=bookworm ID=debian HOME_URL="https://www.debian.org/" SUPPORT_URL="https://www.debian.org/support" BUG_REPORT_URL="https://bugs.debian.org/"
Versions of Apache Airflow Providers
apache-airflow-providers-amazon==9.16.0
apache-airflow-providers-atlassian-jira==3.2.0
apache-airflow-providers-celery==3.13.0
apache-airflow-providers-cncf-kubernetes==10.9.0
apache-airflow-providers-common-compat==1.8.0
apache-airflow-providers-common-io==1.6.4
apache-airflow-providers-common-sql==1.28.2
apache-airflow-providers-databricks==7.7.4
apache-airflow-providers-datadog==3.9.2
apache-airflow-providers-docker==4.4.4
apache-airflow-providers-elasticsearch==6.3.4
apache-airflow-providers-fab==3.0.1
apache-airflow-providers-ftp==3.13.2
apache-airflow-providers-google==18.1.0
apache-airflow-providers-grpc==3.8.2
apache-airflow-providers-hashicorp==4.3.3
apache-airflow-providers-http==5.4.0
apache-airflow-providers-imap==3.9.3
apache-airflow-providers-jira==3.1.0
apache-airflow-providers-microsoft-azure==12.8.0
apache-airflow-providers-mongo==5.2.2
apache-airflow-providers-mysql==6.3.4
apache-airflow-providers-odbc==4.10.2
apache-airflow-providers-openlineage==2.7.3
apache-airflow-providers-opsgenie==5.9.2
apache-airflow-providers-postgres==6.4.0
apache-airflow-providers-redis==4.3.2
apache-airflow-providers-salesforce==5.11.3
apache-airflow-providers-sendgrid==4.1.4
apache-airflow-providers-sftp==5.4.1
apache-airflow-providers-slack==9.4.0
apache-airflow-providers-smtp==2.3.1
apache-airflow-providers-snowflake==6.6.0
apache-airflow-providers-sqlite==4.1.2
apache-airflow-providers-ssh==4.1.5
apache-airflow-providers-standard==1.9.1
apache-airflow-providers-tableau==5.2.1
Deployment
Official Apache Airflow Helm Chart
Deployment details
We are using a custom k8s chart to deploy Airflow. Our image is built on top of the existing Airflow image.
Anything else?
No response
Are you willing to submit PR?
- Yes I am willing to submit a PR!
Code of Conduct
- I agree to follow this project's Code of Conduct