Just a few of 1000s of Use Cases

The ease of working with StreamZero with it's ability to rewire services at will and integrate across clouds and services Agility into engineering.

GcpTransferOperationStatus

Class with Google Cloud Transfer operations statuses.

Hooks

ray_task

Wraps a function to be executed on the Ray cluster.

Decorators

FacebookAdsReportingHook

Hook for the Facebook Ads API

Hooks

VineyardXCom

Custom Backend Serving to use Vineyard.

XCom

AwsGlueJobOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.glue.GlueJobOperator.

Operators

GlueCrawlerSensor

Waits for an AWS Glue crawler to reach any of the statuses below FAILED, CANCELLED, SUCCEEDED

Sensors

AwsGlueJobSensor

This sensor is deprecated. Please use airflow.providers.amazon.aws.sensors.glue.GlueJobSensor.

Sensors

GlueJobOperator

Creates an AWS Glue Job. AWS Glue is a serverless Spark ETL service for running Spark Jobs on the AWS cloud. Language support Python and Scala

Operators

GlueCrawlerOperator

Creates, updates and triggers an AWS Glue Crawler. AWS Glue Crawler is a serverless service that manages a catalog of metadata tables that contain the inferred schema, format and data types of data stores within the AWS cloud.

Operators

AwsGlueCrawlerOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.glue_crawler.GlueCrawlerOperator.

Operators

GlueJobSensor

Waits for an AWS Glue Job to reach any of the status below FAILED, STOPPED, SUCCEEDED

Sensors

AwsGlueCrawlerSensor

This sensor is deprecated. Please use airflow.providers.amazon.aws.sensors.glue_crawler.GlueCrawlerSensor.

Sensors

BaseSensorOperator

Sensor operators are derived from this class and inherit these attributes.

Sensors

S3ToSFTPOperator

This operator enables the transferring of files from S3 to a SFTP server.

Transfers

BigQueryUpsertTableOperator

Upsert BigQuery table

Operators

BigQueryDeleteDatasetOperator

This operator deletes an existing dataset from your Project in Big query.

Operators

BigQueryHook

Interact with BigQuery. This hook uses the Google Cloud connection.

Hooks

BigQueryUpdateTableOperator

This operator is used to update table for your Project in BigQuery. Use fields to specify which fields of table to update. If a field is listed in fields and is None in table, it will be deleted.

Operators

BigQueryCheckOperator

Performs checks against BigQuery. The BigQueryCheckOperator expects a sql query that will return a single row. Each value on that first row is evaluated using python bool casting. If any of the values return False the check is failed and errors out.

Operators

BigQueryCreateExternalTableOperator

Creates a new external table in the dataset with the data from Google Cloud Storage.

Operators

_BigQueryDbHookMixin

_BigQueryDbHookMixin

Operators

BigQueryInsertJobOperator

Executes a BigQuery job. Waits for the job to complete and returns job id.

Operators

BigQueryCreateEmptyTableOperator

Creates a new, empty table in the specified BigQuery dataset, optionally with schema.

Operators

BigQueryGetDatasetOperator

This operator is used to return the dataset specified by dataset_id.

Operators

BigQueryDeleteTableOperator

Deletes BigQuery tables

Operators

BigQueryGetDatasetTablesOperator

This operator retrieves the list of tables in the specified dataset.

Operators

BigQueryValueCheckOperator

Performs a simple value check using sql code.

Operators

BigQueryExecuteQueryOperator

Executes BigQuery SQL queries in a specific BigQuery database. This operator does not assert idempotency.

Operators

BigQueryUpdateDatasetOperator

This operator is used to update dataset for your Project in BigQuery. Use fields to specify which fields of dataset to update. If a field is listed in fields and is None in dataset, it will be deleted. If no fields are provided then all fields of provided dataset_resource will be used.

Operators

BigQueryPatchDatasetOperator

This operator is used to patch dataset for your Project in BigQuery. It only replaces fields that are provided in the submitted dataset resource.

Operators

BigQueryGetDataOperator

Fetches the data from a BigQuery table (alternatively fetch data for selected columns) and returns data in a python list. The number of elements in the returned list will be equal to the number of rows fetched. Each element in the list will again be a list where element would represent the columns values for that row.

Operators

BigQueryIntervalCheckOperator

Checks that the values of metrics given as SQL expressions are within a certain tolerance of the ones from days_back before.

Operators

BigQueryUpdateTableSchemaOperator

Update BigQuery Table Schema Updates fields on a table schema based on contents of the supplied schema_fields_updates parameter. The supplied schema does not need to be complete, if the field already exists in the schema you only need to supply keys & values for the items you want to patch, just ensure the “name” key is set.

Operators

BigQueryCreateEmptyDatasetOperator

This operator is used to create new dataset for your Project in BigQuery.

Operators

DataflowTemplatedJobStartOperator

Start a Templated Cloud Dataflow job. The parameters of the operation will be passed to the job.

Operators

DataflowStartFlexTemplateOperator

Starts flex templates with the Dataflow pipeline.

Operators

DataflowStartSqlJobOperator

Starts Dataflow SQL query.

Operators

DataflowCreatePythonJobOperator

Launching Cloud Dataflow jobs written in python. Note that both dataflow_default_options and options will be merged to specify pipeline execution parameter, and dataflow_default_options is expected to save high-level options, for instances, project and zone information, which apply to all dataflow operators in the DAG.

Operators

DataflowCreateJavaJobOperator

Start a Java Cloud Dataflow batch job. The parameters of the operation will be passed to the job.

Operators

PostgresOperator

Executes sql code in a specific Postgres database

Operators

BaseSecretsBackend

Abstract base class to retrieve Connection object given a conn_id or Variable given a key

Secrets

BeamHook

Hook for Apache Beam.

Hooks

EnvironmentVariablesBackend

Retrieves Connection object and Variable from environment variable.

Secrets

DatabricksHook

Interact with Databricks.

Hooks

S3Hook

Interact with AWS S3, using the boto3 library.

Hooks

GCSFileTransformOperator

Copies data from a source GCS location to a temporary location on the local filesystem. Runs a transformation on this file as specified by the transformation script and uploads the output to a destination bucket. If the output bucket is not specified the original file will be overwritten.

Operators

GCSDeleteBucketOperator

Deletes bucket from a Google Cloud Storage.

Operators

GCSDeleteObjectsOperator

Deletes objects from a Google Cloud Storage bucket, either from an explicit list of object names or all objects matching a prefix.

Operators

GCSTimeSpanFileTransformOperator

Determines a list of objects that were added or modified at a GCS source location during a specific time-span, copies them to a temporary location on the local file system, runs a transform on this file as specified by the transformation script and uploads the output to the destination bucket.

Operators

GCSCreateBucketOperator

Creates a new bucket. Google Cloud Storage uses a flat namespace, so you cant create a bucket with a name that is already in use.

Operators

GCSSynchronizeBucketsOperator

Synchronizes the contents of the buckets or buckets directories in the Google Cloud Services.

Operators

GCSObjectCreateAclEntryOperator

Creates a new ACL entry on the specified object.

Operators

GCSBucketCreateAclEntryOperator

Creates a new ACL entry on the specified bucket.

Operators

GCSListObjectsOperator

List all objects from the bucket with the given string prefix and delimiter in name.

Operators

SnowflakeHook

A client to interact with Snowflake.

Hooks

EmrCreateJobFlowOperator

Creates an EMR JobFlow, reading the config from the EMR connection. A dictionary of JobFlow overrides can be passed that override the config from the connection.

Operators

EmrJobFlowSensor

Asks for the state of the EMR JobFlow (Cluster) until it reaches any of the target states. If it fails the sensor errors, failing the task.

Sensors

EmrModifyClusterOperator

An operator that modifies an existing EMR cluster.

Operators

EmrTerminateJobFlowOperator

Operator to terminate EMR JobFlows.

Operators

EmrBaseSensor

Contains general sensor behavior for EMR.

Sensors

EmrContainerSensor

Asks for the state of the job run until it reaches a failure state or success state. If the job run fails, the task will fail.

Sensors

EmrAddStepsOperator

An operator that adds steps to an existing EMR job_flow.

Operators

EmrStepSensor

Asks for the state of the step until it reaches any of the target states. If it fails the sensor errors, failing the task.

Sensors

EmrContainerOperator

An operator that submits jobs to EMR on EKS virtual clusters.

Operators

DataprocMetastoreDeleteBackupOperator

Deletes a single backup.

Operators

DataprocMetastoreListBackupsOperator

Lists backups in a service.

Operators

DataprocMetastoreRestoreServiceOperator

Restores a service from a backup.

Operators

DataprocMetastoreDeleteServiceOperator

Deletes a single service.

Operators

DataprocMetastoreExportMetadataOperator

Exports metadata from a service.

Operators

QuboleOperator

Execute tasks (commands) on QDS .

Operators

DataprocMetastoreCreateServiceOperator

Creates a metastore service in a project and location.

Operators

DataprocMetastoreGetServiceOperator

Gets the details of a single service.

Operators

DataprocMetastoreCreateBackupOperator

Creates a new backup in a given project and location.

Operators

DataprocMetastoreUpdateServiceOperator

Updates the parameters of a single service.

Operators

DataprocMetastoreCreateMetadataImportOperator

Creates a new MetadataImport in a given project and location.

Operators

AzureDataFactoryRunPipelineOperator

Executes a data factory pipeline.

Operators

AwsBaseHook

Interact with AWS. This class is a thin wrapper around the boto3 python library.

Hooks

RedshiftClusterSensor

Waits for a Redshift cluster to reach a specific status.

Sensors

DatabricksRunNowOperator

Runs an existing Spark job run to Databricks using the api/2.0/jobs/run-now API endpoint.

Operators

DatabricksSubmitRunOperator

Submits a Spark job run to Databricks using the api/2.0/jobs/runs/submit API endpoint.

Operators

GreatExpectationsOperator

An operator to leverage Great Expectations as a task in your Airflow DAG.

Operators

GoogleDriveHook

Hook for the Google Drive APIs.

Hooks

GKEStartPodOperator

Executes a task in a Kubernetes pod in the specified Google Kubernetes Engine cluster

Operators

GKECreateClusterOperator

Create a Google Kubernetes Engine Cluster of specified dimensions The operator will wait until the cluster is created.

Operators

GKEDeleteClusterOperator

Deletes the cluster, including the Kubernetes endpoint and all worker nodes.

Operators

DockerOperator

Execute a command inside a docker container.

Operators

MLEngineStartBatchPredictionJobOperator

Start a Google Cloud ML Engine prediction job.

Operators

TriggerDagRunOperator

Triggers a DAG run for a specified dag_id

Operators

MLEngineDeleteVersionOperator

Deletes the version from the model.

Operators

MLEngineCreateModelOperator

Creates a new model.

Operators

MLEngineGetModelOperator

Gets a particular model

Operators

MLEngineTrainingCancelJobOperator

Operator for cleaning up failed MLEngine training job.

Operators

MLEngineManageVersionOperator

Operator for managing a Google Cloud ML Engine version.

Operators

MLEngineManageModelOperator

Operator for managing a Google Cloud ML Engine model.

Operators

MLEngineListVersionsOperator

Lists all available versions of the model

Operators

MLEngineCreateVersionOperator

Creates a new version in the model

Operators

MLEngineSetDefaultVersionOperator

Sets a version in the model.

Operators

MLEngineStartTrainingJobOperator

Operator for launching a MLEngine training job.

Operators

MLEngineDeleteModelOperator

Deletes a model.

Operators

TriggerDagRunLink

Operator link for TriggerDagRunOperator. It allows users to access DAG triggered by task using TriggerDagRunOperator.

Operators

OSSHook

Interact with Alibaba Cloud OSS, using the oss2 library.

Hooks

PythonVirtualenvOperator

Allows one to run a function in a virtualenv that is created and destroyed automatically (with certain caveats).

Operators

ShortCircuitOperator

Allows a workflow to continue only if a condition is met. Otherwise, the workflow “short-circuits” and downstream tasks are skipped.

Operators

PythonOperator

Executes a Python callable

Operators

BranchPythonOperator

Allows a workflow to “branch” or follow a path following the execution of this task.

Operators

EcsOperator

Execute a task on AWS ECS (Elastic Container Service)

Operators

ECSOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.ecs.EcsOperator.

Operators

CloudSQLDatabaseHook

Serves DB connection configuration for Google Cloud SQL (Connections of gcpcloudsqldb type).

Hooks

CloudSQLHook

Hook for Google Cloud SQL APIs.

Hooks

GoogleDeploymentManagerHook

Interact with Google Cloud Deployment Manager using the Google Cloud connection. This allows for scheduled and programmatic inspection and deletion fo resources managed by GDM.

Hooks

DataflowHook

Hook for Google Dataflow.

Hooks

S3TaskHandler

S3TaskHandler is a python log handler that handles and reads task instance logs. It extends airflow FileTaskHandler and uploads to and reads from S3 remote storage.

Log

EmrContainerHook

Interact with AWS EMR Virtual Cluster to run, poll jobs and return job status Additional arguments (such as aws_conn_id) may be specified and are passed down to the underlying AwsBaseHook.

Hooks

EmrHook

Interact with AWS EMR. emr_conn_id is only necessary for using the create_job_flow method.

Hooks

DataprocCreateClusterOperator

Create a new cluster on Google Cloud Dataproc. The operator will wait until the creation is successful or an error occurs in the creation process. If the cluster already exists and use_if_exists is True then the operator will.

Operators

DataprocSubmitHadoopJobOperator

Start a Hadoop Job on a Cloud DataProc cluster.

Operators

DataprocListBatchesOperator

Lists batch workloads.

Operators

DataprocSubmitSparkJobOperator

Start a Spark Job on a Cloud DataProc cluster.

Operators

DataprocInstantiateWorkflowTemplateOperator

Instantiate a WorkflowTemplate on Google Cloud Dataproc. The operator will wait until the WorkflowTemplate is finished executing.

Operators

DataprocUpdateClusterOperator

Updates a cluster in a project.

Operators

DataprocSubmitJobOperator

Submits a job to a cluster.

Operators

DataprocSubmitPySparkJobOperator

