Apache Airflow Provider - Amazon

An Apache Airflow provider for AWS Services.

Version
7.4.1
Downloads
2,762,883/month
Last Published
Apr. 12, 2023
Quick Install

Available Modules

Modules are Python callables available from this provider package.

Types:

SensorsHooksOperatorsLogTransfersSecrets
AthenaSensor
Amazon

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

SensorsUpdated a year ago
AwsBaseHook
Amazon

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

HooksUpdated a year ago
AwsLogsHook
Amazon

Interact with Amazon CloudWatch Logs. Provide thin wrapper around boto3.client("logs").

HooksUpdated a year ago
CloudFormationCreateStackOperator
Amazon

An operator that creates a CloudFormation stack.

OperatorsUpdated a year ago
AwsRedshiftClusterSensor
Amazon

Waits for a Redshift cluster to reach a specific status.

SensorsUpdated 2 years ago
CloudwatchTaskHandler
Amazon

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

LogUpdated a year ago
DynamoDBToS3Operator
Amazon

Replicates records from a DynamoDB table to S3. It scans a DynamoDB table and writes the received records to a file on the local filesystem. It flushe…

TransfersUpdated 10 months ago
EC2Hook
Amazon

Interact with Amazon Elastic Compute Cloud (EC2). Provide thick wrapper around boto3.client("ec2") or boto3.resource("ec2").

HooksUpdated a year ago
EmrHook
Amazon

Interact with Amazon Elastic MapReduce Service (EMR). Provide thick wrapper around boto3.client("emr").

HooksUpdated a year ago
ElastiCacheReplicationGroupHook
Amazon

Interact with Amazon ElastiCache. Provide thick wrapper around boto3.client("elasticache").

HooksUpdated a year ago
FTPToS3Operator
Amazon

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

TransfersUpdated a year ago
GCSToS3Operator
Amazon

Synchronizes a Google Cloud Storage bucket with an S3 bucket.

TransfersUpdated a year ago
GlacierHook
Amazon

Interact with Amazon Glacier. Provide thin wrapper around boto3.client("glacier").

HooksUpdated a year ago
GlacierCreateJobOperator
Amazon

Initiate an Amazon Glacier inventory-retrieval job

OperatorsUpdated a year ago
HiveToDynamoDBOperator
Amazon

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 fo…

TransfersUpdated a year ago
GlacierJobOperationSensor
Amazon

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

SensorsUpdated a year ago
GoogleApiToS3Operator
Amazon

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

TransfersUpdated 9 months ago
ImapAttachmentToS3Operator
Amazon

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

TransfersUpdated a year ago
GlacierToGCSOperator
Amazon

Transfers data from Amazon Glacier to Google Cloud Storage

TransfersUpdated a year ago
RedshiftToS3Operator
Amazon

Execute an UNLOAD command to s3 as a CSV with headers.

TransfersUpdated a year ago
S3Hook
Amazon

Interact with Amazon Simple Storage Service (S3). Provide thick wrapper around boto3.client("s3") and boto3.resource("s3").

HooksUpdated a year ago
ExasolToS3Operator
Amazon

Export data from Exasol database to AWS S3 bucket.

TransfersUpdated a year ago
MongoToS3Operator
Amazon

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

TransfersUpdated a year ago
S3TaskHandler
Amazon

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

LogUpdated 10 months ago
S3ToFTPOperator
Amazon

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

TransfersUpdated a year ago
S3ToSFTPOperator
Amazon

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

TransfersUpdated 9 months ago
S3ToRedshiftOperator
Amazon

Executes an COPY command to load files from s3 to Redshift

TransfersUpdated a year ago
SFTPToS3Operator
Amazon

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

TransfersUpdated 9 months ago
SageMakerHook
Amazon

Interact with Amazon SageMaker. Provide thick wrapper around boto3.client("sagemaker").

HooksUpdated a year ago
SnsPublishOperator
Amazon

