blob: b34e8a88a44b3227edb2b10a664919739d07eec2 [file] [log] [blame]
# -*- coding: utf-8 -*-
#
# Licensed to the Apache Software Foundation (ASF) under one
# or more contributor license agreements. See the NOTICE file
# distributed with this work for additional information
# regarding copyright ownership. The ASF licenses this file
# to you under the Apache License, Version 2.0 (the
# "License"); you may not use this file except in compliance
# with the License. You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing,
# software distributed under the License is distributed on an
# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
# KIND, either express or implied. See the License for the
# specific language governing permissions and limitations
# under the License.
import importlib
from inspect import isabstract
from typing import Any
from unittest import TestCase, mock
from parameterized import parameterized
HOOK = [
(
"airflow.gcp.hooks.compute.ComputeEngineHook",
"airflow.contrib.hooks.gcp_compute_hook.GceHook",
),
(
"airflow.gcp.hooks.base.CloudBaseHook",
"airflow.contrib.hooks.gcp_api_base_hook.GoogleCloudBaseHook",
),
(
"airflow.gcp.hooks.dataflow.DataflowHook",
"airflow.contrib.hooks.gcp_dataflow_hook.DataFlowHook",
),
(
"airflow.providers.google.cloud.hooks.dataproc.DataprocHook",
"airflow.contrib.hooks.gcp_dataproc_hook.DataProcHook",
),
(
"airflow.gcp.hooks.dlp.CloudDLPHook",
"airflow.contrib.hooks.gcp_dlp_hook.CloudDLPHook",
),
(
"airflow.gcp.hooks.functions.CloudFunctionsHook",
"airflow.contrib.hooks.gcp_function_hook.GcfHook",
),
(
"airflow.gcp.hooks.kms.CloudKMSHook",
"airflow.contrib.hooks.gcp_kms_hook.GoogleCloudKMSHook",
),
(
"airflow.gcp.hooks.mlengine.MLEngineHook",
"airflow.contrib.hooks.gcp_mlengine_hook.MLEngineHook",
),
(
"airflow.gcp.hooks.spanner.SpannerHook",
"airflow.contrib.hooks.gcp_spanner_hook.CloudSpannerHook",
),
(
"airflow.gcp.hooks.speech_to_text.CloudSpeechToTextHook",
"airflow.contrib.hooks.gcp_speech_to_text_hook.GCPSpeechToTextHook",
),
(
"airflow.gcp.hooks.text_to_speech.CloudTextToSpeechHook",
"airflow.contrib.hooks.gcp_text_to_speech_hook.GCPTextToSpeechHook",
),
(
"airflow.gcp.hooks.gcs.GCSHook",
"airflow.contrib.hooks.gcs_hook.GoogleCloudStorageHook",
),
(
"airflow.gcp.hooks.cloud_build.CloudBuildHook",
"airflow.contrib.hooks.gcp_cloud_build_hook.CloudBuildHook",
),
(
"airflow.gcp.hooks.bigtable.BigtableHook",
"airflow.contrib.hooks.gcp_bigtable_hook.BigtableHook",
),
(
"airflow.gcp.hooks.kubernetes_engine.GKEHook",
"airflow.contrib.hooks.gcp_container_hook.GKEClusterHook",
),
(
"airflow.gcp.hooks.datastore.DatastoreHook",
"airflow.contrib.hooks.datastore_hook.DatastoreHook",
),
(
"airflow.providers.google.cloud.hooks.natural_language.CloudNaturalLanguageHook",
"airflow.contrib.hooks.gcp_natural_language_hook.CloudNaturalLanguageHook",
),
(
"airflow.providers.google.cloud.hooks.pubsub.PubSubHook",
"airflow.contrib.hooks.gcp_pubsub_hook.PubSubHook",
),
(
"airflow.gcp.hooks.cloud_sql.CloudSQLHook",
"airflow.contrib.hooks.gcp_sql_hook.CloudSqlHook",
),
(
"airflow.gcp.hooks.cloud_sql.CloudSQLDatabaseHook",
"airflow.contrib.hooks.gcp_sql_hook.CloudSqlDatabaseHook",
),
(
"airflow.gcp.hooks.tasks.CloudTasksHook",
"airflow.contrib.hooks.gcp_tasks_hook.CloudTasksHook",
),
(
"airflow.gcp.hooks.cloud_storage_transfer_service.CloudDataTransferServiceHook",
"airflow.contrib.hooks.gcp_transfer_hook.GCPTransferServiceHook",
),
(
"airflow.gcp.hooks.translate.CloudTranslateHook",
"airflow.contrib.hooks.gcp_translate_hook.CloudTranslateHook",
),
(
"airflow.gcp.hooks.video_intelligence.CloudVideoIntelligenceHook",
"airflow.contrib.hooks.gcp_video_intelligence_hook.CloudVideoIntelligenceHook",
),
(
"airflow.providers.google.cloud.hooks.vision.CloudVisionHook",
"airflow.contrib.hooks.gcp_vision_hook.CloudVisionHook",
),
(
"airflow.gcp.hooks.bigquery.BigQueryHook",
"airflow.contrib.hooks.bigquery_hook.BigQueryHook",
),
(
"airflow.providers.amazon.aws.hooks.athena.AWSAthenaHook",
"airflow.contrib.hooks.aws_athena_hook.AWSAthenaHook",
),
(
"airflow.providers.amazon.aws.hooks.datasync.AWSDataSyncHook",
"airflow.contrib.hooks.aws_datasync_hook.AWSDataSyncHook",
),
(
"airflow.providers.amazon.aws.hooks.s3.S3Hook",
"airflow.hooks.S3_hook.S3Hook",
),
(
"airflow.providers.amazon.aws.hooks.sqs.SQSHook",
"airflow.contrib.hooks.aws_sqs_hook.SQSHook",
),
(
"airflow.providers.amazon.aws.hooks.lambda_function.AwsLambdaHook",
"airflow.contrib.hooks.aws_lambda_hook.AwsLambdaHook",
),
(
"airflow.providers.amazon.aws.hooks.sns.AwsSnsHook",
"airflow.contrib.hooks.aws_sns_hook.AwsSnsHook",
),
(
'airflow.providers.apache.pinot.hooks.pinot.PinotDbApiHook',
'airflow.contrib.hooks.pinot_hook.PinotDbApiHook',
),
(
'airflow.providers.apache.pinot.hooks.pinot.PinotAdminHook',
'airflow.contrib.hooks.pinot_hook.PinotAdminHook',
),
(
'airflow.providers.apache.spark.hooks.spark_jdbc.SparkJDBCHook',
'airflow.contrib.hooks.spark_jdbc_hook.SparkJDBCHook',
),
(
'airflow.providers.apache.spark.hooks.spark_sql.SparkSqlHook',
'airflow.contrib.hooks.spark_sql_hook.SparkSqlHook',
),
(
'airflow.providers.apache.spark.hooks.spark_submit.SparkSubmitHook',
'airflow.contrib.hooks.spark_submit_hook.SparkSubmitHook',
),
(
'airflow.providers.apache.sqoop.hooks.sqoop.SqoopHook',
'airflow.contrib.hooks.sqoop_hook.SqoopHook',
),
(
'airflow.providers.apache.druid.hooks.druid.DruidHook',
'airflow.hooks.druid_hook.DruidHook',
),
(
'airflow.providers.apache.druid.hooks.druid.DruidDbApiHook',
'airflow.hooks.druid_hook.DruidDbApiHook',
),
(
'airflow.providers.apache.hdfs.hooks.hdfs.HDFSHookException',
'airflow.hooks.hdfs_hook.HDFSHookException',
),
(
'airflow.providers.apache.hdfs.hooks.hdfs.HDFSHook',
'airflow.hooks.hdfs_hook.HDFSHook',
),
(
'airflow.providers.apache.hive.hooks.hive.HiveMetastoreHook',
'airflow.hooks.hive_hooks.HiveMetastoreHook',
),
(
'airflow.providers.apache.hive.hooks.hive.HiveCliHook',
'airflow.hooks.hive_hooks.HiveCliHook',
),
(
'airflow.providers.apache.hive.hooks.hive.HiveServer2Hook',
'airflow.hooks.hive_hooks.HiveServer2Hook',
),
(
'airflow.providers.apache.pig.hooks.pig.PigCliHook',
'airflow.hooks.pig_hook.PigCliHook',
),
(
'airflow.providers.apache.hdfs.hooks.webhdfs.WebHDFSHook',
'airflow.hooks.webhdfs_hook.WebHDFSHook',
),
(
'airflow.hooks.filesystem.FSHook',
'airflow.contrib.hooks.fs_hook.FSHook',
),
(
'airflow.providers.microsoft.azure.hooks.azure_container_instance.AzureContainerInstanceHook',
'airflow.contrib.hooks.azure_container_instance_hook.AzureContainerInstanceHook',
),
(
'airflow.providers.microsoft.azure.hooks.azure_container_registry.AzureContainerRegistryHook',
'airflow.contrib.hooks.azure_container_registry_hook.AzureContainerRegistryHook',
),
(
'airflow.providers.microsoft.azure.hooks.azure_container_volume.AzureContainerVolumeHook',
'airflow.contrib.hooks.azure_container_volume_hook.AzureContainerVolumeHook',
),
(
'airflow.providers.microsoft.azure.hooks.azure_cosmos.AzureCosmosDBHook',
'airflow.contrib.hooks.azure_cosmos_hook.AzureCosmosDBHook',
),
(
'airflow.providers.microsoft.azure.hooks.azure_fileshare.AzureFileShareHook',
'airflow.contrib.hooks.azure_fileshare_hook.AzureFileShareHook',
),
(
'airflow.providers.microsoft.azure.hooks.wasb.WasbHook',
'airflow.contrib.hooks.wasb_hook.WasbHook',
),
(
'airflow.providers.amazon.aws.hooks.glue_catalog.AwsGlueCatalogHook',
'airflow.contrib.hooks.aws_glue_catalog_hook.AwsGlueCatalogHook',
),
(
'airflow.providers.amazon.aws.hooks.logs.AwsLogsHook',
'airflow.contrib.hooks.aws_logs_hook.AwsLogsHook',
),
(
'airflow.providers.amazon.aws.hooks.emr.EmrHook',
'airflow.contrib.hooks.emr_hook.EmrHook',
),
(
'airflow.providers.amazon.aws.hooks.sagemaker.SageMakerHook',
'airflow.contrib.hooks.sagemaker_hook.SageMakerHook',
),
(
'airflow.providers.mongo.hooks.mongo.MongoHook',
'airflow.contrib.hooks.mongo_hook.MongoHook',
),
(
'airflow.providers.openfass.hooks.openfaas.OpenFaasHook',
'airflow.contrib.hooks.openfaas_hook.OpenFaasHook',
),
(
'airflow.providers.redis.hooks.redis.RedisHook',
'airflow.contrib.hooks.redis_hook.RedisHook',
),
(
'airflow.providers.docker.hooks.docker.DockerHook',
'airflow.hooks.docker_hook.DockerHook',
),
(
'airflow.providers.microsoft.mssql.hooks.mssql.MsSqlHook',
'airflow.hooks.mssql_hook.MsSqlHook',
),
(
'airflow.providers.mysql.hooks.mysql.MySqlHook',
'airflow.hooks.mysql_hook.MySqlHook',
),
(
'airflow.providers.oracle.hooks.oracle.OracleHook',
'airflow.hooks.oracle_hook.OracleHook',
),
(
'airflow.providers.postgres.hooks.postgres.PostgresHook',
'airflow.hooks.postgres_hook.PostgresHook',
),
(
'airflow.providers.presto.hooks.presto.PrestoHook',
'airflow.hooks.presto_hook.PrestoHook',
),
(
'airflow.providers.samba.hooks.samba.SambaHook',
'airflow.hooks.samba_hook.SambaHook',
),
(
'airflow.providers.sqlite.hooks.sqlite.SqliteHook',
'airflow.hooks.sqlite_hook.SqliteHook',
),
]
OPERATOR = [
(
"airflow.operators.adls_to_gcs.ADLSToGCSOperator",
"airflow.contrib.operators.adls_to_gcs.AdlsToGoogleCloudStorageOperator",
),
(
"airflow.gcp.operators.dataflow.DataflowCreateJavaJobOperator",
"airflow.contrib.operators.dataflow_operator.DataFlowJavaOperator",
),
(
"airflow.gcp.operators.dataflow.DataflowCreatePythonJobOperator",
"airflow.contrib.operators.dataflow_operator.DataFlowPythonOperator",
),
(
"airflow.gcp.operators.dataflow.DataflowTemplatedJobStartOperator",
"airflow.contrib.operators.dataflow_operator.DataflowTemplateOperator",
),
(
"airflow.gcp.operators.datastore.CloudDatastoreExportEntitiesOperator",
"airflow.contrib.operators.datastore_export_operator.DatastoreExportOperator",
),
(
"airflow.gcp.operators.datastore.CloudDatastoreImportEntitiesOperator",
"airflow.contrib.operators.datastore_import_operator.DatastoreImportOperator",
),
(
"airflow.operators.local_to_gcs.LocalFilesystemToGCSOperator",
"airflow.contrib.operators.file_to_gcs.FileToGoogleCloudStorageOperator",
),
(
"airflow.gcp.operators.bigtable.BigtableUpdateClusterOperator",
"airflow.contrib.operators.gcp_bigtable_operator.BigtableClusterUpdateOperator",
),
(
"airflow.gcp.operators.bigtable.BigtableCreateInstanceOperator",
"airflow.contrib.operators.gcp_bigtable_operator.BigtableInstanceCreateOperator",
),
(
"airflow.gcp.operators.bigtable.BigtableDeleteInstanceOperator",
"airflow.contrib.operators.gcp_bigtable_operator.BigtableInstanceDeleteOperator",
),
(
"airflow.gcp.operators.bigtable.BigtableCreateTableOperator",
"airflow.contrib.operators.gcp_bigtable_operator.BigtableTableCreateOperator",
),
(
"airflow.gcp.operators.bigtable.BigtableDeleteTableOperator",
"airflow.contrib.operators.gcp_bigtable_operator.BigtableTableDeleteOperator",
),
(
"airflow.gcp.operators.cloud_build.CloudBuildCreateOperator",
"airflow.contrib.operators.gcp_cloud_build_operator.CloudBuildCreateBuildOperator",
),
(
"airflow.gcp.operators.compute.ComputeEngineBaseOperator",
"airflow.contrib.operators.gcp_compute_operator.GceBaseOperator",
),
(
"airflow.gcp.operators.compute.ComputeEngineInstanceGroupUpdateManagerTemplateOperator",
"airflow.contrib.operators.gcp_compute_operator."
"GceInstanceGroupManagerUpdateTemplateOperator",
),
(
"airflow.gcp.operators.compute.ComputeEngineStartInstanceOperator",
"airflow.contrib.operators.gcp_compute_operator.GceInstanceStartOperator",
),
(
"airflow.gcp.operators.compute.ComputeEngineStopInstanceOperator",
"airflow.contrib.operators.gcp_compute_operator.GceInstanceStopOperator",
),
(
"airflow.gcp.operators.compute.ComputeEngineCopyInstanceTemplateOperator",
"airflow.contrib.operators.gcp_compute_operator.GceInstanceTemplateCopyOperator",
),
(
"airflow.gcp.operators.compute.ComputeEngineSetMachineTypeOperator",
"airflow.contrib.operators.gcp_compute_operator.GceSetMachineTypeOperator",
),
(
"airflow.gcp.operators.kubernetes_engine.GKECreateClusterOperator",
"airflow.contrib.operators.gcp_container_operator.GKEClusterCreateOperator",
),
(
"airflow.gcp.operators.kubernetes_engine.GKEDeleteClusterOperator",
"airflow.contrib.operators.gcp_container_operator.GKEClusterDeleteOperator",
),
(
"airflow.gcp.operators.kubernetes_engine.GKEStartPodOperator",
"airflow.contrib.operators.gcp_container_operator.GKEPodOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPCancelDLPJobOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPCancelDLPJobOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPCreateDeidentifyTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPCreateDeidentifyTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPCreateDLPJobOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPCreateDLPJobOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPCreateInspectTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPCreateInspectTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPCreateJobTriggerOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPCreateJobTriggerOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPCreateStoredInfoTypeOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPCreateStoredInfoTypeOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPDeidentifyContentOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPDeidentifyContentOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPDeleteDeidentifyTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPDeleteDeidentifyTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPDeleteDLPJobOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPDeleteDlpJobOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPDeleteInspectTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPDeleteInspectTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPDeleteJobTriggerOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPDeleteJobTriggerOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPDeleteStoredInfoTypeOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPDeleteStoredInfoTypeOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPGetDeidentifyTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPGetDeidentifyTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPGetDLPJobOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPGetDlpJobOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPGetInspectTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPGetInspectTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPGetDLPJobTriggerOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPGetJobTripperOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPGetStoredInfoTypeOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPGetStoredInfoTypeOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPInspectContentOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPInspectContentOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPListDeidentifyTemplatesOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPListDeidentifyTemplatesOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPListDLPJobsOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPListDlpJobsOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPListInfoTypesOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPListInfoTypesOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPListInspectTemplatesOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPListInspectTemplatesOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPListJobTriggersOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPListJobTriggersOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPListStoredInfoTypesOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPListStoredInfoTypesOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPRedactImageOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPRedactImageOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPReidentifyContentOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPReidentifyContentOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPUpdateDeidentifyTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPUpdateDeidentifyTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPUpdateInspectTemplateOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPUpdateInspectTemplateOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPUpdateJobTriggerOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPUpdateJobTriggerOperator",
),
(
"airflow.gcp.operators.dlp.CloudDLPUpdateStoredInfoTypeOperator",
"airflow.contrib.operators.gcp_dlp_operator.CloudDLPUpdateStoredInfoTypeOperator",
),
(
"airflow.gcp.operators.functions.CloudFunctionDeleteFunctionOperator",
"airflow.contrib.operators.gcp_function_operator.GcfFunctionDeleteOperator",
),
(
"airflow.gcp.operators.functions.CloudFunctionDeployFunctionOperator",
"airflow.contrib.operators.gcp_function_operator.GcfFunctionDeployOperator",
),
(
"airflow.providers.google.cloud.operators.natural_language."
"CloudNaturalLanguageAnalyzeEntitiesOperator",
"airflow.contrib.operators.gcp_natural_language_operator."
"CloudLanguageAnalyzeEntitiesOperator",
),
(
"airflow.providers.google.cloud.operators.natural_language."
"CloudNaturalLanguageAnalyzeEntitySentimentOperator",
"airflow.contrib.operators.gcp_natural_language_operator."
"CloudLanguageAnalyzeEntitySentimentOperator",
),
(
"airflow.providers.google.cloud.operators.natural_language."
"CloudNaturalLanguageAnalyzeSentimentOperator",
"airflow.contrib.operators.gcp_natural_language_operator."
"CloudLanguageAnalyzeSentimentOperator",
),
(
"airflow.providers.google.cloud.operators.natural_language."
"CloudNaturalLanguageClassifyTextOperator",
"airflow.contrib.operators.gcp_natural_language_operator.CloudLanguageClassifyTextOperator",
),
(
"airflow.gcp.operators.spanner.SpannerDeleteDatabaseInstanceOperator",
"airflow.contrib.operators.gcp_spanner_operator.CloudSpannerInstanceDatabaseDeleteOperator",
),
(
"airflow.gcp.operators.spanner.SpannerDeployDatabaseInstanceOperator",
"airflow.contrib.operators.gcp_spanner_operator.CloudSpannerInstanceDatabaseDeployOperator",
),
(
"airflow.gcp.operators.spanner.SpannerQueryDatabaseInstanceOperator",
"airflow.contrib.operators.gcp_spanner_operator.CloudSpannerInstanceDatabaseQueryOperator",
),
(
"airflow.gcp.operators.spanner.SpannerUpdateDatabaseInstanceOperator",
"airflow.contrib.operators.gcp_spanner_operator.CloudSpannerInstanceDatabaseUpdateOperator",
),
(
"airflow.gcp.operators.spanner.SpannerDeleteInstanceOperator",
"airflow.contrib.operators.gcp_spanner_operator.CloudSpannerInstanceDeleteOperator",
),
(
"airflow.gcp.operators.spanner.SpannerDeployInstanceOperator",
"airflow.contrib.operators.gcp_spanner_operator.CloudSpannerInstanceDeployOperator",
),
(
"airflow.gcp.operators.speech_to_text.CloudSpeechToTextRecognizeSpeechOperator",
"airflow.contrib.operators.gcp_speech_to_text_operator.GcpSpeechToTextRecognizeSpeechOperator",
),
(
"airflow.gcp.operators.text_to_speech.CloudTextToSpeechSynthesizeOperator",
"airflow.contrib.operators.gcp_text_to_speech_operator.GcpTextToSpeechSynthesizeOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service.CloudDataTransferServiceCreateJobOperator",
"airflow.contrib.operators.gcp_transfer_operator.GcpTransferServiceJobCreateOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service.CloudDataTransferServiceDeleteJobOperator",
"airflow.contrib.operators.gcp_transfer_operator.GcpTransferServiceJobDeleteOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service.CloudDataTransferServiceUpdateJobOperator",
"airflow.contrib.operators.gcp_transfer_operator.GcpTransferServiceJobUpdateOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service."
"CloudDataTransferServiceCancelOperationOperator",
"airflow.contrib.operators.gcp_transfer_operator."
"GcpTransferServiceOperationCancelOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service."
"CloudDataTransferServiceGetOperationOperator",
"airflow.contrib.operators.gcp_transfer_operator."
"GcpTransferServiceOperationGetOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service."
"CloudDataTransferServicePauseOperationOperator",
"airflow.contrib.operators.gcp_transfer_operator."
"GcpTransferServiceOperationPauseOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service."
"CloudDataTransferServiceResumeOperationOperator",
"airflow.contrib.operators.gcp_transfer_operator."
"GcpTransferServiceOperationResumeOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service."
"CloudDataTransferServiceListOperationsOperator",
"airflow.contrib.operators.gcp_transfer_operator."
"GcpTransferServiceOperationsListOperator",
),
(
"airflow.gcp.operators.cloud_storage_transfer_service."
"CloudDataTransferServiceGCSToGCSOperator",
"airflow.contrib.operators.gcp_transfer_operator."
"GoogleCloudStorageToGoogleCloudStorageTransferOperator",
),
(
"airflow.gcp.operators.translate.CloudTranslateTextOperator",
"airflow.contrib.operators.gcp_translate_operator.CloudTranslateTextOperator",
),
(
"airflow.gcp.operators.translate_speech.GcpTranslateSpeechOperator",
"airflow.contrib.operators.gcp_translate_speech_operator.GcpTranslateSpeechOperator",
),
(
"airflow.gcp.operators.video_intelligence."
"CloudVideoIntelligenceDetectVideoExplicitContentOperator",
"airflow.contrib.operators.gcp_video_intelligence_operator."
"CloudVideoIntelligenceDetectVideoExplicitContentOperator",
),
(
"airflow.gcp.operators.video_intelligence."
"CloudVideoIntelligenceDetectVideoLabelsOperator",
"airflow.contrib.operators.gcp_video_intelligence_operator."
"CloudVideoIntelligenceDetectVideoLabelsOperator",
),
(
"airflow.gcp.operators.video_intelligence."
"CloudVideoIntelligenceDetectVideoShotsOperator",
"airflow.contrib.operators.gcp_video_intelligence_operator."
"CloudVideoIntelligenceDetectVideoShotsOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionAddProductToProductSetOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionAddProductToProductSetOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionImageAnnotateOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionAnnotateImageOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionTextDetectOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionDetectDocumentTextOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionDetectImageLabelsOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionDetectImageLabelsOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionDetectImageSafeSearchOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionDetectImageSafeSearchOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionDetectTextOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionDetectTextOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionCreateProductOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductCreateOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionDeleteProductOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductDeleteOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionGetProductOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductGetOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionCreateProductSetOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductSetCreateOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionDeleteProductSetOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductSetDeleteOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionGetProductSetOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductSetGetOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionUpdateProductSetOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductSetUpdateOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionUpdateProductOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionProductUpdateOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionCreateReferenceImageOperator",
"airflow.contrib.operators.gcp_vision_operator.CloudVisionReferenceImageCreateOperator",
),
(
"airflow.providers.google.cloud.operators.vision.CloudVisionRemoveProductFromProductSetOperator",
"airflow.contrib.operators.gcp_vision_operator."
"CloudVisionRemoveProductFromProductSetOperator",
),
(
"airflow.operators.gcs_to_bq.GCSToBigQueryOperator",
"airflow.contrib.operators.gcs_to_bq.GoogleCloudStorageToBigQueryOperator",
),
(
"airflow.operators.gcs_to_gcs.GCSToGCSOperator",
"airflow.contrib.operators.gcs_to_gcs.GoogleCloudStorageToGoogleCloudStorageOperator",
),
(
"airflow.operators.gcs_to_s3.GCSToS3Operator",
"airflow.contrib.operators.gcs_to_s3.GoogleCloudStorageToS3Operator",
),
(
"airflow.gcp.operators.mlengine.MLEngineStartBatchPredictionJobOperator",
"airflow.contrib.operators.mlengine_operator.MLEngineBatchPredictionOperator",
),
(
"airflow.gcp.operators.mlengine.MLEngineManageModelOperator",
"airflow.contrib.operators.mlengine_operator.MLEngineModelOperator",
),
(
"airflow.gcp.operators.mlengine.MLEngineStartTrainingJobOperator",
"airflow.contrib.operators.mlengine_operator.MLEngineTrainingOperator",
),
(
"airflow.gcp.operators.mlengine.MLEngineManageVersionOperator",
"airflow.contrib.operators.mlengine_operator.MLEngineVersionOperator",
),
(
"airflow.operators.mssql_to_gcs.MSSQLToGCSOperator",
"airflow.contrib.operators.mssql_to_gcs.MsSqlToGoogleCloudStorageOperator",
),
(
"airflow.operators.mysql_to_gcs.MySQLToGCSOperator",
"airflow.contrib.operators.mysql_to_gcs.MySqlToGoogleCloudStorageOperator",
),
(
"airflow.operators.postgres_to_gcs.PostgresToGCSOperator",
"airflow.contrib.operators.postgres_to_gcs_operator."
"PostgresToGoogleCloudStorageOperator",
),
(
"airflow.providers.google.cloud.operators.pubsub.PubSubPublishMessageOperator",
"airflow.contrib.operators.pubsub_operator.PubSubPublishOperator",
),
(
"airflow.providers.google.cloud.operators.pubsub.PubSubCreateSubscriptionOperator",
"airflow.contrib.operators.pubsub_operator.PubSubSubscriptionCreateOperator",
),
(
"airflow.providers.google.cloud.operators.pubsub.PubSubDeleteSubscriptionOperator",
"airflow.contrib.operators.pubsub_operator.PubSubSubscriptionDeleteOperator",
),
(
"airflow.providers.google.cloud.operators.pubsub.PubSubCreateTopicOperator",
"airflow.contrib.operators.pubsub_operator.PubSubTopicCreateOperator",
),
(
"airflow.providers.google.cloud.operators.pubsub.PubSubDeleteTopicOperator",
"airflow.contrib.operators.pubsub_operator.PubSubTopicDeleteOperator",
),
(
"airflow.operators.sql_to_gcs.BaseSQLToGCSOperator",
"airflow.contrib.operators.sql_to_gcs.BaseSQLToGoogleCloudStorageOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocCreateClusterOperator",
"airflow.contrib.operators.dataproc_operator.DataprocClusterCreateOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocDeleteClusterOperator",
"airflow.contrib.operators.dataproc_operator.DataprocClusterDeleteOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocScaleClusterOperator",
"airflow.contrib.operators.dataproc_operator.DataprocClusterScaleOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocSubmitHadoopJobOperator",
"airflow.contrib.operators.dataproc_operator.DataProcHadoopOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocSubmitHiveJobOperator",
"airflow.contrib.operators.dataproc_operator.DataProcHiveOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocJobBaseOperator",
"airflow.contrib.operators.dataproc_operator.DataProcJobBaseOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocSubmitPigJobOperator",
"airflow.contrib.operators.dataproc_operator.DataProcPigOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocSubmitPySparkJobOperator",
"airflow.contrib.operators.dataproc_operator.DataProcPySparkOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocSubmitSparkJobOperator",
"airflow.contrib.operators.dataproc_operator.DataProcSparkOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocSubmitSparkSqlJobOperator",
"airflow.contrib.operators.dataproc_operator.DataProcSparkSqlOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocInstantiateInlineWorkflowTemplateOperator",
"airflow.contrib.operators.dataproc_operator."
"DataprocWorkflowTemplateInstantiateInlineOperator",
),
(
"airflow.providers.google.cloud."
"operators.dataproc.DataprocInstantiateWorkflowTemplateOperator",
"airflow.contrib.operators.dataproc_operator."
"DataprocWorkflowTemplateInstantiateOperator",
),
(
"airflow.gcp.operators.bigquery.BigQueryCheckOperator",
"airflow.contrib.operators.bigquery_check_operator.BigQueryCheckOperator",
),
(
"airflow.gcp.operators.bigquery.BigQueryIntervalCheckOperator",
"airflow.contrib.operators.bigquery_check_operator.BigQueryIntervalCheckOperator",
),
(
"airflow.gcp.operators.bigquery.BigQueryValueCheckOperator",
"airflow.contrib.operators.bigquery_check_operator.BigQueryValueCheckOperator",
),
(
"airflow.gcp.operators.bigquery.BigQueryGetDataOperator",
"airflow.contrib.operators.bigquery_get_data.BigQueryGetDataOperator",
),
(
"airflow.gcp.operators.bigquery.BigQueryExecuteQueryOperator",
"airflow.contrib.operators.bigquery_operator.BigQueryOperator",
),
(
"airflow.gcp.operators.bigquery.BigQueryDeleteTableOperator",
"airflow.contrib.operators.bigquery_table_delete_operator.BigQueryTableDeleteOperator",
),
(
"airflow.operators.bigquery_to_bigquery.BigQueryToBigQueryOperator",
"airflow.contrib.operators.bigquery_to_bigquery.BigQueryToBigQueryOperator",
),
(
"airflow.operators.bigquery_to_gcs.BigQueryToGCSOperator",
"airflow.contrib.operators.bigquery_to_gcs.BigQueryToCloudStorageOperator",
),
(
"airflow.operators.bigquery_to_mysql.BigQueryToMySqlOperator",
"airflow.contrib.operators.bigquery_to_mysql_operator.BigQueryToMySqlOperator",
),
(
"airflow.gcp.operators.gcs.GCSBucketCreateAclEntryOperator",
"airflow.contrib.operators.gcs_acl_operator.GoogleCloudStorageBucketCreateAclEntryOperator",
),
(
"airflow.gcp.operators.gcs.GCSObjectCreateAclEntryOperator",
"airflow.contrib.operators.gcs_acl_operator.GoogleCloudStorageObjectCreateAclEntryOperator",
),
(
"airflow.gcp.operators.gcs.GCSDeleteObjectsOperator",
"airflow.contrib.operators.gcs_delete_operator.GoogleCloudStorageDeleteOperator",
),
(
"airflow.gcp.operators.gcs.GCSToLocalOperator",
"airflow.contrib.operators.gcs_download_operator.GoogleCloudStorageDownloadOperator",
),
(
"airflow.gcp.operators.gcs.GCSListObjectsOperator",
"airflow.contrib.operators.gcs_list_operator.GoogleCloudStorageListOperator",
),
(
"airflow.gcp.operators.gcs.GCSCreateBucketOperator",
"airflow.contrib.operators.gcs_operator.GoogleCloudStorageCreateBucketOperator",
),
(
"airflow.providers.amazon.aws.operators.athena.AWSAthenaOperator",
"airflow.contrib.operators.aws_athena_operator.AWSAthenaOperator",
),
(
"airflow.providers.amazon.aws.operators.batch.AwsBatchOperator",
"airflow.contrib.operators.awsbatch_operator.AWSBatchOperator",
),
(
"airflow.providers.amazon.aws.operators.sqs.SQSPublishOperator",
"airflow.contrib.operators.aws_sqs_publish_operator.SQSPublishOperator",
),
(
"airflow.providers.amazon.aws.operators.sns.SnsPublishOperator",
"airflow.contrib.operators.sns_publish_operator.SnsPublishOperator",
),
(
'airflow.providers.apache.druid.operators.druid.DruidOperator',
'airflow.contrib.operators.druid_operator.DruidOperator',
),
(
'airflow.providers.apache.spark.operators.spark_jdbc.SparkSubmitOperator',
'airflow.contrib.operators.spark_jdbc_operator.SparkSubmitOperator',
),
(
'airflow.providers.apache.spark.operators.spark_sql.SparkSqlOperator',
'airflow.contrib.operators.spark_sql_operator.SparkSqlOperator',
),
(
'airflow.providers.apache.spark.operators.spark_submit.SparkSubmitOperator',
'airflow.contrib.operators.spark_submit_operator.SparkSubmitOperator',
),
(
'airflow.providers.apache.sqoop.operators.sqoop.SqoopOperator',
'airflow.contrib.operators.sqoop_operator.SqoopOperator',
),
(
'airflow.providers.apache.druid.operators.druid_check.DruidCheckOperator',
'airflow.operators.druid_check_operator.DruidCheckOperator',
),
(
'airflow.providers.apache.hive.operators.hive.HiveOperator',
'airflow.operators.hive_operator.HiveOperator',
),
(
'airflow.providers.apache.hive.operators.hive_stats.HiveStatsCollectionOperator',
'airflow.operators.hive_stats_operator.HiveStatsCollectionOperator',
),
(
'airflow.providers.apache.pig.operators.pig.PigOperator',
'airflow.operators.pig_operator.PigOperator',
),
(
'airflow.providers.microsoft.azure.operators.adls_list.AzureDataLakeStorageListOperator',
'airflow.contrib.operators.adls_list_operator.AzureDataLakeStorageListOperator',
),
(
'airflow.providers.microsoft.azure.operators'
'.azure_container_instances.AzureContainerInstancesOperator',
'airflow.contrib.operators.azure_container_instances_operator.AzureContainerInstancesOperator',
),
(
'airflow.providers.microsoft.azure.operators.azure_cosmos.AzureCosmosInsertDocumentOperator',
'airflow.contrib.operators.azure_cosmos_operator.AzureCosmosInsertDocumentOperator',
),
(
'airflow.providers.microsoft.azure.operators.wasb_delete_blob.WasbDeleteBlobOperator',
'airflow.contrib.operators.wasb_delete_blob_operator.WasbDeleteBlobOperator',
),
(
'airflow.providers.amazon.aws.operators.ecs.ECSOperator',
'airflow.contrib.operators.ecs_operator.ECSOperator',
),
(
'airflow.providers.amazon.aws.operators.emr_add_steps.EmrAddStepsOperator',
'airflow.contrib.operators.emr_add_steps_operator.EmrAddStepsOperator',
),
(
'airflow.providers.amazon.aws.operators.emr_create_job_flow.EmrCreateJobFlowOperator',
'airflow.contrib.operators.emr_create_job_flow_operator.EmrCreateJobFlowOperator',
),
(
'airflow.providers.amazon.aws.operators.emr_terminate_job_flow.EmrTerminateJobFlowOperator',
'airflow.contrib.operators.emr_terminate_job_flow_operator.EmrTerminateJobFlowOperator',
),
(
'airflow.providers.amazon.aws.operators.s3_copy_object.S3CopyObjectOperator',
'airflow.contrib.operators.s3_copy_object_operator.S3CopyObjectOperator',
),
(
'airflow.providers.amazon.aws.operators.s3_delete_objects.S3DeleteObjectsOperator',
'airflow.contrib.operators.s3_delete_objects_operator.S3DeleteObjectsOperator',
),
(
'airflow.providers.amazon.aws.operators.s3_list.S3ListOperator',
'airflow.contrib.operators.s3_list_operator.S3ListOperator',
),
(
'airflow.providers.amazon.aws.operators.sagemaker_base.SageMakerBaseOperator',
'airflow.contrib.operators.sagemaker_base_operator.SageMakerBaseOperator',
),
(
'airflow.providers.amazon.aws.operators.sagemaker_endpoint_config.SageMakerEndpointConfigOperator',
'airflow.contrib.operators.sagemaker_endpoint_config_operator.SageMakerEndpointConfigOperator',
),
(
'airflow.providers.amazon.aws.operators.sagemaker_endpoint.SageMakerEndpointOperator',
'airflow.contrib.operators.sagemaker_endpoint_operator.SageMakerEndpointOperator',
),
(
'airflow.providers.amazon.aws.operators.sagemaker_model.SageMakerModelOperator',
'airflow.contrib.operators.sagemaker_model_operator.SageMakerModelOperator',
),
(
'airflow.providers.amazon.aws.operators.sagemaker_training.SageMakerTrainingOperator',
'airflow.contrib.operators.sagemaker_training_operator.SageMakerTrainingOperator',
),
(
'airflow.providers.amazon.aws.operators.sagemaker_transform.SageMakerTransformOperator',
'airflow.contrib.operators.sagemaker_transform_operator.SageMakerTransformOperator',
),
(
'airflow.providers.amazon.aws.operators.sagemaker_tuning.SageMakerTuningOperator',
'airflow.contrib.operators.sagemaker_tuning_operator.SageMakerTuningOperator',
),
(
'airflow.providers.docker.operators.docker_swarm.DockerSwarmOperator',
'airflow.contrib.operators.docker_swarm_operator.DockerSwarmOperator',
),
(
'airflow.providers.cncf.kubernetes.operators.kubernetes_pod.KubernetesPodOperator',
'airflow.contrib.operators.kubernetes_pod_operator.KubernetesPodOperator',
),
(
'airflow.providers.redis.operators.redis_publish.RedisPublishOperator',
'airflow.contrib.operators.redis_publish_operator.RedisPublishOperator',
),
(
'airflow.operators.bash.BashOperator',
'airflow.operators.bash_operator.BashOperator',
),
(
'airflow.providers.docker.operators.docker.DockerOperator',
'airflow.operators.docker_operator.DockerOperator',
),
(
'airflow.providers.microsoft.mssql.operators.mssql.MsSqlOperator',
'airflow.operators.mssql_operator.MsSqlOperator',
),
(
'airflow.providers.mysql.operators.mysql.MySqlOperator',
'airflow.operators.mysql_operator.MySqlOperator',
),
(
'airflow.providers.oracle.operators.oracle.OracleOperator',
'airflow.operators.oracle_operator.OracleOperator',
),
(
'airflow.providers.papermill.operators.papermill.PapermillOperator',
'airflow.operators.papermill_operator.PapermillOperator',
),
(
'airflow.providers.presto.operators.presto_check.PrestoCheckOperator',
'airflow.operators.presto_check_operator.PrestoCheckOperator',
),
(
'airflow.providers.presto.operators.presto_check.PrestoIntervalCheckOperator',
'airflow.operators.presto_check_operator.PrestoIntervalCheckOperator',
),
(
'airflow.providers.presto.operators.presto_check.PrestoValueCheckOperator',
'airflow.operators.presto_check_operator.PrestoValueCheckOperator',
),
(
'airflow.operators.python.BranchPythonOperator',
'airflow.operators.python_operator.BranchPythonOperator',
),
(
'airflow.operators.python.PythonOperator',
'airflow.operators.python_operator.PythonOperator',
),
(
'airflow.operators.python.ShortCircuitOperator',
'airflow.operators.python_operator.ShortCircuitOperator',
),
(
'airflow.operators.python.PythonVirtualenvOperator',
'airflow.operators.python_operator.PythonVirtualenvOperator',
),
(
'airflow.providers.sqlite.operators.sqlite.SqliteOperator',
'airflow.operators.sqlite_operator.SqliteOperator',
),
]
SENSOR = [
(
"airflow.gcp.sensors.bigtable.BigtableTableReplicationCompletedSensor",
"airflow.contrib.operators.gcp_bigtable_operator."
"BigtableTableWaitForReplicationSensor",
),
(
"airflow.gcp.sensors.cloud_storage_transfer_service."
"CloudDataTransferServiceJobStatusSensor",
"airflow.contrib.sensors.gcp_transfer_sensor."
"GCPTransferServiceWaitForJobStatusSensor",
),
(
"airflow.providers.google.cloud.sensors.pubsub.PubSubPullSensor",
"airflow.contrib.sensors.pubsub_sensor.PubSubPullSensor",
),
(
"airflow.gcp.sensors.bigquery.BigQueryTableExistenceSensor",
"airflow.contrib.sensors.bigquery_sensor.BigQueryTableSensor",
),
(
"airflow.gcp.sensors.gcs.GCSObjectExistenceSensor",
"airflow.contrib.sensors.gcs_sensor.GoogleCloudStorageObjectSensor",
),
(
"airflow.gcp.sensors.gcs.GCSObjectUpdateSensor",
"airflow.contrib.sensors.gcs_sensor.GoogleCloudStorageObjectUpdatedSensor",
),
(
"airflow.gcp.sensors.gcs.GCSObjectsWtihPrefixExistenceSensor",
"airflow.contrib.sensors.gcs_sensor.GoogleCloudStoragePrefixSensor",
),
(
"airflow.gcp.sensors.gcs.GCSUploadSessionCompleteSensor",
"airflow.contrib.sensors.gcs_sensor.GoogleCloudStorageUploadSessionCompleteSensor",
),
(
"airflow.providers.amazon.aws.sensors.athena.AthenaSensor",
"airflow.contrib.sensors.aws_athena_sensor.AthenaSensor",
),
(
"airflow.providers.amazon.aws.sensors.sqs.SQSSensor",
"airflow.contrib.sensors.aws_sqs_sensor.SQSSensor",
),
(
'airflow.providers.apache.hdfs.sensors.hdfs.HdfsSensorFolder',
'airflow.contrib.sensors.hdfs_sensor.HdfsSensorFolder',
),
(
'airflow.providers.apache.hdfs.sensors.hdfs.HdfsSensorRegex',
'airflow.contrib.sensors.hdfs_sensor.HdfsSensorRegex',
),
(
'airflow.providers.apache.hive.sensors.hive_partition.HivePartitionSensor',
'airflow.sensors.hive_partition_sensor.HivePartitionSensor',
),
(
'airflow.providers.apache.hive.sensors.metastore_partition.MetastorePartitionSensor',
'airflow.sensors.metastore_partition_sensor.MetastorePartitionSensor',
),
(
'airflow.providers.apache.hive.sensors.named_hive_partition.NamedHivePartitionSensor',
'airflow.sensors.named_hive_partition_sensor.NamedHivePartitionSensor',
),
(
'airflow.providers.apache.hdfs.sensors.web_hdfs.WebHdfsSensor',
'airflow.sensors.web_hdfs_sensor.WebHdfsSensor',
),
(
'airflow.providers.apache.hdfs.sensors.hdfs.HdfsSensor',
'airflow.sensors.hdfs_sensor.HdfsSensor',
),
(
'airflow.sensors.weekday_sensor.DayOfWeekSensor',
'airflow.contrib.sensors.weekday_sensor.DayOfWeekSensor',
),
(
'airflow.sensors.filesystem.FileSensor',
'airflow.contrib.sensors.file_sensor.FileSensor',
),
(
'airflow.providers.microsoft.azure.sensors.wasb.WasbBlobSensor',
'airflow.contrib.sensors.wasb_sensor.WasbBlobSensor',
),
(
'airflow.providers.microsoft.azure.sensors.wasb.WasbPrefixSensor',
'airflow.contrib.sensors.wasb_sensor.WasbPrefixSensor',
),
(
'airflow.providers.amazon.aws.sensors.glue_catalog_partition.AwsGlueCatalogPartitionSensor',
'airflow.contrib.sensors.aws_glue_catalog_partition_sensor.AwsGlueCatalogPartitionSensor',
),
(
'airflow.providers.amazon.aws.sensors.emr_base.EmrBaseSensor',
'airflow.contrib.sensors.emr_base_sensor.EmrBaseSensor',
),
(
'airflow.providers.amazon.aws.sensors.emr_job_flow.EmrJobFlowSensor',
'airflow.contrib.sensors.emr_job_flow_sensor.EmrJobFlowSensor',
),
(
'airflow.providers.amazon.aws.sensors.emr_step.EmrStepSensor',
'airflow.contrib.sensors.emr_step_sensor.EmrStepSensor',
),
(
'airflow.providers.amazon.aws.sensors.sagemaker_base.SageMakerBaseSensor',
'airflow.contrib.sensors.sagemaker_base_sensor.SageMakerBaseSensor',
),
(
'airflow.providers.amazon.aws.sensors.sagemaker_endpoint.SageMakerEndpointSensor',
'airflow.contrib.sensors.sagemaker_endpoint_sensor.SageMakerEndpointSensor',
),
(
'airflow.providers.amazon.aws.sensors.sagemaker_transform.SageMakerTransformSensor',
'airflow.contrib.sensors.sagemaker_transform_sensor.SageMakerTransformSensor',
),
(
'airflow.providers.amazon.aws.sensors.sagemaker_tuning.SageMakerTuningSensor',
'airflow.contrib.sensors.sagemaker_tuning_sensor.SageMakerTuningSensor',
),
(
'airflow.providers.amazon.aws.operators.s3_file_transform.S3FileTransformOperator',
'airflow.operators.s3_file_transform_operator.S3FileTransformOperator',
),
(
'airflow.providers.amazon.aws.sensors.s3_key.S3KeySensor',
'airflow.sensors.s3_key_sensor.S3KeySensor',
),
(
'airflow.providers.amazon.aws.sensors.s3_prefix.S3PrefixSensor',
'airflow.sensors.s3_prefix_sensor.S3PrefixSensor',
),
(
'airflow.sensors.bash.BashSensor',
'airflow.contrib.sensors.bash_sensor.BashSensor',
),
(
'airflow.providers.celery.sensors.celery_queue.CeleryQueueSensor',
'airflow.contrib.sensors.celery_queue_sensor.CeleryQueueSensor',
),
(
'airflow.providers.mongo.sensors.mongo.MongoSensor',
'airflow.contrib.sensors.mongo_sensor.MongoSensor',
),
(
'airflow.sensors.python.PythonSensor',
'airflow.contrib.sensors.python_sensor.PythonSensor',
),
(
'airflow.providers.redis.sensors.redis_key.RedisKeySensor',
'airflow.contrib.sensors.redis_key_sensor.RedisKeySensor',
),
(
'airflow.providers.redis.sensors.redis_pub_sub.RedisPubSubSensor',
'airflow.contrib.sensors.redis_pub_sub_sensor.RedisPubSubSensor',
),
]
PROTOCOLS = [
(
"airflow.providers.amazon.aws.hooks.batch_client.AwsBatchProtocol",
"airflow.contrib.operators.awsbatch_operator.BatchProtocol",
),
(
'airflow.providers.amazon.aws.operators.ecs.ECSProtocol',
'airflow.contrib.operators.ecs_operator.ECSProtocol',
),
]
ALL = HOOK + OPERATOR + SENSOR + PROTOCOLS
RENAMED_HOOKS = [
(old_class, new_class)
for old_class, new_class in HOOK + OPERATOR + SENSOR
if old_class.rpartition(".")[2] != new_class.rpartition(".")[2]
]
class TestMovingCoreToContrib(TestCase):
@staticmethod
def assert_warning(msg: str, warning: Any):
error = "Text '{}' not in warnings".format(msg)
assert any(msg in str(w) for w in warning.warnings), error
def assert_is_subclass(self, clazz, other):
self.assertTrue(
issubclass(clazz, other), "{} is not subclass of {}".format(clazz, other)
)
def assert_proper_import(self, old_resource, new_resource):
new_path, _, _ = new_resource.rpartition(".")
old_path, _, _ = old_resource.rpartition(".")
with self.assertWarns(DeprecationWarning) as warning_msg:
# Reload to see deprecation warning each time
importlib.reload(importlib.import_module(old_path))
self.assert_warning(new_path, warning_msg)
@staticmethod
def get_class_from_path(path_to_class, parent=False):
"""
:param parent indicates if "path_to_class" arg is super class
"""
path, _, class_name = path_to_class.rpartition(".")
module = importlib.import_module(path)
class_ = getattr(module, class_name)
if isabstract(class_) and not parent:
class_name = f"Mock({class_.__name__})"
attributes = {
a: mock.MagicMock() for a in class_.__abstractmethods__
}
new_class = type(class_name, (class_,), attributes)
return new_class
return class_
@parameterized.expand(PROTOCOLS)
def test_is_protocol_deprecated(self, _, old_module):
deprecation_warning_msg = "This class is deprecated."
old_module_class = self.get_class_from_path(old_module)
with self.assertWarnsRegex(DeprecationWarning, deprecation_warning_msg) as wrn:
self.assertTrue(deprecation_warning_msg, wrn)
old_module_class()
@parameterized.expand(RENAMED_HOOKS)
def test_is_class_deprecated(self, new_module, old_module):
deprecation_warning_msg = "This class is deprecated."
old_module_class = self.get_class_from_path(old_module)
with self.assertWarnsRegex(DeprecationWarning, deprecation_warning_msg) as wrn:
with mock.patch("{}.__init__".format(new_module)) as init_mock:
init_mock.return_value = None
self.assertTrue(deprecation_warning_msg, wrn)
old_module_class()
init_mock.assert_called_once_with()
@parameterized.expand(ALL)
def test_is_subclass(self, parent_class_path, sub_class_path):
with mock.patch("{}.__init__".format(parent_class_path)):
parent_class_path = self.get_class_from_path(parent_class_path, parent=True)
sub_class_path = self.get_class_from_path(sub_class_path)
self.assert_is_subclass(sub_class_path, parent_class_path)
@parameterized.expand(ALL)
def test_warning_on_import(self, new_path, old_path):
self.assert_proper_import(old_path, new_path)