Start a PySpark Job on a Cloud DataProc cluster.

Operators

DataprocDeleteBatchOperator

Deletes the batch workload resource.

Operators

DataprocSubmitSparkSqlJobOperator

Start a Spark SQL query Job on a Cloud DataProc cluster.

Operators

DataprocJobBaseOperator

The base class for operators that launch job on DataProc.

Operators

DataprocCreateBatchOperator

Creates a batch workload.

Operators

DataprocInstantiateInlineWorkflowTemplateOperator

Instantiate a WorkflowTemplate Inline on Google Cloud Dataproc. The operator will wait until the WorkflowTemplate is finished executing.

Operators

DataprocDeleteClusterOperator

Deletes a cluster in a project.

Operators

DataprocScaleClusterOperator

Scale, up or down, a cluster on Google Cloud Dataproc. The operator will wait until the cluster is re-scaled.

Operators

DataprocSubmitPigJobOperator

Start a Pig query Job on a Cloud DataProc cluster. The parameters of the operation will be passed to the cluster.

Operators

DataprocSubmitHiveJobOperator

Start a Hive query Job on a Cloud DataProc cluster.

Operators

DataprocGetBatchOperator

Gets the batch workload resource representation.

Operators

DataprocCreateWorkflowTemplateOperator

Creates new workflow template.

Operators

CloudBuildListBuildTriggersOperator

Lists existing BuildTriggers.

Operators

CloudBuildCreateBuildOperator

Starts a build with the specified configuration.

Operators

CloudBuildCreateBuildTriggerOperator

Creates a new BuildTrigger.

Operators

CloudBuildCancelBuildOperator

Cancels a build in progress.

Operators

CloudBuildDeleteBuildTriggerOperator

Deletes a BuildTrigger by its project ID and trigger ID.

Operators

CloudBuildRunBuildTriggerOperator

Runs a BuildTrigger at a particular source revision.

Operators

CloudBuildRetryBuildOperator

Creates a new build based on the specified build. This method creates a new build using the original build request, which may or may not result in an identical build.

Operators

CloudBuildUpdateBuildTriggerOperator

Updates a BuildTrigger by its project ID and trigger ID.

Operators

CloudBuildListBuildsOperator

Lists previously requested builds.

Operators

CloudBuildGetBuildOperator

Returns information about a previously requested build.

Operators

CloudBuildGetBuildTriggerOperator

Returns information about a BuildTrigger.

Operators

GCSToS3Operator

Synchronizes a Google Cloud Storage bucket with an S3 bucket.

Transfers

AthenaHook

Interact with AWS Athena to run, poll queries and return query results

Hooks

AWSAthenaHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.athena.AthenaHook.

Hooks

DynamoDBToS3Operator

Replicates records from a DynamoDB table to S3. It scans a DynamoDB table and write the received records to a file on the local filesystem. It flushes the file to S3 once the file size exceeds the file size limit specified by the user.

Transfers

GCSHook

Interact with Google Cloud Storage. This hook uses the Google Cloud connection.

Hooks

RedshiftToS3Operator

Executes an UNLOAD command to s3 as a CSV with headers

Transfers

DataprocCreatePysparkJobOperator

Runs Pyspark job in Data Proc cluster.

Operators

DataprocCreateHiveJobOperator

Runs Hive job in Data Proc cluster.

Operators

DataprocCreateClusterOperator

Creates Yandex.Cloud Data Proc cluster.

Operators

DataprocCreateMapReduceJobOperator

Runs Mapreduce job in Data Proc cluster.

Operators

DataprocCreateSparkJobOperator

Runs Spark job in Data Proc cluster.

Operators

DataprocDeleteClusterOperator

Deletes Yandex.Cloud Data Proc cluster.

Operators

BatchSensor

Asks for the state of the Batch Job execution until it reaches a failure state or success state. If the job fails, the task will fail.

Sensors

BatchOperator

Execute a job on AWS Batch

Operators

AwsBatchOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.batch.BatchOperator.

Operators

_DockerDecoratedOperator

Wraps a Python callable and captures args/kwargs when called for execution.

Decorators

GCSToBigQueryOperator

Loads files from Google Cloud Storage into BigQuery.

Transfers

FTPHook

Interact with FTP.

Hooks

SFTPHook

This hook is inherited from SSH hook. Please refer to SSH hook for the input arguments.

Hooks

FTPSHook

Interact with FTPS.

Hooks

KubernetesPodOperator

Execute a task in a Kubernetes Pod

Operators

FromXLSXQueryOperator

Execute an SQL query an XLSX/XLS file and export the result into a Parquet or CSV file

Operators

FromXLSXOperator

Convert an XLSX/XLS file into Parquet or CSV file

Operators

WasbHook

Interacts with Azure Blob Storage through the wasb:// protocol.

Hooks

SFTPToWasbOperator

Transfer files to Azure Blob Storage from SFTP server.

Transfers

LocalFilesystemToWasbOperator

Uploads a file to Azure Blob Storage.

Transfers

AzureDataFactoryHook

A hook to interact with Azure Data Factory.

Hooks

CloudMemorystoreMemcachedUpdateInstanceOperator

Updates the metadata and configuration of a specific Memcached instance.

Operators

CloudMemorystoreCreateInstanceAndImportOperator

Creates a Redis instance based on the specified tier and memory size and import a Redis RDB snapshot file from Cloud Storage into a this instance.

Operators

CloudMemorystoreMemcachedGetInstanceOperator

Gets the details of a specific Memcached instance.

Operators

CloudMemorystoreGetInstanceOperator

Gets the details of a specific Redis instance.

Operators

CloudMemorystoreImportOperator

Import a Redis RDB snapshot file from Cloud Storage into a Redis instance.

Operators

CloudMemorystoreExportAndDeleteInstanceOperator

Export Redis instance data into a Redis RDB format file in Cloud Storage. In next step, deletes a this instance.

Operators

CloudMemorystoreMemcachedListInstancesOperator

locations.

Operators

CloudMemorystoreMemcachedApplyParametersOperator

Will update current set of Parameters to the set of specified nodes of the Memcached Instance.

Operators

CloudMemorystoreExportInstanceOperator

Export Redis instance data into a Redis RDB format file in Cloud Storage.

Operators

CloudMemorystoreMemcachedCreateInstanceOperator

Creates a Memcached instance based on the specified tier and memory size.

Operators

CloudMemorystoreListInstancesOperator

Lists all Redis instances owned by a project in either the specified location (region) or all locations.

Operators

CloudMemorystoreScaleInstanceOperator

Updates the metadata and configuration of a specific Redis instance.

Operators

CloudMemorystoreCreateInstanceOperator

Creates a Redis instance based on the specified tier and memory size.

Operators

CloudMemorystoreDeleteInstanceOperator

Deletes a specific Redis instance. Instance stops serving and data is deleted.

Operators

CloudMemorystoreFailoverInstanceOperator

Initiates a failover of the primary node to current replica node for a specific STANDARD tier Cloud Memorystore for Redis instance.

Operators

CloudMemorystoreMemcachedUpdateParametersOperator

parameters, it must be followed by apply_parameters to apply the parameters to nodes of the Memcached Instance.

Operators

CloudMemorystoreMemcachedDeleteInstanceOperator

Deletes a specific Memcached instance. Instance stops serving and data is deleted.

Operators

CloudMemorystoreUpdateInstanceOperator

Updates the metadata and configuration of a specific Redis instance.

Operators

DataprocJobSensor

Check for the state of a previously submitted Dataproc job.

Sensors

CloudDataFusionGetInstanceOperator

Gets details of a single Data Fusion instance.

Operators

CloudDataFusionCreateInstanceOperator

Creates a new Data Fusion instance in the specified project and location.

Operators

CloudDataFusionStartPipelineOperator

Starts a Cloud Data Fusion pipeline. Works for both batch and stream pipelines.

Operators

CloudComposerUpdateEnvironmentOperator

Update an environment.

Operators

CloudComposerListImageVersionsOperator

List ImageVersions for provided location.

Operators

CloudComposerDeleteEnvironmentOperator

Delete an environment.

Operators

CloudDataFusionDeleteInstanceOperator

Deletes a single Date Fusion instance.

Operators

CloudDataFusionStopPipelineOperator

Stops a Cloud Data Fusion pipeline. Works for both batch and stream pipelines.

Operators

CloudDataFusionDeletePipelineOperator

Deletes a Cloud Data Fusion pipeline.

Operators

CloudDataFusionUpdateInstanceOperator

Updates a single Data Fusion instance.

Operators

CloudComposerGetEnvironmentOperator

Get an existing environment.

Operators

CloudComposerCreateEnvironmentOperator

Create a new environment.

Operators

CloudDataFusionListPipelinesOperator

Lists Cloud Data Fusion pipelines.

Operators

CloudDataFusionCreatePipelineOperator

Creates a Cloud Data Fusion pipeline.

Operators

CloudComposerListEnvironmentsOperator

List environments.

Operators

CloudDataFusionRestartInstanceOperator

Restart a single Data Fusion instance. At the end of an operation instance is fully restarted.

Operators

LambdaHook

Interact with AWS Lambda

Hooks

AwsLambdaHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.lambda_function.LambdaHook.

Hooks

FileSensor

Waits for a file or folder to land in a filesystem.

Sensors

RedshiftSQLOperator

Executes SQL Statements against an Amazon Redshift cluster

Operators

SqlToS3Operator

Saves data from an specific SQL query into a file in S3.

Transfers

HttpSensor

Executes a HTTP GET statement and returns False on failure caused by 404 Not Found or response_check returning False.

Sensors

BigQueryToBigQueryOperator

Copies data from one BigQuery table to another.

Transfers

SageMakerEndpointOperator

Create a SageMaker endpoint.

Operators

SageMakerTrainingOperator

Initiate a SageMaker training job.

Operators

SageMakerTransformOperator

Initiate a SageMaker transform job.

Operators

SageMakerTuningOperator

Initiate a SageMaker hyperparameter tuning job.

Operators

SageMakerProcessingOperator

Initiate a SageMaker processing job.

Operators

SageMakerBaseOperator

This is the base operator for all SageMaker operators.

Operators

SageMakerHook

Interact with Amazon SageMaker.

Hooks

SageMakerModelOperator

Create a SageMaker model.

Operators

SageMakerEndpointConfigOperator

Create a SageMaker endpoint config.

Operators

OracleHook

Interact with Oracle SQL.

Hooks

DbApiHook

Abstract base class for sql hooks.

Hooks

S3DeleteObjectsOperator

To enable users to delete single object or multiple objects from a bucket using a single HTTP request.

Operators

S3FileTransformOperator

Copies data from a source S3 location to a temporary location on the local filesystem. Runs a transformation on this file as specified by the transformation script and uploads the output to a destination S3 location.

Operators

S3DeleteBucketOperator

This operator deletes an S3 bucket

Operators

S3DeleteBucketTaggingOperator

This operator deletes tagging from an S3 bucket.

Operators

S3CreateBucketOperator

This operator creates an S3 bucket

Operators

S3ListPrefixesOperator

List all subfolders from the bucket with the given string prefix in name.

Operators

S3PutBucketTaggingOperator

This operator puts tagging for an S3 bucket.

Operators

S3CopyObjectOperator

Creates a copy of an object that is already stored in S3.

Operators

S3GetBucketTaggingOperator

This operator gets tagging from an S3 bucket

Operators

S3ListOperator

List all objects from the bucket with the given string prefix in name.

Operators

SparkSubmitHook

This hook is a wrapper around the spark-submit binary to kick off a spark-submit job. It requires that the “spark-submit” binary is in the PATH or the spark_home to be supplied.

Hooks

PostgresHook

Interact with Postgres.

Hooks

MySqlHook

Interact with MySQL.

Hooks

BigQueryDeleteDataTransferConfigOperator

Deletes transfer configuration.

Operators

BigQueryDataTransferServiceStartTransferRunsOperator

Start manual transfer runs to be executed now with schedule_time equal to current time. The transfer runs can be created for a time range where the run_time is between start_time (inclusive) and end_time (exclusive), or for a specific run_time.

Operators

BigQueryCreateDataTransferOperator

Creates a new data transfer configuration.

Operators

LocalFilesystemBackend

Retrieves Connection objects and Variables from local files

Secrets

AzureCosmosDBHook

Interacts with Azure CosmosDB.

Hooks

TrinoHook

Interact with Trino through trino package.

Hooks

PrestoHook

Interact with Presto through prestodb.

Hooks

EksFargateProfileStateSensor

Check the state of an AWS Fargate profile until it reaches the target state or another terminal state.

Sensors

EKSFargateProfileStateSensor

This sensor is deprecated. Please use airflow.providers.amazon.aws.sensors.eks.EksFargateProfileStateSensor.

Sensors

EKSNodegroupStateSensor

This sensor is deprecated. Please use airflow.providers.amazon.aws.sensors.eks.EksNodegroupStateSensor.

Sensors

EKSClusterStateSensor

This sensor is deprecated. Please use airflow.providers.amazon.aws.sensors.eks.EksClusterStateSensor.

Sensors

EksNodegroupStateSensor

Check the state of an EKS managed node group until it reaches the target state or another terminal state.

Sensors

EksClusterStateSensor

Check the state of an Amazon EKS Cluster until it reaches the target state or another terminal state.

Sensors

BeamRunJavaPipelineOperator

Launching Apache Beam pipelines written in Java.

Operators

BeamRunPythonPipelineOperator

Launching Apache Beam pipelines written in Python. Note that both default_pipeline_options and pipeline_options will be merged to specify pipeline execution parameter, and default_pipeline_options is expected to save high-level options, for instances, project and zone information, which apply to all beam operators in the DAG.

Operators

LivyOperator

This operator wraps the Apache Livy batch REST API, allowing to submit a Spark application to the underlying cluster.

Operators

LivyHook

Hook for Apache Livy through the REST API.

Hooks

CloudComposerHook

Hook for Google Cloud Composer APIs.

Hooks

CloudDLPHook

Hook for Google Cloud Data Loss Prevention (DLP) APIs. Cloud DLP allows clients to detect the presence of Personally Identifiable Information (PII) and other privacy-sensitive data in user-supplied, unstructured data streams, like text blocks or images. The service also includes methods for sensitive data redaction and scheduling of data scans on Google Cloud based data sets.