Publish a message to Amazon SNS.

OperatorsUpdated a year ago
SecretsManagerHook
Amazon

Interact with Amazon SecretsManager Service. Provide thin wrapper around boto3.client("secretsmanager").

HooksUpdated a year ago
SecretsManagerBackend
Amazon

Retrieves Connection or Variables from AWS Secrets Manager

SecretsUpdated a year ago
SystemsManagerParameterStoreBackend
Amazon

Retrieves Connection or Variables from AWS SSM Parameter Store

SecretsUpdated a year ago
CloudFormationDeleteStackSensor
Amazon

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

SensorsUpdated a year ago
CloudFormationCreateStackSensor
Amazon

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

SensorsUpdated a year ago
CloudFormationDeleteStackOperator
Amazon

An operator that deletes a CloudFormation stack.

OperatorsUpdated a year ago
StepFunctionHook
Amazon

Interact with an AWS Step Functions State Machine. Provide thin wrapper around boto3.client("stepfunctions").

HooksUpdated a year ago
DmsHook
Amazon

Interact with AWS Database Migration Service (DMS). Provide thin wrapper around boto3.client("dms").

HooksUpdated a year ago
LocalFilesystemToS3Operator
Amazon

Uploads a file from a local filesystem to Amazon S3.

TransfersUpdated a year ago
SalesforceToS3Operator
Amazon

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

TransfersUpdated a year ago
SqsSensor
Amazon

Get messages from an Amazon SQS queue and then delete the messages from the queue. If deletion of messages fails, an AirflowException is thrown. Other…

SensorsUpdated a year ago
SqsHook
Amazon

Interact with Amazon Simple Queue Service. Provide thin wrapper around boto3.client("sqs").

HooksUpdated a year ago
SqsPublishOperator
Amazon

Publish a message to an Amazon SQS queue.

OperatorsUpdated a year ago
SnsHook
Amazon

Interact with Amazon Simple Notification Service. Provide thin wrapper around boto3.client("sns").

HooksUpdated a year ago
RedshiftResumeClusterOperator
Amazon

Resume a paused AWS Redshift Cluster

OperatorsUpdated 9 months ago
RedshiftPauseClusterOperator
Amazon

Pause an AWS Redshift Cluster if it has status available.

OperatorsUpdated 9 months ago
GlueJobHook
Amazon

Interact with AWS Glue. Provide thick wrapper around boto3.client("glue").

HooksUpdated 10 months ago
RedshiftClusterSensor
Amazon

Waits for a Redshift cluster to reach a specific status.

SensorsUpdated a year ago
SqlToS3Operator
Amazon

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

TransfersUpdated a year ago
GlueCatalogPartitionSensor
Amazon

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

SensorsUpdated a year ago
GlueCrawlerSensor
Amazon

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

SensorsUpdated a year ago
GlueCatalogHook
Amazon

Interact with AWS Glue Data Catalog. Provide thin wrapper around boto3.client("glue").

HooksUpdated a year ago
GlueJobSensor
Amazon

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

SensorsUpdated a year ago
SesHook
Amazon

Interact with Amazon Simple Email Service. Provide thin wrapper around boto3.client("ses").

HooksUpdated a year ago
GlueCrawlerOperator
Amazon

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…

OperatorsUpdated a year ago
GlueJobOperator
Amazon

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

OperatorsUpdated 10 months ago
LambdaHook
Amazon

Interact with AWS Lambda. Provide thin wrapper around boto3.client("lambda").

HooksUpdated a year ago
GlueCrawlerHook
Amazon

Interacts with AWS Glue Crawler. Provide thin wrapper around boto3.client("glue").

HooksUpdated a year ago
EmrContainerHook
Amazon

Interact with Amazon EMR Containers (Amazon EMR on EKS). Provide thick wrapper around boto3.client("emr-containers").

HooksUpdated a year ago
EksPodOperator
Amazon

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

