Skip to content

TestNatsBroker

faststream.nats.TestNatsBroker #

TestNatsBroker(broker, with_real=False, connect_only=None)

Bases: TestBroker[NatsBroker]

A class to test NATS brokers.

Source code in faststream/testing/broker.py
def __init__(
    self,
    broker: Broker,
    with_real: bool = False,
    connect_only: Optional[bool] = None,
) -> None:
    self.with_real = with_real
    self.broker = broker

    if connect_only is None:
        try:
            connect_only = is_contains_context_name(
                self.__class__.__name__,
                TestApp.__name__,
            )
        except Exception:  # pragma: no cover
            warnings.warn(
                (
                    "\nError `{e!r}` occurred at `{self.__class__.__name__}` AST parsing."
                    "\n`connect_only` is set to `False` by default."
                ),
                category=RuntimeWarning,
                stacklevel=1,
            )

            connect_only = False

    self.connect_only = connect_only
    self._fake_subscribers: List[SubscriberProto[Any]] = []

with_real instance-attribute #

with_real = with_real

broker instance-attribute #

broker = broker

connect_only instance-attribute #

connect_only = connect_only

create_publisher_fake_subscriber staticmethod #

create_publisher_fake_subscriber(broker, publisher)
Source code in faststream/nats/testing.py
@staticmethod
def create_publisher_fake_subscriber(
    broker: NatsBroker,
    publisher: "AsyncAPIPublisher",
) -> Tuple["LogicSubscriber[Any, Any]", bool]:
    sub: Optional[LogicSubscriber[Any, Any]] = None
    publisher_stream = publisher.stream.name if publisher.stream else None
    for handler in broker._subscribers.values():
        if _is_handler_suitable(handler, publisher.subject, publisher_stream):
            sub = handler
            break

    if sub is None:
        is_real = False
        sub = broker.subscriber(publisher.subject)
    else:
        is_real = True

    return sub, is_real