Hooks

BiqQueryDataTransferServiceHook

Hook for Google Bigquery Transfer API.

Hooks

CloudVideoIntelligenceHook

Hook for Google Cloud Video Intelligence APIs.

Hooks

OSLoginHook

Hook for Google OS login APIs.

Hooks

CloudAutoMLHook

Google Cloud AutoML hook.

Hooks

CloudKMSHook

Hook for Google Cloud Key Management service.

Hooks

CloudTasksHook

Hook for Google Cloud Tasks APIs. Cloud Tasks allows developers to manage the execution of background work in their applications.

Hooks

DataprocHook

Hook for Google Cloud Dataproc APIs.

Hooks

BigtableHook

Hook for Google Cloud Bigtable APIs.

Hooks

CloudTextToSpeechHook

Hook for Google Cloud Text to Speech API.

Hooks

CloudTranslateHook

Hook for Google Cloud translate APIs.

Hooks

CloudBuildHook

Hook for the Google Cloud Build Service.

Hooks

PubSubHook

Hook for accessing Google Pub/Sub.

Hooks

CloudNaturalLanguageHook

Hook for Google Cloud Natural Language Service.

Hooks

GoogleBaseHook

A base hook for Google cloud-related hooks. Google cloud has a shared REST API client that is built in the same way no matter which service you use. This class helps construct and authorize the credentials needed to then call googleapiclient.discovery.build() to actually discover and build a client for a Google cloud service.

Hooks

GCSTaskHandler

GCSTaskHandler is a python log handler that handles and reads task instance logs. It extends airflow FileTaskHandler and uploads to and reads from GCS remote storage. Upon log reading failure, it reads from host machines local disk.

Log

CloudVisionHook

Hook for Google Cloud Vision APIs.

Hooks

CloudSpeechToTextHook

Hook for Google Cloud Speech API.

Hooks

GKEHook

Hook for Google Kubernetes Engine APIs.

Hooks

CloudDataCatalogHook

Hook for Google Cloud Data Catalog Service.

Hooks

WorkflowsHook

Hook for Google GCP APIs.

Hooks

SpannerHook

Hook for Google Cloud Spanner APIs.

Hooks

DataprocMetastoreHook

Hook for Google Cloud Dataproc Metastore APIs.

Hooks

BigQueryTablePartitionExistenceSensor

Checks for the existence of a partition within a table in Google Bigquery.

Sensors

BigQueryTableExistenceSensor

Checks for the existence of a table in Google Bigquery.

Sensors

S3PrefixSensor

Waits for a prefix or all prefixes to exist. A prefix is the first part of a key, thus enabling checking of constructs similar to glob airfl* or SQL LIKE airfl%. There is the possibility to precise a delimiter to indicate the hierarchy or keys, meaning that the match will stop at that delimiter. Current code accepts sane delimiters, i.e. characters that are NOT special characters in the Python regex engine.

Sensors

S3KeySensor

Waits for a key (a file-like instance on S3) to be present in a S3 bucket. S3 being a key/value it does not support folders. The path is just a key a resource.

Sensors

S3KeysUnchangedSensor

Checks for changes in the number of objects at prefix in AWS S3 bucket and returns True if the inactivity period has passed with no increase in the number of objects. Note, this sensor will not behave correctly in reschedule mode, as the state of the listed objects in the S3 bucket will be lost between rescheduled invocations.

Sensors

S3KeySizeSensor

Waits for a key (a file-like instance on S3) to be present and be more than some size in a S3 bucket. S3 being a key/value it does not support folders. The path is just a key a resource.

Sensors

HightouchHook

Hook for Hightouch API

Hooks

ElasticsearchTaskHandler

ElasticsearchTaskHandler is a python log handler that reads logs from Elasticsearch. Note that Airflow does not handle the indexing of logs into Elasticsearch. Instead, Airflow flushes logs into local files. Additional software setup is required to index the logs into Elasticsearch, such as using Filebeat and Logstash. To efficiently query and sort Elasticsearch results, this handler assumes each log message has a field log_id consists of ti primary keys log_id = {dag_id}-{task_id}-{execution_date}-{try_number} Log messages with specific log_id are sorted based on offset, which is a unique integer indicates log messages order. Timestamps here are unreliable because multiple log messages might have the same timestamp.

Log

SmartSensorOperator

Smart sensor operators are derived from this class.

Sensors

SensorWork

This class stores a sensor work with decoded context value. It is only used inside of smart sensor.

Sensors

PostgresToGCSOperator

Copy data from Postgres to Google Cloud Storage in JSON or CSV format.

Transfers

DiscoverableHook

Interface that providers can implement to be discovered by ProvidersManager.

Hooks

BaseHook

Abstract base class for hooks, hooks are meant as an interface to interact with external systems. MySqlHook, HiveHook, PigHook return object that can handle the connection and interaction to specific instances of these systems, and expose consistent methods to interact with them.

Hooks

HiveOperator

Executes hql code or hive script in a specific Hive database.

Operators

CloudComposerExecutionTrigger

The trigger handles the async communication with the Google Cloud Composer

Triggers

HiveCliHook

Simple wrapper around the hive CLI.

Hooks

HiveServer2Hook

Wrapper around the pyhive library

Hooks

HiveMetastoreHook

Wrapper to interact with the Hive Metastore

Hooks

GCSToGCSOperator

Copies objects from a bucket to another, with renaming if requested.

Transfers

SnsPublishOperator

Publish a message to Amazon SNS.

Operators

EksDeleteClusterOperator

Deletes the Amazon EKS Cluster control plane and all nodegroups attached to it.

Operators

EksCreateFargateProfileOperator

Creates an AWS Fargate profile for an Amazon EKS cluster.

Operators

CloudVisionDetectImageSafeSearchOperator

Detects Document Text in the image

Operators

EksCreateClusterOperator

Creates an Amazon EKS Cluster control plane.

Operators

AzureBaseHook

This hook acts as a base hook for azure services. It offers several authentication mechanisms to authenticate the client library used for upstream azure hooks.

Hooks

GithubOperator

GithubOperator to interact and perform action on GitHub API. This operator is designed to use GitHub Python SDK

Operators

EksDeleteFargateProfileOperator

Deletes an AWS Fargate profile from an Amazon EKS Cluster.

Operators

CloudVisionUpdateProductOperator

Makes changes to a Product resource. Only the display_name, description, and labels fields can be updated right now.

Operators

CloudVisionDeleteReferenceImageOperator

Deletes a ReferenceImage ID resource.

Operators

SimpleHttpOperator

Calls an endpoint on an HTTP system to execute an action

Operators

GithubSensor

Base GithubSensor which can monitor for any change.

Sensors

CloudVisionGetProductOperator

Gets information associated with a Product.

Operators

CloudVisionDetectTextOperator

Detects Text in the image

Operators

CloudVisionCreateReferenceImageOperator

Creates and returns a new ReferenceImage ID resource.

Operators

GithubTagSensor

Monitors a github tag for its creation.

Sensors

EKSCreateClusterOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.eks.EksCreateClusterOperator.

Operators

BaseGithubRepositorySensor

Base GitHub sensor at Repository level.

Sensors

CloudVisionAddProductToProductSetOperator

Adds a Product to the specified ProductSet. If the Product is already present, no change is made.

Operators

EKSCreateFargateProfileOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.eks.EksCreateFargateProfileOperator.

Operators

CloudVisionDetectImageLabelsOperator

Detects Document Text in the image

Operators

GithubHook

Interact with Github.

Hooks

EKSCreateNodegroupOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.eks.EksCreateNodegroupOperator.

Operators

CloudVisionGetProductSetOperator

Gets information associated with a ProductSet.

Operators

EKSPodOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.eks.EksPodOperator.

Operators

CloudVisionUpdateProductSetOperator

Makes changes to a ProductSet resource. Only display_name can be updated currently.

Operators

CloudVisionRemoveProductFromProductSetOperator

Removes a Product from the specified ProductSet.

Operators

EksDeleteNodegroupOperator

Deletes an Amazon EKS managed node group from an Amazon EKS Cluster.

Operators

PsrpHook

Hook for PowerShell Remoting Protocol execution.

Hooks

CloudVisionDeleteProductOperator

Permanently deletes a product and its reference images.

Operators

EksPodOperator

Executes a task in a Kubernetes pod on the specified Amazon EKS Cluster.

Operators

EKSDeleteClusterOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.eks.EksDeleteClusterOperator.

Operators

EKSDeleteFargateProfileOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.eks.EksDeleteFargateProfileOperator.

Operators

CloudVisionImageAnnotateOperator

Run image detection and annotation for an image or a batch of images.

Operators

EKSDeleteNodegroupOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.eks.EksDeleteNodegroupOperator.

Operators

EksCreateNodegroupOperator

Creates an Amazon EKS managed node group for an existing Amazon EKS Cluster.

Operators

CloudVisionDeleteProductSetOperator

Permanently deletes a ProductSet. Products and ReferenceImages in the ProductSet are not deleted. The actual image files are not deleted from Google Cloud Storage.

Operators

CloudVisionCreateProductOperator

Creates and returns a new product resource.

Operators

CloudVisionCreateProductSetOperator

Creates a new ProductSet resource.

Operators

CloudVisionTextDetectOperator

Detects Document Text in the image

Operators

EKSHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.eks.EksHook.

Hooks

EksHook

Interact with Amazon EKS, using the boto3 library.

Hooks

MsSqlOperator

Executes sql code in a specific Microsoft SQL database

Operators

TrinoToMySqlOperator

Moves data from Trino to MySQL, note that for now the data is loaded into memory before being pushed to MySQL, so this operator should be used for smallish amount of data.

Transfers

MsSqlToHiveOperator

Moves data from Microsoft SQL Server to Hive. The operator runs your query against Microsoft SQL Server, stores the file locally before loading it into a Hive table. If the create or recreate arguments are set to True, a CREATE TABLE and DROP TABLE statements are generated. Hive data types are inferred from the cursors metadata. Note that the table generated in Hive uses STORED AS textfile which isnt the most efficient serialization format. If a large amount of data is loaded and/or if the table gets queried considerably, you may want to use this operator only to stage the data into a temporary table before loading it into its final destination using a HiveOperator.

Transfers

MySqlOperator

Executes sql code in a specific MySQL database

Operators

HiveToMySqlOperator

Moves data from Hive to MySQL, note that for now the data is loaded into memory before being pushed to MySQL, so this operator should be used for smallish amount of data.

Transfers

PrestoToMySqlOperator

Moves data from Presto to MySQL, note that for now the data is loaded into memory before being pushed to MySQL, so this operator should be used for smallish amount of data.

Transfers

VerticaToMySqlOperator

Moves data from Vertica to MySQL.

Transfers

ZendeskHook

Interact with Zendesk. This hook uses the Zendesk conn_id.

Hooks

ExternalTaskSensor

Waits for a different DAG or a task in a different DAG to complete for a specific execution_date

Sensors

SpannerDeployDatabaseInstanceOperator

Creates a new Cloud Spanner database, or if database exists, the operator does nothing.

Operators

ExasolOperator

Executes sql code in a specific Exasol database

Operators

CloudSQLBaseOperator

Abstract base operator for Google Cloud SQL operators to inherit from.

Operators

BranchSQLOperator

Executes sql code in a specific database

Operators

SparkSqlOperator

Execute Spark SQL query

Operators

SnowflakeOperator

Executes SQL code in a Snowflake database

Operators

HiveToDruidOperator

Moves data from Hive to Druid, [del]note that for now the data is loaded into memory before being pushed to Druid, so this operator should be used for smallish amount of data.[/del]

Transfers

SnowflakeCheckOperator

Performs a check against Snowflake. The SnowflakeCheckOperator expects a sql query that will return a single row. Each value on that first row is evaluated using python bool casting. If any of the values return False the check is failed and errors out.

Operators

HiveToDynamoDBOperator

Moves data from Hive to DynamoDB, note that for now the data is loaded into memory before being pushed to DynamoDB, so this operator should be used for smallish amount of data.

Transfers

SQLThresholdCheckOperator

Performs a value check using sql code against a minimum threshold and a maximum threshold. Thresholds can be in the form of a numeric value OR a sql statement that results a numeric.

Operators

SpannerUpdateDatabaseInstanceOperator

Updates a Cloud Spanner database with the specified DDL statement.

Operators

CloudSQLDeleteInstanceDatabaseOperator

Deletes a database from a Cloud SQL instance.

Operators

CloudSQLPatchInstanceDatabaseOperator

Updates a resource containing information about a database inside a Cloud SQL instance using patch semantics.

Operators

MySqlToHiveOperator

Moves data from MySql to Hive. The operator runs your query against MySQL, stores the file locally before loading it into a Hive table. If the create or recreate arguments are set to True, a CREATE TABLE and DROP TABLE statements are generated. Hive data types are inferred from the cursors metadata. Note that the table generated in Hive uses STORED AS textfile which isnt the most efficient serialization format. If a large amount of data is loaded and/or if the table gets queried considerably, you may want to use this operator only to stage the data into a temporary table before loading it into its final destination using a HiveOperator.

Transfers

SQLCheckOperator

Performs checks against a db. The SQLCheckOperator expects a sql query that will return a single row. Each value on that first row is evaluated using python bool casting. If any of the values return False the check is failed and errors out.

Operators

BaseSQLToGCSOperator

Copy data from SQL to Google Cloud Storage in JSON or CSV format.

Transfers

SalesforceToGcsOperator

Submits Salesforce query and uploads results to Google Cloud Storage

Transfers

SQLIntervalCheckOperator

Checks that the values of metrics given as SQL expressions are within a certain tolerance of the ones from days_back before.

Operators

CloudSQLImportInstanceOperator

Imports data into a Cloud SQL instance from a SQL dump or CSV file in Cloud Storage.

Operators

SpannerDeleteDatabaseInstanceOperator

Deletes a Cloud Spanner database.

Operators

CloudSQLCreateInstanceDatabaseOperator

Creates a new database inside a Cloud SQL instance.

Operators