OperatorsUpdated 9 months ago
EmrContainerOperator
Amazon

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

OperatorsUpdated a year ago
EksFargateProfileStateSensor
Amazon

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

SensorsUpdated a year ago
FirehoseHook
Amazon

Interact with Amazon Kinesis Firehose. Provide thick wrapper around boto3.client("firehose").

HooksUpdated a year ago
EksNodegroupStateSensor
Amazon

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

SensorsUpdated a year ago
EksDeleteClusterOperator
Amazon

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

OperatorsUpdated 9 months ago
EksDeleteNodegroupOperator
Amazon

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

OperatorsUpdated 9 months ago
EmrContainerSensor
Amazon

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.

SensorsUpdated a year ago
EksCreateNodegroupOperator
Amazon

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

OperatorsUpdated 9 months ago
EksCreateClusterOperator
Amazon

Creates an Amazon EKS Cluster control plane.

OperatorsUpdated 9 months ago
EksDeleteFargateProfileOperator
Amazon

Deletes an AWS Fargate profile from an Amazon EKS Cluster.

OperatorsUpdated 9 months ago
EksHook
Amazon

Interact with Amazon Elastic Kubernetes Service (EKS). Provide thin wrapper around boto3.client("eks").

HooksUpdated a year ago
EksClusterStateSensor
Amazon

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

SensorsUpdated a year ago
DataSyncOperator
Amazon

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

OperatorsUpdated a year ago
DataSyncHook
Amazon

Interact with AWS DataSync. Provide thick wrapper around boto3.client("datasync").

HooksUpdated a year ago
BatchOperator
Amazon

Execute a job on AWS Batch

OperatorsUpdated 9 months ago
EksCreateFargateProfileOperator
Amazon

Creates an AWS Fargate profile for an Amazon EKS cluster.

OperatorsUpdated 9 months ago
BatchWaitersHook
Amazon

A utility to manage waiters for AWS Batch services.

HooksUpdated 10 months ago
CloudFormationHook
Amazon

Interact with AWS CloudFormation. Provide thin wrapper around boto3.client("cloudformation").

HooksUpdated a year ago
DynamoDBHook
Amazon

Interact with Amazon DynamoDB. Provide thick wrapper around boto3.resource("dynamodb").

HooksUpdated a year ago
BatchClientHook
Amazon

Interact with AWS Batch. Provide thick wrapper around boto3.client("batch").

HooksUpdated 9 months ago
BatchSensor
Amazon

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.

SensorsUpdated a year ago
AthenaOperator
Amazon

An operator that submits a presto query to athena.

OperatorsUpdated a year ago
AthenaHook
Amazon

Interact with Amazon Athena. Provide thick wrapper around boto3.client("athena").

HooksUpdated a year ago
RedshiftHook
Amazon

Interact with Amazon Redshift. Provide thin wrapper around boto3.client("redshift").

HooksUpdated 10 months ago
RedshiftSQLHook
Amazon

Execute statements against Amazon Redshift, using redshift_connector

HooksUpdated a year ago
S3CopyObjectOperator
Amazon

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

OperatorsUpdated a year ago
S3CreateBucketOperator
Amazon

This operator creates an S3 bucket

OperatorsUpdated a year ago
RedshiftSQLOperator
Amazon

Executes SQL Statements against an Amazon Redshift cluster

OperatorsUpdated a year ago
S3DeleteBucketTaggingOperator
Amazon

This operator deletes tagging from an S3 bucket.

OperatorsUpdated a year ago
S3DeleteBucketOperator
Amazon

This operator deletes an S3 bucket

OperatorsUpdated a year ago
S3FileTransformOperator
Amazon

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 transfor…

OperatorsUpdated a year ago
S3DeleteObjectsOperator
Amazon

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

OperatorsUpdated a year ago
S3GetBucketTaggingOperator
Amazon

This operator gets tagging from an S3 bucket

