@@ -29,29 +29,29 @@ For example, instead of ``from airflow.sensors import TimeDeltaSensor``, use ``f
29
29
* AIR302
30
30
31
31
* [x] ``airflow.sensors.base_sensor_operator.BaseSensorOperator `` → ``airflow.sdk.bases.sensor.BaseSensorOperator ``
32
- * [x] ``airflow.sensors.date_time_sensor.DateTimeSensor `` → ``airflow.sensors.date_time.DateTimeSensor ``
33
32
* [x] ``airflow.hooks.base_hook.BaseHook `` → ``airflow.hooks.base.BaseHook ``
34
33
35
34
* AIR303
36
35
37
- * [ ] ``airflow.sensors.external_task_sensor.ExternalTaskMarker `` → ``airflow.providers.standard.sensors.external_task.ExternalTaskMarker ``
38
- * [ ] ``airflow.sensors.external_task_sensor.ExternalTaskSensor `` → ``airflow.providers.standard.sensors.external_task.ExternalTaskSensor ``
39
- * [ ] ``airflow.sensors.external_task_sensor.ExternalTaskSensorLink `` → ``airflow.providers.standard.sensors.external_task.ExternalTaskSensorLink ``
40
- * [ ] ``airflow.sensors.time_delta_sensor.TimeDeltaSensor `` → ``airflow.providers.standard.sensors.time_delta.TimeDeltaSensor ``
41
- * [ ] ``airflow.operators.dagrun_operator.TriggerDagRunLink `` → ``airflow.providers.standard.operators.trigger_dagrun.TriggerDagRunLink ``
42
- * [ ] ``airflow.operators.dagrun_operator.TriggerDagRunOperator `` → ``airflow.providers.standard.operators.trigger_dagrun.TriggerDagRunOperator ``
43
- * [ ] ``airflow.operators.python_operator.BranchPythonOperator `` → ``airflow.providers.standard.operators.python.BranchPythonOperator ``
44
- * [ ] ``airflow.operators.python_operator.PythonOperator `` → ``airflow.providers.standard.operators.python.PythonOperator ``
45
- * [ ] ``airflow.operators.python_operator.PythonVirtualenvOperator `` → ``airflow.providers.standard.operators.python.PythonVirtualenvOperator ``
46
- * [ ] ``airflow.operators.python_operator.ShortCircuitOperator `` → ``airflow.providers.standard.operators.python.ShortCircuitOperator ``
47
- * [ ] ``airflow.operators.latest_only_operator.LatestOnlyOperator `` → ``airflow.providers.standard.operators.latest_only.LatestOnlyOperator ``
48
- * [ ] ``airflow.operators.bash_operator.BashOperator `` → ``airflow.providers.standard.operators.bash.BashOperator ``
49
- * [ ] ``airflow.operators.branch_operator.BaseBranchOperator `` → ``airflow.providers.standard.operators.branch.BaseBranchOperator ``
50
- * [ ] ``airflow.operators.EmptyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
51
- * [ ] ``airflow.operators.DummyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
52
- * [ ] ``airflow.operators.dummy_operator.EmptyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
53
- * [ ] ``airflow.operators.dummy_operator.DummyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
54
- * [ ] ``airflow.operators.email_operator.EmailOperator `` → ``airflow.providers.smtp.operators.smtp.EmailOperator ``
36
+ * [x] ``airflow.sensors.external_task_sensor.ExternalTaskMarker `` → ``airflow.providers.standard.sensors.external_task.ExternalTaskMarker ``
37
+ * [x] ``airflow.sensors.external_task_sensor.ExternalTaskSensor `` → ``airflow.providers.standard.sensors.external_task.ExternalTaskSensor ``
38
+ * [x] ``airflow.sensors.external_task_sensor.ExternalTaskSensorLink `` → ``airflow.providers.standard.sensors.external_task.ExternalTaskSensorLink ``
39
+ * [x] ``airflow.sensors.time_delta_sensor.TimeDeltaSensor `` → ``airflow.providers.standard.sensors.time_delta.TimeDeltaSensor ``
40
+ * [x] ``airflow.operators.dagrun_operator.TriggerDagRunLink `` → ``airflow.providers.standard.operators.trigger_dagrun.TriggerDagRunLink ``
41
+ * [x] ``airflow.operators.dagrun_operator.TriggerDagRunOperator `` → ``airflow.providers.standard.operators.trigger_dagrun.TriggerDagRunOperator ``
42
+ * [x] ``airflow.operators.python_operator.BranchPythonOperator `` → ``airflow.providers.standard.operators.python.BranchPythonOperator ``
43
+ * [x] ``airflow.operators.python_operator.PythonOperator `` → ``airflow.providers.standard.operators.python.PythonOperator ``
44
+ * [x] ``airflow.operators.python_operator.PythonVirtualenvOperator `` → ``airflow.providers.standard.operators.python.PythonVirtualenvOperator ``
45
+ * [x] ``airflow.operators.python_operator.ShortCircuitOperator `` → ``airflow.providers.standard.operators.python.ShortCircuitOperator ``
46
+ * [x] ``airflow.operators.latest_only_operator.LatestOnlyOperator `` → ``airflow.providers.standard.operators.latest_only.LatestOnlyOperator ``
47
+ * [x] ``airflow.operators.bash_operator.BashOperator `` → ``airflow.providers.standard.operators.bash.BashOperator ``
48
+ * [x] ``airflow.operators.branch_operator.BaseBranchOperator `` → ``airflow.providers.standard.operators.branch.BaseBranchOperator ``
49
+ * [x] ``airflow.sensors.date_time_sensor.DateTimeSensor `` → ``airflow.providers.standardi.sensors.DateTimeSensor ``
50
+ * [x] ``airflow.operators.dumm y.EmptyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
51
+ * [x] ``airflow.operators.dumm y.DummyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
52
+ * [x] ``airflow.operators.dummy_operator.EmptyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
53
+ * [x] ``airflow.operators.dummy_operator.DummyOperator `` → ``airflow.providers.standard.operators.empty.EmptyOperator ``
54
+ * [x] ``airflow.operators.email_operator.EmailOperator `` → ``airflow.providers.smtp.operators.smtp.EmailOperator ``
55
55
* [x] ``airflow.executors.celery_executor.CeleryExecutor `` → ``airflow.providers.celery.executors.celery_executor.CeleryExecutor ``
56
56
* [x] ``airflow.executors.celery_kubernetes_executor.CeleryKubernetesExecutor `` → ``airflow.providers.celery.executors.celery_kubernetes_executor.CeleryKubernetesExecutor ``
57
57
* [x] ``airflow.executors.dask_executor.DaskExecutor `` → ``airflow.providers.daskexecutor.executors.dask_executor.DaskExecutor ``
0 commit comments