SpannerDeployInstanceOperator

Creates a new Cloud Spanner instance, or if an instance with the same instance_id exists in the specified project, updates the Cloud Spanner instance.

Operators

JdbcOperator

Executes sql code in a database using jdbc driver.

Operators

HiveToSambaOperator

Executes hql code in a specific Hive database and loads the results of the query as a csv to a Samba location.

Transfers

OracleOperator

Executes sql code in a specific Oracle database.

Operators

BaseSQLOperator

This is a base class for generic SQL Operator to get a DB Hook

Operators

SpannerQueryDatabaseInstanceOperator

Executes an arbitrary DML query (INSERT, UPDATE, DELETE).

Operators

CloudSQLExportInstanceOperator

Exports data from a Cloud SQL instance to a Cloud Storage bucket as a SQL dump or CSV file.

Operators

SnowflakeToSlackOperator

Executes an SQL statement in Snowflake and sends the results to Slack. The results of the query are rendered into the slack_message parameter as a Pandas dataframe using a JINJA variable called {{ results_df }}. The results_df variable name can be changed by specifying a different results_df_name parameter. The Tabulate library is added to the JINJA environment as a filter to allow the dataframe to be rendered nicely. as an ascii rendered table.

Transfers

SQLValueCheckOperator

Performs a simple value check using sql code.

Operators

CloudSQLInstancePatchOperator

Updates settings of a Cloud SQL instance.

Operators

SpannerDeleteInstanceOperator

Deletes a Cloud Spanner instance. If an instance does not exist, no action is taken and the operator succeeds.

Operators

SnowflakeIntervalCheckOperator

Checks that the values of metrics given as SQL expressions are within a certain tolerance of the ones from days_back before.

Operators

SqoopOperator

Execute a Sqoop job. Documentation for Apache Sqoop can be found here

Operators

CloudSQLExecuteQueryOperator

Performs DML or DDL query on an existing Cloud Sql instance. It optionally uses cloud-sql-proxy to establish secure connection with the database.

Operators

CloudSQLCreateInstanceOperator

Creates a new Cloud SQL instance. If an instance with the same name exists, no action will be taken and the operator will succeed.

Operators

SnowflakeValueCheckOperator

Performs a simple check using sql code against a specified value, within a certain level of tolerance.

Operators

CloudSQLDeleteInstanceOperator

Deletes a Cloud SQL instance.

Operators

OracleStoredProcedureOperator

Executes stored procedure in a specific Oracle database.

Operators

VerticaOperator

Executes sql code in a specific Vertica database.

Operators

VerticaToHiveOperator

Moves data from Vertica to Hive. The operator runs your query against Vertica, stores the file locally before loading it into a Hive table. If the create or recreate arguments are set to True, a CREATE TABLE and DROP TABLE statements are generated. Hive data types are inferred from the cursors metadata. Note that the table generated in Hive uses STORED AS textfile which isnt the most efficient serialization format. If a large amount of data is loaded and/or if the table gets queried considerably, you may want to use this operator only to stage the data into a temporary table before loading it into its final destination using a HiveOperator.

Transfers

SqliteOperator

Executes sql code in a specific Sqlite database

Operators

SSHHook

Hook for ssh remote execution using Paramiko. This hook also lets you create ssh tunnel and serve as basis for SFTP file transfer

Hooks

SSHOperator

SSHOperator to execute commands on given remote host using the ssh_hook.

Operators

PSRPHook

Hook for PowerShell Remoting Protocol execution.

Hooks

PsrpOperator

PowerShell Remoting Protocol operator.

Operators

PSRPOperator

PowerShell Remoting Protocol operator.

Operators

HttpHook

Interact with HTTP servers.

Hooks

EmrCreateJobFlowOperator

Creates an EMR JobFlow, reading the config from the EMR connection. A dictionary of JobFlow overrides can be passed that override the config from the connection.

Operators

SQSSensor

This sensor is deprecated. Please use airflow.providers.amazon.aws.sensors.sqs.SqsSensor.

Sensors

SqsSensor

Get messages from an SQS queue and then deletes the message from the SQS queue. If deletion of messages fails an AirflowException is thrown otherwise, the message is pushed through XCom with the key messages.

Sensors

FireboltOperator

Executes SQL code in a Firebolt database

Operators

FireboltHook

A client to interact with Firebolt. This hook requires the firebolt_conn_id connection. The firebolt login, password, and api_endpoint field must be setup in the connection. Other inputs can be defined in the connection or hook instantiation.

Hooks

SlackHook

Creates a Slack connection to be used for calls.

Hooks

YandexCloudBaseHook

A base hook for Yandex.Cloud related tasks.

Hooks

ComputeEngineSSHHook

Hook to connect to a remote instance in compute engine

Hooks

AzureDataLakeHook

Interacts with Azure Data Lake.

Hooks

PagerdutyEventsHook

This class can be used to interact with the Pagerduty Events API.

Hooks

AzureContainerVolumeHook

A hook which wraps an Azure Volume.

Hooks

KubernetesHook

Creates Kubernetes API connection.

Hooks

AsanaHook

Wrapper around Asana Python client library.

Hooks

AzureBatchHook

Hook for Azure Batch APIs

Hooks

AzureFileShareHook

Interacts with Azure FileShare Storage.

Hooks

QuboleHook

Hook for Qubole communication

Hooks

LevelDBHook

Plyvel Wrapper to Interact With LevelDB Database LevelDB Connection Documentation

Hooks

CloudantHook

Interact with Cloudant. This class is a thin wrapper around the cloudant python library.

Hooks

AzureDataExplorerHook

Interacts with Azure Data Explorer (Kusto).

Hooks

LevelDBHookException

Exception specific for LevelDB

Hooks

PagerdutyHook

The PagerdutyHook can be used to interact with both the PagerDuty API and the PagerDuty Events API.

Hooks

DockerHook

Interact with a Docker Daemon or Registry.

Hooks

AzureContainerRegistryHook

A hook to communicate with a Azure Container Registry.

Hooks

SalesforceHook

Creates new connection to Salesforce and allows you to pull data out of SFDC and save it to a file.

Hooks

JdbcHook

General hook for jdbc db access.

Hooks

WinRMHook

Hook for winrm remote execution using pywinrm.

Hooks

MySQLToS3Operator

This class is deprecated. Please use airflow.providers.amazon.aws.transfers.sql_to_s3.SqlToS3Operator.

Transfers

AwsLogsHook

Interact with AWS CloudWatch Logs

Hooks

S3ToGCSOperator

Synchronizes an S3 key, possibly a prefix, with a Google Cloud Storage destination path.

Transfers

PubSubDeleteSubscriptionOperator

Delete a PubSub subscription.

Operators

PubSubPullSensor

Pulls messages from a PubSub subscription and passes them through XCom. Always waits for at least one message to be returned from the subscription.

Sensors

PubSubPublishMessageOperator

Publish messages to a PubSub topic.

Operators

PubSubCreateSubscriptionOperator

Create a PubSub subscription.

Operators

GCSToLocalFilesystemOperator

Downloads a file from Google Cloud Storage.

Transfers

PubSubPullOperator

Pulls messages from a PubSub subscription and passes them through XCom. If the queue is empty, returns empty list - never waits for messages. If you do need to wait, please use airflow.providers.google.cloud.sensors.PubSubPullSensor instead.

Operators

PubSubDeleteTopicOperator

Delete a PubSub topic.

Operators

PubSubCreateTopicOperator

Create a PubSub topic.

Operators

CloudDataTransferServiceHook

Hook for Google Storage Transfer Service.

Hooks

CloudFormationCreateStackOperator

An operator that creates a CloudFormation stack.

Operators

CloudFormationDeleteStackOperator

An operator that deletes a CloudFormation stack.

Operators

QubolePartitionSensor

Wait for a Hive partition to show up in QHS (Qubole Hive Service) and check for its presence via QDS APIs

Sensors

JenkinsJobTriggerOperator

Trigger a Jenkins Job and monitor its execution. This operator depend on python-jenkins library, version >= 0.4.15 to communicate with jenkins server. Youll also need to configure a Jenkins connection in the connections screen.

Operators

GoogleAnalyticsListAccountsOperator

Lists all accounts to which the user has access.

Operators

BranchDayOfWeekOperator

Branches into one of two lists of tasks depending on the current day.

Operators

AthenaOperator

An operator that submits a presto query to athena.

Operators

CloudDataTransferServiceGCSToGCSOperator

Copies objects from a bucket to another using the Google Cloud Storage Transfer Service.

Operators

DataprepRunJobGroupOperator

Create a jobGroup, which launches the specified job as the authenticated user. This performs the same action as clicking on the Run Job button in the application. To get recipe_id please follow the Dataprep API documentation

Operators

AsanaCreateTaskOperator

This operator can be used to create Asana tasks. For more information on Asana optional task parameters, see

Operators

GoogleCampaignManagerReportSensor

Check if report is ready.

Sensors

OpsgenieCreateAlertOperator

This operator allows you to post alerts to Opsgenie. Accepts a connection that has an Opsgenie API key as the connections password. This operator sets the domain to conn_id.host, and if not set will default to https://api.opsgenie.com.

Operators

QuboleCheckOperator

Performs a simple value check using Qubole command. By default, each value on the first row of this Qubole command is compared with a pre-defined value. The check fails and errors out if the output of the command is not within the permissible limit of expected value.

Operators

RedshiftResumeClusterOperator

Resume a paused AWS Redshift Cluster

Operators

SlackWebhookOperator

This operator allows you to post messages to Slack using incoming webhooks. Takes both Slack webhook token directly and connection that has Slack webhook token. If both supplied, http_conn_id will be used as base_url, and webhook_token will be taken as endpoint, the relative path of the url.

Operators

GoogleDisplayVideo360GetSDFDownloadOperationSensor

Sensor for detecting the completion of SDF operation.

Sensors

AwsBatchWaitersHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.batch.BatchWaitersHook.

Hooks

SqoopHook

This hook is a wrapper around the sqoop 1 binary. To be able to use the hook it is required that “sqoop” is in the PATH.

Hooks

CloudFunctionDeleteFunctionOperator

Deletes the specified function from Google Cloud Functions.

Operators

CloudDLPDeleteDLPJobOperator

Deletes a long-running DlpJob. This method indicates that the client is no longer interested in the DlpJob result. The job will be cancelled if possible.

Operators

VaultHook

Hook to Interact with HashiCorp Vault KeyValue Secret engine.

Hooks

CloudDataCatalogDeleteEntryGroupOperator

Deletes an EntryGroup.

Operators

WorkflowsCreateWorkflowOperator

Creates a new workflow. If a workflow with the specified name already exists in the specified project and location, the long running operation will return [ALREADY_EXISTS][google.rpc.Code.ALREADY_EXISTS] error.

Operators

CloudSpeechToTextRecognizeSpeechOperator

Recognizes speech from audio file and returns it as text.

Operators

FacebookAdsReportToGcsOperator

Fetches the results from the Facebook Ads API as desired in the params Converts and saves the data as a temporary JSON file Uploads the JSON to Google Cloud Storage

Transfers

CloudTranslateTextOperator

Translate a string or list of strings.

Operators

CloudTasksQueueUpdateOperator

Updates a queue in Cloud Tasks.

Operators

HdfsSensor

Waits for a file or folder to land in HDFS

Sensors

GoogleDisplayVideo360RunReportOperator

Runs a stored query to generate a report.

Operators

StackdriverDisableNotificationChannelsOperator

Disables one or more enabled notification channels identified by filter parameter. Inoperative in case the policy is already disabled.

Operators

FTPSensor

Waits for a file or directory to be present on FTP.

Sensors

WorkflowsListWorkflowsOperator

Lists Workflows in a given project and location. The default order is not specified.

Operators

OSSCreateBucketOperator

This operator creates an OSS bucket

Operators

GoogleCampaignManagerDeleteReportOperator

Deletes a report by its ID.

Operators

RedshiftPauseClusterOperator

Pause an AWS Redshift Cluster if it has status available.

Operators

OpsgenieCloseAlertOperator

This operator allows you to close alerts to Opsgenie. Accepts a connection that has an Opsgenie API key as the connections password. This operator sets the domain to conn_id.host, and if not set will default to api.opsgenie.com.

Operators

AsanaUpdateTaskOperator

This operator can be used to update Asana tasks. For more information on Asana optional task parameters, see developers.asana.com/docs/update-a-task

Operators

QuboleFileSensor

Wait for a file or folder to be present in cloud storage and check for its presence via QDS APIs

Sensors

CloudDLPUpdateJobTriggerOperator

Updates a job trigger.

Operators

DynamoDBHook

Interact with AWS DynamoDB.

Hooks

CloudDataCatalogDeleteTagOperator

Deletes a tag.

Operators

BigtableTableReplicationCompletedSensor

Sensor that waits for Cloud Bigtable table to be fully replicated to its clusters. No exception will be raised if the instance or the table does not exist.

Sensors

CloudDataCatalogSearchCatalogOperator

Searches Data Catalog for multiple resources like entries, tags that match a query.

Operators

PapermillOperator

Executes a jupyter notebook through papermill that is annotated with parameters

Operators

SambaHook

Allows for interaction with a Samba server.

Hooks

GoogleCampaignManagerDownloadReportOperator

Retrieves a report and uploads it to GCS bucket.

Operators

WorkflowsCancelExecutionOperator

Cancels an execution using the given workflow_id and execution_id.

Operators

CloudTranslateSpeechOperator

Recognizes speech in audio input and translates it.

Operators

AzureCosmosDocumentSensor

Checks for the existence of a document which matches the given query in CosmosDB.

Sensors

CloudTasksTasksListOperator

Lists the tasks in Cloud Tasks.

Operators

CloudDLPDeidentifyContentOperator

De-identifies potentially sensitive info from a ContentItem. This method has limits on input size and output size.

Operators

BashOperator

Execute a Bash script, command or set of commands.

Operators

DmsDescribeTasksOperator

Describes AWS DMS replication tasks.

Operators

GCSObjectsWtihPrefixExistenceSensor

This class is deprecated. Please use airflow.providers.google.cloud.sensors.gcs.GCSObjectsWithPrefixExistenceSensor.