OperatorsUpdated a year ago
S3KeySensor
Amazon

Waits for one or multiple keys (a file-like instance on S3) to be present in a S3 bucket. The path is just a key/value pointer to a resource for the g…

SensorsUpdated a year ago
S3ListOperator
Amazon

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

OperatorsUpdated a year ago
S3KeysUnchangedSensor
Amazon

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 nu…

SensorsUpdated a year ago
S3ListPrefixesOperator
Amazon

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

OperatorsUpdated a year ago
S3PutBucketTaggingOperator
Amazon

This operator puts tagging for an S3 bucket.

OperatorsUpdated a year ago
SageMakerBaseOperator
Amazon

This is the base operator for all SageMaker operators.

OperatorsUpdated a year ago
SageMakerBaseSensor
Amazon

Contains general sensor behavior for SageMaker.

SensorsUpdated a year ago
SageMakerEndpointConfigOperator
Amazon

Creates an endpoint configuration that Amazon SageMaker hosting services uses to deploy models. In the configuration, you identify one or more models,…

OperatorsUpdated a year ago
SageMakerEndpointOperator
Amazon

When you create a serverless endpoint, SageMaker provisions and manages the compute resources for you. Then, you can make inference requests to the en…

OperatorsUpdated a year ago
SageMakerModelOperator
Amazon

Creates a model in Amazon SageMaker. In the request, you name the model and describe a primary container. For the primary container, you specify the D…

OperatorsUpdated a year ago
SageMakerEndpointSensor
Amazon

Polls the endpoint state until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
EmrAddStepsOperator
Amazon

An operator that adds steps to an existing EMR job_flow.

OperatorsUpdated a year ago
EmrBaseSensor
Amazon

Contains general sensor behavior for EMR.

SensorsUpdated a year ago
SageMakerTuningSensor
Amazon

Asks for the state of the tuning state until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reac…

SensorsUpdated a year ago
StepFunctionExecutionSensor
Amazon

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

SensorsUpdated a year ago
StepFunctionGetExecutionOutputOperator
Amazon

An Operator that returns the output of an AWS Step Function State Machine execution.

OperatorsUpdated a year ago
SageMakerProcessingOperator
Amazon

Use Amazon SageMaker Processing to analyze data and evaluate machine learning models on Amazon SageMake. With Processing, you can use a simplified, ma…

OperatorsUpdated a year ago
StepFunctionStartExecutionOperator
Amazon

An Operator that begins execution of an AWS Step Function State Machine.

OperatorsUpdated a year ago
DmsCreateTaskOperator
Amazon

Creates AWS DMS replication task.

OperatorsUpdated a year ago
DmsDescribeTasksOperator
Amazon

Describes AWS DMS replication tasks.

OperatorsUpdated a year ago
DmsDeleteTaskOperator
Amazon

Deletes AWS DMS replication task.

OperatorsUpdated a year ago
DmsStartTaskOperator
Amazon

Starts AWS DMS replication task.

OperatorsUpdated a year ago
DmsTaskCompletedSensor
Amazon

Pokes DMS task until it is completed.

SensorsUpdated a year ago
DmsStopTaskOperator
Amazon

Stops AWS DMS replication task.

OperatorsUpdated a year ago
DmsTaskBaseSensor
Amazon

Contains general sensor behavior for DMS task.

SensorsUpdated a year ago
EC2InstanceStateSensor
Amazon

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

SensorsUpdated a year ago
EC2StartInstanceOperator
Amazon

Start AWS EC2 instance using boto3.

OperatorsUpdated 10 months ago
EC2StopInstanceOperator
Amazon

Stop AWS EC2 instance using boto3.

OperatorsUpdated 10 months ago
EmrJobFlowSensor
Amazon

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.

SensorsUpdated a year ago
EmrTerminateJobFlowOperator
Amazon

Operator to terminate EMR JobFlows.

