Skip to content
Merged
Show file tree
Hide file tree
Changes from all commits
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
1 change: 1 addition & 0 deletions .pre-commit-config.yaml
Original file line number Diff line number Diff line change
Expand Up @@ -593,6 +593,7 @@ repos:
^providers/apache/beam/.*\.py$|
^providers/apache/flink/.*\.py$|
^providers/apache/iceberg/.*\.py$|
^providers/apache/kafka/.*\.py$|
^providers/cloudant/.*\.py$|
^providers/cohere/.*\.py$|
^providers/common/compat/.*\.py$|
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,8 +27,6 @@
from airflow.models import Connection
from airflow.providers.apache.kafka.hooks.client import KafkaAdminClientHook

pytestmark = pytest.mark.db_test

log = logging.getLogger(__name__)


Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,8 +27,6 @@
# Import Hook
from airflow.providers.apache.kafka.hooks.consume import KafkaConsumerHook

pytestmark = pytest.mark.db_test


class TestConsumerHook:
"""
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,9 +26,6 @@
from airflow.models import Connection
from airflow.providers.apache.kafka.hooks.produce import KafkaProducerHook

pytestmark = pytest.mark.db_test


log = logging.getLogger(__name__)


Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -28,9 +28,6 @@
# Import Operator
from airflow.providers.apache.kafka.operators.consume import ConsumeFromTopicOperator

pytestmark = pytest.mark.db_test


log = logging.getLogger(__name__)


Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,9 +25,6 @@
from airflow.models import Connection
from airflow.providers.apache.kafka.operators.produce import ProduceToTopicOperator

pytestmark = pytest.mark.db_test


log = logging.getLogger(__name__)


Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,9 +26,6 @@
from airflow.models import Connection
from airflow.providers.apache.kafka.sensors.kafka import AwaitMessageSensor, AwaitMessageTriggerFunctionSensor

pytestmark = pytest.mark.db_test


log = logging.getLogger(__name__)


Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,8 +27,6 @@

from tests_common.test_utils.version_compat import AIRFLOW_V_3_0_PLUS, get_base_airflow_version_tuple

pytestmark = pytest.mark.db_test


def apply_function_false(message):
return False
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -30,8 +30,6 @@
from airflow.providers.apache.kafka.triggers.msg_queue import KafkaMessageQueueTrigger
from airflow.providers.common.messaging.triggers.msg_queue import MessageQueueTrigger

pytestmark = pytest.mark.db_test


def apply_function_false(message):
return False
Expand Down