Sensors

BigQueryDataTransferServiceTransferRunSensor

Waits for Data Transfer Service run to complete.

Sensors

BigQueryToGCSOperator

Transfers a BigQuery table to a Google Cloud Storage bucket.

Transfers

CloudDLPCreateJobTriggerOperator

Creates a job trigger to run DLP actions such as scanning storage for sensitive information on a set schedule.

Operators

GoogleSearchAdsHook

Hook for Google Search Ads 360.

Hooks

QuboleCheckOperator

Performs checks against Qubole Commands. QuboleCheckOperator expects a command that will be executed on QDS. By default, each value on first row of the result of this Qubole Command is evaluated using python bool casting. If any of the values return False, the check is failed and errors out.

Operators

WasbDeleteBlobOperator

Deletes blob(s) on Azure Blob Storage.

Operators

DataprepGetJobGroupOperator

Get the specified job group. A job group is a job that is executed from a specific node in a flow. API documentation clouddataprep.com/documentation/api#section/Overview

Operators

BaseBranchOperator

This is a base class for creating operators with branching functionality, similarly to BranchPythonOperator.

Operators

AsanaDeleteTaskOperator

This operator can be used to delete Asana tasks.

Operators

DataflowJobMetricsSensor

Checks the metrics of a job in Google Cloud Dataflow.

Sensors

GoogleDisplayVideo360ReportSensor

Sensor for detecting the completion of DV360 reports.

Sensors

GoogleCampaignManagerBatchInsertConversionsOperator

Inserts conversions.

Operators

CloudDataCatalogLookupEntryOperator

Get an entry by target resource name.

Operators

SQSPublishOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.sqs.SqsPublishOperator.

Operators

PrestoToGCSOperator

Copy data from PrestoDB to Google Cloud Storage in JSON or CSV format.

Transfers

CloudTasksQueueCreateOperator

Creates a queue in Cloud Tasks.

Operators

CloudDLPInspectContentOperator

Finds potentially sensitive info in content. This method has limits on input size, processing time, and output size.

Operators

EC2InstanceStateSensor

Check the state of the AWS EC2 instance until state of the instance become equal to the target state.

Sensors

GoogleSheetsCreateSpreadsheetOperator

Creates a new spreadsheet.

Operators

CloudDataCatalogCreateEntryOperator

Creates an entry.

Operators

AWSDataSyncOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.datasync.DataSyncOperator.

Operators

CloudDLPCreateDLPJobOperator

Creates a new job to inspect storage or calculate risk metrics.

Operators

AutoMLTrainModelOperator

Creates Google Cloud AutoML model.

Operators

CassandraHook

Hook used to interact with Cassandra

Hooks

StackdriverHook

Stackdriver Hook for connecting with Google Cloud Stackdriver

Hooks

JiraTicketSensor

Monitors a jira ticket for given change in terms of function.

Sensors

SegmentHook

Create new connection to Segment and allows you to pull data out of Segment or write to it.

Hooks

WorkflowsGetWorkflowOperator

Gets details of a single Workflow.

Operators

HdfsFolderSensor

Waits for a non-empty directory

Sensors

CassandraTableSensor

Checks for the existence of a table in a Cassandra cluster.

Sensors

GCSToGoogleSheetsOperator

Uploads .csv file from Google Cloud Storage to provided Google Spreadsheet.

Transfers

AthenaSensor

Asks for the state of the Query until it reaches a failure state or success state. If the query fails, the task will fail.

Sensors

GoogleAnalyticsRetrieveAdsLinksListOperator

Lists webProperty-Google Ads links for a given web property

Operators

SingularityOperator

Execute a command inside a Singularity container

Operators

StepFunctionGetExecutionOutputOperator

An Operator that begins execution of an Step Function State Machine

Operators

CloudTasksTaskRunOperator

Forces to run a task in Cloud Tasks.

Operators

CloudNaturalLanguageAnalyzeSentimentOperator

Analyzes the sentiment of the provided text.

Operators

CloudDLPRedactImageOperator

Redacts potentially sensitive info from an image. This method has limits on input size, processing time, and output size.

Operators

DrillOperator

Executes the provided SQL in the identified Drill environment.

Operators

CloudDatastoreAllocateIdsOperator

Allocate IDs for incomplete keys. Return list of keys.

Operators

SlackAPIOperator

Base Slack Operator The SlackAPIPostOperator is derived from this operator. In the future additional Slack API Operators will be derived from this class as well. Only one of slack_conn_id and token is required.

Operators

CloudFirestoreExportDatabaseOperator

Exports a copy of all or a subset of documents from Google Cloud Firestore to another storage system, such as Google Cloud Storage.

Operators

GoogleSearchAdsDownloadReportOperator

Downloads a report to GCS bucket.

Operators

WasbPrefixSensor

Waits for blobs matching a prefix to arrive on Azure Blob Storage.

Sensors

CloudDatastoreRollbackOperator

Roll back a transaction.

Operators

GoogleAnalyticsDeletePreviousDataUploadsOperator

Deletes previous GA uploads to leave the latest file to control the size of the Data Set Quota.

Operators

PlexusJobOperator

Submits a Plexus job.

Operators

CloudDLPCreateStoredInfoTypeOperator

Creates a pre-built stored infoType to be used for inspection.

Operators

CloudDataCatalogGetTagTemplateOperator

Gets a tag template.

Operators

GoogleAdsListAccountsOperator

Saves list of customers on GCS in form of a csv file.

Operators

DataFusionHook

Hook for Google DataFusion.

Hooks

WasbBlobSensor

Waits for a blob to arrive on Azure Blob Storage.

Sensors

CloudTasksQueuesListOperator

Lists queues from Cloud Tasks.

Operators

DmsTaskCompletedSensor

Pokes DMS task until it is completed.

Sensors

OSSDownloadObjectOperator

This operator to Download an OSS object

Operators

OracleToOracleOperator

Moves data from Oracle to Oracle.

Transfers

AzureDataFactoryPipelineRunStatusSensor

Checks the status of a pipeline run.

Sensors

DayOfWeekSensor

Waits until the first specified day of the week. For example, if the execution day of the task is 2018-12-22 (Saturday) and you pass FRIDAY, the task will wait until next Friday.

Sensors

SFTPToGCSOperator

Transfer files to Google Cloud Storage from SFTP server.

Transfers

CloudDLPReidentifyContentOperator

Re-identifies content that has been de-identified.

Operators

GoogleDataprepHook

Hook for connection with Dataprep API. To get connection Dataprep with Airflow you need Dataprep token. clouddataprep.com/documentation/api#section/Authentication

Hooks

TableauJobStatusSensor

Watches the status of a Tableau Server Job.

Sensors

CloudTasksQueueGetOperator

Gets a queue from Cloud Tasks.

Operators

MongoToS3Operator

Operator meant to move data from mongo via pymongo to s3 via boto.

Transfers

ComputeEngineCopyInstanceTemplateOperator

Copies the instance template, applying specified changes.

Operators

AwsSnsHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.sns.SnsHook.

Hooks

CloudDLPGetDLPJobOperator

Gets the latest state of a long-running DlpJob.

Operators

StepFunctionExecutionSensor

Asks for the state of the Step Function State Machine Execution until it reaches a failure state or success state. If it fails, failing the task.

Sensors

CloudDataTransferServiceS3ToGCSOperator

Synchronizes an S3 bucket with a Google Cloud Storage bucket using the Google Cloud Storage Transfer Service.

Operators

CloudDatastoreImportEntitiesOperator

Import entities from Cloud Storage to Google Cloud Datastore

Operators

StackdriverListAlertPoliciesOperator

Fetches all the Alert Policies identified by the filter passed as filter parameter. The desired return type can be specified by the format parameter, the supported formats are “dict”, “json” and None which returns python dictionary, stringified JSON and protobuf respectively.

Operators

LifeSciencesRunPipelineOperator

Runs a Life Sciences Pipeline

Operators

OSSDeleteObjectOperator

This operator to delete an OSS object

Operators

OracleToAzureDataLakeOperator

Moves data from Oracle to Azure Data Lake. The operator runs the query against Oracle and stores the file locally before loading it into Azure Data Lake.

Transfers

EmailOperator

Sends an email.

Operators

SFTPSensor

Waits for a file or directory to be present on SFTP.

Sensors

DatadogHook

Uses datadog API to send metrics of practically anything measurable, so its possible to track

Hooks

CloudDLPDeleteJobTriggerOperator

Deletes a job trigger.

Operators

CassandraToGCSOperator

Copy data from Cassandra to Google Cloud Storage in JSON format

Transfers

AwsGlueCatalogHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.glue_catalog.GlueCatalogHook.

Hooks

SageMakerEndpointSensor

Asks for the state of the endpoint state until it reaches a terminal state. If it fails the sensor errors, the task fails.

Sensors

DmsCreateTaskOperator

Creates AWS DMS replication task.

Operators

SecretsManagerHook

Hook for the Google Secret Manager API.

Hooks

MySQLToGCSOperator

Copy data from MySQL to Google Cloud Storage in JSON or CSV format.

Transfers

QuboleSensor

Base class for all Qubole Sensors

Sensors

GoogleAdsHook

Hook for the Google Ads API.

Hooks

BigtableUpdateInstanceOperator

Updates an existing Cloud Bigtable instance.

Operators

JiraSensor

Monitors a jira ticket for any change.

Sensors

GoogleDriveToGCSOperator

Writes a Google Drive file into Google Cloud Storage.

Transfers

CloudDataCatalogCreateTagTemplateOperator

Creates a tag template.

Operators

LocalFilesystemToS3Operator

Uploads a file from a local filesystem to Amazon S3.

Transfers

LifeSciencesHook

Hook for the Google Cloud Life Sciences APIs.

Hooks

JiraOperator

JiraOperator to interact and perform action on Jira issue tracking system. This operator is designed to use Jira Python SDK.

Operators

RedisPubSubSensor

Redis sensor for reading a message from pub sub channels

Sensors

CloudDatastoreDeleteOperationOperator

Deletes the long-running operation.

Operators

KylinHook

Interact with Kylin to run CubeSource commands and get job status.

Hooks

GoogleDisplayVideo360SDFtoGCSOperator

Download SDF media and save it in the Google Cloud Storage.

Operators

CloudDLPListJobTriggersOperator

Lists job triggers.

Operators

GlueCrawlerHook

Interacts with AWS Glue Crawler.

Hooks

BigtableCreateInstanceOperator

Creates a new Cloud Bigtable instance. If the Cloud Bigtable instance with the given ID exists, the operator does not compare its configuration and immediately succeeds. No changes are made to the existing instance.

Operators

CloudMemorystoreHook

Hook for Google Cloud Memorystore APIs.

Hooks

WasbTaskHandler

WasbTaskHandler is a python log handler that handles and reads task instance logs. It extends airflow FileTaskHandler and uploads to and reads from Wasb remote storage.

Log

SqlSensor

Runs a sql statement repeatedly until a criteria is met. It will keep trying until success or failure criteria are met, or if the first cell is not in (0, 0, , None). Optional success and failure callables are called with the first cell returned as the argument. If success callable is defined the sensor will keep retrying until the criteria is met. If failure callable is defined and the criteria is met the sensor will raise AirflowException. Failure criteria is evaluated before success criteria. A fail_on_empty boolean can also be passed to the sensor in which case it will fail if no rows have been returned

Sensors

SecretsManagerHook

Interact with Amazon SecretsManager Service.

Hooks

GoogleCampaignManagerRunReportOperator

Runs a report.

Operators

CloudDataCatalogGetEntryOperator

Gets an entry.

Operators

CloudDataCatalogListTagsOperator

Lists the tags on an Entry.

Operators

GoogleDisplayVideo360DeleteReportOperator

Deletes a stored query as well as the associated stored reports.

Operators

OpsgenieAlertHook

This hook allows you to post alerts to Opsgenie. Accepts a connection that has an Opsgenie API key as the connections password. This hook sets the domain to conn_id.host, and if not set will default to api.opsgenie.com.

Hooks

SqsHook

Interact with Amazon Simple Queue Service.

Hooks

AzureBatchOperator

Executes a job on Azure Batch Service

Operators

ImapAttachmentToS3Operator

Transfers a mail attachment from a mail server into s3 bucket.

Transfers

OSSDeleteBucketOperator

This operator to delete an OSS bucket

Operators

StackdriverEnableNotificationChannelsOperator

Enables one or more disabled alerting policies identified by filter parameter. Inoperative in case the policy is already enabled.

Operators

EC2StopInstanceOperator

Stop AWS EC2 instance using boto3.

Operators

SageMakerTrainingSensor

Asks for the state of the training state until it reaches a terminal state. If it fails the sensor errors, failing the task.

Sensors

OpenFaasHook

Interact with OpenFaaS to query, deploy, invoke and update function

Hooks

RedisPublishOperator

Publish a message to Redis.

Operators

CloudDLPCancelDLPJobOperator

Starts asynchronous cancellation on a long-running DlpJob.

Operators

PigOperator

Executes pig script.

Operators

CloudTasksTaskDeleteOperator

Deletes a task from Cloud Tasks.

Operators

CloudDataCatalogUpdateTagTemplateFieldOperator

Updates a field in a tag template. This method cannot be used to update the field type.

Operators

LevelDBOperator

Execute command in LevelDB

Operators

CloudDLPCreateInspectTemplateOperator

Creates an InspectTemplate for re-using frequently used configuration for inspecting content, images, and storage.

Operators

DatadogSensor

A sensor to listen, with a filter, to datadog event streams and determine if some event was emitted.

Sensors

AutoMLCreateDatasetOperator

Creates a Google Cloud AutoML dataset.

Operators

CloudDataCatalogUpdateEntryOperator

Updates an existing entry.

Operators

GoogleDisplayVideo360DownloadReportOperator

Retrieves a stored query.

Operators

TrinoToGCSOperator

Copy data from TrinoDB to Google Cloud Storage in JSON or CSV format.

Transfers

DataSyncOperator

Find, Create, Update, Execute and Delete AWS DataSync Tasks.

Operators

StackdriverDisableAlertPoliciesOperator

Disables one or more enabled alerting policies identified by filter parameter. Inoperative in case the policy is already disabled.

