You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by GitBox <gi...@apache.org> on 2021/11/01 14:54:42 UTC

[GitHub] [airflow] fredthomsen commented on issue #19328: Status of testing Providers that were prepared on October 30, 2021

fredthomsen commented on issue #19328:
URL: https://github.com/apache/airflow/issues/19328#issuecomment-956302369


   [#18847](https://github.com/apache/airflow/pull/18847) and [#18752](https://github.com/apache/airflow/pull/18752) for [samba: 3.0.1rc1](https://pypi.org/project/apache-airflow-providers-samba/3.0.1rc1) are both good.
   
   ‐‐‐‐‐‐‐ Original Message ‐‐‐‐‐‐‐
   On Saturday, October 30th, 2021 at 9:49 AM, Jarek Potiuk ***@***.***> wrote:
   
   > Body
   >
   > I have a kind request for all the contributors to the latest provider packages release.
   > Could you help us to test the RC versions of the providers and let us know in the comment,
   > if the issue is addressed there.
   >
   > Providers that need testing
   >
   > Those are providers that require testing as there were some substantial changes introduced:
   >
   > Provider [amazon: 2.4.0rc1](https://pypi.org/project/apache-airflow-providers-amazon/2.4.0rc1)
   >
   > -  [MySQLToS3Operator add support for parquet format (#18755)](https://github.com/apache/airflow/pull/18755): ***@***.***(https://github.com/guotongfei)
   > -  [Add RedshiftSQLHook, RedshiftSQLOperator (#18447)](https://github.com/apache/airflow/pull/18447): ***@***.***(https://github.com/Brooke-white)
   > -  [Add AWS Fargate profile support (#18645)](https://github.com/apache/airflow/pull/18645): ***@***.***(https://github.com/ferruzzi)
   > -  [Add emr cluster link (#18691)](https://github.com/apache/airflow/pull/18691): ***@***.***(https://github.com/anaynayak)
   > -  [AwsGlueJobOperator: add wait_for_completion to Glue job run (#18814)](https://github.com/apache/airflow/pull/18814): ***@***.***(https://github.com/ron-damon)
   > -  [AwsGlueJobOperator: add run_job_kwargs to Glue job run (#16796)](https://github.com/apache/airflow/pull/16796): ***@***.***(https://github.com/ron-damon)
   > -  [Add additional dependency for postgres extra for amazon provider (#18737)](https://github.com/apache/airflow/pull/18737): ***@***.***(https://github.com/potiuk)
   > -  [Remove extra postgres dependency from AWS Provider (#18844)](https://github.com/apache/airflow/pull/18844): ***@***.***(https://github.com/mariotaddeucci)
   > -  [Remove duplicated code on S3ToRedshiftOperator (#18671)](https://github.com/apache/airflow/pull/18671): ***@***.***(https://github.com/mariotaddeucci)
   > -  [Enable AWS Secrets Manager backend to retrieve conns using different fields (#18764)](https://github.com/apache/airflow/pull/18764): ***@***.***(https://github.com/JavierLopezT)
   > -  [Enable FTPToS3Operator to transfer several files (#17937)](https://github.com/apache/airflow/pull/17937): ***@***.***(https://github.com/JavierLopezT)
   > -  [Support all Unix wildcards in S3KeySensor (#18211)](https://github.com/apache/airflow/pull/18211): ***@***.***(https://github.com/john-jac)
   > -  [Fixing ses email backend (#18042)](https://github.com/apache/airflow/pull/18042): ***@***.***(https://github.com/ignaski)
   > -  [Fixup string concatenations (#19099)](https://github.com/apache/airflow/pull/19099): ***@***.***(https://github.com/blag)
   > -  [Update S3PrefixSensor to support checking multiple prefixes within a bucket (#18807)](https://github.com/apache/airflow/pull/18807): ***@***.***(https://github.com/anaynayak)
   > -  [Adds an s3 list prefixes operator (#17145)](https://github.com/apache/airflow/pull/17145): ***@***.***(https://github.com/jarfgit)
   > -  [Move validation of templated input params to run after the context init (#19048)](https://github.com/apache/airflow/pull/19048): ***@***.***(https://github.com/eskarimov)
   > -  [ECSOperator: airflow exception on edge case when cloudwatch log stream is not found (#18733)](https://github.com/apache/airflow/pull/18733): ***@***.***(https://github.com/codenamestif)
   > -  [Amazon Athena Example (#18785)](https://github.com/apache/airflow/pull/18785): ***@***.***(https://github.com/john-jac)
   > -  [Amazon SQS Example (#18760)](https://github.com/apache/airflow/pull/18760): ***@***.***(https://github.com/john-jac)
   >
   > Provider [apache.beam: 3.1.0rc1](https://pypi.org/project/apache-airflow-providers-apache-beam/3.1.0rc1)
   >
   > -  [Use google cloud credentials when executing beam commands in subprocesses (#18992)](https://github.com/apache/airflow/pull/18992): ***@***.***(https://github.com/SamWheating)
   >
   > Provider [apache.cassandra: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-apache-cassandra/2.1.0rc1)
   >
   > -  [Adding a default conn ID value for Apache Cassandra sensors (#18620)](https://github.com/apache/airflow/pull/18620): ***@***.***(https://github.com/josh-fell)
   >
   > Provider [apache.hdfs: 2.1.1rc1](https://pypi.org/project/apache-airflow-providers-apache-hdfs/2.1.1rc1)
   >
   > -  [hdfs provider: fix deprecation warning in WebHDFSHook (#18331)](https://github.com/apache/airflow/pull/18331): ***@***.***(https://github.com/Aakcht)
   >
   > Provider [apache.hive: 2.0.3rc1](https://pypi.org/project/apache-airflow-providers-apache-hive/2.0.3rc1)
   >
   > -  [fix get_connections deprecation warn in hivemetastore hook (#18854)](https://github.com/apache/airflow/pull/18854): ***@***.***(https://github.com/Aakcht)
   >
   > Provider [apache.livy: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-apache-livy/2.1.0rc1)
   >
   > -  [Fetching and logging Livy session logs for LivyOperator (#17393)](https://github.com/apache/airflow/pull/17393): ***@***.***(https://github.com/sreenath-kamath)
   >
   > Provider [asana: 1.1.0rc1](https://pypi.org/project/apache-airflow-providers-asana/1.1.0rc1)
   >
   > -  [Use built-in cached_property on Python 3.8 for Asana provider (#17597)](https://github.com/apache/airflow/pull/17597): ***@***.***(https://github.com/kaxil)
   >
   > Provider [cncf.kubernetes: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-cncf-kubernetes/2.1.0rc1)
   >
   > -  [Add more type hints to PodLauncher (#18928)](https://github.com/apache/airflow/pull/18928): ***@***.***(https://github.com/jameslamb)
   > -  [add more information to PodLauncher timeout error (#17953)](https://github.com/apache/airflow/pull/17953): ***@***.***(https://github.com/jameslamb)
   >
   > Provider [databricks: 2.0.2rc1](https://pypi.org/project/apache-airflow-providers-databricks/2.0.2rc1)
   >
   > -  [Move DB call out of DatabricksHook.__init__ (#18339)](https://github.com/apache/airflow/pull/18339): ***@***.***(https://github.com/kaxil)
   >
   > Provider [docker: 2.3.0rc1](https://pypi.org/project/apache-airflow-providers-docker/2.3.0rc1)
   >
   > -  [Add support of placement in the DockerSwarmOperator (#18990)](https://github.com/apache/airflow/pull/18990): ***@***.***(https://github.com/enima2684)
   > -  [Fixup string concatenations (#19099)](https://github.com/apache/airflow/pull/19099): ***@***.***(https://github.com/blag)
   > -  [Remove the docker timeout workaround (#18872)](https://github.com/apache/airflow/pull/18872): ***@***.***(https://github.com/RyanSiu1995)
   > -  [Move docker decorator example dag to docker provider (#18739)](https://github.com/apache/airflow/pull/18739): ***@***.***(https://github.com/ephraimbuddy)
   >
   > Provider [elasticsearch: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-elasticsearch/2.1.0rc1)
   >
   > -  [AIP 39: Documentation (#17552)](https://github.com/apache/airflow/pull/17552): ***@***.***(https://github.com/uranusjr)
   > -  [Adds example showing the ES_hook (#17944)](https://github.com/apache/airflow/pull/17944): ***@***.***(https://github.com/frankcash)
   >
   > Provider [exasol: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-exasol/2.0.1rc1)
   >
   > -  [ExasolHook get_pandas_df does not return pandas dataframe but None (#17850)](https://github.com/apache/airflow/pull/17850): ***@***.***(https://github.com/Goodkat)
   >
   > Provider [facebook: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-facebook/2.1.0rc1)
   >
   > -  [Align the default version with Facebook business SDK (#18883)](https://github.com/apache/airflow/pull/18883): ***@***.***(https://github.com/RyanSiu1995)
   >
   > Provider [google: 6.1.0rc1](https://pypi.org/project/apache-airflow-providers-google/6.1.0rc1)
   >
   > -  [Add value to "namespaceId" of query (#19163)](https://github.com/apache/airflow/pull/19163): ***@***.***(https://github.com/deedmitrij)
   > -  [Add pre-commit hook for common misspelling check in files (#18964)](https://github.com/apache/airflow/pull/18964): ***@***.***(https://github.com/ephraimbuddy)
   > -  [Support query timeout as an argument in CassandraToGCSOperator (#18927)](https://github.com/apache/airflow/pull/18927): ***@***.***(https://github.com/xuan616)
   > -  [Update BigQueryCreateExternalTableOperator doc and parameters (#18676)](https://github.com/apache/airflow/pull/18676): ***@***.***(https://github.com/tnyz)
   > -  [Replacing non-attribute template_fields for BigQueryToMsSqlOperator (#19052)](https://github.com/apache/airflow/pull/19052): ***@***.***(https://github.com/josh-fell)
   > -  [Upgrade the dataproc package to 3.0.0 and migrate from v1beta2 to v1 api (#18879)](https://github.com/apache/airflow/pull/18879): ***@***.***(https://github.com/lwyszomi)
   > -  [Use google cloud credentials when executing beam commands in subprocesses (#18992)](https://github.com/apache/airflow/pull/18992): ***@***.***(https://github.com/SamWheating)
   > -  [Replace default api_version of FacebookAdsReportToGcsOperator (#18996)](https://github.com/apache/airflow/pull/18996): ***@***.***(https://github.com/eladkal)
   > -  [Dataflow Operators - use project and location from job in on_kill method. (#18699)](https://github.com/apache/airflow/pull/18699): ***@***.***(https://github.com/lwyszomi)
   > -  [Fix hard-coded /tmp directory in CloudSQL Hook (#19229)](https://github.com/apache/airflow/pull/19229): ***@***.***(https://github.com/potiuk)
   > -  [Fix bug in Dataflow hook when no jobs are returned (#18981)](https://github.com/apache/airflow/pull/18981): ***@***.***(https://github.com/keze)
   > -  [Fix BigQueryToMsSqlOperator documentation (#18995)](https://github.com/apache/airflow/pull/18995): ***@***.***(https://github.com/potatochip)
   > -  [Move validation of templated input params to run after the context init (#19048)](https://github.com/apache/airflow/pull/19048): ***@***.***(https://github.com/eskarimov)
   > -  [Google provider catch invalid secret name (#18790)](https://github.com/apache/airflow/pull/18790): ***@***.***(https://github.com/raphaelauv)
   >
   > Provider [hashicorp: 2.1.1rc1](https://pypi.org/project/apache-airflow-providers-hashicorp/2.1.1rc1)
   >
   > -  [Fixing Vault AppRole authentication with CONN_URI (#18064)](https://github.com/apache/airflow/pull/18064): ***@***.***(https://github.com/nathadfield)
   >
   > Provider [jdbc: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-jdbc/2.0.1rc1)
   >
   > -  [Fix type annotations in OracleOperator, JdbcOperator, SqliteOperator (#17406)](https://github.com/apache/airflow/pull/17406): ***@***.***(https://github.com/shadrus)
   >
   > Provider [jenkins: 2.0.3rc1](https://pypi.org/project/apache-airflow-providers-jenkins/2.0.3rc1)
   >
   > -  [Remove distutils usages for Python 3.10 (#19064)](https://github.com/apache/airflow/pull/19064): ***@***.***(https://github.com/uranusjr)
   >
   > Provider [microsoft.azure: 3.3.0rc1](https://pypi.org/project/apache-airflow-providers-microsoft-azure/3.3.0rc1)
   >
   > -  [update azure cosmos to latest version (#18695)](https://github.com/apache/airflow/pull/18695): ***@***.***(https://github.com/eladkal)
   > -  [Added sas_token var to BlobServiceClient return. Updated tests (#19234)](https://github.com/apache/airflow/pull/19234): ***@***.***(https://github.com/ReadytoRocc)
   > -  [Add pre-commit hook for common misspelling check in files (#18964)](https://github.com/apache/airflow/pull/18964): ***@***.***(https://github.com/ephraimbuddy)
   > -  [Fix changelog for Azure Provider (#18736)](https://github.com/apache/airflow/pull/18736): ***@***.***(https://github.com/potiuk)
   > -  [Expanding docs on client auth for AzureKeyVaultBackend (#18659)](https://github.com/apache/airflow/pull/18659): ***@***.***(https://github.com/alexbegg)
   > -  [Static start_date and default arg cleanup for Microsoft providers example DAGs (#19062)](https://github.com/apache/airflow/pull/19062): ***@***.***(https://github.com/josh-fell)
   >
   > Provider [microsoft.psrp: 1.0.1rc1](https://pypi.org/project/apache-airflow-providers-microsoft-psrp/1.0.1rc1)
   >
   > -  [Fix unexpected bug in exiting PSRPHook.client context manager (#18014)](https://github.com/apache/airflow/pull/18014): ***@***.***(https://github.com/malthe)
   >
   > Provider [mongo: 2.2.0rc1](https://pypi.org/project/apache-airflow-providers-mongo/2.2.0rc1)
   >
   > -  [#19223 add mongo_db param to MongoSensor (#19276)](https://github.com/apache/airflow/pull/19276): ***@***.***(https://github.com/bhavaniravi)
   >
   > Provider [neo4j: 2.0.2rc1](https://pypi.org/project/apache-airflow-providers-neo4j/2.0.2rc1)
   >
   > -  [fix Neo4jHook to get the query response (#18007)](https://github.com/apache/airflow/pull/18007): ***@***.***(https://github.com/minu7)
   >
   > Provider [openfaas: 2.0.0rc1](https://pypi.org/project/apache-airflow-providers-openfaas/2.0.0rc1)
   >
   > -  [Auto-apply apply_default decorator (#15667)](https://github.com/apache/airflow/pull/15667): ***@***.***(https://github.com/ashb)
   >
   > Provider [pagerduty: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-pagerduty/2.1.0rc1)
   >
   > -  [Add standard hook fields to pagerdutyHook to make hook show up in UI (#18763)](https://github.com/apache/airflow/pull/18763): ***@***.***(https://github.com/GuidoTournois)
   > -  [Make a separate hook for interacting with the Pagerduty Events API (#18784)](https://github.com/apache/airflow/pull/18784): ***@***.***(https://github.com/GuidoTournois)
   >
   > Provider [papermill: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-papermill/2.1.0rc1)
   >
   > -  [Add support for templated fields in PapermillOperator (#18357)](https://github.com/apache/airflow/pull/18357): ***@***.***(https://github.com/eladkal)
   > -  [Fix usage of range(len()) to enumerate (#18174)](https://github.com/apache/airflow/pull/18174): ***@***.***(https://github.com/kaxil)
   >
   > Provider [postgres: 2.3.0rc1](https://pypi.org/project/apache-airflow-providers-postgres/2.3.0rc1)
   >
   > -  [Added upsert method on S3ToRedshift operator (#18027)](https://github.com/apache/airflow/pull/18027): ***@***.***(https://github.com/mariotaddeucci)
   > -  [Fix example dag of PostgresOperator (#18236)](https://github.com/apache/airflow/pull/18236): ***@***.***(https://github.com/eladkal)
   >
   > Provider [salesforce: 3.3.0rc1](https://pypi.org/project/apache-airflow-providers-salesforce/3.3.0rc1)
   >
   > -  [Add SalesforceApexRestOperator (#18819)](https://github.com/apache/airflow/pull/18819): ***@***.***(https://github.com/mariotaddeucci)
   >
   > Provider [samba: 3.0.1rc1](https://pypi.org/project/apache-airflow-providers-samba/3.0.1rc1)
   >
   > -  [Handle leading slash in samba path (#18847)](https://github.com/apache/airflow/pull/18847): ***@***.***(https://github.com/fredthomsen)
   > -  [Open src and dst in binary for samba copy (#18752)](https://github.com/apache/airflow/pull/18752): ***@***.***(https://github.com/fredthomsen)
   >
   > Provider [sftp: 2.2.0rc1](https://pypi.org/project/apache-airflow-providers-sftp/2.2.0rc1)
   >
   > -  [SFTP hook to prefer the SSH paramiko key over the key file path (#18988)](https://github.com/apache/airflow/pull/18988): ***@***.***(https://github.com/30blay)
   >
   > Provider [slack: 4.1.0rc1](https://pypi.org/project/apache-airflow-providers-slack/4.1.0rc1)
   >
   > -  [Restore 'filename' to template_fields of SlackAPIFileOperator (#18466)](https://github.com/apache/airflow/pull/18466): ***@***.***(https://github.com/SayTen)
   >
   > Provider [snowflake: 2.3.0rc1](https://pypi.org/project/apache-airflow-providers-snowflake/2.3.0rc1)
   >
   > -  [Add test_connection method for Snowflake Hook (#19041)](https://github.com/apache/airflow/pull/19041): ***@***.***(https://github.com/msumit)
   > -  [Add region to Snowflake URI. (#18650)](https://github.com/apache/airflow/pull/18650): ***@***.***(https://github.com/dimberman)
   >
   > Provider [sqlite: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-sqlite/2.0.1rc1)
   >
   > -  [Fix sqlite hook - insert and replace functions (#17695)](https://github.com/apache/airflow/pull/17695): ***@***.***(https://github.com/subkanthi)
   >
   > Provider [ssh: 2.3.0rc1](https://pypi.org/project/apache-airflow-providers-ssh/2.3.0rc1)
   >
   > -  [Refactor SSHOperator so a subclass can run many commands (#10874) (#17378)](https://github.com/apache/airflow/pull/17378): ***@***.***(https://github.com/baolsen)
   > -  [update sshtunnel version (#18684)](https://github.com/apache/airflow/pull/18684): ***@***.***(https://github.com/eladkal)
   > -  [Correctly handle get_pty attribute if command passed as XComArg or template (#19323)](https://github.com/apache/airflow/pull/19323): ***@***.***(https://github.com/josh-fell)
   >
   > Provider [tableau: 2.1.2rc1](https://pypi.org/project/apache-airflow-providers-tableau/2.1.2rc1)
   >
   > -  [Remove distutils usages for Python 3.10 (#19064)](https://github.com/apache/airflow/pull/19064): ***@***.***(https://github.com/uranusjr)
   >
   > Provider [trino: 2.0.2rc1](https://pypi.org/project/apache-airflow-providers-trino/2.0.2rc1)
   >
   > -  [Properly handle verify parameter in TrinoHook (#18791)](https://github.com/apache/airflow/pull/18791): @danarwix
   >
   > Provider [yandex: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-yandex/2.1.0rc1)
   >
   > -  [Add autoscaling subcluster support and remove defaults (#17033)](https://github.com/apache/airflow/pull/17033): @peter-volkov
   >
   > Providers that do not need testing
   >
   > Those are providers that were either doc-only or had changes that do not require testing.
   >
   > - Provider [airbyte: 2.1.1rc1](https://pypi.org/project/apache-airflow-providers-airbyte/2.1.1rc1)
   > - Provider [alibaba: 1.0.0rc1](https://pypi.org/project/apache-airflow-providers-alibaba/1.0.0rc1)
   > - Provider [apache.drill: 1.0.1rc1](https://pypi.org/project/apache-airflow-providers-apache-drill/1.0.1rc1)
   > - Provider [apache.druid: 2.0.2rc1](https://pypi.org/project/apache-airflow-providers-apache-druid/2.0.2rc1)
   > - Provider [apache.kylin: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-apache-kylin/2.0.1rc1)
   > - Provider [apache.pig: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-apache-pig/2.0.1rc1)
   > - Provider [apache.pinot: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-apache-pinot/2.0.1rc1)
   > - Provider [apache.spark: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-apache-spark/2.0.1rc1)
   > - Provider [apache.sqoop: 2.0.2rc1](https://pypi.org/project/apache-airflow-providers-apache-sqoop/2.0.2rc1)
   > - Provider [celery: 2.1.0rc1](https://pypi.org/project/apache-airflow-providers-celery/2.1.0rc1)
   > - Provider [cloudant: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-cloudant/2.0.1rc1)
   > - Provider [datadog: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-datadog/2.0.1rc1)
   > - Provider [dingding: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-dingding/2.0.1rc1)
   > - Provider [discord: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-discord/2.0.1rc1)
   > - Provider [ftp: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-ftp/2.0.1rc1)
   > - Provider [grpc: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-grpc/2.0.1rc1)
   > - Provider [http: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-http/2.0.1rc1)
   > - Provider [imap: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-imap/2.0.1rc1)
   > - Provider [influxdb: 1.0.0rc1](https://pypi.org/project/apache-airflow-providers-influxdb/1.0.0rc1)
   > - Provider [jira: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-jira/2.0.1rc1)
   > - Provider [microsoft.mssql: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-microsoft-mssql/2.0.1rc1)
   > - Provider [microsoft.winrm: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-microsoft-winrm/2.0.1rc1)
   > - Provider [mysql: 2.1.1rc1](https://pypi.org/project/apache-airflow-providers-mysql/2.1.1rc1)
   > - Provider [odbc: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-odbc/2.0.1rc1)
   > - Provider [opsgenie: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-opsgenie/2.0.1rc1)
   > - Provider [oracle: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-oracle/2.0.1rc1)
   > - Provider [plexus: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-plexus/2.0.1rc1)
   > - Provider [presto: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-presto/2.0.1rc1)
   > - Provider [qubole: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-qubole/2.0.1rc1)
   > - Provider [redis: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-redis/2.0.1rc1)
   > - Provider [segment: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-segment/2.0.1rc1)
   > - Provider [sendgrid: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-sendgrid/2.0.1rc1)
   > - Provider [singularity: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-singularity/2.0.1rc1)
   > - Provider [telegram: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-telegram/2.0.1rc1)
   > - Provider [vertica: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-vertica/2.0.1rc1)
   > - Provider [zendesk: 2.0.1rc1](https://pypi.org/project/apache-airflow-providers-zendesk/2.0.1rc1)
   >
   > Thanks to all who contributed to those provider's release
   >
   > ***@***.***(https://github.com/sreenath-kamath) ***@***.***(https://github.com/jarfgit) ***@***.***(https://github.com/frankcash) ***@***.***(https://github.com/deedmitrij) ***@***.***(https://github.com/enima2684) ***@***.***(https://github.com/uranusjr) @peter-volkov ***@***.***(https://github.com/mariotaddeucci) ***@***.***(https://github.com/potatochip) ***@***.***(https://github.com/john-jac) ***@***.***(https://github.com/malthe) ***@***.***(https://github.com/msumit) ***@***.***(https://github.com/dimberman) ***@***.***(https://github.com/jameslamb) ***@***.***(https://github.com/Brooke-white) ***@***.***(https://github.com/codenamestif) ***@***.***(https://github.com/GuidoTournois) ***@***.***(https://github.com/minu7) ***@***.***(https://github.com/ashb) ***@***.***(https://github.com/shadrus) ***@***.***(https://github.com/ignaski) ***@***.***(https://github.com/ferruzzi) ***@***.***(https://github.com/eladkal) ***@***.***(https://github.com/ephraimbuddy) ***@***.***(h
 ttps://github.com/eskarimov) ***@***.***(https://github.com/JavierLopezT) ***@***.***(https://github.com/keze) ***@***.***(https://github.com/josh-fell) ***@***.***(https://github.com/anaynayak) ***@***.***(https://github.com/raphaelauv) ***@***.***(https://github.com/blag) ***@***.***(https://github.com/Aakcht) ***@***.***(https://github.com/guotongfei) ***@***.***(https://github.com/SamWheating) ***@***.***(https://github.com/potiuk) ***@***.***(https://github.com/ron-damon) @danarwix
   > ***@***.***(https://github.com/subkanthi) ***@***.***(https://github.com/alexbegg) ***@***.***(https://github.com/bhavaniravi) ***@***.***(https://github.com/tnyz) ***@***.***(https://github.com/Goodkat) ***@***.***(https://github.com/fredthomsen) ***@***.***(https://github.com/SayTen) ***@***.***(https://github.com/kaxil) ***@***.***(https://github.com/lwyszomi) ***@***.***(https://github.com/ReadytoRocc) ***@***.***(https://github.com/baolsen) ***@***.***(https://github.com/30blay) ***@***.***(https://github.com/nathadfield) ***@***.***(https://github.com/xuan616) ***@***.***(https://github.com/RyanSiu1995)
   >
   > Committer
   >
   > -  I acknowledge that I am a maintainer/committer of the Apache Airflow project.
   >
   > —
   > You are receiving this because you were mentioned.
   > Reply to this email directly, [view it on GitHub](https://github.com/apache/airflow/issues/19328), or [unsubscribe](https://github.com/notifications/unsubscribe-auth/AAGW3QC7BCJJ3AEDYHQ4UATUJQAXLANCNFSM5HBDLQLQ).


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org