OperatorsUpdated a year ago
EmrModifyClusterOperator
Amazon

An operator that modifies an existing EMR cluster.

OperatorsUpdated a year ago
EmrStepSensor
Amazon

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

SensorsUpdated a year ago
EmrCreateJobFlowOperator
Amazon

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 …

OperatorsUpdated a year ago
SageMakerTransformOperator
Amazon

Starts a transform job. A transform job uses a trained model to get inferences on a dataset and saves these results to an Amazon S3 location that you …

OperatorsUpdated a year ago
SageMakerTransformSensor
Amazon

Polls the transform job until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
SageMakerTuningOperator
Amazon

Starts a hyperparameter tuning job. A hyperparameter tuning job finds the best version of a model by running many training jobs on your dataset using …

OperatorsUpdated a year ago
SageMakerTrainingSensor
Amazon

Polls the training job until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
SageMakerTrainingOperator
Amazon

Starts a model training job. After training completes, Amazon SageMaker saves the resulting model artifacts to an Amazon S3 location that you specify.

OperatorsUpdated a year ago
SageMakerDeleteModelOperator
Amazon

Deletes a SageMaker model.

OperatorsUpdated a year ago
RedshiftDeleteClusterOperator
Amazon

Delete an AWS Redshift cluster.

OperatorsUpdated 9 months ago
RedshiftDataOperator
Amazon

Executes SQL Statements against an Amazon Redshift cluster using Redshift Data

OperatorsUpdated a year ago
RedshiftCreateClusterOperator
Amazon

Creates a new cluster with the specified parameters.

OperatorsUpdated 9 months ago
S3CreateObjectOperator
Amazon

Creates a new object from data as string or bytes.

OperatorsUpdated a year ago
RdsSnapshotExistenceSensor
Amazon

Waits for RDS snapshot with a specific status.

SensorsUpdated a year ago
RdsExportTaskExistenceSensor
Amazon

Waits for RDS export task with a specific status.

SensorsUpdated a year ago
RdsCreateEventSubscriptionOperator
Amazon

Creates an RDS event notification subscription

OperatorsUpdated a year ago
RedshiftDataHook
Amazon

Interact with AWS Redshift Data, using the boto3 library Hook attribute conn has all methods that listed in documentation

HooksUpdated a year ago
RdsHook
Amazon

Interact with AWS RDS using proper client from the boto3 library.

HooksUpdated a year ago
StsHook
Amazon

Interact with AWS Security Token Service (STS). Provide thin wrapper around boto3.client("sts").

HooksUpdated a year ago
RdsDeleteEventSubscriptionOperator
Amazon

Deletes an RDS event notification subscription

OperatorsUpdated a year ago
RdsCopyDbSnapshotOperator
Amazon

Copies the specified DB instance or DB cluster snapshot

OperatorsUpdated a year ago
RdsStartExportTaskOperator
Amazon

Starts an export of a snapshot to Amazon S3. The provided IAM role must have access to the S3 bucket.

OperatorsUpdated a year ago
QuickSightCreateIngestionOperator
Amazon

Creates and starts a new SPICE ingestion for a dataset. Also, helps to Refresh existing SPICE datasets.

OperatorsUpdated a year ago
RdsCreateDbSnapshotOperator
Amazon

Creates a snapshot of a DB instance or DB cluster. The source DB instance or cluster must be in the available or storage-optimization state.

OperatorsUpdated a year ago
RdsDeleteDbSnapshotOperator
Amazon

Deletes a DB instance or cluster snapshot or terminating the copy operation

OperatorsUpdated a year ago
QuickSightHook
Amazon

Interact with Amazon QuickSight. Provide thin wrapper around boto3.client("quicksight").

HooksUpdated 9 months ago
QuickSightSensor
Amazon

Watches for the status of an Amazon QuickSight Ingestion.

SensorsUpdated 9 months ago
RdsCancelExportTaskOperator
Amazon