Operators

WebHDFSHook

Interact with HDFS. This class is a wrapper around the hdfscli library.

Hooks

GoogleDisplayVideo360UploadLineItemsOperator

Uploads line items in CSV format.

Operators

CloudDataCatalogDeleteTagTemplateOperator

Deletes a tag template and all tags using the template.

Operators

GlacierToGCSOperator

Transfers data from Amazon Glacier to Google Cloud Storage

Transfers

AzureFileShareToGCSOperator

Synchronizes a Azure FileShare directory content (excluding subdirectories), possibly filtered by a prefix, with a Google Cloud Storage destination path.

Transfers

ComputeEngineInstanceGroupUpdateManagerTemplateOperator

Patches the Instance Group Manager, replacing source template URL with the destination one. API V1 does not have update/patch operations for Instance Group Manager, so you must use beta or newer API version. Beta is the default.

Operators

DmsHook

Interact with AWS Database Migration Service.

Hooks

FTPSSensor

Waits for a file or directory to be present on FTP over SSL.

Sensors

CloudFormationCreateStackSensor

Waits for a stack to be created successfully on AWS CloudFormation.

Sensors

ADLSToGCSOperator

Synchronizes an Azure Data Lake Storage path with a GCS bucket

Transfers

ExasolToS3Operator

Export data from Exasol database to AWS S3 bucket.

Transfers

HivePartitionSensor

Waits for a partition to show up in Hive.

Sensors

CloudDataTransferServiceJobStatusSensor

Waits for at least one operation belonging to the job to have the expected status.

Sensors

LocalFilesystemToGCSOperator

Uploads a file or list of files to Google Cloud Storage. Optionally can compress the file for upload.

Transfers

AzureBlobStorageToGCSOperator

Operator transfers data from Azure Blob Storage to specified bucket in Google Cloud Storage

Transfers

SnsHook

Interact with Amazon Simple Notification Service.

Hooks

CloudMemorystoreMemcachedHook

Hook for Google Cloud Memorystore for Memcached service APIs.

Hooks

AutoMLTablesListTableSpecsOperator

Lists table specs in a dataset.

Operators

CloudDataCatalogRenameTagTemplateFieldOperator

Renames a field in a tag template.

Operators

AWSCloudFormationHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.cloud_formation.CloudFormationHook.

Hooks

AwsFirehoseHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.kinesis.FirehoseHook.

Hooks

GoogleCalendarHook

Interact with Google Calendar via Google Cloud connection Reading and writing cells in Google Sheet

Hooks

StackdriverDeleteAlertOperator

Deletes an alerting policy.

Operators

AutoMLBatchPredictOperator

Perform a batch prediction on Google Cloud AutoML.

Operators

BashSensor

Executes a bash command/script and returns True if and only if the return code is 0.

Sensors

CloudDLPGetStoredInfoTypeOperator

Gets a stored infoType.

Operators

DataflowJobAutoScalingEventsSensor

Checks for the job autoscaling event in Google Cloud Dataflow.

Sensors

HiveStatsCollectionOperator

Gathers partition statistics using a dynamically generated Presto query, inserts the stats into a MySql table with this format. Stats overwrite themselves if you rerun the same date/partition.

Operators

ADLSDeleteOperator

Delete files in the specified path.

Operators

CloudDataCatalogCreateEntryGroupOperator

Creates an EntryGroup.

Operators

DingdingOperator

This operator allows you send Dingding message using Dingding custom bot. Get Dingding token from conn_id.password. And prefer set domain to conn_id.host, if not will use default oapi.dingtalk.com.

Operators

CloudDatastoreExportEntitiesOperator

Export entities from Google Cloud Datastore to Cloud Storage

Operators

CloudDLPListStoredInfoTypesOperator

Lists stored infoTypes.

Operators

SqliteHook

Interact with SQLite.

Hooks

SFTPOperator

SFTPOperator for transferring files from remote host to local or vice a versa. This operator uses ssh_hook to open sftp transport channel that serve as basis for file transfer.

Operators

DmsStartTaskOperator

Starts AWS DMS replication task.

Operators

CloudDataTransferServiceResumeOperationOperator

Resumes a transfer operation in Google Storage Transfer Service.

Operators

CloudFunctionInvokeFunctionOperator

Invokes a deployed Cloud Function. To be used for testing purposes as very limited traffic is allowed.

Operators

MetastoreBackend

Retrieves Connection object and Variable from airflow metastore database.

Secrets

SparkJDBCHook

This hook extends the SparkSubmitHook specifically for performing data transfers to/from JDBC-based databases with Apache Spark.

Hooks

AWSDataSyncHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.datasync.DataSyncHook.

Hooks

HDFSHook

Interact with HDFS. This class is a wrapper around the snakebite library.

Hooks

CloudDLPListInfoTypesOperator

Returns a list of the sensitive information types that the DLP API supports.

Operators

PinotAdminHook

This hook is a wrapper around the pinot-admin.sh script. For now, only small subset of its subcommands are implemented, which are required to ingest offline data into Apache Pinot (i.e., AddSchema, AddTable, CreateSegment, and UploadSegment). Their command options are based on Pinot v0.1.0.

Hooks

GoogleCampaignManagerInsertReportOperator

Creates a report.

Operators

CloudDLPListDeidentifyTemplatesOperator

Lists DeidentifyTemplates.

Operators

AutoMLDeployModelOperator

Deploys a model. If a model is already deployed, deploying it with the same parameters has no effect. Deploying with different parameters (as e.g. changing node_number) will reset the deployment state without pausing the model_ids availability.

Operators

GoogleDriveFileExistenceSensor

Checks for the existence of a file in Google Cloud Storage.

Sensors

DruidOperator

Allows to submit a task directly to druid

Operators

StackdriverListNotificationChannelsOperator

Fetches all the Notification Channels identified by the filter passed as filter parameter. The desired return type can be specified by the format parameter, the supported formats are “dict”, “json” and None which returns python dictionary, stringified JSON and protobuf respectively.

Operators

GoogleCampaignManagerBatchUpdateConversionsOperator

Updates existing conversions.

Operators

AirbyteTriggerSyncOperator

This operator allows you to submit a job to an Airbyte server to run a integration process between your source and destination.

Operators

RedshiftHook

Interact with AWS Redshift, using the boto3 library

Hooks

AzureContainerInstanceHook

A hook to communicate with Azure Container Instances.

Hooks

DataprocHook

A base hook for Yandex.Cloud Data Proc.

Hooks

ImapHook

This hook connects to a mail server by using the imap protocol.

Hooks

CloudTasksQueueDeleteOperator

Deletes a queue from Cloud Tasks, even if it has tasks in it.

Operators

Neo4jHook

Interact with Neo4j.

Hooks

BigQueryToMySqlOperator

Fetches the data from a BigQuery table (alternatively fetch data for selected columns) and insert that data into a MySQL table.

Transfers

CloudDLPGetDLPJobTriggerOperator

Gets a job trigger.

Operators

GoogleAnalyticsGetAdsLinkOperator

Returns a web property-Google Ads link to which the user has access.

Operators

SegmentTrackEventOperator

Send Track Event to Segment for a specified user_id and event

Operators

GoogleCampaignManagerHook

Hook for Google Campaign Manager.

Hooks

FirehoseHook

Interact with AWS Kinesis Firehose.

Hooks

DataflowJobMessagesSensor

Checks for the job message in Google Cloud Dataflow.

Sensors

S3ToHiveOperator

Moves data from S3 to Hive. The operator downloads a file from S3, stores the file locally before loading it into a Hive table. If the create or recreate arguments are set to True, a CREATE TABLE and DROP TABLE statements are generated. Hive data types are inferred from the cursors metadata from.

Transfers

S3ToFTPOperator

This operator enables the transferring of files from S3 to a FTP server.

Transfers

CloudDataCatalogDeleteTagTemplateFieldOperator

Deletes a field in a tag template and all uses of that field.

Operators

RedshiftSQLHook

Execute statements against Amazon Redshift, using redshift_connector

Hooks

S3ToRedshiftOperator

Executes an COPY command to load files from s3 to Redshift

Transfers

LocalToAzureDataLakeStorageOperator

This class is deprecated. Please use airflow.providers.microsoft.azure.transfers.local_to_adls.LocalFilesystemToADLSOperator.

Transfers

DruidHook

Connection to Druid overlord for ingestion

Hooks

GrpcOperator

Calls a gRPC endpoint to execute an action

Operators

CloudNaturalLanguageClassifyTextOperator

Classifies a document into categories.

Operators

AutoMLTablesUpdateDatasetOperator

Updates a dataset.

Operators

AwsGlueJobHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.glue.GlueJobHook.

Hooks

MetastorePartitionSensor

An alternative to the HivePartitionSensor that talk directly to the MySQL db. This was created as a result of observing sub optimal queries generated by the Metastore thrift service when hitting subpartitioned tables. The Thrift services queries were written in a way that wouldnt leverage the indexes.

Sensors

BatchWaitersHook

A utility to manage waiters for AWS Batch services.

Hooks

DatastoreHook

Interact with Google Cloud Datastore. This hook uses the Google Cloud connection.

Hooks

GlacierJobOperationSensor

Glacier sensor for checking job state. This operator runs only in reschedule mode.

Sensors

AutoMLDeleteModelOperator

Delete Google Cloud AutoML model.

Operators

OSSKeySensor

Waits for a key (a file-like instance on OSS) to be present in a OSS bucket. OSS being a key/value it does not support folders. The path is just a key a resource.

Sensors

CloudDataCatalogUpdateTagTemplateOperator

Updates a tag template.

Operators

ComputeEngineSetMachineTypeOperator

the request.

Operators

CloudTasksTaskGetOperator

Gets a task from Cloud Tasks.

Operators

CloudNaturalLanguageAnalyzeEntitySentimentOperator

Finds entities, similar to AnalyzeEntities in the text and analyzes sentiment associated with each entity and its mentions.

Operators

SparkJDBCOperator

This operator extends the SparkSubmitOperator specifically for performing data transfers to/from JDBC-based databases with Apache Spark. As with the SparkSubmitOperator, it assumes that the “spark-submit” binary is available on the PATH.

Operators

ComputeEngineStartInstanceOperator

Starts an instance in Google Compute Engine.

Operators

LivySensor

Monitor a Livy sessions for termination.

Sensors

GoogleDisplayVideo360DownloadLineItemsOperator

Retrieves line items in CSV format.

Operators

NamedHivePartitionSensor

Waits for a set of partitions to show up in Hive.

Sensors

HdfsRegexSensor

Waits for matching files by matching on regex

Sensors

CloudFormationHook

Interact with AWS CloudFormation.

Hooks

CloudTextToSpeechSynthesizeOperator

Synthesizes text to speech and stores it in Google Cloud Storage

Operators

JiraHook

Jira interaction hook, a Wrapper around JIRA Python SDK.

Hooks

GoogleSheetsToGCSOperator

Writes Google Sheet data into Google Cloud Storage.

Transfers

BigQueryToMsSqlOperator

Fetches the data from a BigQuery table (alternatively fetch data for selected columns) and insert that data into a MSSQL table.

Transfers

BigtableUpdateClusterOperator

Updates a Cloud Bigtable cluster.

Operators

CloudDatastoreGetOperationOperator

Gets the latest state of a long-running operation.

Operators

DmsDeleteTaskOperator

Deletes AWS DMS replication task.

Operators

SecretsManagerBackend

Retrieves Connection or Variables from AWS Secrets Manager

Secrets

AwsBatchClientHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.batch.BatchClientHook.

Hooks

CloudDataCatalogGetEntryGroupOperator

Gets an entry group.

Operators

TimeDeltaSensor

Waits for a timedelta after the tasks execution_date + schedule_interval. In Airflow, the daily task stamped with execution_date 2016-01-01 can only start running on 2016-01-02. The timedelta here represents the time after the execution period has closed.

Sensors

CloudDLPGetDeidentifyTemplateOperator

Gets a DeidentifyTemplate.

Operators

CloudDataCatalogUpdateTagOperator

Updates an existing tag.

Operators

SageMakerTransformSensor

Asks for the state of the transform state until it reaches a terminal state. The sensor will error if the job errors, throwing a AirflowException containing the failure reason.

Sensors

VaultBackend

Retrieves Connections and Variables from Hashicorp Vault.

Secrets

CloudDLPDeleteDeidentifyTemplateOperator

Deletes a DeidentifyTemplate.

Operators

CloudTasksQueueResumeOperator

Resumes a queue in Cloud Tasks.

Operators

CloudDataCatalogCreateTagTemplateFieldOperator

Creates a field in a tag template.

Operators

SystemsManagerParameterStoreBackend

Retrieves Connection or Variables from AWS SSM Parameter Store

Secrets

TelegramOperator

This operator allows you to post messages to Telegram using Telegram Bot API. Takes both Telegram Bot API token directly or connection that has Telegram token in password field. If both supplied, token parameter will be given precedence.

Operators

AwsGlueCrawlerHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.glue_crawler.GlueCrawlerHook.

Hooks

PythonSensor

Waits for a Python callable to return True.

Sensors

DataSyncHook

Interact with AWS DataSync.

Hooks

AirbyteHook

Hook for Airbyte API

Hooks

ExasolHook

Interact with Exasol.

Hooks

CloudDataTransferServiceDeleteJobOperator

Delete a transfer job. This is a soft delete. After a transfer job is deleted, the job and all the transfer executions are subject to garbage collection. Transfer jobs become eligible for garbage collection 30 days after soft delete.

Operators

CloudDLPDeleteStoredInfoTypeOperator

Deletes a stored infoType.

Operators

CloudVideoIntelligenceDetectVideoExplicitContentOperator

Performs video annotation, annotating explicit content.

Operators

CloudDLPListDLPJobsOperator

Lists DlpJobs that match the specified filter in the request.

Operators

AutoMLPredictOperator

Runs prediction operation on Google Cloud AutoML.

Operators

GoogleAnalyticsModifyFileHeadersDataImportOperator

GA has a very particular naming convention for Data Import.

Operators

GrpcHook

General interaction with gRPC servers.

Hooks

SFTPToS3Operator

