-
Notifications
You must be signed in to change notification settings - Fork 15.9k
Closed
Labels
area:providerskind:metaHigh-level information important to the communityHigh-level information important to the communitytesting statusStatus of testing releasesStatus of testing releases
Description
Body
I have a kind request for all the contributors to the latest provider distributions release.
Could you please help us to test the RC versions of the providers?
The guidelines on how to test providers can be found in
Verify providers by contributors
Let us know in the comments, whether the issue is addressed.
These are providers that require testing as there were some substantial changes introduced:
Provider airbyte: 5.2.2rc1
Provider alibaba: 3.2.2rc1
- Cleanup type ignores in alibaba provider (#53299): @mingdaoy
- Move Base imports to
version_compatfor Alibaba provider Airflow 3.0 compatibility (#52777): @sunank200
Provider amazon: 9.11.0rc1
- Add full support for AWS SSM Run Command in Airflow (#52769): @Shlomit-B
Linked issues: - Enhancement: AWS Provider sql to s3 operator pd.read_sql kwargs (#53399): @CincyBC
- Support HA schedulers for the Lambda Executor (#53396): @o-nikolas
- Fix variable name in EKS command for token expiration timestamp (#53720): @nailo2c
Linked issues: - Fix EMR operator parameter documentation and naming (#53446): @BobDu
- remove ECS Operator retry mechanism on task failed to start (#53083): @vladimirbinshtok
- Resolve OOM When Reading Large Logs in Webserver (#49470): @jason810496
Linked issues: - Fix unreachable code mypy warnings in amazon provider (#53414): @gopidesupavan
- Refactoring get con part dbapihook in providers (#53335): @kyungjunleeme
- Cleanup type ignores in amazon provider where possible (#53239): @gopidesupavan
- Always build xmlsec and lxml packages from sources in our images (#53137): @potiuk
Linked issues: - Improve mypy typing for RedshiftHook (#53099): @gopidesupavan
- Make amazon provider compatible with mypy 1.16.1 (#53088): @gopidesupavan
Provider apache.beam: 6.1.3rc1
- Cleanup type ignores in apache/beam provider (#53303): @mingdaoy
- Replace
BaseHookto Task SDK forapache/beam(#52781): @bdsoha
Linked issues:
Provider apache.cassandra: 3.8.2rc1
- Make apache cassandra provider compatible with mypy 1.16.1 (#53110): @jscheffl
- Replace
BaseHookto Task SDK forapache/cassandra(#52689): @bdsoha
Linked issues:
Provider apache.drill: 3.1.2rc1
- improve test coverage for apache drill (#53517): @sjyangkevin
Linked issues: - Clean up mypy ignores in drill provider (#53320): @gopidesupavan
- Cleanup type ignores in apache/drill provider (#53304): @mingdaoy
Provider apache.druid: 4.3.0rc1
- add
ssl_verify_certsupport toDruidDbApiHook.get_conn(#52926): @nailo2c
Linked issues: - Replace
BaseHookto Task SDK forapache/druid(#52690): @bdsoha
Linked issues:
Provider apache.flink: 1.7.2rc1
- added both different namespace for taskmanager or for global namespace (#53653): @Nataneljpwd
Linked issues:
Provider apache.hdfs: 4.10.2rc1
- Replace
BaseHookto Task SDK forapache/hdfs(#52684): @bdsoha
Linked issues:
Provider apache.hive: 9.1.2rc1
- Fix hive changelog (#53665): @eladkal
- Deprecate decorators from Core (#53629): @kaxil
- Cleanup type ignores in apache/hive provider (#53302): @mingdaoy
- Replace
BaseHookto Task SDK forapache/hive(#52685): @bdsoha
Linked issues:
Provider apache.iceberg: 1.3.2rc1
- Replace
BaseHookto Task SDK forapache/iceberg(#52783): @bdsoha
Linked issues:
Provider apache.kafka: 1.10.1rc1
- Add validation for commit_cadence in Kafka ConsumeFromTopicOperator (#52015): @jason810496
Linked issues: - Cleanup type ignores in apache/kafka provider (#53300): @mingdaoy
- Make kafka provider compatible with mypy 1.16.1 (#53125): @gopidesupavan
- Replace
BaseHookto Task SDK forapache/kafka(#52784): @bdsoha
Linked issues:
Provider apache.kylin: 3.9.2rc1
Provider apache.pig: 4.7.2rc1
- Replace
BaseHookto Task SDK forapache/pig(#52687): @bdsoha
Linked issues:
Provider apache.pinot: 4.8.2rc1
- Deprecate decorators from Core (#53629): @kaxil
- Cleanup type ignores in apache/pinot provider (#53311): @kyungjunleeme
- Replace
BaseHookto Task SDK forapache/pinot(#52841): @bdsoha
Linked issues:
Provider apache.spark: 5.3.2rc1
- Deprecate decorators from Core (#53629): @kaxil
- Cleanup type ignores in apache/spark provider (#53301): @mingdaoy
- Replace
BaseHookto Task SDK forapache/pyspark(#52842): @bdsoha
Linked issues: - Replace
BaseHookto Task SDK forapache/spark(#52683): @bdsoha
Linked issues:
Provider apache.tinkerpop: 1.0.2rc1
- Cleanup type ignores in apache/tinkerpop provider (#53305): @kyungjunleeme
Linked issues: - Replace
BaseHookto Task SDK forapache/tinkerpop(#52844): @bdsoha
Linked issues:
Provider apprise: 2.1.2rc1
Provider arangodb: 2.8.2rc1
Provider asana: 2.10.2rc1
Provider atlassian.jira: 3.1.2rc1
- Cleanup mypy ignores atlasian jira provider where possible (#53263): @gopidesupavan
- Move all BaseHook usages to version_compat in Atlassian (#52790): @sunank200
Provider celery: 3.12.2rc1
Provider cloudant: 4.2.2rc1
Provider cncf.kubernetes: 10.6.2rc1
- Pass cluster context to AsyncKubernetesHook (#53504): @suprjinx
- Handle multiple pods to prevent
KubernetesJobOperatorfalls with parallelism option (#49899): @Crowiant - bug fix - evicted pod not inclued in creating pod (#53059): @kyungjunleeme
Linked issues: - Deprecate decorators from Core (#53629): @kaxil
- Use asyncio.run instead of loop.run_until_complete. (#53475): @dstandish
- Remove
airflow.utils.xcommodule and add backcompat shim (#53187): @amoghrajesh - Cleanup mypy ignores cncf provider where possible (#53264): @gopidesupavan
- Replace usages of
XCOM_RETURN_KEYin providers to not be from utils (#53170): @amoghrajesh - Make cncf provider compatible with mypy 1.16.1 (#53121): @gopidesupavan
- Move all BaseHook usages to version_compat in cncf (#52798): @sunank200
Provider cohere: 1.5.3rc1
Provider common.compat: 1.7.3rc1
Provider common.io: 1.6.2rc1
- Prevent FileNotFoundError in deserialize_value of XCom io provider to crash the scheduler (#52702): @dabla
- Deprecate decorators from Core (#53629): @kaxil
- Cleanup type ignores in common/io provider (#53298): @mingdaoy
- Move remaining
airflow.iocode to Task SDK (#53211): @kaxil - Replace usages of
XCOM_RETURN_KEYin providers to not be from utils (#53170): @amoghrajesh
Provider common.sql: 1.27.4rc1
- Fix unreachable code mypy warnings in teradata provider (#53488): @fweilun
- Add sql extras to pandas in the providers where sqlalchemy is needed (#53535): @potiuk
- Cleanup type ignores in common/sql provider (#53297): @mingdaoy
- Move all BaseHook and BaseSensorOperator usages to version_compat in Common SQL (#52800): @sunank200
Provider databricks: 7.7.0rc1
- feat: Refactor Databricks error handling with utility functions (#52704): @gaurav7261
- Fix URI Construction in Databricks Hook (#53217): @BrianLii
Linked issues: - fix: Improve logging and timeouts in OL helpers (#53139): @kacpermuda
- Fix Task Group Deprecation error from plugin (#53813): @kaxil
- Remove
apiprefix from update_job_permission in databricks hook (#53039): @fjmacagno - Refactor: Consolidate API endpoints for improved security and maintainability (#53214): @kyungjunleeme
Linked issues:
Provider datadog: 3.9.2rc1
- Cleanup mypy ignore in datadog provider where possible (#53268): @gopidesupavan
- Move all BaseHook usages to version_compat in Datadog (#52801): @sunank200
Provider docker: 4.4.2rc1
Provider edge3: 1.1.2rc2
- Fix UnboundLocalError for
edge_job_command_len(#52328): @yanshil
Linked issues: - Extend run detection to dev-mode to load plugin (#53576): @jscheffl
Linked issues: - Add queue and remove queue cli commands for EdgeExecutor (#53505): @dheerajturaga
- Ensure Edge Plugin for API endpoint is only loaded on API-Server and AF2 Webserver (#52952): @jscheffl
Linked issues: - Fix unreachable code mypy warnings in edge3 provider (#53430): @jscheffl
- Make edge3 provider compatible with mypy 1.16.1 (#53104): @gopidesupavan
- Fix task configuration defaults for AbstractOperator (#52871): @kaxil
- Deprecate decorators from Core (#53629): @kaxil
- Cleanup type ignores in edge3 provider where possible (#53248): @jscheffl
- Remove deprecation in Edge for DEFAULT_QUEUE (#52954): @jscheffl
- Force the definition of
execution_api_server_urlbased onapi_url(#52184): @bdsoha
Linked issues: - Remove FAB dependency from Edge3 Provider (#51995): @jscheffl
Linked issues: - Fix Edge State Model Link (#51860): @jscheffl
Provider elasticsearch: 6.3.2rc1
- Make Elasticsearch/OpensearchTaskHandler to render log well (#53639): @Owen-CH-Leung
Linked issues: - Resolve OOM When Reading Large Logs in Webserver (#49470): @jason810496
Linked issues: - Fix unreachable code mypy warnings in elasticsearch provider (#53464): @yunchipang
Linked issues: - Move all BaseHook usages to version_compat in Elastic Search (#52805): @sunank200
Provider exasol: 4.8.2rc1
- Refactoring get con part dbapihook in providers (#53335): @kyungjunleeme
- Cleanup mypy ignore in exasol provider where possible (#53278): @gopidesupavan
Provider fab: 2.3.1rc1
- Remove
MENUfromResourceMethodin auth manager (#52731): @vincbeck
Linked issues: - Fix FAB provider in unreachable code (#53436): @gopidesupavan
- Cleanup mypy ignore for fab provider in init_jinja_globals (#53328): @gopidesupavan
- Remove unused batch methods from auth manager (#52883): @vincbeck
- Remove extra slash from endpoint URL (#53755): @lpillmann
- Clarify FAB auth provider versioning and webserver_config.py deprecation for Airflow 3.x (#53606): @nrnavaneet
Provider facebook: 3.8.2rc1
Provider ftp: 3.13.2rc1
Provider git: 0.0.5rc1
- fix: always create GitHook even when
repo_urlis provided (#52897): @nailo2c
Linked issues: - Moving BaseHook usages to version_compat for git (#52944): @amoghrajesh
Provider github: 2.9.2rc1
- Cleanup type ignores in github provider where possible (#53291): @mingdaoy
- Move all BaseHook usages to version_compat in Github (#52810): @sunank200
Provider google: 17.0.0rc1
- Remove deprecated from google provider scheduled for June and July 2025 (#53197): @Crowiant
- Handle multiple pods to prevent
KubernetesJobOperatorfalls with parallelism option (#49899): @Crowiant - Adjust ray operators in google provider. Add ray package as a dependency. (#53182): @Crowiant
- Add new operators for Experiment and Experiment run entities for Vertex AI in google provider (#52964): @Crowiant
- feature: Added support for Google cloud log sink management via google provider (#52001): @arvindp25
Linked issues: - Fix DataprocClusterTrigger by passing objects in correct types so that they can be serialized (#53485): @VladaZakharova
- fix: Change DataprocAsyncHook parent class to GoogleBaseAsyncHook (#52981): @kgw7401
Linked issues: - Fix GCSToBigQueryOperator: avoid pushing non-serializable task_instance to XCom (#53094): @arvindp25
Linked issues: - Bugfix: StackdriverHook channel and policy assignments when creating/updating notifications and policy's (#53131): @gopidesupavan
- Bugfix/return DataflowJobMessagesSensor and DataflowJobAutoScalingEventsSensor result with xcom_value (#53115): @gopidesupavan
- Refactor google.cloud imports to prevent conflicts with airflow google provider namespace and resolve mypy errors (#53338): @gopidesupavan
- Clean up mypy ignores in google provider (#53249): @gopidesupavan
- Make google provider compatible with mypy 1.16.1 (#53148): @gopidesupavan
- Remove
MAX_XCOM_SIZEhardcoded constant from Airflow core (#52978): @amoghrajesh - Replace BaseHook to Task SDK for google (#52809): @fweilun
- Remove extra slash from endpoint URL (#53755): @lpillmann
Provider grpc: 3.8.2rc1
- Cleanup type ignores in grpc provider (#53293): @mingdaoy
- Move all BaseHook usages to version_compat in gRPC (#52811): @sunank200
Provider hashicorp: 4.3.2rc1
- Fix unreachable code errors in Vault provider (#53437): @dominikhei
- Move all BaseHook usages to version_compat in HashiCorp (#52812): @sunank200
Provider http: 5.3.3rc1
- Cleanup type ignores in http provider (#53294): @mingdaoy
- Make http provider compatible with mypy 1.16.1 (#53108): @jscheffl
Linked issues: - Move all BaseHook usages to version_compat in HTTP (#52814): @sunank200
Provider imap: 3.9.2rc1
Provider influxdb: 2.9.3rc1
- Cleanup type ignores in influxdb provider (#53295): @mingdaoy
- Move all BaseHook usages to version_compat in InfluxDB (#52817): @sunank200
Provider jdbc: 5.2.2rc1
Provider jenkins: 4.1.2rc1
- Cleanup type ignores in jenkins provider where possible (#53292): @mingdaoy
- Move all BaseHook usages to version_compat in Jenkins (#52820): @sunank200
Provider microsoft.azure: 12.6.0rc1
- Add
account_hostto extra fields in ADLSget_fs()method (#53521): @samuelkhtu
Linked issues:- Linked Issue #53333: @samuelkhtu
- Resolve OOM When Reading Large Logs in Webserver (#49470): @jason810496
Linked issues: - Set up process for sharing code between different components. (#53149): @ashb
- Deprecate decorators from Core (#53629): @kaxil
- Bumping min version of azure-storage-blob to 12.26.0 (#53440): @amoghrajesh
- Remove
airflow.utils.xcommodule and add backcompat shim (#53187): @amoghrajesh - Cleanup type ignores in 4 microsoft providers where possible (#53312): @jscheffl
- Import
XCOM_RETURN_KEYin providers from task SDK (#53180): @amoghrajesh - Replace usages of
XCOM_RETURN_KEYin providers to not be from utils (#53170): @amoghrajesh - Make microsoft azure provider compatible with mypy 1.16.1 (#53107): @gopidesupavan
- Replace BaseHook to Task SDK for microsoft azure (#52821): @fweilun
Provider microsoft.mssql: 4.3.2rc1
Provider microsoft.psrp: 3.1.2rc1
- Cleanup type ignores in 4 microsoft providers where possible (#53312): @jscheffl
- Move all BaseHook usages to version_compat in Microsoft PSRP (#52854): @sunank200
Provider microsoft.winrm: 3.10.2rc1
- Cleanup type ignores in 4 microsoft providers where possible (#53312): @jscheffl
- Move all BaseHook usages to version_compat in Microsoft WinRM (#52855): @sunank200
Provider mongo: 5.2.2rc1
- Fix: ignore connection schema when schema is none in mongo hook (#53780): @gopidesupavan
- Move all BaseHook usages to version_compat in MongoDB (#52857): @sunank200
Provider mysql: 6.3.3rc1
Provider neo4j: 3.10.0rc1
- feat(provider): pass parameters to Neo4j driver session (#52990): @rmidhun23
Linked issues:- Linked Issue #52723: @rmidhun23
- Cleanup type ignores in neo4j provider where possible (#53287): @jscheffl
Provider openai: 1.6.2rc1
- Cleanup type ignores in openai provider where possible (#53285): @jscheffl
- Move all BaseHook usages to version_compat in openai (#52819): @mingdaoy
Linked issues:
Provider openfaas: 3.8.2rc1
Provider openlineage: 2.6.0rc1
- OpenLineage EmptyOperator (#53730): @RNHTTR
- feat: Add new documentation facet to all OL events (#52343): @kacpermuda
Linked issues: - fix: Adjust emits_ol_events to account for inlets check since AF3.0.2 (#53449): @kacpermuda
- fix: Check dynamic transport env vars in is_disabled() (#53370): @kacpermuda
- Fix Task Group Deprecation error from plugin (#53813): @kaxil
- Updating
apache-airflow-providers-openlineagedependencies to use1.36.0(#53671): @jroachgolf84 - Cleanup type ignores in openlineage provider where possible (#53284): @jscheffl
- Make openlineage provider compatible with mypy 1.16.1 (#53119): @gopidesupavan
Provider opensearch: 1.7.2rc1
- Make Elasticsearch/OpensearchTaskHandler to render log well (#53639): @Owen-CH-Leung
Linked issues: - Fix RuntimeError when using OpensearchTaskHandler as remote log handler (#53529): @Owen-CH-Leung
Linked issues: - Resolve OOM When Reading Large Logs in Webserver (#49470): @jason810496
Linked issues: - Cleanup type ignores in opensearch provider where possible (#53283): @jscheffl
- Make opensearch provider compatible with mypy 1.16.1 (#53112): @gopidesupavan
- Replace BaseHook to Task SDK for opensearch (#52851): @kyungjunleeme
Linked issues:
Provider opsgenie: 5.9.2rc1
- Cleanup type ignores in opsgenie provider where possible (#53281): @jscheffl
- Move all BaseHook usages to version_compat in opsgenie (#52859): @sunank200
Provider oracle: 4.1.3rc1
Provider pagerduty: 5.0.2rc1
Provider papermill: 3.11.2rc1
- Cleanup type ignores in papermill provider where possible (#53279): @jscheffl
- Moving BaseHook usages to version_compat for papermill (#52947): @amoghrajesh
Provider pinecone: 2.3.3rc1
- Cleanup type ignores in pinecone provider where possible (#53276): @jscheffl
- Moving BaseHook usages to version_compat for pinecone (#52911): @amoghrajesh
Provider postgres: 6.2.2rc1
- Fix: ensure get_df uses SQLAlchemy engine to avoid pandas warning (#52224): @daesung9511
Linked issues:- Linked Issue #52142: @cultcom
- Cleanup type ignores in postgres provider where possible (#53275): @jscheffl
Provider presto: 5.9.2rc1
- Add sql extras to pandas in the providers where sqlalchemy is needed (#53535): @potiuk
- Cleanup type ignores in presto provider where possible (#53274): @jscheffl
Provider qdrant: 1.4.2rc1
Provider redis: 4.2.0rc1
- Add AwaitMessageTrigger for Redis PubSub (#52917): @Jasperora
- Resolve OOM When Reading Large Logs in Webserver (#49470): @jason810496
Linked issues: - Cleanup type ignores in redis provider where possible (#53272): @jscheffl
- Imported BaseHook from version_compat in Redis (#52789): @dominikhei
Provider salesforce: 5.11.2rc1
- Cleanup type ignores in salesforce provider where possible (#53271): @jscheffl
- Moving BaseHook usages to version_compat for salesforce (#52912): @amoghrajesh
Provider samba: 4.10.2rc1
- Cleanup type ignores in samba provider where possible (#53269): @jscheffl
- Bugfix/fix mypy samba (#53113): @jscheffl
- Moving BaseHook usages to version_compat for samba (#52913): @amoghrajesh
Provider segment: 3.8.2rc1
- Cleanup type ignores in segment provider where possible (#53267): @jscheffl
- Moving BaseHook usages to version_compat for segment (#52914): @amoghrajesh
Provider sendgrid: 4.1.3rc1
- Re-add back werkzeug dependency for sendgrid on Python 3.12 (#53133): @potiuk
- Moving BaseHook usages to version_compat for sendgrid (#52915): @amoghrajesh
Provider sftp: 5.3.3rc1
- Update
apache-airflow-providers-ssh>=4.0.0dependency (#53100): @jroachgolf84
Linked issues:- Linked Issue #53084: @ivan-toriya-precis
- Fix BlobWriter (GCS) support for SFTP Streaming (#52850): @tiranux
Linked issues:- Linked Issue #49801: @ignaciojcano
- Linked Issue #48107: @kkulczak
- Cleanup type ignores in sftp provider where possible (#53266): @jscheffl
- Move all BaseHook usages to version_compat in SFTP (#52894): @sjyangkevin
Provider singularity: 3.8.2rc1
- Fix unreachable code mypy warnings in singularity provider (#53468): @yunchipang
Linked issues: - Cleanup type ignores in singularity provider where possible (#53262): @jscheffl
Provider slack: 9.1.3rc1
Provider smtp: 2.1.2rc1
- Fix: enter SmtpHook before trying to read properties (#53418): @m-rossi
Linked issues:- Linked Issue #49920: @dramis
- Cleanup type ignores in smtp provider where possible (#53260): @jscheffl
- Moving BaseHook usages to version_compat for smtp (#52950): @amoghrajesh
Provider snowflake: 6.5.1rc1
- Another magic pip resolver hint (#53329): @notatallshaw
- fix: Improve logging and timeouts in OL helpers (#53139): @kacpermuda
- Cleanup type ignores in snowflake provider where possible (#53258): @jscheffl
- Make snowpark optional for snowflake provider and disable it for Pyth… (#53489): @potiuk
- Deprecate decorators from Core (#53629): @kaxil
Provider sqlite: 4.1.2rc1
- Fix unreachable code mypy warnings in sqlite provider (#53433): @jscheffl
- Refactoring get con part dbapihook in providers (#53335): @kyungjunleeme
Provider ssh: 4.1.2rc1
- Cleanup type ignores in ssh provider where possible (#53257): @jscheffl
- Move all BaseHook usages to version_compat in ssh (#52780): @sunank200
Provider standard: 1.5.0rc1
- Add venv pycache clean up for the PythonVirtualenvOperator (#53390): @olegkachur-e
- Add Human-in-the-loop logic to core Airflow and implement
HITLOperator,ApprovalOperator,HITLEntryOperatorin standard provider (#52868): @Lee-W
Linked issues:- Linked Issue #52348: @Lee-W
- Linked Issue #52204: @Lee-W
- Linked Issue #52205: @Lee-W
- Fix key error in _handle_execution_date_fn for ExternalTaskSensor (#53728): @gopidesupavan
Linked issues:- Linked Issue #52431: @yeswanth-s1th
- fix: Type mismatch for DateInterval in latest only operator (#53541): @leakec
- fix(hitl): Fix HITLEntryOperator "options" and "defaults" handling (#53184): @Lee-W
- fix(hitl): handle
HITLDetailwhen task instance is retried (#53824): @Lee-W - Fix unreachable code mypy warnings in standard provider (#53431): @jscheffl
- Cleanup mypy ignore in standard provider where possible (#53308): @gopidesupavan
- Move
BaseHookimports to version_compat for standard provider (#52766): @amoghrajesh - Deprecate and move
airflow.utils.task_groupto SDK (#53450): @ephraimbuddy - Deprecate decorators from Core (#53629): @kaxil
- Replace usages of
XCOM_RETURN_KEYin providers to not be from utils (#53170): @amoghrajesh - Remove
set_current_contextfromairflow.models.taskinstance(#53036): @kaxil - Refactor: Replace direct BaseOperator import with version_compat import (#53847): @kyungjunleeme
Provider tableau: 5.2.0rc1
- Added JWT authentication to the TableauHook (#51756): @dominikhei
- Cleanup type ignores in tableau provider where possible (#53256): @jscheffl
- Imported BaseHook from version_compat in Tableau (#52787): @dominikhei
Provider telegram: 4.8.2rc1
- Cleanup type ignores in telegram provider where possible (#53255): @jscheffl
- Move all BaseHook usages to version_compat in Telegram (#52778): @sunank200
Provider teradata: 3.2.1rc1
- Cleanup type ignores in teradata provider where possible (#53254): @jscheffl
- Make teradata provider compatible with mypy 1.16.1 (#53128): @gopidesupavan
- Move all BaseHook usages to version_compat in teradata provider (#52858): @phanikumv
Provider trino: 6.3.2rc1
Provider vertica: 4.1.2rc1
Provider weaviate: 3.2.2rc1
Provider yandex: 4.2.0rc1
- Add environment and oslogin for yandex dataproc create cluster (#52973): @Egorees
- Fix unreachable code errors in yandex provider (#53453): @jeff3071
Linked issues: - Moving BaseHook usages to version_compat for yandex (#52963): @phanikumv
Provider ydb: 2.2.2rc1
Provider zendesk: 4.10.2rc1
- Move BaseHook to version_compat for zendesk (#52966): @phanikumv
Linked issues:
All users involved in the PRs:
@notatallshaw @lpillmann @jroachgolf84 @Crowiant @m-rossi @Jasperora @sunank200 @kacpermuda @gaurav7261 @jeff3071 @amoghrajesh @dominikhei @gopidesupavan @suprjinx @Owen-CH-Leung @ashb @potiuk @samuelkhtu @dstandis
Committer
- I acknowledge that I am a maintainer/committer of the Apache Airflow project.
Metadata
Metadata
Assignees
Labels
area:providerskind:metaHigh-level information important to the communityHigh-level information important to the communitytesting statusStatus of testing releasesStatus of testing releases