Cancels an export task in progress that is exporting a snapshot to Amazon S3

OperatorsUpdated a year ago
RdsBaseSensor
Amazon

Base operator that implements common functions for all sensors

SensorsUpdated a year ago
AppflowHook
Amazon

Interact with Amazon Appflow. Provide thin wrapper around boto3.client("appflow").

HooksUpdated 10 months ago
EcsHook
Amazon

Interact with Amazon Elastic Container Service (ECS). Provide thin wrapper around boto3.client("ecs").

HooksUpdated 10 months ago
EmrServerlessHook
Amazon

Interact with Amazon EMR Serverless. Provide thin wrapper around boto3.client("emr-serverless").

HooksUpdated a year ago
AppflowRunOperator
Amazon

Execute a Appflow run with filters as is.

OperatorsUpdated 10 months ago
AppflowBaseOperator
Amazon

Amazon Appflow Base Operator class (not supposed to be used directly in DAGs).

OperatorsUpdated 10 months ago
AppflowRunBeforeOperator
Amazon

Execute a Appflow run after updating the filters to select only previous data.

OperatorsUpdated 10 months ago
AppflowRunFullOperator
Amazon

Execute a Appflow full run removing any filter.

OperatorsUpdated 10 months ago
AppflowRunAfterOperator
Amazon

Execute a Appflow run after updating the filters to select only future data.

OperatorsUpdated 10 months ago
AppflowRecordsShortCircuitOperator
Amazon

Short-circuit in case of a empty Appflow’s run.

OperatorsUpdated 10 months ago
BatchCreateComputeEnvironmentOperator
Amazon

Create an AWS Batch compute environment

OperatorsUpdated 9 months ago
AppflowRunDailyOperator
Amazon

Execute a Appflow run after updating the filters to select only a single day.

OperatorsUpdated 10 months ago
EcsCreateClusterOperator
Amazon

Creates an AWS ECS cluster.

OperatorsUpdated 9 months ago
EcsRegisterTaskDefinitionOperator
Amazon

Register a task definition on AWS ECS.

OperatorsUpdated 9 months ago
EcsDeregisterTaskDefinitionOperator
Amazon

Deregister a task definition on AWS ECS.

OperatorsUpdated 9 months ago
EcsDeleteClusterOperator
Amazon

Deletes an AWS ECS cluster.

OperatorsUpdated 9 months ago
EcsRunTaskOperator
Amazon

Execute a task on AWS ECS (Elastic Container Service)

OperatorsUpdated 9 months ago
EmrEksCreateClusterOperator
Amazon

An operator that creates EMR on EKS virtual clusters.

OperatorsUpdated a year ago
EmrServerlessStartJobOperator
Amazon

Operator to start EMR Serverless job.

OperatorsUpdated a year ago
EmrServerlessDeleteApplicationOperator
Amazon

Operator to delete EMR Serverless application

OperatorsUpdated a year ago
EmrServerlessCreateApplicationOperator
Amazon

Operator to create Serverless EMR Application

OperatorsUpdated a year ago
AwsLambdaInvokeFunctionOperator
Amazon

This class is deprecated. Please use airflow.providers.amazon.aws.operators.lambda_function.LambdaInvokeFunctionOperator.

OperatorsUpdated a year ago
RdsDeleteDbInstanceOperator
Amazon

Deletes an RDS DB Instance

OperatorsUpdated a year ago
RdsCreateDbInstanceOperator
Amazon

Creates an RDS DB instance

OperatorsUpdated a year ago
RedshiftDeleteClusterSnapshotOperator
Amazon

Deletes the specified manual snapshot

OperatorsUpdated 9 months ago
RedshiftCreateClusterSnapshotOperator
Amazon

Creates a manual snapshot of the specified cluster. The cluster must be in the available state

OperatorsUpdated 9 months ago
BatchComputeEnvironmentSensor
Amazon

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