This operator enables the transferring of files from a SFTP server to Amazon S3.

Transfers

CloudDatastoreBeginTransactionOperator

Begins a new transaction. Returns a transaction handle.

Operators

WorkflowsListExecutionsOperator

Returns a list of executions which belong to the workflow with the given name. The method returns executions of all workflow revisions. Returned executions are ordered by their start time (newest first).

Operators

ElasticsearchHook

Interact with Elasticsearch through the elasticsearch-dbapi.

Hooks

ComputeEngineStopInstanceOperator

Stops an instance in Google Compute Engine.

Operators

CloudFunctionDeployFunctionOperator

Creates a function in Google Cloud Functions. If a function with this name already exists, it will be updated.

Operators

GoogleAnalyticsDataImportUploadOperator

Take a file from Cloud Storage and uploads it to GA via data import API.

Operators

TableauHook

Connects to the Tableau Server Instance and allows to communicate with it.

Hooks

CloudDataCatalogDeleteEntryOperator

Deletes an existing entry.

Operators

GCSToGoogleDriveOperator

Copies objects from a Google Cloud Storage service to a Google Drive service, with renaming if requested.

Transfers

StepFunctionHook

Interact with an AWS Step Functions State Machine.

Hooks

WinRMOperator

WinRMOperator to execute commands on given remote host using the winrm_hook.

Operators

DiscordWebhookHook

This hook allows you to post messages to Discord using incoming webhooks. Takes a Discord connection ID with a default relative webhook endpoint. The default endpoint can be overridden using the webhook_endpoint parameter (discordapp.com/developers/docs/resources/webhook).

Hooks

S3ToMySqlOperator

Loads a file from S3 into a MySQL table.

Transfers

ADLSListOperator

List all files from the specified path

Operators

AzureContainerInstancesOperator

Start a container on Azure Container Instances

Operators

SalesforceToS3Operator

Submits a Salesforce query and uploads the results to AWS S3.

Transfers

GCSObjectsWithPrefixExistenceSensor

Checks for the existence of GCS objects at a given prefix, passing matches via XCom.

Sensors

AutoMLTablesListColumnSpecsOperator

Lists column specs in a table.

Operators

SQLToGoogleSheetsOperator

Copy data from SQL results to provided Google Spreadsheet.

Transfers

BigtableDeleteInstanceOperator

Deletes the Cloud Bigtable instance, including its clusters and all related tables.

Operators

CloudDataTransferServiceCancelOperationOperator

Cancels a transfer operation in Google Storage Transfer Service.

Operators

BatchClientHook

A client for AWS Batch services.

Hooks

ComputeEngineBaseOperator

Abstract base operator for Google Compute Engine operators to inherit from.

Operators

OracleToGCSOperator

Copy data from Oracle to Google Cloud Storage in JSON or CSV format.

Transfers

CloudDatastoreRunQueryOperator

Run a query for entities. Returns the batch of query results.

Operators

CloudFormationDeleteStackSensor

Waits for a stack to be deleted successfully on AWS CloudFormation.

Sensors

SparkSubmitOperator

This hook is a wrapper around the spark-submit binary to kick off a spark-submit job. It requires that the “spark-submit” binary is in the PATH or the spark-home is set in the extra on the connection.

Operators

BigtableDeleteTableOperator

Deletes the Cloud Bigtable table.

Operators

StackdriverDeleteNotificationChannelOperator

Deletes a notification channel.

Operators

ImapAttachmentSensor

Waits for a specific attachment on a mail server.

Sensors

CloudDataFusionPipelineStateSensor

Check the status of the pipeline in the Google Cloud Data Fusion

Sensors

WorkflowsUpdateWorkflowOperator

Updates an existing workflow. Running this method has no impact on already running executions of the workflow. A new revision of the workflow may be created as a result of a successful update operation. In that case, such revision will be used in new workflow executions.

Operators

DingdingHook

This hook allows you send Dingding message using Dingding custom bot. Get Dingding token from conn_id.password. And prefer set domain to conn_id.host, if not will use default oapi.dingtalk.com.

Hooks

ElastiCacheReplicationGroupHook

Interact with AWS ElastiCache

Hooks

AzureDataExplorerQueryOperator

Operator for querying Azure Data Explorer (Kusto).

Operators

CloudDLPListInspectTemplatesOperator

Lists InspectTemplates.

Operators

CloudDataTransferServiceUpdateJobOperator

Updates a transfer job that runs periodically.

Operators

BranchDateTimeOperator

Branches into one of two lists of tasks depending on the current datetime. For more information on how to use this operator, take a look at the guide. BranchDateTimeOperator

Operators

SlackAPIFileOperator

Send a file to a slack channel

Operators

MongoSensor

Checks for the existence of a document which matches the given query in MongoDB.

Sensors

AsanaFindTaskOperator

This operator can be used to retrieve Asana tasks that match various filters. See developers.asana.com/docs/update-a-task for a list of possible filters.

Operators

StackdriverUpsertAlertOperator

Creates a new alert or updates an existing policy identified the name field in the alerts parameter.

Operators

SQSHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.sqs.SqsHook.

Hooks

DmsStopTaskOperator

Stops AWS DMS replication task.

Operators

StackdriverUpsertNotificationChannelOperator

Creates a new notification or updates an existing notification channel identified the name field in the alerts parameter.

Operators

GCSToSFTPOperator

Transfer files from a Google Cloud Storage bucket to SFTP server.

Transfers

CloudDLPGetInspectTemplateOperator

Gets an InspectTemplate.

Operators

CloudFirestoreHook

Hook for the Google Firestore APIs.

Hooks

GoogleDiscoveryApiHook

A hook to use the Google API Discovery Service.

Hooks

CloudDataTransferServiceCreateJobOperator

Creates a transfer job that runs periodically.

Operators

WorkflowExecutionSensor

Checks state of an execution for the given workflow_id and execution_id.

Sensors

GoogleSearchAdsInsertReportOperator

Inserts a report request into the reporting system.

Operators

DockerSwarmOperator

Execute a command as an ephemeral docker swarm service. Example use-case - Using Docker Swarm orchestration to make one-time scripts highly available.

Operators

DataflowJobStatusSensor

Checks for the status of a job in Google Cloud Dataflow.

Sensors

AutoMLListDatasetOperator

Lists AutoML Datasets in project.

Operators

GSheetsHook

Interact with Google Sheets via Google Cloud connection Reading and writing cells in Google Sheet. developers.google.com/sheets/api/guides/values

Hooks

GlueCatalogHook

Interact with AWS Glue Catalog

Hooks

GoogleDisplayVideo360CreateReportOperator

Creates a query.

Operators

SparkSqlHook

This hook is a wrapper around the spark-sql binary. It requires that the “spark-sql” binary is in the PATH.

Hooks

CloudSecretManagerBackend

Retrieves Connection object from Google Cloud Secrets Manager

Secrets

WorkflowsDeleteWorkflowOperator

Deletes a workflow with the specified name. This method also cancels and deletes all running executions of the workflow.

Operators

WorkflowsGetExecutionOperator

Returns an execution for the given workflow_id and execution_id.

Operators

CloudTasksTaskCreateOperator

Creates a task in Cloud Tasks.

Operators

SparkKubernetesOperator

Creates sparkApplication object in kubernetes cluster.

Operators

AutoMLGetModelOperator

Get Google Cloud AutoML model.

Operators

GlueJobHook

Interact with AWS Glue - create job, trigger, crawler

Hooks

TableauOperator

Execute a Tableau API Resource tableau.github.io/server-client-python/docs/api-ref

Operators

StepFunctionStartExecutionOperator

An Operator that begins execution of an Step Function State Machine

Operators

CloudDLPUpdateInspectTemplateOperator

Updates the InspectTemplate.

Operators

CloudFunctionsHook

Hook for the Google Cloud Functions APIs.

Hooks

TableauRefreshWorkbookOperator

This operator is deprecated. Please use airflow.providers.tableau.operators.tableau.

Operators

EC2Hook

Interact with AWS EC2 Service.

Hooks

SalesforceApexRestOperator

Execute a APEX Rest API action

Operators

CassandraRecordSensor

Checks for the existence of a record in a Cassandra cluster.

Sensors

CloudDataTransferServiceListOperationsOperator

Lists long-running operations in Google Storage Transfer Service that match the specified filter.

Operators

CloudVideoIntelligenceDetectVideoLabelsOperator

Performs video annotation, annotating video labels.

Operators

CloudDataCatalogCreateTagOperator

Creates a tag on an entry.

Operators

GCSObjectUpdateSensor

Checks if an object is updated in Google Cloud Storage.

Sensors

GoogleDisplayVideo360CreateSDFDownloadTaskOperator

Creates SDF operation task.

Operators

DruidDbApiHook

Interact with Druid broker

Hooks

AWSAthenaOperator

This operator is deprecated. Please use airflow.providers.amazon.aws.operators.athena.AthenaOperator.

Operators

AutoMLImportDataOperator

Imports data to a Google Cloud AutoML dataset.

Operators

MSSQLToGCSOperator

Copy data from Microsoft SQL Server to Google Cloud Storage in JSON or CSV format.

Transfers

BigtableCreateTableOperator

Creates the table in the Cloud Bigtable instance.

Operators

CloudDLPCreateDeidentifyTemplateOperator

Creates a DeidentifyTemplate for re-using frequently used configuration for de-identifying content, images, and storage.

Operators

CloudDataTransferServicePauseOperationOperator

Pauses a transfer operation in Google Storage Transfer Service.

Operators

OSSUploadObjectOperator

This operator to upload an file-like object

Operators

ComputeEngineHook

Hook for Google Compute Engine APIs.

Hooks

DataprepGetJobsForJobGroupOperator

Get information about the batch jobs within a Cloud Dataprep job. API documentation clouddataprep.com/documentation/api#section/Overview

Operators

EC2StartInstanceOperator

Start AWS EC2 instance using boto3.

Operators

SqsPublishOperator

Publish message to a SQS queue.

Operators

AzureCosmosInsertDocumentOperator

Inserts a new document into the specified Cosmos database and collection It will create both the database and collection if they do not already exist

Operators

Neo4jOperator

Executes sql code in a specific Neo4j database

Operators

CloudDLPDeleteInspectTemplateOperator

Deletes an InspectTemplate.

Operators

AirbyteJobSensor

Check for the state of a previously submitted Airbyte job.

Sensors

GlacierCreateJobOperator

Initiate an Amazon Glacier inventory-retrieval job

Operators

DateTimeSensor

Waits until the specified datetime.

Sensors

DmsTaskBaseSensor

Contains general sensor behavior for DMS task.

Sensors

GoogleDriveToLocalOperator

Writes a Google Drive file into local Storage.

Transfers

WorkflowsCreateExecutionOperator

Creates a new execution using the latest revision of the given workflow.

Operators

AwsGlueCatalogPartitionSensor

This sensor is deprecated. Please use airflow.providers.amazon.aws.sensors.glue_catalog_partition.GlueCatalogPartitionSensor.

Sensors

GoogleAnalyticsHook

Hook for Google Analytics 360.

Hooks

S3ToSnowflakeOperator

Executes an COPY command to load files from s3 to Snowflake

Transfers

GoogleDisplayVideo360Hook

Hook for Google Display & Video 360.

Hooks

CloudTasksQueuePurgeOperator

Purges a queue by deleting all of its tasks from Cloud Tasks.

Operators

GCSUploadSessionCompleteSensor

Checks for changes in the number of objects at prefix in Google Cloud Storage bucket and returns True if the inactivity period has passed with no increase in the number of objects. Note, this sensor will no behave correctly in reschedule mode, as the state of the listed objects in the GCS bucket will be lost between rescheduled invocations.

Sensors

AwsDynamoDBHook

This class is deprecated. Please use airflow.providers.amazon.aws.hooks.dynamodb.DynamoDBHook.

Hooks

TelegramHook

This hook allows you to post messages to Telegram using the telegram python-telegram-bot library.

Hooks

MLEngineHook

Hook for Google ML Engine APIs.

Hooks

CloudVideoIntelligenceDetectVideoShotsOperator

Performs video annotation, annotating video shots.

Operators

OSSDeleteBatchObjectOperator

This operator to delete OSS objects

Operators

SageMakerTuningSensor

Asks for the state of the tuning state until it reaches a terminal state. The sensor will error if the job errors, throwing a AirflowException containing the failure reason.

Sensors

CloudTasksQueuePauseOperator

Pauses a queue in Cloud Tasks.

Operators

StackdriverEnableAlertPoliciesOperator

Enables one or more disabled alerting policies identified by filter parameter. Inoperative in case the policy is already enabled.

Operators

GoogleSearchAdsReportSensor

Polls for the status of a report request.

Sensors

InfluxDBOperator

Executes sql code in a specific InfluxDB database

Operators

KylinCubeOperator

This operator is used to submit request about kylin build/refresh/merge, and can track job status . so users can easier to build kylin job

Operators

CloudDatastoreCommitOperator

Commit a transaction, optionally creating, deleting or modifying some entities.

Operators

LocalFilesystemToADLSOperator

Upload file(s) to Azure Data Lake

Transfers

SubDagOperator

This runs a sub dag. By convention, a sub dags dag_id should be prefixed by its parent and a dot. As in parent.child. Although SubDagOperator can occupy a pool/concurrency slot, user can specify the mode=reschedule so that the slot will be released periodically to avoid potential deadlock.

Operators

PinotDbApiHook

Interact with Pinot Broker Query API

Hooks

CloudNaturalLanguageAnalyzeEntitiesOperator

Finds named entities in the text along with entity types, salience, mentions for each entity, and other properties.

Operators

SlackWebhookHook

This hook allows you to post messages to Slack using incoming webhooks. Takes both Slack webhook token directly and connection that has Slack webhook token. If both supplied, http_conn_id will be used as base_url, and webhook_token will be taken as endpoint, the relative path of the url.

Hooks

GoogleAdsToGcsOperator

Fetches the daily results from the Google Ads API for 1-n clients Converts and saves the data as a temporary CSV file Uploads the CSV to Google Cloud Storage

Transfers

AutoMLDeleteDatasetOperator

