You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by GitBox <gi...@apache.org> on 2022/06/01 09:25:51 UTC

[GitHub] [airflow] pankajastro commented on a diff in pull request #24038: Implement Azure Service Bus Queue Operator's

pankajastro commented on code in PR #24038:
URL: https://github.com/apache/airflow/pull/24038#discussion_r886588397


##########
airflow/providers/microsoft/azure/hooks/asb_admin_client.py:
##########
@@ -0,0 +1,90 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+from azure.servicebus.management import QueueProperties, ServiceBusAdministrationClient
+
+from airflow.exceptions import AirflowBadRequest, AirflowException
+from airflow.providers.microsoft.azure.hooks.base_asb import BaseAzureServiceBusHook
+
+
+class AzureServiceBusAdminClientHook(BaseAzureServiceBusHook):
+    """
+    Interacts with Azure ServiceBus management client
+    and Use this client to create, update, list, and delete resources of a ServiceBus namespace.
+    it uses the same azure service bus client connection inherits from the base class
+    """
+
+    def __init__(self, *args, **kwargs) -> None:
+        super().__init__(*args, **kwargs)
+
+    def get_conn(self) -> ServiceBusAdministrationClient:
+        """Create and returns ServiceBusAdministration by using the connection string in connection details"""
+        conn = self.get_connection(self.conn_id)
+        extras = conn.extra_dejson
+
+        self.connection_string = str(
+            extras.get('connection_string') or extras.get('extra__azure_service_bus__connection_string')
+        )
+        return ServiceBusAdministrationClient.from_connection_string(self.connection_string)
+
+    def create_queue(
+        self,
+        queue_name: str,
+        max_delivery_count: int = 10,
+        dead_lettering_on_message_expiration: bool = True,
+        enable_batched_operations: bool = True,
+    ) -> QueueProperties:
+        """
+        Create Queue by connecting to service Bus Admin client return the QueueProperties
+
+        :param queue_name: The name of the queue or a QueueProperties with name.
+        :param max_delivery_count: The maximum delivery count. A message is automatically
+            dead lettered after this number of deliveries. Default value is 10..
+        :param dead_lettering_on_message_expiration: A value that indicates whether this subscription has
+            dead letter support when a message expires.
+        :param enable_batched_operations: Value that indicates whether server-side batched
+            operations are enabled.
+        """
+        if queue_name is None:
+            raise AirflowBadRequest("Queue name cannot be None.")
+
+        try:
+            with self.get_conn() as service_mgmt_conn:
+                queue = service_mgmt_conn.create_queue(
+                    queue_name,
+                    max_delivery_count=max_delivery_count,
+                    dead_lettering_on_message_expiration=dead_lettering_on_message_expiration,
+                    enable_batched_operations=enable_batched_operations,
+                )
+                return queue
+        except Exception as e:
+            raise AirflowException(e)

Review Comment:
   Catching and raising exceptions does not add much value. 



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

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

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