SensorsUpdated a year ago
BatchJobQueueSensor
Amazon

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

SensorsUpdated a year ago
EcsBaseSensor
Amazon

Contains general sensor behavior for Elastic Container Service.

SensorsUpdated a year ago
EcsTaskDefinitionStateSensor
Amazon

Polls the task definition state until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
EcsClusterStateSensor
Amazon

Polls the cluster state until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
EcsTaskStateSensor
Amazon

Polls the task state until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
EmrServerlessApplicationSensor
Amazon

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

SensorsUpdated a year ago
EmrServerlessJobSensor
Amazon

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.

SensorsUpdated a year ago
RdsDbSensor
Amazon

Waits for an RDS instance or cluster to enter one of a number of states

SensorsUpdated a year ago
SageMakerStartPipelineOperator
Amazon

Starts a SageMaker pipeline execution.

OperatorsUpdated a year ago
SageMakerAutoMLSensor
Amazon

Polls the auto ML job until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
LambdaFunctionStateSensor
Amazon

Asks for the state of the Lambda until it reaches a target state. If the query fails, the task will fail.

SensorsUpdated a year ago
EmrStartNotebookExecutionOperator
Amazon

An operator that starts an EMR notebook execution.

OperatorsUpdated a year ago
SageMakerCreateExperimentOperator
Amazon

Creates a SageMaker experiment, to be then associated to jobs etc.

OperatorsUpdated a year ago
EmrStopNotebookExecutionOperator
Amazon

An operator that stops a running EMR notebook execution.

OperatorsUpdated a year ago
SageMakerAutoMLOperator
Amazon

Creates an auto ML job, learning to predict the given column from the data provided through S3. The learning output is written to the specified S3 loc…

OperatorsUpdated a year ago
SageMakerRegisterModelVersionOperator
Amazon

Registers an Amazon SageMaker model by creating a model version that specifies the model group to which it belongs. Will create the model group if it …

OperatorsUpdated a year ago
SageMakerPipelineSensor
Amazon

Polls the pipeline until it reaches a terminal state. Raises an AirflowException with the failure reason if a failed state is reached.

SensorsUpdated a year ago
EcrHook
Amazon

Interact with Amazon Elastic Container Registry (ECR). Provide thin wrapper around boto3.client("ecr").

HooksUpdated a year ago
RdsStopDbOperator
Amazon

Stops an RDS DB instance / cluster

OperatorsUpdated a year ago
LambdaCreateFunctionOperator
Amazon

Creates an AWS Lambda function.

OperatorsUpdated a year ago
GlacierUploadArchiveOperator
Amazon

This operator add an archive to an Amazon S3 Glacier vault

OperatorsUpdated a year ago
EmrNotebookExecutionSensor
Amazon

Polls the state of the EMR notebook execution until it reaches any of the target states. If a failure state is reached, the sensor throws an error, an…

SensorsUpdated a year ago
SsmHook
Amazon

Interact with Amazon Systems Manager (SSM). Provide thin wrapper around boto3.client("ssm").

HooksUpdated a year ago
SageMakerStopPipelineOperator
Amazon

Stops a SageMaker pipeline execution.

OperatorsUpdated a year ago
RdsStartDbOperator
Amazon

Starts an RDS DB instance / cluster

OperatorsUpdated a year ago
EcsOperator
Amazon

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

OperatorsUpdated 9 months ago
LambdaInvokeFunctionOperator
Amazon

Invokes an AWS Lambda function. You can invoke a function synchronously (and wait for the response), or asynchronously. To invoke a function asynchron…

OperatorsUpdated a year ago
EksBaseSensor
Amazon

Base class to check various EKS states. Subclasses need to implement get_state and get_terminal_states methods.

SensorsUpdated a year ago
S3ToSqlOperator
Amazon

Loads Data from S3 into a SQL Database. You need to provide a parser function that takes a filename as an input and returns an iterable of rows

TransfersUpdated a year ago