Deletes a dataset and all of its contents.

Operators

CloudwatchTaskHandler

CloudwatchTaskHandler is a python log handler that handles and reads task instance logs.

Log

SageMakerBaseSensor

Contains general sensor behavior for SageMaker.

Sensors

CloudDLPUpdateStoredInfoTypeOperator

Updates the stored infoType by creating a new version.

Operators

CeleryQueueSensor

Waits for a Celery queue to be empty. By default, in order to be considered empty, the queue must not have any tasks in the reserved, scheduled or active states.

Sensors

DiscordWebhookOperator

This operator allows you to post messages to Discord using incoming webhooks. Takes a Discord connection ID with a default relative webhook endpoint. The default endpoint can be overridden using the webhook_endpoint parameter (discordapp.com/developers/docs/resources/webhook).

Operators

FTPToS3Operator

This operator enables the transfer of files from a FTP server to S3. It can be used to transfer one or multiple files.

Transfers

GlueCatalogPartitionSensor

Waits for a partition to show up in AWS Glue Catalog.

Sensors

GCSObjectExistenceSensor

Checks for the existence of a file in Google Cloud Storage.

Sensors

InfluxDBHook

Interact with InfluxDB.

Hooks

MongoHook

Interact with Mongo. This hook uses the Mongo conn_id. PyMongo Wrapper to Interact With Mongo Database Mongo Connection Documentation docs.mongodb.com/manual/reference/connection-string/index.html You can specify connection string options in extra field of your connection docs.mongodb.com/manual/reference/connection-string/index.html#connection-string-options

Hooks

CloudDLPUpdateDeidentifyTemplateOperator

Updates the DeidentifyTemplate.

Operators

GoogleApiToS3Operator

Basic class for transferring data from a Google API endpoint into a S3 Bucket.

Transfers

CloudDataTransferServiceGetOperationOperator

Gets the latest state of a long-running operation in Google Storage Transfer Service.

Operators

SlackAPIPostOperator

Posts messages to a slack channel

Operators

AzureKeyVaultBackend

Retrieves Airflow Connections or Variables from Azure Key Vault secrets.

Secrets

TimeSensor

Waits until the specified time of the day.

Sensors

SparkKubernetesSensor

Checks sparkApplication object in kubernetes cluster

Sensors

GlacierHook

Hook for connection with Amazon Glacier

Hooks

FivetranHook

Fivetran API interaction hook. :param fivetran_conn_id Conn ID of the Connection to be used to

Hooks

FivetranOperator

FivetranOperator starts a Fivetran sync job.

Operators

AwsRedshiftClusterSensor

Waits for a Redshift cluster to reach a specific status.

Sensors

RedisKeySensor

Checks for the existence of a key in a Redis

Sensors

WebHdfsSensor

Waits for a file or folder to land in HDFS

Sensors

DummyOperator

Operator that does literally nothing. It can be used to group tasks in a DAG.

Operators

OpsgenieAlertOperator

This operator is deprecated. Please use airflow.providers.opsgenie.operators.opsgenie.OpsgenieCreateAlertOperator.

Operators

SubprocessHook

Hook for running processes with the subprocess module

Hooks

LatestOnlyOperator

Allows a workflow to skip tasks that are not running during the most recent schedule interval.

Operators

OpsgenieAlertHook

This hook allows you to post alerts to Opsgenie. Accepts a connection that has an Opsgenie API key as the connections password. This hook sets the domain to conn_id.host, and if not set will default to api.opsgenie.com.

Hooks

SageMakerEndpointOperator

Create a SageMaker endpoint.

Operators

SageMakerTransformSensor

Asks for the state of the transform state until it reaches a terminal state. The sensor will error if the job errors, throwing a AirflowException containing the failure reason.

Sensors

SageMakerProcessingOperator

Initiate a SageMaker processing job.

Operators

SageMakerTuningOperator

Initiate a SageMaker hyperparameter tuning job.

Operators

SageMakerTuningSensor

Asks for the state of the tuning state until it reaches a terminal state. The sensor will error if the job errors, throwing a AirflowException containing the failure reason.

Sensors

SageMakerBaseSensor

Contains general sensor behavior for SageMaker. Subclasses should implement get_sagemaker_response() and state_from_response() methods. Subclasses should also implement NON_TERMINAL_STATES and FAILED_STATE methods.

Sensors

SageMakerTransformOperator

Initiate a SageMaker transform job.

Operators

SageMakerTrainingSensor

Asks for the state of the training state until it reaches a terminal state. If it fails the sensor errors, failing the task.

Sensors

SageMakerEndpointSensor

Asks for the state of the endpoint state until it reaches a terminal state. If it fails the sensor errors, the task fails.

Sensors

SageMakerTrainingOperator

Initiate a SageMaker training job.

Operators

SageMakerEndpointConfigOperator

Create a SageMaker endpoint config.

Operators

SageMakerModelOperator

Create a SageMaker model.

Operators

SageMakerBaseOperator

This is the base operator for all SageMaker operators.

Operators

EMRContainerHook

This class is deprecated. Please use airflow.providers.amazon.aws.hooks.emr.EmrContainerHook.

Hooks

QuboleCheckHook

Qubole check hook

Hooks

SESHook

This hook is deprecated. Please use airflow.providers.amazon.aws.hooks.ses.SesHook.

Hooks

SesHook

Interact with Amazon Simple Email Service.

Hooks

RedshiftHook

Interact with AWS Redshift, using the boto3 library

Hooks

RedshiftSQLHook

Execute statements against Amazon Redshift, using redshift_connector

Hooks

RedshiftSQLOperator

Executes SQL Statements against an Amazon Redshift cluster

Operators

EMRContainerOperator

This class is deprecated. Please use airflow.providers.amazon.aws.operators.emr.EmrContainerOperator.

Operators

EmrModifyClusterOperator

An operator that modifies an existing EMR cluster.

Operators

EmrAddStepsOperator

An operator that adds steps to an existing EMR job_flow.

Operators

EmrStepSensor

Asks for the state of the step until it reaches any of the target states. If it fails the sensor errors, failing the task.

Sensors

EmrJobFlowSensor

Asks for the state of the EMR JobFlow (Cluster) until it reaches any of the target states. If it fails the sensor errors, failing the task.

Sensors

EmrTerminateJobFlowOperator

Operator to terminate EMR JobFlows.

Operators

EMRContainerSensor

This class is deprecated. Please use airflow.providers.amazon.aws.sensors.emr.EmrContainerSensor.

Sensors

EmrBaseSensor

Contains general sensor behavior for EMR.

Sensors

dataframe

Convert a Table object into a Pandas DataFrame or persist a DataFrame result to a database table.

Decorators

truncate

Perform a TRUNCATE operation on a given table.

Functions

merge

Merge data into an existing table in situations where there may be conflicts. This function adds data to a table with either an "update" or "ignore" strategy. The "ignore" strategy does not add values that conflict, while the "update" strategy overwrites the older values.

Functions

save_file

Export a database table as a CSV or Parquet file to local storage, Amazon S3, or Google Cloud Storage.

Functions

append

Append the results of a source table onto a target table. This function assumes there are no conflicts between the schemas of both tables.

Functions

TempTable

A metadata representation of database table within the Astro ecosystem that will not be persisted after corresponding operations are complete.

Objects

Table

A metadata representation of an existing or to-be-created database table within the Astro ecosystem.

Objects

transform_file

Execute a SELECT SQL statement contained in a file. Data returned from this SQL is inserted into a temporary table which can used by other downstream tasks.

Functions

run_raw_sql

Execute SQL that is not expected to return data like DDL or DML operations.

Decorators

transform

Execute an explicit, SELECT SQL statement. Data returned from this SQL is inserted into a temporary table which can used by other downstream tasks.

Decorators

load_file

Load CSV or Parquet files from local storage, Amazon S3, or Google Cloud Storage into a SQL database.

Functions

aggregate_check

Validate the result from a SQL which performs an aggregation matches an expected value or falls within a provided range.

Functions

DmsCreateTaskOperator

Creates AWS DMS replication task.

Operators

DmsDeleteTaskOperator

Deletes AWS DMS replication task.

Operators

DmsStopTaskOperator

Stops AWS DMS replication task.

Operators

DmsTaskCompletedSensor

Pokes DMS task until it is completed.

Sensors

DmsTaskBaseSensor

Contains general sensor behavior for DMS task.

Sensors

DmsDescribeTasksOperator

Describes AWS DMS replication tasks.

Operators

DmsStartTaskOperator

Starts AWS DMS replication task.

Operators

DrillHook

Interact with Apache Drill via sqlalchemy-drill.

Hooks

S3DeleteObjectsOperator

To enable users to delete single object or multiple objects from a bucket using a single HTTP request.

Operators

S3KeySizeSensor

Waits for a key (a file-like instance on S3) to be present and be more than some size in a S3 bucket. S3 being a key/value it does not support folders. The path is just a key a resource.

Sensors

S3PrefixSensor

Waits for a prefix or all prefixes to exist. A prefix is the first part of a key, thus enabling checking of constructs similar to glob airfl* or SQL LIKE airfl%. There is the possibility to precise a delimiter to indicate the hierarchy or keys, meaning that the match will stop at that delimiter. Current code accepts sane delimiters, i.e. characters that are NOT special characters in the Python regex engine.

Sensors

S3ListOperator

List all objects from the bucket with the given string prefix in name.

Operators

S3DeleteBucketOperator

This operator deletes an S3 bucket

Operators

S3FileTransformOperator

Copies data from a source S3 location to a temporary location on the local filesystem. Runs a transformation on this file as specified by the transformation script and uploads the output to a destination S3 location.

Operators

S3KeysUnchangedSensor

Checks for changes in the number of objects at prefix in AWS S3 bucket and returns True if the inactivity period has passed with no increase in the number of objects. Note, this sensor will not behave correctly in reschedule mode, as the state of the listed objects in the S3 bucket will be lost between rescheduled invocations.

Sensors

S3CopyObjectOperator

Creates a copy of an object that is already stored in S3.

Operators

S3CreateBucketOperator

This operator creates an S3 bucket

Operators

S3DeleteBucketTaggingOperator

This operator deletes tagging from an S3 bucket.

Operators

S3KeySensor

Waits for a key (a file-like instance on S3) to be present in a S3 bucket. S3 being a key/value it does not support folders. The path is just a key a resource.

Sensors

S3PutBucketTaggingOperator

This operator puts tagging for an S3 bucket.

Operators

S3ListPrefixesOperator

List all subfolders from the bucket with the given string prefix in name.

Operators

S3GetBucketTaggingOperator

This operator gets tagging from an S3 bucket

Operators

StepFunctionStartExecutionOperator

An Operator that begins execution of an Step Function State Machine

Operators

StepFunctionExecutionSensor

Asks for the state of the Step Function State Machine Execution until it reaches a failure state or success state. If it fails, failing the task.

Sensors

StepFunctionGetExecutionOutputOperator

An Operator that begins execution of an Step Function State Machine

Operators

EC2StartInstanceOperator

Start AWS EC2 instance using boto3.

Operators

EC2InstanceStateSensor

Check the state of the AWS EC2 instance until state of the instance become equal to the target state.

Sensors

EC2StopInstanceOperator

Stop AWS EC2 instance using boto3.

Operators

JenkinsHook

Hook to manage connection to jenkins server

Hooks

PlexusHook

Used for jwt token generation and storage to make Plexus API calls. Requires email and password Airflow variables be created.

Hooks

FSHook

Allows for interaction with an file server.

Hooks

RayBackend

Custom Backend Serving to use Ray.

XCom

AzureDataLakeStorageDeleteOperator

This class is deprecated. Please use airflow.providers.microsoft.azure.operators.adls.ADLSDeleteOperator.

Operators

AzureDataLakeStorageListOperator

This class is deprecated. Please use airflow.providers.microsoft.azure.operators.adls.ADLSListOperator.

Operators

FileToWasbOperator

Uploads a file to Azure Blob Storage.

Transfers

ToXLSXOperator

Convert Parquest, CSV, JSON, JSON Lines into XLSX

Operators

FivetranSensor

FivetranSensor monitors a Fivetran sync job for completion.

Sensors

HightouchTriggerSyncOperator

This operator triggers a run for a specified Sync in Hightouch via the Hightouch API.

Operators

RayClientHook

A Connection Hook for accessing Ray via the Ray Client.

Hooks

OdbcHook

Interact with odbc data sources using pyodbc.

Hooks

MsSqlHook

Interact with Microsoft SQL Server.

Hooks

VerticaHook

Interact with Vertica.

Hooks

CensusHook

Census API hook

Hooks

CensusSensor

Waits for sync to complete.

Sensors

CensusOperator

Triggers sync with Census API.

Operators

LakeFSCreateBranchOperator

Create a lakeFS branch by calling the lakeFS server.

Operators

LakeFSCommitOperator

Commit changes to a lakeFS branch.

Operators

LakeFSMergeOperator

Merge source branch to destination branch

Operators

LakeFSCommitSensor

Executes a get branch operation until that branch was committed.

Sensors

LakeFSFileSensor

Waits for the given file to appear

Sensors

LakeFSHook

LakeFSHook that interacts with a lakeFS server.

Hooks

DatahubRestHook

Creates a DataHub Rest API connection used to send metadata to DataHub. Takes the endpoint for your DataHub Rest API in the Server Endpoint(host) field.

Hooks

DatahubEmitterOperator

Emits a Metadata Change Event to DataHub using either a DataHub Rest or Kafka connection.

Operators

DatahubGenericHook

Emits Metadata Change Events using either the DatahubRestHook or the DatahubKafkaHook. Set up a DataHub Rest or Kafka connection to use.

Hooks

DatahubBaseOperator

The DatahubBaseOperator is used as a base operator all DataHub operators.

Operators

DatahubLineageBackend

Sends lineage data from tasks to DataHub.

Lineage

DatahubKafkaHook

Creates a DataHub Kafka connection used to send metadata to DataHub. Takes your kafka broker in the Kafka Broker(host) field.

Hooks

RedisHook

Wrapper for connection to interact with Redis in-memory data structure store

Hooks

PigCliHook

Simple wrapper around the pig CLI.

Hooks