From c032ecfebd5ab3981af4b35c646d49a63673e5a2 Mon Sep 17 00:00:00 2001 From: Nikita Pastukhov Date: Fri, 13 Dec 2024 18:52:18 +0300 Subject: [PATCH 1/9] tests: refactor publish js frame test --- tests/brokers/nats/test_consume.py | 17 ++++++----------- 1 file changed, 6 insertions(+), 11 deletions(-) diff --git a/tests/brokers/nats/test_consume.py b/tests/brokers/nats/test_consume.py index 18fb87c818..f03daaec4c 100644 --- a/tests/brokers/nats/test_consume.py +++ b/tests/brokers/nats/test_consume.py @@ -75,22 +75,17 @@ def subscriber(m) -> None: async with self.patch_broker(consume_broker) as br: await br.start() - completed, _ = await asyncio.wait( - ( - asyncio.create_task(br.publish("hello", queue, stream=stream.name)), - asyncio.create_task(event.wait()), - ), + + result = await br.publish("hello", queue, stream=stream.name) + + await asyncio.wait( + (asyncio.create_task(event.wait()),), timeout=3, ) - publish_with_stream_returns_ack_frame = False - for task in completed: - if isinstance(task.result(), PubAck): - publish_with_stream_returns_ack_frame = True - break + assert isinstance(result, PubAck), result assert event.is_set() - assert publish_with_stream_returns_ack_frame async def test_consume_with_filter( self, From acf1d8c436030a0b524751bc4f974b73e215f747 Mon Sep 17 00:00:00 2001 From: Spataphore <93342746+spataphore1337@users.noreply.github.com> Date: Sat, 14 Dec 2024 13:35:02 +0300 Subject: [PATCH 2/9] feat: make return RecordMetada if not no_confirm, change annotations and convert Doc to doc string. (#1983) * feat: change returns kafka publish, change annotation and convert Doc to doc string * docs: generate API References * delete docs * change annotations on broker publish and publish_batch * add tests and use lint.sh --------- Co-authored-by: spataphore1337 --- docs/docs/en/api/faststream/AckPolicy.md | 11 - docs/docs/en/api/faststream/BaseMiddleware.md | 11 - docs/docs/en/api/faststream/Context.md | 11 - docs/docs/en/api/faststream/Depends.md | 11 - .../en/api/faststream/ExceptionMiddleware.md | 11 - docs/docs/en/api/faststream/FastStream.md | 11 - docs/docs/en/api/faststream/Header.md | 11 - docs/docs/en/api/faststream/Path.md | 11 - docs/docs/en/api/faststream/Response.md | 11 - docs/docs/en/api/faststream/TestApp.md | 11 - docs/docs/en/api/faststream/app/FastStream.md | 11 - docs/docs/en/api/faststream/apply_types.md | 11 - .../en/api/faststream/asgi/AsgiFastStream.md | 11 - .../en/api/faststream/asgi/AsgiResponse.md | 11 - .../api/faststream/asgi/app/AsgiFastStream.md | 11 - .../en/api/faststream/asgi/app/CliRunState.md | 11 - .../api/faststream/asgi/app/OuterRunState.md | 11 - .../en/api/faststream/asgi/app/ServerState.md | 11 - .../asgi/app/cast_uvicorn_params.md | 11 - .../asgi/factories/make_asyncapi_asgi.md | 11 - .../asgi/factories/make_ping_asgi.md | 11 - docs/docs/en/api/faststream/asgi/get.md | 11 - .../en/api/faststream/asgi/handlers/get.md | 11 - .../api/faststream/asgi/make_asyncapi_asgi.md | 11 - .../en/api/faststream/asgi/make_ping_asgi.md | 11 - .../faststream/asgi/response/AsgiResponse.md | 11 - .../asgi/websocket/WebSocketClose.md | 11 - .../api/faststream/confluent/KafkaBroker.md | 11 - .../faststream/confluent/KafkaPublisher.md | 11 - .../api/faststream/confluent/KafkaResponse.md | 11 - .../en/api/faststream/confluent/KafkaRoute.md | 11 - .../api/faststream/confluent/KafkaRouter.md | 11 - .../en/api/faststream/confluent/TestApp.md | 11 - .../faststream/confluent/TestKafkaBroker.md | 11 - .../faststream/confluent/TopicPartition.md | 11 - .../confluent/broker/KafkaBroker.md | 11 - .../confluent/broker/broker/KafkaBroker.md | 11 - .../broker/logging/KafkaParamsStorage.md | 11 - .../broker/registrator/KafkaRegistrator.md | 11 - .../client/AsyncConfluentConsumer.md | 11 - .../client/AsyncConfluentProducer.md | 11 - .../confluent/client/BatchBuilder.md | 11 - .../confluent/client/check_msg_error.md | 11 - .../confluent/client/create_topics.md | 11 - .../confluent/config/BrokerAddressFamily.md | 11 - .../confluent/config/BuiltinFeatures.md | 11 - .../confluent/config/ClientDNSLookup.md | 11 - .../confluent/config/CompressionCodec.md | 11 - .../confluent/config/CompressionType.md | 11 - .../confluent/config/ConfluentConfig.md | 11 - .../confluent/config/ConfluentFastConfig.md | 11 - .../api/faststream/confluent/config/Debug.md | 11 - .../confluent/config/GroupProtocol.md | 11 - .../confluent/config/IsolationLevel.md | 11 - .../confluent/config/OffsetStoreMethod.md | 11 - .../confluent/config/SASLOAUTHBearerMethod.md | 11 - .../confluent/config/SecurityProtocol.md | 11 - .../faststream/confluent/fastapi/Context.md | 11 - .../confluent/fastapi/KafkaRouter.md | 11 - .../confluent/fastapi/fastapi/KafkaRouter.md | 11 - .../confluent/message/ConsumerProtocol.md | 11 - .../confluent/message/FakeConsumer.md | 11 - .../confluent/message/KafkaMessage.md | 11 - .../opentelemetry/KafkaTelemetryMiddleware.md | 11 - .../middleware/KafkaTelemetryMiddleware.md | 11 - .../BaseConfluentTelemetrySettingsProvider.md | 11 - ...BatchConfluentTelemetrySettingsProvider.md | 11 - .../ConfluentTelemetrySettingsProvider.md | 11 - .../telemetry_attributes_provider_factory.md | 11 - .../confluent/parser/AsyncConfluentParser.md | 11 - .../prometheus/KafkaPrometheusMiddleware.md | 11 - .../middleware/KafkaPrometheusMiddleware.md | 11 - .../BaseConfluentMetricsSettingsProvider.md | 11 - .../BatchConfluentMetricsSettingsProvider.md | 11 - .../ConfluentMetricsSettingsProvider.md | 11 - .../provider/settings_provider_factory.md | 11 - .../publisher/factory/create_publisher.md | 11 - .../publisher/fake/KafkaFakePublisher.md | 11 - .../producer/AsyncConfluentFastProducer.md | 11 - .../specified/SpecificationBatchPublisher.md | 11 - .../SpecificationDefaultPublisher.md | 11 - .../specified/SpecificationPublisher.md | 11 - .../publisher/state/EmptyProducerState.md | 11 - .../publisher/state/ProducerState.md | 11 - .../confluent/publisher/state/RealProducer.md | 11 - .../publisher/usecase/BatchPublisher.md | 11 - .../publisher/usecase/DefaultPublisher.md | 11 - .../publisher/usecase/LogicPublisher.md | 11 - .../confluent/response/KafkaPublishCommand.md | 11 - .../confluent/response/KafkaResponse.md | 11 - .../confluent/router/KafkaPublisher.md | 11 - .../faststream/confluent/router/KafkaRoute.md | 11 - .../confluent/router/KafkaRouter.md | 11 - .../confluent/schemas/TopicPartition.md | 11 - .../params/ConsumerConnectionParams.md | 11 - .../schemas/partition/TopicPartition.md | 11 - .../confluent/security/parse_security.md | 11 - .../subscriber/factory/create_subscriber.md | 11 - .../specified/SpecificationBatchSubscriber.md | 11 - ...pecificationConcurrentDefaultSubscriber.md | 11 - .../SpecificationDefaultSubscriber.md | 11 - .../specified/SpecificationSubscriber.md | 11 - .../subscriber/usecase/BatchSubscriber.md | 11 - .../usecase/ConcurrentDefaultSubscriber.md | 11 - .../subscriber/usecase/DefaultSubscriber.md | 11 - .../subscriber/usecase/LogicSubscriber.md | 11 - .../confluent/testing/FakeProducer.md | 11 - .../confluent/testing/MockConfluentMessage.md | 11 - .../confluent/testing/TestKafkaBroker.md | 11 - .../confluent/testing/build_message.md | 11 - .../api/faststream/exceptions/AckMessage.md | 11 - .../api/faststream/exceptions/ContextError.md | 11 - .../exceptions/FastStreamException.md | 11 - .../FeatureNotSupportedException.md | 11 - .../faststream/exceptions/HandlerException.md | 11 - .../faststream/exceptions/IgnoredException.md | 11 - .../faststream/exceptions/IncorrectState.md | 11 - .../api/faststream/exceptions/NackMessage.md | 11 - .../faststream/exceptions/RejectMessage.md | 11 - .../api/faststream/exceptions/SetupError.md | 11 - .../api/faststream/exceptions/SkipMessage.md | 11 - .../exceptions/StartupValidationError.md | 11 - .../faststream/exceptions/StopApplication.md | 11 - .../api/faststream/exceptions/StopConsume.md | 11 - .../exceptions/SubscriberNotFound.md | 11 - .../en/api/faststream/kafka/KafkaBroker.md | 11 - .../en/api/faststream/kafka/KafkaPublisher.md | 11 - .../en/api/faststream/kafka/KafkaResponse.md | 11 - .../en/api/faststream/kafka/KafkaRoute.md | 11 - .../en/api/faststream/kafka/KafkaRouter.md | 11 - docs/docs/en/api/faststream/kafka/TestApp.md | 11 - .../api/faststream/kafka/TestKafkaBroker.md | 11 - .../en/api/faststream/kafka/TopicPartition.md | 11 - .../faststream/kafka/broker/KafkaBroker.md | 11 - .../kafka/broker/broker/KafkaBroker.md | 11 - .../broker/logging/KafkaParamsStorage.md | 11 - .../broker/registrator/KafkaRegistrator.md | 11 - .../api/faststream/kafka/fastapi/Context.md | 11 - .../faststream/kafka/fastapi/KafkaRouter.md | 11 - .../kafka/fastapi/fastapi/KafkaRouter.md | 11 - .../kafka/message/ConsumerProtocol.md | 11 - .../faststream/kafka/message/FakeConsumer.md | 11 - .../kafka/message/KafkaAckableMessage.md | 11 - .../faststream/kafka/message/KafkaMessage.md | 11 - .../opentelemetry/KafkaTelemetryMiddleware.md | 11 - .../middleware/KafkaTelemetryMiddleware.md | 11 - .../BaseKafkaTelemetrySettingsProvider.md | 11 - .../BatchKafkaTelemetrySettingsProvider.md | 11 - .../KafkaTelemetrySettingsProvider.md | 11 - .../telemetry_attributes_provider_factory.md | 11 - .../kafka/parser/AioKafkaBatchParser.md | 11 - .../faststream/kafka/parser/AioKafkaParser.md | 11 - .../prometheus/KafkaPrometheusMiddleware.md | 11 - .../middleware/KafkaPrometheusMiddleware.md | 11 - .../BaseKafkaMetricsSettingsProvider.md | 11 - .../BatchKafkaMetricsSettingsProvider.md | 11 - .../provider/KafkaMetricsSettingsProvider.md | 11 - .../provider/settings_provider_factory.md | 11 - .../publisher/factory/create_publisher.md | 11 - .../publisher/fake/KafkaFakePublisher.md | 11 - .../producer/AioKafkaFastProducer.md | 11 - .../specified/SpecificationBatchPublisher.md | 11 - .../SpecificationDefaultPublisher.md | 11 - .../specified/SpecificationPublisher.md | 11 - .../publisher/state/EmptyProducerState.md | 11 - .../kafka/publisher/state/ProducerState.md | 11 - .../kafka/publisher/state/RealProducer.md | 11 - .../kafka/publisher/usecase/BatchPublisher.md | 11 - .../publisher/usecase/DefaultPublisher.md | 11 - .../kafka/publisher/usecase/LogicPublisher.md | 11 - .../kafka/response/KafkaPublishCommand.md | 11 - .../kafka/response/KafkaResponse.md | 11 - .../faststream/kafka/router/KafkaPublisher.md | 11 - .../api/faststream/kafka/router/KafkaRoute.md | 11 - .../faststream/kafka/router/KafkaRouter.md | 11 - .../params/ConsumerConnectionParams.md | 11 - .../kafka/security/parse_security.md | 11 - .../subscriber/factory/create_subscriber.md | 11 - .../specified/SpecificationBatchSubscriber.md | 11 - ...pecificationConcurrentDefaultSubscriber.md | 11 - .../SpecificationDefaultSubscriber.md | 11 - .../specified/SpecificationSubscriber.md | 11 - .../subscriber/usecase/BatchSubscriber.md | 11 - .../usecase/ConcurrentDefaultSubscriber.md | 11 - .../subscriber/usecase/DefaultSubscriber.md | 11 - .../subscriber/usecase/LogicSubscriber.md | 11 - .../faststream/kafka/testing/FakeProducer.md | 11 - .../kafka/testing/TestKafkaBroker.md | 11 - .../faststream/kafka/testing/build_message.md | 11 - .../en/api/faststream/message/AckStatus.md | 11 - .../en/api/faststream/message/SourceType.md | 11 - .../api/faststream/message/StreamMessage.md | 11 - .../api/faststream/message/decode_message.md | 11 - .../api/faststream/message/encode_message.md | 11 - .../en/api/faststream/message/gen_cor_id.md | 11 - .../faststream/message/message/AckStatus.md | 11 - .../message/message/StreamMessage.md | 11 - .../message/source_type/SourceType.md | 11 - .../message/utils/decode_message.md | 11 - .../message/utils/encode_message.md | 11 - .../faststream/message/utils/gen_cor_id.md | 11 - .../api/faststream/middlewares/AckPolicy.md | 11 - .../middlewares/AcknowledgementMiddleware.md | 11 - .../faststream/middlewares/BaseMiddleware.md | 11 - .../middlewares/ExceptionMiddleware.md | 11 - .../acknowledgement/conf/AckPolicy.md | 11 - .../middleware/AcknowledgementMiddleware.md | 11 - .../middlewares/base/BaseMiddleware.md | 11 - .../exception/ExceptionMiddleware.md | 11 - .../middlewares/exception/ignore_handler.md | 11 - .../logging/CriticalLogMiddleware.md | 11 - docs/docs/en/api/faststream/nats/AckPolicy.md | 11 - .../en/api/faststream/nats/ConsumerConfig.md | 11 - .../en/api/faststream/nats/DeliverPolicy.md | 11 - .../en/api/faststream/nats/DiscardPolicy.md | 11 - .../en/api/faststream/nats/ExternalStream.md | 11 - docs/docs/en/api/faststream/nats/JStream.md | 11 - docs/docs/en/api/faststream/nats/KvWatch.md | 11 - .../docs/en/api/faststream/nats/NatsBroker.md | 11 - .../en/api/faststream/nats/NatsPublisher.md | 11 - .../en/api/faststream/nats/NatsResponse.md | 11 - docs/docs/en/api/faststream/nats/NatsRoute.md | 11 - .../docs/en/api/faststream/nats/NatsRouter.md | 11 - docs/docs/en/api/faststream/nats/ObjWatch.md | 11 - docs/docs/en/api/faststream/nats/Placement.md | 11 - docs/docs/en/api/faststream/nats/PubAck.md | 11 - docs/docs/en/api/faststream/nats/PullSub.md | 11 - docs/docs/en/api/faststream/nats/RePublish.md | 11 - .../en/api/faststream/nats/ReplayPolicy.md | 11 - .../en/api/faststream/nats/RetentionPolicy.md | 11 - .../en/api/faststream/nats/StorageType.md | 11 - .../en/api/faststream/nats/StreamConfig.md | 11 - .../en/api/faststream/nats/StreamSource.md | 11 - docs/docs/en/api/faststream/nats/TestApp.md | 11 - .../en/api/faststream/nats/TestNatsBroker.md | 11 - .../api/faststream/nats/broker/NatsBroker.md | 11 - .../nats/broker/broker/NatsBroker.md | 11 - .../nats/broker/logging/NatsParamsStorage.md | 11 - .../broker/registrator/NatsRegistrator.md | 11 - .../nats/broker/state/BrokerState.md | 11 - .../nats/broker/state/ConnectedState.md | 11 - .../broker/state/ConnectionBrokenState.md | 11 - .../nats/broker/state/EmptyBrokerState.md | 11 - .../en/api/faststream/nats/fastapi/Context.md | 11 - .../api/faststream/nats/fastapi/NatsRouter.md | 11 - .../nats/fastapi/fastapi/NatsRouter.md | 11 - .../nats/helpers/KVBucketDeclarer.md | 11 - .../nats/helpers/OSBucketDeclarer.md | 11 - .../faststream/nats/helpers/StreamBuilder.md | 11 - .../bucket_declarer/KVBucketDeclarer.md | 11 - .../obj_storage_declarer/OSBucketDeclarer.md | 11 - .../helpers/object_builder/StreamBuilder.md | 11 - .../nats/helpers/state/ConnectedState.md | 11 - .../nats/helpers/state/ConnectionState.md | 11 - .../helpers/state/EmptyConnectionState.md | 11 - .../nats/message/NatsBatchMessage.md | 11 - .../faststream/nats/message/NatsKvMessage.md | 11 - .../faststream/nats/message/NatsMessage.md | 11 - .../faststream/nats/message/NatsObjMessage.md | 11 - .../opentelemetry/NatsTelemetryMiddleware.md | 11 - .../middleware/NatsTelemetryMiddleware.md | 11 - .../BaseNatsTelemetrySettingsProvider.md | 11 - .../NatsBatchTelemetrySettingsProvider.md | 11 - .../provider/NatsTelemetrySettingsProvider.md | 11 - .../telemetry_attributes_provider_factory.md | 11 - .../api/faststream/nats/parser/BatchParser.md | 11 - .../en/api/faststream/nats/parser/JsParser.md | 11 - .../en/api/faststream/nats/parser/KvParser.md | 11 - .../faststream/nats/parser/NatsBaseParser.md | 11 - .../api/faststream/nats/parser/NatsParser.md | 11 - .../api/faststream/nats/parser/ObjParser.md | 11 - .../prometheus/NatsPrometheusMiddleware.md | 11 - .../middleware/NatsPrometheusMiddleware.md | 11 - .../BaseNatsMetricsSettingsProvider.md | 11 - .../BatchNatsMetricsSettingsProvider.md | 11 - .../provider/NatsMetricsSettingsProvider.md | 11 - .../provider/settings_provider_factory.md | 11 - .../publisher/factory/create_publisher.md | 11 - .../nats/publisher/fake/NatsFakePublisher.md | 11 - .../publisher/producer/NatsFastProducer.md | 11 - .../publisher/producer/NatsJSFastProducer.md | 11 - .../specified/SpecificationPublisher.md | 11 - .../nats/publisher/usecase/LogicPublisher.md | 11 - .../nats/response/NatsPublishCommand.md | 11 - .../faststream/nats/response/NatsResponse.md | 11 - .../faststream/nats/router/NatsPublisher.md | 11 - .../api/faststream/nats/router/NatsRoute.md | 11 - .../api/faststream/nats/router/NatsRouter.md | 11 - .../en/api/faststream/nats/schemas/JStream.md | 11 - .../en/api/faststream/nats/schemas/KvWatch.md | 11 - .../api/faststream/nats/schemas/ObjWatch.md | 11 - .../en/api/faststream/nats/schemas/PubAck.md | 11 - .../en/api/faststream/nats/schemas/PullSub.md | 11 - .../nats/schemas/js_stream/JStream.md | 11 - .../js_stream/compile_nats_wildcard.md | 11 - .../js_stream/is_subject_match_wildcard.md | 11 - .../nats/schemas/kv_watch/KvWatch.md | 11 - .../nats/schemas/obj_watch/ObjWatch.md | 11 - .../nats/schemas/pull_sub/PullSub.md | 11 - .../nats/security/parse_security.md | 11 - .../subscriber/adapters/UnsubscribeAdapter.md | 11 - .../subscriber/adapters/Unsubscriptable.md | 11 - .../nats/subscriber/adapters/Watchable.md | 11 - .../subscriber/factory/create_subscriber.md | 11 - .../SpecificationBatchPullStreamSubscriber.md | 11 - .../SpecificationConcurrentCoreSubscriber.md | 11 - ...ificationConcurrentPullStreamSubscriber.md | 11 - ...ificationConcurrentPushStreamSubscriber.md | 11 - .../specified/SpecificationCoreSubscriber.md | 11 - .../SpecificationKeyValueWatchSubscriber.md | 11 - .../SpecificationObjStoreWatchSubscriber.md | 11 - .../SpecificationPullStreamSubscriber.md | 11 - .../SpecificationPushStreamSubscriber.md | 11 - .../specified/SpecificationSubscriber.md | 11 - .../state/ConnectedSubscriberState.md | 11 - .../subscriber/state/EmptySubscriberState.md | 11 - .../nats/subscriber/state/SubscriberState.md | 11 - .../usecases/BatchPullStreamSubscriber.md | 11 - .../usecases/ConcurrentCoreSubscriber.md | 11 - .../ConcurrentPullStreamSubscriber.md | 11 - .../ConcurrentPushStreamSubscriber.md | 11 - .../subscriber/usecases/CoreSubscriber.md | 11 - .../usecases/KeyValueWatchSubscriber.md | 11 - .../subscriber/usecases/LogicSubscriber.md | 11 - .../usecases/ObjStoreWatchSubscriber.md | 11 - .../usecases/PullStreamSubscriber.md | 11 - .../usecases/PushStreamSubscription.md | 11 - .../usecases/basic/DefaultSubscriber.md | 11 - .../usecases/basic/LogicSubscriber.md | 11 - .../ConcurrentCoreSubscriber.md | 11 - .../core_subscriber/CoreSubscriber.md | 11 - .../KeyValueWatchSubscriber.md | 11 - .../ObjStoreWatchSubscriber.md | 11 - .../usecases/stream_basic/StreamSubscriber.md | 11 - .../BatchPullStreamSubscriber.md | 11 - .../ConcurrentPullStreamSubscriber.md | 11 - .../PullStreamSubscriber.md | 11 - .../ConcurrentPushStreamSubscriber.md | 11 - .../PushStreamSubscription.md | 11 - .../faststream/nats/testing/FakeProducer.md | 11 - .../faststream/nats/testing/PatchedMessage.md | 11 - .../faststream/nats/testing/TestNatsBroker.md | 11 - .../faststream/nats/testing/build_message.md | 11 - .../api/faststream/opentelemetry/Baggage.md | 11 - .../opentelemetry/TelemetryMiddleware.md | 11 - .../TelemetrySettingsProvider.md | 11 - .../opentelemetry/baggage/Baggage.md | 11 - .../opentelemetry/consts/MessageAction.md | 11 - .../middleware/BaseTelemetryMiddleware.md | 11 - .../middleware/TelemetryMiddleware.md | 11 - .../provider/TelemetrySettingsProvider.md | 11 - docs/docs/en/api/faststream/params/Context.md | 11 - docs/docs/en/api/faststream/params/Depends.md | 11 - docs/docs/en/api/faststream/params/Header.md | 11 - docs/docs/en/api/faststream/params/Path.md | 11 - .../faststream/params/no_cast/NoCastField.md | 11 - .../api/faststream/params/params/Context.md | 11 - .../en/api/faststream/params/params/Header.md | 11 - .../en/api/faststream/params/params/Path.md | 11 - .../api/faststream/prometheus/ConsumeAttrs.md | 11 - .../prometheus/MetricsSettingsProvider.md | 11 - .../prometheus/PrometheusMiddleware.md | 11 - .../prometheus/container/MetricsContainer.md | 11 - .../prometheus/manager/MetricsManager.md | 11 - .../middleware/BasePrometheusMiddleware.md | 11 - .../middleware/PrometheusMiddleware.md | 11 - .../provider/MetricsSettingsProvider.md | 11 - .../prometheus/types/ConsumeAttrs.md | 11 - .../prometheus/types/ProcessingStatus.md | 11 - .../prometheus/types/PublishingStatus.md | 11 - .../en/api/faststream/rabbit/ExchangeType.md | 11 - .../en/api/faststream/rabbit/RabbitBroker.md | 11 - .../api/faststream/rabbit/RabbitExchange.md | 11 - .../api/faststream/rabbit/RabbitPublisher.md | 11 - .../en/api/faststream/rabbit/RabbitQueue.md | 11 - .../api/faststream/rabbit/RabbitResponse.md | 11 - .../en/api/faststream/rabbit/RabbitRoute.md | 11 - .../en/api/faststream/rabbit/RabbitRouter.md | 11 - docs/docs/en/api/faststream/rabbit/TestApp.md | 11 - .../api/faststream/rabbit/TestRabbitBroker.md | 11 - .../faststream/rabbit/broker/RabbitBroker.md | 11 - .../rabbit/broker/broker/RabbitBroker.md | 11 - .../broker/logging/RabbitParamsStorage.md | 11 - .../broker/registrator/RabbitRegistrator.md | 11 - .../api/faststream/rabbit/fastapi/Context.md | 11 - .../faststream/rabbit/fastapi/RabbitRouter.md | 11 - .../rabbit/fastapi/fastapi/RabbitRouter.md | 11 - .../rabbit/helpers/declarer/RabbitDeclarer.md | 11 - .../rabbit/helpers/state/ConnectedState.md | 11 - .../rabbit/helpers/state/ConnectionState.md | 11 - .../helpers/state/EmptyConnectionState.md | 11 - .../rabbit/message/RabbitMessage.md | 11 - .../RabbitTelemetryMiddleware.md | 11 - .../middleware/RabbitTelemetryMiddleware.md | 11 - .../RabbitTelemetrySettingsProvider.md | 11 - .../faststream/rabbit/parser/AioPikaParser.md | 11 - .../prometheus/RabbitPrometheusMiddleware.md | 11 - .../middleware/RabbitPrometheusMiddleware.md | 11 - .../provider/RabbitMetricsSettingsProvider.md | 11 - .../publisher/factory/create_publisher.md | 11 - .../publisher/fake/RabbitFakePublisher.md | 11 - .../publisher/options/MessageOptions.md | 11 - .../publisher/options/PublishOptions.md | 11 - .../publisher/producer/AioPikaFastProducer.md | 11 - .../rabbit/publisher/producer/LockState.md | 11 - .../rabbit/publisher/producer/LockUnset.md | 11 - .../rabbit/publisher/producer/RealLock.md | 11 - .../specified/SpecificationPublisher.md | 11 - .../publisher/usecase/LogicPublisher.md | 11 - .../rabbit/publisher/usecase/PublishKwargs.md | 11 - .../publisher/usecase/RequestPublishKwargs.md | 11 - .../rabbit/response/RabbitPublishCommand.md | 11 - .../rabbit/response/RabbitResponse.md | 11 - .../rabbit/router/RabbitPublisher.md | 11 - .../faststream/rabbit/router/RabbitRoute.md | 11 - .../faststream/rabbit/router/RabbitRouter.md | 11 - .../rabbit/schemas/BaseRMQInformation.md | 11 - .../faststream/rabbit/schemas/ExchangeType.md | 11 - .../rabbit/schemas/RabbitExchange.md | 11 - .../faststream/rabbit/schemas/RabbitQueue.md | 11 - .../rabbit/schemas/constants/ExchangeType.md | 11 - .../rabbit/schemas/exchange/RabbitExchange.md | 11 - .../schemas/proto/BaseRMQInformation.md | 11 - .../rabbit/schemas/queue/RabbitQueue.md | 11 - .../rabbit/security/parse_security.md | 11 - .../subscriber/factory/create_subscriber.md | 11 - .../specified/SpecificationSubscriber.md | 11 - .../subscriber/usecase/LogicSubscriber.md | 11 - .../faststream/rabbit/testing/FakeProducer.md | 11 - .../rabbit/testing/PatchedMessage.md | 11 - .../rabbit/testing/TestRabbitBroker.md | 11 - .../rabbit/testing/apply_pattern.md | 11 - .../rabbit/testing/build_message.md | 11 - .../api/faststream/rabbit/utils/build_url.md | 11 - .../rabbit/utils/is_routing_exchange.md | 11 - docs/docs/en/api/faststream/redis/ListSub.md | 11 - docs/docs/en/api/faststream/redis/PubSub.md | 11 - .../en/api/faststream/redis/RedisBroker.md | 11 - .../en/api/faststream/redis/RedisPublisher.md | 11 - .../en/api/faststream/redis/RedisResponse.md | 11 - .../en/api/faststream/redis/RedisRoute.md | 11 - .../en/api/faststream/redis/RedisRouter.md | 11 - .../docs/en/api/faststream/redis/StreamSub.md | 11 - docs/docs/en/api/faststream/redis/TestApp.md | 11 - .../api/faststream/redis/TestRedisBroker.md | 11 - .../redis/broker/broker/RedisBroker.md | 11 - .../broker/logging/RedisParamsStorage.md | 11 - .../broker/registrator/RedisRegistrator.md | 11 - .../api/faststream/redis/fastapi/Context.md | 11 - .../faststream/redis/fastapi/RedisRouter.md | 11 - .../redis/fastapi/fastapi/RedisRouter.md | 11 - .../redis/helpers/state/ConnectedState.md | 11 - .../redis/helpers/state/ConnectionState.md | 11 - .../helpers/state/EmptyConnectionState.md | 11 - .../redis/message/BatchListMessage.md | 11 - .../redis/message/BatchStreamMessage.md | 11 - .../redis/message/DefaultListMessage.md | 11 - .../redis/message/DefaultStreamMessage.md | 11 - .../faststream/redis/message/PubSubMessage.md | 11 - .../redis/message/RedisBatchListMessage.md | 11 - .../redis/message/RedisBatchStreamMessage.md | 11 - .../redis/message/RedisListMessage.md | 11 - .../faststream/redis/message/RedisMessage.md | 11 - .../redis/message/RedisStreamMessage.md | 11 - .../redis/message/UnifyRedisDict.md | 11 - .../redis/message/UnifyRedisMessage.md | 11 - .../opentelemetry/RedisTelemetryMiddleware.md | 11 - .../middleware/RedisTelemetryMiddleware.md | 11 - .../RedisTelemetrySettingsProvider.md | 11 - .../api/faststream/redis/parser/RawMessage.md | 11 - .../redis/parser/RedisBatchListParser.md | 11 - .../redis/parser/RedisBatchStreamParser.md | 11 - .../redis/parser/RedisListParser.md | 11 - .../redis/parser/RedisPubSubParser.md | 11 - .../redis/parser/RedisStreamParser.md | 11 - .../faststream/redis/parser/SimpleParser.md | 11 - .../prometheus/RedisPrometheusMiddleware.md | 11 - .../middleware/RedisPrometheusMiddleware.md | 11 - .../BaseRedisMetricsSettingsProvider.md | 11 - .../BatchRedisMetricsSettingsProvider.md | 11 - .../provider/RedisMetricsSettingsProvider.md | 11 - .../provider/settings_provider_factory.md | 11 - .../publisher/factory/create_publisher.md | 11 - .../publisher/fake/RedisFakePublisher.md | 11 - .../publisher/producer/RedisFastProducer.md | 11 - .../SpecificationChannelPublisher.md | 11 - .../SpecificationListBatchPublisher.md | 11 - .../specified/SpecificationListPublisher.md | 11 - .../specified/SpecificationPublisher.md | 11 - .../specified/SpecificationStreamPublisher.md | 11 - .../publisher/usecase/ChannelPublisher.md | 11 - .../publisher/usecase/ListBatchPublisher.md | 11 - .../redis/publisher/usecase/ListPublisher.md | 11 - .../redis/publisher/usecase/LogicPublisher.md | 11 - .../publisher/usecase/StreamPublisher.md | 11 - .../redis/response/DestinationType.md | 11 - .../redis/response/RedisPublishCommand.md | 11 - .../redis/response/RedisResponse.md | 11 - .../faststream/redis/router/RedisPublisher.md | 11 - .../api/faststream/redis/router/RedisRoute.md | 11 - .../faststream/redis/router/RedisRouter.md | 11 - .../api/faststream/redis/schemas/ListSub.md | 11 - .../en/api/faststream/redis/schemas/PubSub.md | 11 - .../api/faststream/redis/schemas/StreamSub.md | 11 - .../redis/schemas/list_sub/ListSub.md | 11 - .../proto/RedisSpecificationProtocol.md | 11 - .../redis/schemas/proto/validate_options.md | 11 - .../redis/schemas/pub_sub/PubSub.md | 11 - .../redis/schemas/stream_sub/StreamSub.md | 11 - .../redis/security/parse_security.md | 11 - .../subscriber/factory/create_subscriber.md | 11 - .../SpecificationChannelSubscriber.md | 11 - .../SpecificationListBatchSubscriber.md | 11 - .../specified/SpecificationListSubscriber.md | 11 - .../SpecificationStreamBatchSubscriber.md | 11 - .../SpecificationStreamSubscriber.md | 11 - .../specified/SpecificationSubscriber.md | 11 - .../subscriber/usecase/BatchListSubscriber.md | 11 - .../subscriber/usecase/ChannelSubscriber.md | 11 - .../subscriber/usecase/ListSubscriber.md | 11 - .../subscriber/usecase/LogicSubscriber.md | 11 - .../usecase/StreamBatchSubscriber.md | 11 - .../subscriber/usecase/StreamSubscriber.md | 11 - .../redis/testing/ChannelVisitor.md | 11 - .../faststream/redis/testing/FakeProducer.md | 11 - .../faststream/redis/testing/ListVisitor.md | 11 - .../faststream/redis/testing/StreamVisitor.md | 11 - .../redis/testing/TestRedisBroker.md | 11 - .../api/faststream/redis/testing/Visitor.md | 11 - .../faststream/redis/testing/build_message.md | 11 - .../api/faststream/response/PublishCommand.md | 11 - .../en/api/faststream/response/PublishType.md | 11 - .../en/api/faststream/response/Response.md | 11 - .../faststream/response/ensure_response.md | 11 - .../response/publish_type/PublishType.md | 11 - .../response/response/PublishCommand.md | 11 - .../faststream/response/response/Response.md | 11 - .../response/utils/ensure_response.md | 11 - .../api/faststream/security/BaseSecurity.md | 11 - .../en/api/faststream/security/SASLGSSAPI.md | 11 - .../faststream/security/SASLOAuthBearer.md | 11 - .../api/faststream/security/SASLPlaintext.md | 11 - .../api/faststream/security/SASLScram256.md | 11 - .../api/faststream/security/SASLScram512.md | 11 - .../api/faststream/specification/AsyncAPI.md | 11 - .../api/faststream/specification/Contact.md | 11 - .../faststream/specification/ExternalDocs.md | 11 - .../api/faststream/specification/License.md | 11 - .../en/api/faststream/specification/Tag.md | 11 - .../specification/asyncapi/AsyncAPI.md | 11 - .../asyncapi/factory/AsyncAPI.md | 11 - .../asyncapi/get_asyncapi_html.md | 11 - .../asyncapi/message/get_model_schema.md | 11 - .../asyncapi/message/get_response_schema.md | 11 - .../asyncapi/message/parse_handler_params.md | 11 - .../asyncapi/site/get_asyncapi_html.md | 11 - .../specification/asyncapi/site/serve_app.md | 11 - .../specification/asyncapi/utils/clear_key.md | 11 - .../asyncapi/utils/move_pydantic_refs.md | 11 - .../asyncapi/utils/resolve_payloads.md | 11 - .../asyncapi/utils/to_camelcase.md | 11 - .../asyncapi/v2_6_0/AsyncAPI2.md | 11 - .../asyncapi/v2_6_0/facade/AsyncAPI2.md | 11 - .../v2_6_0/generate/get_app_schema.md | 11 - .../v2_6_0/generate/get_broker_channels.md | 11 - .../v2_6_0/generate/get_broker_server.md | 11 - .../generate/resolve_channel_messages.md | 11 - .../asyncapi/v2_6_0/get_app_schema.md | 11 - .../asyncapi/v2_6_0/schema/ApplicationInfo.md | 11 - .../v2_6_0/schema/ApplicationSchema.md | 11 - .../asyncapi/v2_6_0/schema/Channel.md | 11 - .../asyncapi/v2_6_0/schema/Components.md | 11 - .../asyncapi/v2_6_0/schema/Contact.md | 11 - .../asyncapi/v2_6_0/schema/CorrelationId.md | 11 - .../asyncapi/v2_6_0/schema/ExternalDocs.md | 11 - .../asyncapi/v2_6_0/schema/License.md | 11 - .../asyncapi/v2_6_0/schema/Message.md | 11 - .../asyncapi/v2_6_0/schema/Operation.md | 11 - .../asyncapi/v2_6_0/schema/Parameter.md | 11 - .../asyncapi/v2_6_0/schema/Reference.md | 11 - .../asyncapi/v2_6_0/schema/Server.md | 11 - .../asyncapi/v2_6_0/schema/ServerVariable.md | 11 - .../asyncapi/v2_6_0/schema/Tag.md | 11 - .../v2_6_0/schema/bindings/ChannelBinding.md | 11 - .../schema/bindings/OperationBinding.md | 11 - .../schema/bindings/amqp/ChannelBinding.md | 11 - .../schema/bindings/amqp/OperationBinding.md | 11 - .../bindings/amqp/channel/ChannelBinding.md | 11 - .../schema/bindings/amqp/channel/Exchange.md | 11 - .../schema/bindings/amqp/channel/Queue.md | 11 - .../amqp/operation/OperationBinding.md | 11 - .../schema/bindings/kafka/ChannelBinding.md | 11 - .../schema/bindings/kafka/OperationBinding.md | 11 - .../bindings/kafka/channel/ChannelBinding.md | 11 - .../kafka/operation/OperationBinding.md | 11 - .../schema/bindings/main/ChannelBinding.md | 11 - .../schema/bindings/main/OperationBinding.md | 11 - .../bindings/main/channel/ChannelBinding.md | 11 - .../main/operation/OperationBinding.md | 11 - .../schema/bindings/nats/ChannelBinding.md | 11 - .../schema/bindings/nats/OperationBinding.md | 11 - .../bindings/nats/channel/ChannelBinding.md | 11 - .../nats/operation/OperationBinding.md | 11 - .../schema/bindings/redis/ChannelBinding.md | 11 - .../schema/bindings/redis/OperationBinding.md | 11 - .../bindings/redis/channel/ChannelBinding.md | 11 - .../redis/operation/OperationBinding.md | 11 - .../schema/bindings/sqs/ChannelBinding.md | 11 - .../schema/bindings/sqs/OperationBinding.md | 11 - .../bindings/sqs/channel/ChannelBinding.md | 11 - .../schema/bindings/sqs/channel/from_spec.md | 11 - .../sqs/operation/OperationBinding.md | 11 - .../bindings/sqs/operation/from_spec.md | 11 - .../v2_6_0/schema/channels/Channel.md | 11 - .../v2_6_0/schema/components/Components.md | 11 - .../asyncapi/v2_6_0/schema/contact/Contact.md | 11 - .../v2_6_0/schema/docs/ExternalDocs.md | 11 - .../v2_6_0/schema/info/ApplicationInfo.md | 11 - .../asyncapi/v2_6_0/schema/license/License.md | 11 - .../v2_6_0/schema/message/CorrelationId.md | 11 - .../asyncapi/v2_6_0/schema/message/Message.md | 11 - .../v2_6_0/schema/operations/Operation.md | 11 - .../v2_6_0/schema/schema/ApplicationSchema.md | 11 - .../asyncapi/v2_6_0/schema/servers/Server.md | 11 - .../v2_6_0/schema/servers/ServerVariable.md | 11 - .../asyncapi/v2_6_0/schema/tag/Tag.md | 11 - .../asyncapi/v2_6_0/schema/utils/Parameter.md | 11 - .../asyncapi/v2_6_0/schema/utils/Reference.md | 11 - .../asyncapi/v3_0_0/AsyncAPI3.md | 11 - .../asyncapi/v3_0_0/facade/AsyncAPI3.md | 11 - .../v3_0_0/generate/get_app_schema.md | 11 - .../v3_0_0/generate/get_broker_channels.md | 11 - .../v3_0_0/generate/get_broker_server.md | 11 - .../asyncapi/v3_0_0/get_app_schema.md | 11 - .../asyncapi/v3_0_0/schema/ApplicationInfo.md | 11 - .../v3_0_0/schema/ApplicationSchema.md | 11 - .../asyncapi/v3_0_0/schema/Channel.md | 11 - .../asyncapi/v3_0_0/schema/Components.md | 11 - .../asyncapi/v3_0_0/schema/Contact.md | 11 - .../asyncapi/v3_0_0/schema/CorrelationId.md | 11 - .../asyncapi/v3_0_0/schema/ExternalDocs.md | 11 - .../asyncapi/v3_0_0/schema/License.md | 11 - .../asyncapi/v3_0_0/schema/Message.md | 11 - .../asyncapi/v3_0_0/schema/Operation.md | 11 - .../asyncapi/v3_0_0/schema/Parameter.md | 11 - .../asyncapi/v3_0_0/schema/Reference.md | 11 - .../asyncapi/v3_0_0/schema/Server.md | 11 - .../asyncapi/v3_0_0/schema/ServerVariable.md | 11 - .../asyncapi/v3_0_0/schema/Tag.md | 11 - .../v3_0_0/schema/bindings/ChannelBinding.md | 11 - .../schema/bindings/OperationBinding.md | 11 - .../schema/bindings/amqp/ChannelBinding.md | 11 - .../schema/bindings/amqp/OperationBinding.md | 11 - .../bindings/amqp/channel/ChannelBinding.md | 11 - .../amqp/operation/OperationBinding.md | 11 - .../schema/bindings/kafka/ChannelBinding.md | 11 - .../schema/bindings/kafka/OperationBinding.md | 11 - .../schema/bindings/main/ChannelBinding.md | 11 - .../schema/bindings/main/OperationBinding.md | 11 - .../bindings/main/channel/ChannelBinding.md | 11 - .../main/operation/OperationBinding.md | 11 - .../schema/bindings/nats/ChannelBinding.md | 11 - .../schema/bindings/nats/OperationBinding.md | 11 - .../schema/bindings/redis/ChannelBinding.md | 11 - .../schema/bindings/redis/OperationBinding.md | 11 - .../schema/bindings/sqs/ChannelBinding.md | 11 - .../schema/bindings/sqs/OperationBinding.md | 11 - .../v3_0_0/schema/channels/Channel.md | 11 - .../v3_0_0/schema/components/Components.md | 11 - .../asyncapi/v3_0_0/schema/contact/Contact.md | 11 - .../v3_0_0/schema/docs/ExternalDocs.md | 11 - .../v3_0_0/schema/info/ApplicationInfo.md | 11 - .../asyncapi/v3_0_0/schema/license/License.md | 11 - .../v3_0_0/schema/message/CorrelationId.md | 11 - .../asyncapi/v3_0_0/schema/message/Message.md | 11 - .../v3_0_0/schema/operations/Action.md | 11 - .../v3_0_0/schema/operations/Operation.md | 11 - .../v3_0_0/schema/schema/ApplicationSchema.md | 11 - .../asyncapi/v3_0_0/schema/servers/Server.md | 11 - .../asyncapi/v3_0_0/schema/tag/Tag.md | 11 - .../asyncapi/v3_0_0/schema/utils/Parameter.md | 11 - .../asyncapi/v3_0_0/schema/utils/Reference.md | 11 - .../base/info/BaseApplicationInfo.md | 11 - .../base/schema/BaseApplicationSchema.md | 11 - .../base/specification/Specification.md | 11 - .../proto/EndpointSpecification.md | 11 - .../proto/ServerSpecification.md | 11 - .../proto/broker/ServerSpecification.md | 11 - .../proto/endpoint/EndpointSpecification.md | 11 - .../specification/schema/Contact.md | 11 - .../specification/schema/ContactDict.md | 11 - .../specification/schema/ExternalDocs.md | 11 - .../specification/schema/ExternalDocsDict.md | 11 - .../specification/schema/License.md | 11 - .../specification/schema/LicenseDict.md | 11 - .../specification/schema/Message.md | 11 - .../specification/schema/Operation.md | 11 - .../specification/schema/PublisherSpec.md | 11 - .../specification/schema/SubscriberSpec.md | 11 - .../faststream/specification/schema/Tag.md | 11 - .../specification/schema/TagDict.md | 11 - .../schema/bindings/ChannelBinding.md | 11 - .../schema/bindings/OperationBinding.md | 11 - .../schema/bindings/amqp/ChannelBinding.md | 11 - .../schema/bindings/amqp/Exchange.md | 11 - .../schema/bindings/amqp/OperationBinding.md | 11 - .../schema/bindings/amqp/Queue.md | 11 - .../schema/bindings/kafka/ChannelBinding.md | 11 - .../schema/bindings/kafka/OperationBinding.md | 11 - .../schema/bindings/main/ChannelBinding.md | 11 - .../schema/bindings/main/OperationBinding.md | 11 - .../schema/bindings/nats/ChannelBinding.md | 11 - .../schema/bindings/nats/OperationBinding.md | 11 - .../schema/bindings/redis/ChannelBinding.md | 11 - .../schema/bindings/redis/OperationBinding.md | 11 - .../schema/bindings/sqs/ChannelBinding.md | 11 - .../schema/bindings/sqs/OperationBinding.md | 11 - .../specification/schema/extra/Contact.md | 11 - .../specification/schema/extra/ContactDict.md | 11 - .../schema/extra/ExternalDocs.md | 11 - .../schema/extra/ExternalDocsDict.md | 11 - .../specification/schema/extra/License.md | 11 - .../specification/schema/extra/LicenseDict.md | 11 - .../specification/schema/extra/Tag.md | 11 - .../specification/schema/extra/TagDict.md | 11 - .../schema/extra/contact/Contact.md | 11 - .../schema/extra/contact/ContactDict.md | 11 - .../extra/external_docs/ExternalDocs.md | 11 - .../extra/external_docs/ExternalDocsDict.md | 11 - .../schema/extra/license/License.md | 11 - .../schema/extra/license/LicenseDict.md | 11 - .../specification/schema/extra/tag/Tag.md | 11 - .../specification/schema/extra/tag/TagDict.md | 11 - .../specification/schema/message/Message.md | 11 - .../schema/message/model/Message.md | 11 - .../schema/operation/Operation.md | 11 - .../schema/operation/model/Operation.md | 11 - .../schema/publisher/PublisherSpec.md | 11 - .../schema/subscriber/SubscriberSpec.md | 11 - docs/docs/en/release.md | 2 +- faststream/kafka/broker/broker.py | 251 ++++++++++-------- faststream/kafka/publisher/producer.py | 11 +- faststream/kafka/publisher/usecase.py | 244 +++++++++-------- tests/brokers/kafka/test_publish.py | 28 +- 744 files changed, 310 insertions(+), 8355 deletions(-) delete mode 100644 docs/docs/en/api/faststream/AckPolicy.md delete mode 100644 docs/docs/en/api/faststream/BaseMiddleware.md delete mode 100644 docs/docs/en/api/faststream/Context.md delete mode 100644 docs/docs/en/api/faststream/Depends.md delete mode 100644 docs/docs/en/api/faststream/ExceptionMiddleware.md delete mode 100644 docs/docs/en/api/faststream/FastStream.md delete mode 100644 docs/docs/en/api/faststream/Header.md delete mode 100644 docs/docs/en/api/faststream/Path.md delete mode 100644 docs/docs/en/api/faststream/Response.md delete mode 100644 docs/docs/en/api/faststream/TestApp.md delete mode 100644 docs/docs/en/api/faststream/app/FastStream.md delete mode 100644 docs/docs/en/api/faststream/apply_types.md delete mode 100644 docs/docs/en/api/faststream/asgi/AsgiFastStream.md delete mode 100644 docs/docs/en/api/faststream/asgi/AsgiResponse.md delete mode 100644 docs/docs/en/api/faststream/asgi/app/AsgiFastStream.md delete mode 100644 docs/docs/en/api/faststream/asgi/app/CliRunState.md delete mode 100644 docs/docs/en/api/faststream/asgi/app/OuterRunState.md delete mode 100644 docs/docs/en/api/faststream/asgi/app/ServerState.md delete mode 100644 docs/docs/en/api/faststream/asgi/app/cast_uvicorn_params.md delete mode 100644 docs/docs/en/api/faststream/asgi/factories/make_asyncapi_asgi.md delete mode 100644 docs/docs/en/api/faststream/asgi/factories/make_ping_asgi.md delete mode 100644 docs/docs/en/api/faststream/asgi/get.md delete mode 100644 docs/docs/en/api/faststream/asgi/handlers/get.md delete mode 100644 docs/docs/en/api/faststream/asgi/make_asyncapi_asgi.md delete mode 100644 docs/docs/en/api/faststream/asgi/make_ping_asgi.md delete mode 100644 docs/docs/en/api/faststream/asgi/response/AsgiResponse.md delete mode 100644 docs/docs/en/api/faststream/asgi/websocket/WebSocketClose.md delete mode 100644 docs/docs/en/api/faststream/confluent/KafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/confluent/KafkaPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/KafkaResponse.md delete mode 100644 docs/docs/en/api/faststream/confluent/KafkaRoute.md delete mode 100644 docs/docs/en/api/faststream/confluent/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/confluent/TestApp.md delete mode 100644 docs/docs/en/api/faststream/confluent/TestKafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/confluent/TopicPartition.md delete mode 100644 docs/docs/en/api/faststream/confluent/broker/KafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/confluent/broker/broker/KafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/confluent/broker/logging/KafkaParamsStorage.md delete mode 100644 docs/docs/en/api/faststream/confluent/broker/registrator/KafkaRegistrator.md delete mode 100644 docs/docs/en/api/faststream/confluent/client/AsyncConfluentConsumer.md delete mode 100644 docs/docs/en/api/faststream/confluent/client/AsyncConfluentProducer.md delete mode 100644 docs/docs/en/api/faststream/confluent/client/BatchBuilder.md delete mode 100644 docs/docs/en/api/faststream/confluent/client/check_msg_error.md delete mode 100644 docs/docs/en/api/faststream/confluent/client/create_topics.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/BrokerAddressFamily.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/BuiltinFeatures.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/ClientDNSLookup.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/CompressionCodec.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/CompressionType.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/ConfluentConfig.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/ConfluentFastConfig.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/Debug.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/GroupProtocol.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/IsolationLevel.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/OffsetStoreMethod.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/SASLOAUTHBearerMethod.md delete mode 100644 docs/docs/en/api/faststream/confluent/config/SecurityProtocol.md delete mode 100644 docs/docs/en/api/faststream/confluent/fastapi/Context.md delete mode 100644 docs/docs/en/api/faststream/confluent/fastapi/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/confluent/fastapi/fastapi/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/confluent/message/ConsumerProtocol.md delete mode 100644 docs/docs/en/api/faststream/confluent/message/FakeConsumer.md delete mode 100644 docs/docs/en/api/faststream/confluent/message/KafkaMessage.md delete mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/KafkaTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/middleware/KafkaTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/BaseConfluentTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/BatchConfluentTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/ConfluentTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/telemetry_attributes_provider_factory.md delete mode 100644 docs/docs/en/api/faststream/confluent/parser/AsyncConfluentParser.md delete mode 100644 docs/docs/en/api/faststream/confluent/prometheus/KafkaPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/confluent/prometheus/middleware/KafkaPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/BaseConfluentMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/BatchConfluentMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/ConfluentMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/settings_provider_factory.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/factory/create_publisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/fake/KafkaFakePublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/producer/AsyncConfluentFastProducer.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationBatchPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationDefaultPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/state/EmptyProducerState.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/state/ProducerState.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/state/RealProducer.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/usecase/BatchPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/usecase/DefaultPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/publisher/usecase/LogicPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/response/KafkaPublishCommand.md delete mode 100644 docs/docs/en/api/faststream/confluent/response/KafkaResponse.md delete mode 100644 docs/docs/en/api/faststream/confluent/router/KafkaPublisher.md delete mode 100644 docs/docs/en/api/faststream/confluent/router/KafkaRoute.md delete mode 100644 docs/docs/en/api/faststream/confluent/router/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/confluent/schemas/TopicPartition.md delete mode 100644 docs/docs/en/api/faststream/confluent/schemas/params/ConsumerConnectionParams.md delete mode 100644 docs/docs/en/api/faststream/confluent/schemas/partition/TopicPartition.md delete mode 100644 docs/docs/en/api/faststream/confluent/security/parse_security.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/factory/create_subscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationBatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationDefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/BatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/ConcurrentDefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/DefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/LogicSubscriber.md delete mode 100644 docs/docs/en/api/faststream/confluent/testing/FakeProducer.md delete mode 100644 docs/docs/en/api/faststream/confluent/testing/MockConfluentMessage.md delete mode 100644 docs/docs/en/api/faststream/confluent/testing/TestKafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/confluent/testing/build_message.md delete mode 100644 docs/docs/en/api/faststream/exceptions/AckMessage.md delete mode 100644 docs/docs/en/api/faststream/exceptions/ContextError.md delete mode 100644 docs/docs/en/api/faststream/exceptions/FastStreamException.md delete mode 100644 docs/docs/en/api/faststream/exceptions/FeatureNotSupportedException.md delete mode 100644 docs/docs/en/api/faststream/exceptions/HandlerException.md delete mode 100644 docs/docs/en/api/faststream/exceptions/IgnoredException.md delete mode 100644 docs/docs/en/api/faststream/exceptions/IncorrectState.md delete mode 100644 docs/docs/en/api/faststream/exceptions/NackMessage.md delete mode 100644 docs/docs/en/api/faststream/exceptions/RejectMessage.md delete mode 100644 docs/docs/en/api/faststream/exceptions/SetupError.md delete mode 100644 docs/docs/en/api/faststream/exceptions/SkipMessage.md delete mode 100644 docs/docs/en/api/faststream/exceptions/StartupValidationError.md delete mode 100644 docs/docs/en/api/faststream/exceptions/StopApplication.md delete mode 100644 docs/docs/en/api/faststream/exceptions/StopConsume.md delete mode 100644 docs/docs/en/api/faststream/exceptions/SubscriberNotFound.md delete mode 100644 docs/docs/en/api/faststream/kafka/KafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/kafka/KafkaPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/KafkaResponse.md delete mode 100644 docs/docs/en/api/faststream/kafka/KafkaRoute.md delete mode 100644 docs/docs/en/api/faststream/kafka/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/kafka/TestApp.md delete mode 100644 docs/docs/en/api/faststream/kafka/TestKafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/kafka/TopicPartition.md delete mode 100644 docs/docs/en/api/faststream/kafka/broker/KafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/kafka/broker/broker/KafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/kafka/broker/logging/KafkaParamsStorage.md delete mode 100644 docs/docs/en/api/faststream/kafka/broker/registrator/KafkaRegistrator.md delete mode 100644 docs/docs/en/api/faststream/kafka/fastapi/Context.md delete mode 100644 docs/docs/en/api/faststream/kafka/fastapi/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/kafka/fastapi/fastapi/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/kafka/message/ConsumerProtocol.md delete mode 100644 docs/docs/en/api/faststream/kafka/message/FakeConsumer.md delete mode 100644 docs/docs/en/api/faststream/kafka/message/KafkaAckableMessage.md delete mode 100644 docs/docs/en/api/faststream/kafka/message/KafkaMessage.md delete mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/KafkaTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/middleware/KafkaTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/BaseKafkaTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/BatchKafkaTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/KafkaTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/telemetry_attributes_provider_factory.md delete mode 100644 docs/docs/en/api/faststream/kafka/parser/AioKafkaBatchParser.md delete mode 100644 docs/docs/en/api/faststream/kafka/parser/AioKafkaParser.md delete mode 100644 docs/docs/en/api/faststream/kafka/prometheus/KafkaPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/kafka/prometheus/middleware/KafkaPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/BaseKafkaMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/BatchKafkaMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/KafkaMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/settings_provider_factory.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/factory/create_publisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/fake/KafkaFakePublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/producer/AioKafkaFastProducer.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationBatchPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationDefaultPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/state/EmptyProducerState.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/state/ProducerState.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/state/RealProducer.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/usecase/BatchPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/usecase/DefaultPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/publisher/usecase/LogicPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/response/KafkaPublishCommand.md delete mode 100644 docs/docs/en/api/faststream/kafka/response/KafkaResponse.md delete mode 100644 docs/docs/en/api/faststream/kafka/router/KafkaPublisher.md delete mode 100644 docs/docs/en/api/faststream/kafka/router/KafkaRoute.md delete mode 100644 docs/docs/en/api/faststream/kafka/router/KafkaRouter.md delete mode 100644 docs/docs/en/api/faststream/kafka/schemas/params/ConsumerConnectionParams.md delete mode 100644 docs/docs/en/api/faststream/kafka/security/parse_security.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/factory/create_subscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationBatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationDefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/BatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/ConcurrentDefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/DefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/LogicSubscriber.md delete mode 100644 docs/docs/en/api/faststream/kafka/testing/FakeProducer.md delete mode 100644 docs/docs/en/api/faststream/kafka/testing/TestKafkaBroker.md delete mode 100644 docs/docs/en/api/faststream/kafka/testing/build_message.md delete mode 100644 docs/docs/en/api/faststream/message/AckStatus.md delete mode 100644 docs/docs/en/api/faststream/message/SourceType.md delete mode 100644 docs/docs/en/api/faststream/message/StreamMessage.md delete mode 100644 docs/docs/en/api/faststream/message/decode_message.md delete mode 100644 docs/docs/en/api/faststream/message/encode_message.md delete mode 100644 docs/docs/en/api/faststream/message/gen_cor_id.md delete mode 100644 docs/docs/en/api/faststream/message/message/AckStatus.md delete mode 100644 docs/docs/en/api/faststream/message/message/StreamMessage.md delete mode 100644 docs/docs/en/api/faststream/message/source_type/SourceType.md delete mode 100644 docs/docs/en/api/faststream/message/utils/decode_message.md delete mode 100644 docs/docs/en/api/faststream/message/utils/encode_message.md delete mode 100644 docs/docs/en/api/faststream/message/utils/gen_cor_id.md delete mode 100644 docs/docs/en/api/faststream/middlewares/AckPolicy.md delete mode 100644 docs/docs/en/api/faststream/middlewares/AcknowledgementMiddleware.md delete mode 100644 docs/docs/en/api/faststream/middlewares/BaseMiddleware.md delete mode 100644 docs/docs/en/api/faststream/middlewares/ExceptionMiddleware.md delete mode 100644 docs/docs/en/api/faststream/middlewares/acknowledgement/conf/AckPolicy.md delete mode 100644 docs/docs/en/api/faststream/middlewares/acknowledgement/middleware/AcknowledgementMiddleware.md delete mode 100644 docs/docs/en/api/faststream/middlewares/base/BaseMiddleware.md delete mode 100644 docs/docs/en/api/faststream/middlewares/exception/ExceptionMiddleware.md delete mode 100644 docs/docs/en/api/faststream/middlewares/exception/ignore_handler.md delete mode 100644 docs/docs/en/api/faststream/middlewares/logging/CriticalLogMiddleware.md delete mode 100644 docs/docs/en/api/faststream/nats/AckPolicy.md delete mode 100644 docs/docs/en/api/faststream/nats/ConsumerConfig.md delete mode 100644 docs/docs/en/api/faststream/nats/DeliverPolicy.md delete mode 100644 docs/docs/en/api/faststream/nats/DiscardPolicy.md delete mode 100644 docs/docs/en/api/faststream/nats/ExternalStream.md delete mode 100644 docs/docs/en/api/faststream/nats/JStream.md delete mode 100644 docs/docs/en/api/faststream/nats/KvWatch.md delete mode 100644 docs/docs/en/api/faststream/nats/NatsBroker.md delete mode 100644 docs/docs/en/api/faststream/nats/NatsPublisher.md delete mode 100644 docs/docs/en/api/faststream/nats/NatsResponse.md delete mode 100644 docs/docs/en/api/faststream/nats/NatsRoute.md delete mode 100644 docs/docs/en/api/faststream/nats/NatsRouter.md delete mode 100644 docs/docs/en/api/faststream/nats/ObjWatch.md delete mode 100644 docs/docs/en/api/faststream/nats/Placement.md delete mode 100644 docs/docs/en/api/faststream/nats/PubAck.md delete mode 100644 docs/docs/en/api/faststream/nats/PullSub.md delete mode 100644 docs/docs/en/api/faststream/nats/RePublish.md delete mode 100644 docs/docs/en/api/faststream/nats/ReplayPolicy.md delete mode 100644 docs/docs/en/api/faststream/nats/RetentionPolicy.md delete mode 100644 docs/docs/en/api/faststream/nats/StorageType.md delete mode 100644 docs/docs/en/api/faststream/nats/StreamConfig.md delete mode 100644 docs/docs/en/api/faststream/nats/StreamSource.md delete mode 100644 docs/docs/en/api/faststream/nats/TestApp.md delete mode 100644 docs/docs/en/api/faststream/nats/TestNatsBroker.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/NatsBroker.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/broker/NatsBroker.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/logging/NatsParamsStorage.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/registrator/NatsRegistrator.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/state/BrokerState.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/state/ConnectedState.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/state/ConnectionBrokenState.md delete mode 100644 docs/docs/en/api/faststream/nats/broker/state/EmptyBrokerState.md delete mode 100644 docs/docs/en/api/faststream/nats/fastapi/Context.md delete mode 100644 docs/docs/en/api/faststream/nats/fastapi/NatsRouter.md delete mode 100644 docs/docs/en/api/faststream/nats/fastapi/fastapi/NatsRouter.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/KVBucketDeclarer.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/OSBucketDeclarer.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/StreamBuilder.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/bucket_declarer/KVBucketDeclarer.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/obj_storage_declarer/OSBucketDeclarer.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/object_builder/StreamBuilder.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/state/ConnectedState.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/state/ConnectionState.md delete mode 100644 docs/docs/en/api/faststream/nats/helpers/state/EmptyConnectionState.md delete mode 100644 docs/docs/en/api/faststream/nats/message/NatsBatchMessage.md delete mode 100644 docs/docs/en/api/faststream/nats/message/NatsKvMessage.md delete mode 100644 docs/docs/en/api/faststream/nats/message/NatsMessage.md delete mode 100644 docs/docs/en/api/faststream/nats/message/NatsObjMessage.md delete mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/NatsTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/middleware/NatsTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/BaseNatsTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsBatchTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/telemetry_attributes_provider_factory.md delete mode 100644 docs/docs/en/api/faststream/nats/parser/BatchParser.md delete mode 100644 docs/docs/en/api/faststream/nats/parser/JsParser.md delete mode 100644 docs/docs/en/api/faststream/nats/parser/KvParser.md delete mode 100644 docs/docs/en/api/faststream/nats/parser/NatsBaseParser.md delete mode 100644 docs/docs/en/api/faststream/nats/parser/NatsParser.md delete mode 100644 docs/docs/en/api/faststream/nats/parser/ObjParser.md delete mode 100644 docs/docs/en/api/faststream/nats/prometheus/NatsPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/nats/prometheus/middleware/NatsPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/BaseNatsMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/BatchNatsMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/NatsMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/settings_provider_factory.md delete mode 100644 docs/docs/en/api/faststream/nats/publisher/factory/create_publisher.md delete mode 100644 docs/docs/en/api/faststream/nats/publisher/fake/NatsFakePublisher.md delete mode 100644 docs/docs/en/api/faststream/nats/publisher/producer/NatsFastProducer.md delete mode 100644 docs/docs/en/api/faststream/nats/publisher/producer/NatsJSFastProducer.md delete mode 100644 docs/docs/en/api/faststream/nats/publisher/specified/SpecificationPublisher.md delete mode 100644 docs/docs/en/api/faststream/nats/publisher/usecase/LogicPublisher.md delete mode 100644 docs/docs/en/api/faststream/nats/response/NatsPublishCommand.md delete mode 100644 docs/docs/en/api/faststream/nats/response/NatsResponse.md delete mode 100644 docs/docs/en/api/faststream/nats/router/NatsPublisher.md delete mode 100644 docs/docs/en/api/faststream/nats/router/NatsRoute.md delete mode 100644 docs/docs/en/api/faststream/nats/router/NatsRouter.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/JStream.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/KvWatch.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/ObjWatch.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/PubAck.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/PullSub.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/js_stream/JStream.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/js_stream/compile_nats_wildcard.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/js_stream/is_subject_match_wildcard.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/kv_watch/KvWatch.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/obj_watch/ObjWatch.md delete mode 100644 docs/docs/en/api/faststream/nats/schemas/pull_sub/PullSub.md delete mode 100644 docs/docs/en/api/faststream/nats/security/parse_security.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/adapters/UnsubscribeAdapter.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/adapters/Unsubscriptable.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/adapters/Watchable.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/factory/create_subscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationBatchPullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentCoreSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPushStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationCoreSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationKeyValueWatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationObjStoreWatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPushStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/state/ConnectedSubscriberState.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/state/EmptySubscriberState.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/state/SubscriberState.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/BatchPullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentCoreSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPushStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/CoreSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/KeyValueWatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/LogicSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ObjStoreWatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/PullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/PushStreamSubscription.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/basic/DefaultSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/basic/LogicSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/ConcurrentCoreSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/CoreSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/key_value_subscriber/KeyValueWatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/object_storage_subscriber/ObjStoreWatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_basic/StreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/BatchPullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/ConcurrentPullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/PullStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/ConcurrentPushStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/PushStreamSubscription.md delete mode 100644 docs/docs/en/api/faststream/nats/testing/FakeProducer.md delete mode 100644 docs/docs/en/api/faststream/nats/testing/PatchedMessage.md delete mode 100644 docs/docs/en/api/faststream/nats/testing/TestNatsBroker.md delete mode 100644 docs/docs/en/api/faststream/nats/testing/build_message.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/Baggage.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/TelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/TelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/baggage/Baggage.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/consts/MessageAction.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/middleware/BaseTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/middleware/TelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/opentelemetry/provider/TelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/params/Context.md delete mode 100644 docs/docs/en/api/faststream/params/Depends.md delete mode 100644 docs/docs/en/api/faststream/params/Header.md delete mode 100644 docs/docs/en/api/faststream/params/Path.md delete mode 100644 docs/docs/en/api/faststream/params/no_cast/NoCastField.md delete mode 100644 docs/docs/en/api/faststream/params/params/Context.md delete mode 100644 docs/docs/en/api/faststream/params/params/Header.md delete mode 100644 docs/docs/en/api/faststream/params/params/Path.md delete mode 100644 docs/docs/en/api/faststream/prometheus/ConsumeAttrs.md delete mode 100644 docs/docs/en/api/faststream/prometheus/MetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/prometheus/PrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/prometheus/container/MetricsContainer.md delete mode 100644 docs/docs/en/api/faststream/prometheus/manager/MetricsManager.md delete mode 100644 docs/docs/en/api/faststream/prometheus/middleware/BasePrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/prometheus/middleware/PrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/prometheus/provider/MetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/prometheus/types/ConsumeAttrs.md delete mode 100644 docs/docs/en/api/faststream/prometheus/types/ProcessingStatus.md delete mode 100644 docs/docs/en/api/faststream/prometheus/types/PublishingStatus.md delete mode 100644 docs/docs/en/api/faststream/rabbit/ExchangeType.md delete mode 100644 docs/docs/en/api/faststream/rabbit/RabbitBroker.md delete mode 100644 docs/docs/en/api/faststream/rabbit/RabbitExchange.md delete mode 100644 docs/docs/en/api/faststream/rabbit/RabbitPublisher.md delete mode 100644 docs/docs/en/api/faststream/rabbit/RabbitQueue.md delete mode 100644 docs/docs/en/api/faststream/rabbit/RabbitResponse.md delete mode 100644 docs/docs/en/api/faststream/rabbit/RabbitRoute.md delete mode 100644 docs/docs/en/api/faststream/rabbit/RabbitRouter.md delete mode 100644 docs/docs/en/api/faststream/rabbit/TestApp.md delete mode 100644 docs/docs/en/api/faststream/rabbit/TestRabbitBroker.md delete mode 100644 docs/docs/en/api/faststream/rabbit/broker/RabbitBroker.md delete mode 100644 docs/docs/en/api/faststream/rabbit/broker/broker/RabbitBroker.md delete mode 100644 docs/docs/en/api/faststream/rabbit/broker/logging/RabbitParamsStorage.md delete mode 100644 docs/docs/en/api/faststream/rabbit/broker/registrator/RabbitRegistrator.md delete mode 100644 docs/docs/en/api/faststream/rabbit/fastapi/Context.md delete mode 100644 docs/docs/en/api/faststream/rabbit/fastapi/RabbitRouter.md delete mode 100644 docs/docs/en/api/faststream/rabbit/fastapi/fastapi/RabbitRouter.md delete mode 100644 docs/docs/en/api/faststream/rabbit/helpers/declarer/RabbitDeclarer.md delete mode 100644 docs/docs/en/api/faststream/rabbit/helpers/state/ConnectedState.md delete mode 100644 docs/docs/en/api/faststream/rabbit/helpers/state/ConnectionState.md delete mode 100644 docs/docs/en/api/faststream/rabbit/helpers/state/EmptyConnectionState.md delete mode 100644 docs/docs/en/api/faststream/rabbit/message/RabbitMessage.md delete mode 100644 docs/docs/en/api/faststream/rabbit/opentelemetry/RabbitTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/rabbit/opentelemetry/middleware/RabbitTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/rabbit/opentelemetry/provider/RabbitTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/rabbit/parser/AioPikaParser.md delete mode 100644 docs/docs/en/api/faststream/rabbit/prometheus/RabbitPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/rabbit/prometheus/middleware/RabbitPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/rabbit/prometheus/provider/RabbitMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/factory/create_publisher.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/fake/RabbitFakePublisher.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/options/MessageOptions.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/options/PublishOptions.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/AioPikaFastProducer.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/LockState.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/LockUnset.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/RealLock.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/specified/SpecificationPublisher.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/usecase/LogicPublisher.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/usecase/PublishKwargs.md delete mode 100644 docs/docs/en/api/faststream/rabbit/publisher/usecase/RequestPublishKwargs.md delete mode 100644 docs/docs/en/api/faststream/rabbit/response/RabbitPublishCommand.md delete mode 100644 docs/docs/en/api/faststream/rabbit/response/RabbitResponse.md delete mode 100644 docs/docs/en/api/faststream/rabbit/router/RabbitPublisher.md delete mode 100644 docs/docs/en/api/faststream/rabbit/router/RabbitRoute.md delete mode 100644 docs/docs/en/api/faststream/rabbit/router/RabbitRouter.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/BaseRMQInformation.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/ExchangeType.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/RabbitExchange.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/RabbitQueue.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/constants/ExchangeType.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/exchange/RabbitExchange.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/proto/BaseRMQInformation.md delete mode 100644 docs/docs/en/api/faststream/rabbit/schemas/queue/RabbitQueue.md delete mode 100644 docs/docs/en/api/faststream/rabbit/security/parse_security.md delete mode 100644 docs/docs/en/api/faststream/rabbit/subscriber/factory/create_subscriber.md delete mode 100644 docs/docs/en/api/faststream/rabbit/subscriber/specified/SpecificationSubscriber.md delete mode 100644 docs/docs/en/api/faststream/rabbit/subscriber/usecase/LogicSubscriber.md delete mode 100644 docs/docs/en/api/faststream/rabbit/testing/FakeProducer.md delete mode 100644 docs/docs/en/api/faststream/rabbit/testing/PatchedMessage.md delete mode 100644 docs/docs/en/api/faststream/rabbit/testing/TestRabbitBroker.md delete mode 100644 docs/docs/en/api/faststream/rabbit/testing/apply_pattern.md delete mode 100644 docs/docs/en/api/faststream/rabbit/testing/build_message.md delete mode 100644 docs/docs/en/api/faststream/rabbit/utils/build_url.md delete mode 100644 docs/docs/en/api/faststream/rabbit/utils/is_routing_exchange.md delete mode 100644 docs/docs/en/api/faststream/redis/ListSub.md delete mode 100644 docs/docs/en/api/faststream/redis/PubSub.md delete mode 100644 docs/docs/en/api/faststream/redis/RedisBroker.md delete mode 100644 docs/docs/en/api/faststream/redis/RedisPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/RedisResponse.md delete mode 100644 docs/docs/en/api/faststream/redis/RedisRoute.md delete mode 100644 docs/docs/en/api/faststream/redis/RedisRouter.md delete mode 100644 docs/docs/en/api/faststream/redis/StreamSub.md delete mode 100644 docs/docs/en/api/faststream/redis/TestApp.md delete mode 100644 docs/docs/en/api/faststream/redis/TestRedisBroker.md delete mode 100644 docs/docs/en/api/faststream/redis/broker/broker/RedisBroker.md delete mode 100644 docs/docs/en/api/faststream/redis/broker/logging/RedisParamsStorage.md delete mode 100644 docs/docs/en/api/faststream/redis/broker/registrator/RedisRegistrator.md delete mode 100644 docs/docs/en/api/faststream/redis/fastapi/Context.md delete mode 100644 docs/docs/en/api/faststream/redis/fastapi/RedisRouter.md delete mode 100644 docs/docs/en/api/faststream/redis/fastapi/fastapi/RedisRouter.md delete mode 100644 docs/docs/en/api/faststream/redis/helpers/state/ConnectedState.md delete mode 100644 docs/docs/en/api/faststream/redis/helpers/state/ConnectionState.md delete mode 100644 docs/docs/en/api/faststream/redis/helpers/state/EmptyConnectionState.md delete mode 100644 docs/docs/en/api/faststream/redis/message/BatchListMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/BatchStreamMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/DefaultListMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/DefaultStreamMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/PubSubMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/RedisBatchListMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/RedisBatchStreamMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/RedisListMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/RedisMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/RedisStreamMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/message/UnifyRedisDict.md delete mode 100644 docs/docs/en/api/faststream/redis/message/UnifyRedisMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/opentelemetry/RedisTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/redis/opentelemetry/middleware/RedisTelemetryMiddleware.md delete mode 100644 docs/docs/en/api/faststream/redis/opentelemetry/provider/RedisTelemetrySettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/redis/parser/RawMessage.md delete mode 100644 docs/docs/en/api/faststream/redis/parser/RedisBatchListParser.md delete mode 100644 docs/docs/en/api/faststream/redis/parser/RedisBatchStreamParser.md delete mode 100644 docs/docs/en/api/faststream/redis/parser/RedisListParser.md delete mode 100644 docs/docs/en/api/faststream/redis/parser/RedisPubSubParser.md delete mode 100644 docs/docs/en/api/faststream/redis/parser/RedisStreamParser.md delete mode 100644 docs/docs/en/api/faststream/redis/parser/SimpleParser.md delete mode 100644 docs/docs/en/api/faststream/redis/prometheus/RedisPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/redis/prometheus/middleware/RedisPrometheusMiddleware.md delete mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/BaseRedisMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/BatchRedisMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/RedisMetricsSettingsProvider.md delete mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/settings_provider_factory.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/factory/create_publisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/fake/RedisFakePublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/producer/RedisFastProducer.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationChannelPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListBatchPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationStreamPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/ChannelPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/ListBatchPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/ListPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/LogicPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/StreamPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/response/DestinationType.md delete mode 100644 docs/docs/en/api/faststream/redis/response/RedisPublishCommand.md delete mode 100644 docs/docs/en/api/faststream/redis/response/RedisResponse.md delete mode 100644 docs/docs/en/api/faststream/redis/router/RedisPublisher.md delete mode 100644 docs/docs/en/api/faststream/redis/router/RedisRoute.md delete mode 100644 docs/docs/en/api/faststream/redis/router/RedisRouter.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/ListSub.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/PubSub.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/StreamSub.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/list_sub/ListSub.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/proto/RedisSpecificationProtocol.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/proto/validate_options.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/pub_sub/PubSub.md delete mode 100644 docs/docs/en/api/faststream/redis/schemas/stream_sub/StreamSub.md delete mode 100644 docs/docs/en/api/faststream/redis/security/parse_security.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/factory/create_subscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationChannelSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListBatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamBatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/BatchListSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/ChannelSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/ListSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/LogicSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/StreamBatchSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/StreamSubscriber.md delete mode 100644 docs/docs/en/api/faststream/redis/testing/ChannelVisitor.md delete mode 100644 docs/docs/en/api/faststream/redis/testing/FakeProducer.md delete mode 100644 docs/docs/en/api/faststream/redis/testing/ListVisitor.md delete mode 100644 docs/docs/en/api/faststream/redis/testing/StreamVisitor.md delete mode 100644 docs/docs/en/api/faststream/redis/testing/TestRedisBroker.md delete mode 100644 docs/docs/en/api/faststream/redis/testing/Visitor.md delete mode 100644 docs/docs/en/api/faststream/redis/testing/build_message.md delete mode 100644 docs/docs/en/api/faststream/response/PublishCommand.md delete mode 100644 docs/docs/en/api/faststream/response/PublishType.md delete mode 100644 docs/docs/en/api/faststream/response/Response.md delete mode 100644 docs/docs/en/api/faststream/response/ensure_response.md delete mode 100644 docs/docs/en/api/faststream/response/publish_type/PublishType.md delete mode 100644 docs/docs/en/api/faststream/response/response/PublishCommand.md delete mode 100644 docs/docs/en/api/faststream/response/response/Response.md delete mode 100644 docs/docs/en/api/faststream/response/utils/ensure_response.md delete mode 100644 docs/docs/en/api/faststream/security/BaseSecurity.md delete mode 100644 docs/docs/en/api/faststream/security/SASLGSSAPI.md delete mode 100644 docs/docs/en/api/faststream/security/SASLOAuthBearer.md delete mode 100644 docs/docs/en/api/faststream/security/SASLPlaintext.md delete mode 100644 docs/docs/en/api/faststream/security/SASLScram256.md delete mode 100644 docs/docs/en/api/faststream/security/SASLScram512.md delete mode 100644 docs/docs/en/api/faststream/specification/AsyncAPI.md delete mode 100644 docs/docs/en/api/faststream/specification/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/License.md delete mode 100644 docs/docs/en/api/faststream/specification/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/AsyncAPI.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/factory/AsyncAPI.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/get_asyncapi_html.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/message/get_model_schema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/message/get_response_schema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/message/parse_handler_params.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/site/get_asyncapi_html.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/site/serve_app.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/clear_key.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/move_pydantic_refs.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/resolve_payloads.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/to_camelcase.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/AsyncAPI2.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/facade/AsyncAPI2.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_app_schema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_channels.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_server.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/resolve_channel_messages.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/get_app_schema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationInfo.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationSchema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Channel.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Components.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/CorrelationId.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/License.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Message.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Operation.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Parameter.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Reference.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Server.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ServerVariable.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Exchange.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Queue.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/from_spec.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/from_spec.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/channels/Channel.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/components/Components.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/contact/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/docs/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/info/ApplicationInfo.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/license/License.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/CorrelationId.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/Message.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/operations/Operation.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/schema/ApplicationSchema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/Server.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/ServerVariable.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/tag/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Parameter.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Reference.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/AsyncAPI3.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/facade/AsyncAPI3.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_app_schema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_channels.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_server.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/get_app_schema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationInfo.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationSchema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Channel.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Components.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/CorrelationId.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/License.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Message.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Operation.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Parameter.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Reference.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Server.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ServerVariable.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/channel/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/operation/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/channels/Channel.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/components/Components.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/contact/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/docs/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/info/ApplicationInfo.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/license/License.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/CorrelationId.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/Message.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Action.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Operation.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/schema/ApplicationSchema.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/servers/Server.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/tag/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Parameter.md delete mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Reference.md delete mode 100644 docs/docs/en/api/faststream/specification/base/info/BaseApplicationInfo.md delete mode 100644 docs/docs/en/api/faststream/specification/base/schema/BaseApplicationSchema.md delete mode 100644 docs/docs/en/api/faststream/specification/base/specification/Specification.md delete mode 100644 docs/docs/en/api/faststream/specification/proto/EndpointSpecification.md delete mode 100644 docs/docs/en/api/faststream/specification/proto/ServerSpecification.md delete mode 100644 docs/docs/en/api/faststream/specification/proto/broker/ServerSpecification.md delete mode 100644 docs/docs/en/api/faststream/specification/proto/endpoint/EndpointSpecification.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/ContactDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/ExternalDocsDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/License.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/LicenseDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/Message.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/Operation.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/PublisherSpec.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/SubscriberSpec.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/TagDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/Exchange.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/Queue.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/kafka/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/kafka/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/main/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/main/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/nats/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/nats/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/redis/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/redis/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/sqs/ChannelBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/sqs/OperationBinding.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/ContactDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/ExternalDocsDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/License.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/LicenseDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/TagDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/contact/Contact.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/contact/ContactDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocs.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocsDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/license/License.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/license/LicenseDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/tag/Tag.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/extra/tag/TagDict.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/message/Message.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/message/model/Message.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/operation/Operation.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/operation/model/Operation.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/publisher/PublisherSpec.md delete mode 100644 docs/docs/en/api/faststream/specification/schema/subscriber/SubscriberSpec.md diff --git a/docs/docs/en/api/faststream/AckPolicy.md b/docs/docs/en/api/faststream/AckPolicy.md deleted file mode 100644 index 4d7218c81b..0000000000 --- a/docs/docs/en/api/faststream/AckPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.AckPolicy diff --git a/docs/docs/en/api/faststream/BaseMiddleware.md b/docs/docs/en/api/faststream/BaseMiddleware.md deleted file mode 100644 index 21145bf983..0000000000 --- a/docs/docs/en/api/faststream/BaseMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.BaseMiddleware diff --git a/docs/docs/en/api/faststream/Context.md b/docs/docs/en/api/faststream/Context.md deleted file mode 100644 index c6400b1e56..0000000000 --- a/docs/docs/en/api/faststream/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.Context diff --git a/docs/docs/en/api/faststream/Depends.md b/docs/docs/en/api/faststream/Depends.md deleted file mode 100644 index c0704687e8..0000000000 --- a/docs/docs/en/api/faststream/Depends.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: fast_depends.use.Depends diff --git a/docs/docs/en/api/faststream/ExceptionMiddleware.md b/docs/docs/en/api/faststream/ExceptionMiddleware.md deleted file mode 100644 index a5e2038f22..0000000000 --- a/docs/docs/en/api/faststream/ExceptionMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.ExceptionMiddleware diff --git a/docs/docs/en/api/faststream/FastStream.md b/docs/docs/en/api/faststream/FastStream.md deleted file mode 100644 index 8d79ba3921..0000000000 --- a/docs/docs/en/api/faststream/FastStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.FastStream diff --git a/docs/docs/en/api/faststream/Header.md b/docs/docs/en/api/faststream/Header.md deleted file mode 100644 index 98bdb592a7..0000000000 --- a/docs/docs/en/api/faststream/Header.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.Header diff --git a/docs/docs/en/api/faststream/Path.md b/docs/docs/en/api/faststream/Path.md deleted file mode 100644 index 7716f47c23..0000000000 --- a/docs/docs/en/api/faststream/Path.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.Path diff --git a/docs/docs/en/api/faststream/Response.md b/docs/docs/en/api/faststream/Response.md deleted file mode 100644 index 3475e3f584..0000000000 --- a/docs/docs/en/api/faststream/Response.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.Response diff --git a/docs/docs/en/api/faststream/TestApp.md b/docs/docs/en/api/faststream/TestApp.md deleted file mode 100644 index 2301790c21..0000000000 --- a/docs/docs/en/api/faststream/TestApp.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.TestApp diff --git a/docs/docs/en/api/faststream/app/FastStream.md b/docs/docs/en/api/faststream/app/FastStream.md deleted file mode 100644 index 24235253c2..0000000000 --- a/docs/docs/en/api/faststream/app/FastStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.app.FastStream diff --git a/docs/docs/en/api/faststream/apply_types.md b/docs/docs/en/api/faststream/apply_types.md deleted file mode 100644 index 9dc4603bd2..0000000000 --- a/docs/docs/en/api/faststream/apply_types.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: fast_depends.use.inject diff --git a/docs/docs/en/api/faststream/asgi/AsgiFastStream.md b/docs/docs/en/api/faststream/asgi/AsgiFastStream.md deleted file mode 100644 index 49a94bd574..0000000000 --- a/docs/docs/en/api/faststream/asgi/AsgiFastStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.AsgiFastStream diff --git a/docs/docs/en/api/faststream/asgi/AsgiResponse.md b/docs/docs/en/api/faststream/asgi/AsgiResponse.md deleted file mode 100644 index 4814f18557..0000000000 --- a/docs/docs/en/api/faststream/asgi/AsgiResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.AsgiResponse diff --git a/docs/docs/en/api/faststream/asgi/app/AsgiFastStream.md b/docs/docs/en/api/faststream/asgi/app/AsgiFastStream.md deleted file mode 100644 index 9d58b9576c..0000000000 --- a/docs/docs/en/api/faststream/asgi/app/AsgiFastStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.app.AsgiFastStream diff --git a/docs/docs/en/api/faststream/asgi/app/CliRunState.md b/docs/docs/en/api/faststream/asgi/app/CliRunState.md deleted file mode 100644 index 1124f2d50b..0000000000 --- a/docs/docs/en/api/faststream/asgi/app/CliRunState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.app.CliRunState diff --git a/docs/docs/en/api/faststream/asgi/app/OuterRunState.md b/docs/docs/en/api/faststream/asgi/app/OuterRunState.md deleted file mode 100644 index 3789ea0461..0000000000 --- a/docs/docs/en/api/faststream/asgi/app/OuterRunState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.app.OuterRunState diff --git a/docs/docs/en/api/faststream/asgi/app/ServerState.md b/docs/docs/en/api/faststream/asgi/app/ServerState.md deleted file mode 100644 index 6d5e2c20c6..0000000000 --- a/docs/docs/en/api/faststream/asgi/app/ServerState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.app.ServerState diff --git a/docs/docs/en/api/faststream/asgi/app/cast_uvicorn_params.md b/docs/docs/en/api/faststream/asgi/app/cast_uvicorn_params.md deleted file mode 100644 index 1431e2c833..0000000000 --- a/docs/docs/en/api/faststream/asgi/app/cast_uvicorn_params.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.app.cast_uvicorn_params diff --git a/docs/docs/en/api/faststream/asgi/factories/make_asyncapi_asgi.md b/docs/docs/en/api/faststream/asgi/factories/make_asyncapi_asgi.md deleted file mode 100644 index e96de51b01..0000000000 --- a/docs/docs/en/api/faststream/asgi/factories/make_asyncapi_asgi.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.factories.make_asyncapi_asgi diff --git a/docs/docs/en/api/faststream/asgi/factories/make_ping_asgi.md b/docs/docs/en/api/faststream/asgi/factories/make_ping_asgi.md deleted file mode 100644 index fb163d02a1..0000000000 --- a/docs/docs/en/api/faststream/asgi/factories/make_ping_asgi.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.factories.make_ping_asgi diff --git a/docs/docs/en/api/faststream/asgi/get.md b/docs/docs/en/api/faststream/asgi/get.md deleted file mode 100644 index 044c05ed81..0000000000 --- a/docs/docs/en/api/faststream/asgi/get.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.get diff --git a/docs/docs/en/api/faststream/asgi/handlers/get.md b/docs/docs/en/api/faststream/asgi/handlers/get.md deleted file mode 100644 index 8f3c04a050..0000000000 --- a/docs/docs/en/api/faststream/asgi/handlers/get.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.handlers.get diff --git a/docs/docs/en/api/faststream/asgi/make_asyncapi_asgi.md b/docs/docs/en/api/faststream/asgi/make_asyncapi_asgi.md deleted file mode 100644 index 5e57a1a2db..0000000000 --- a/docs/docs/en/api/faststream/asgi/make_asyncapi_asgi.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.make_asyncapi_asgi diff --git a/docs/docs/en/api/faststream/asgi/make_ping_asgi.md b/docs/docs/en/api/faststream/asgi/make_ping_asgi.md deleted file mode 100644 index 5c24aaef19..0000000000 --- a/docs/docs/en/api/faststream/asgi/make_ping_asgi.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.make_ping_asgi diff --git a/docs/docs/en/api/faststream/asgi/response/AsgiResponse.md b/docs/docs/en/api/faststream/asgi/response/AsgiResponse.md deleted file mode 100644 index 037739b09d..0000000000 --- a/docs/docs/en/api/faststream/asgi/response/AsgiResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.response.AsgiResponse diff --git a/docs/docs/en/api/faststream/asgi/websocket/WebSocketClose.md b/docs/docs/en/api/faststream/asgi/websocket/WebSocketClose.md deleted file mode 100644 index 130ee9a59a..0000000000 --- a/docs/docs/en/api/faststream/asgi/websocket/WebSocketClose.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.asgi.websocket.WebSocketClose diff --git a/docs/docs/en/api/faststream/confluent/KafkaBroker.md b/docs/docs/en/api/faststream/confluent/KafkaBroker.md deleted file mode 100644 index 99fd644946..0000000000 --- a/docs/docs/en/api/faststream/confluent/KafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.KafkaBroker diff --git a/docs/docs/en/api/faststream/confluent/KafkaPublisher.md b/docs/docs/en/api/faststream/confluent/KafkaPublisher.md deleted file mode 100644 index 73e485fcc5..0000000000 --- a/docs/docs/en/api/faststream/confluent/KafkaPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.KafkaPublisher diff --git a/docs/docs/en/api/faststream/confluent/KafkaResponse.md b/docs/docs/en/api/faststream/confluent/KafkaResponse.md deleted file mode 100644 index eb0eab479c..0000000000 --- a/docs/docs/en/api/faststream/confluent/KafkaResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.KafkaResponse diff --git a/docs/docs/en/api/faststream/confluent/KafkaRoute.md b/docs/docs/en/api/faststream/confluent/KafkaRoute.md deleted file mode 100644 index 723012794f..0000000000 --- a/docs/docs/en/api/faststream/confluent/KafkaRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.KafkaRoute diff --git a/docs/docs/en/api/faststream/confluent/KafkaRouter.md b/docs/docs/en/api/faststream/confluent/KafkaRouter.md deleted file mode 100644 index b9e7b0d991..0000000000 --- a/docs/docs/en/api/faststream/confluent/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.KafkaRouter diff --git a/docs/docs/en/api/faststream/confluent/TestApp.md b/docs/docs/en/api/faststream/confluent/TestApp.md deleted file mode 100644 index ad101303af..0000000000 --- a/docs/docs/en/api/faststream/confluent/TestApp.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.testing.app.TestApp diff --git a/docs/docs/en/api/faststream/confluent/TestKafkaBroker.md b/docs/docs/en/api/faststream/confluent/TestKafkaBroker.md deleted file mode 100644 index 0a24384f69..0000000000 --- a/docs/docs/en/api/faststream/confluent/TestKafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.TestKafkaBroker diff --git a/docs/docs/en/api/faststream/confluent/TopicPartition.md b/docs/docs/en/api/faststream/confluent/TopicPartition.md deleted file mode 100644 index 9b5e09bdf9..0000000000 --- a/docs/docs/en/api/faststream/confluent/TopicPartition.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.TopicPartition diff --git a/docs/docs/en/api/faststream/confluent/broker/KafkaBroker.md b/docs/docs/en/api/faststream/confluent/broker/KafkaBroker.md deleted file mode 100644 index cdfdbc6ef1..0000000000 --- a/docs/docs/en/api/faststream/confluent/broker/KafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.broker.KafkaBroker diff --git a/docs/docs/en/api/faststream/confluent/broker/broker/KafkaBroker.md b/docs/docs/en/api/faststream/confluent/broker/broker/KafkaBroker.md deleted file mode 100644 index 05c8356f26..0000000000 --- a/docs/docs/en/api/faststream/confluent/broker/broker/KafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.broker.broker.KafkaBroker diff --git a/docs/docs/en/api/faststream/confluent/broker/logging/KafkaParamsStorage.md b/docs/docs/en/api/faststream/confluent/broker/logging/KafkaParamsStorage.md deleted file mode 100644 index 900f945037..0000000000 --- a/docs/docs/en/api/faststream/confluent/broker/logging/KafkaParamsStorage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.broker.logging.KafkaParamsStorage diff --git a/docs/docs/en/api/faststream/confluent/broker/registrator/KafkaRegistrator.md b/docs/docs/en/api/faststream/confluent/broker/registrator/KafkaRegistrator.md deleted file mode 100644 index 80068d2349..0000000000 --- a/docs/docs/en/api/faststream/confluent/broker/registrator/KafkaRegistrator.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.broker.registrator.KafkaRegistrator diff --git a/docs/docs/en/api/faststream/confluent/client/AsyncConfluentConsumer.md b/docs/docs/en/api/faststream/confluent/client/AsyncConfluentConsumer.md deleted file mode 100644 index 25374c405d..0000000000 --- a/docs/docs/en/api/faststream/confluent/client/AsyncConfluentConsumer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.client.AsyncConfluentConsumer diff --git a/docs/docs/en/api/faststream/confluent/client/AsyncConfluentProducer.md b/docs/docs/en/api/faststream/confluent/client/AsyncConfluentProducer.md deleted file mode 100644 index 29bfac283f..0000000000 --- a/docs/docs/en/api/faststream/confluent/client/AsyncConfluentProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.client.AsyncConfluentProducer diff --git a/docs/docs/en/api/faststream/confluent/client/BatchBuilder.md b/docs/docs/en/api/faststream/confluent/client/BatchBuilder.md deleted file mode 100644 index 232f9ecdf2..0000000000 --- a/docs/docs/en/api/faststream/confluent/client/BatchBuilder.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.client.BatchBuilder diff --git a/docs/docs/en/api/faststream/confluent/client/check_msg_error.md b/docs/docs/en/api/faststream/confluent/client/check_msg_error.md deleted file mode 100644 index 71ac291b6e..0000000000 --- a/docs/docs/en/api/faststream/confluent/client/check_msg_error.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.client.check_msg_error diff --git a/docs/docs/en/api/faststream/confluent/client/create_topics.md b/docs/docs/en/api/faststream/confluent/client/create_topics.md deleted file mode 100644 index 8efc1a80c4..0000000000 --- a/docs/docs/en/api/faststream/confluent/client/create_topics.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.client.create_topics diff --git a/docs/docs/en/api/faststream/confluent/config/BrokerAddressFamily.md b/docs/docs/en/api/faststream/confluent/config/BrokerAddressFamily.md deleted file mode 100644 index bf5cfbaca7..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/BrokerAddressFamily.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.BrokerAddressFamily diff --git a/docs/docs/en/api/faststream/confluent/config/BuiltinFeatures.md b/docs/docs/en/api/faststream/confluent/config/BuiltinFeatures.md deleted file mode 100644 index 41e324305d..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/BuiltinFeatures.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.BuiltinFeatures diff --git a/docs/docs/en/api/faststream/confluent/config/ClientDNSLookup.md b/docs/docs/en/api/faststream/confluent/config/ClientDNSLookup.md deleted file mode 100644 index 15f67688f1..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/ClientDNSLookup.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.ClientDNSLookup diff --git a/docs/docs/en/api/faststream/confluent/config/CompressionCodec.md b/docs/docs/en/api/faststream/confluent/config/CompressionCodec.md deleted file mode 100644 index dd9640afd4..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/CompressionCodec.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.CompressionCodec diff --git a/docs/docs/en/api/faststream/confluent/config/CompressionType.md b/docs/docs/en/api/faststream/confluent/config/CompressionType.md deleted file mode 100644 index 8139bfcdda..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/CompressionType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.CompressionType diff --git a/docs/docs/en/api/faststream/confluent/config/ConfluentConfig.md b/docs/docs/en/api/faststream/confluent/config/ConfluentConfig.md deleted file mode 100644 index 9ebd97c1ff..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/ConfluentConfig.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.ConfluentConfig diff --git a/docs/docs/en/api/faststream/confluent/config/ConfluentFastConfig.md b/docs/docs/en/api/faststream/confluent/config/ConfluentFastConfig.md deleted file mode 100644 index 27861ffd5b..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/ConfluentFastConfig.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.ConfluentFastConfig diff --git a/docs/docs/en/api/faststream/confluent/config/Debug.md b/docs/docs/en/api/faststream/confluent/config/Debug.md deleted file mode 100644 index 2036046f5d..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/Debug.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.Debug diff --git a/docs/docs/en/api/faststream/confluent/config/GroupProtocol.md b/docs/docs/en/api/faststream/confluent/config/GroupProtocol.md deleted file mode 100644 index a5cab4b1d9..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/GroupProtocol.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.GroupProtocol diff --git a/docs/docs/en/api/faststream/confluent/config/IsolationLevel.md b/docs/docs/en/api/faststream/confluent/config/IsolationLevel.md deleted file mode 100644 index d122261f0f..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/IsolationLevel.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.IsolationLevel diff --git a/docs/docs/en/api/faststream/confluent/config/OffsetStoreMethod.md b/docs/docs/en/api/faststream/confluent/config/OffsetStoreMethod.md deleted file mode 100644 index 4b203e65e9..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/OffsetStoreMethod.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.OffsetStoreMethod diff --git a/docs/docs/en/api/faststream/confluent/config/SASLOAUTHBearerMethod.md b/docs/docs/en/api/faststream/confluent/config/SASLOAUTHBearerMethod.md deleted file mode 100644 index 2cb635c6b0..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/SASLOAUTHBearerMethod.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.SASLOAUTHBearerMethod diff --git a/docs/docs/en/api/faststream/confluent/config/SecurityProtocol.md b/docs/docs/en/api/faststream/confluent/config/SecurityProtocol.md deleted file mode 100644 index 8415d3214e..0000000000 --- a/docs/docs/en/api/faststream/confluent/config/SecurityProtocol.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.config.SecurityProtocol diff --git a/docs/docs/en/api/faststream/confluent/fastapi/Context.md b/docs/docs/en/api/faststream/confluent/fastapi/Context.md deleted file mode 100644 index 99bf141f5c..0000000000 --- a/docs/docs/en/api/faststream/confluent/fastapi/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.fastapi.context.Context diff --git a/docs/docs/en/api/faststream/confluent/fastapi/KafkaRouter.md b/docs/docs/en/api/faststream/confluent/fastapi/KafkaRouter.md deleted file mode 100644 index 034203e103..0000000000 --- a/docs/docs/en/api/faststream/confluent/fastapi/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.fastapi.KafkaRouter diff --git a/docs/docs/en/api/faststream/confluent/fastapi/fastapi/KafkaRouter.md b/docs/docs/en/api/faststream/confluent/fastapi/fastapi/KafkaRouter.md deleted file mode 100644 index 87edcc2c3d..0000000000 --- a/docs/docs/en/api/faststream/confluent/fastapi/fastapi/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.fastapi.fastapi.KafkaRouter diff --git a/docs/docs/en/api/faststream/confluent/message/ConsumerProtocol.md b/docs/docs/en/api/faststream/confluent/message/ConsumerProtocol.md deleted file mode 100644 index 18971d0829..0000000000 --- a/docs/docs/en/api/faststream/confluent/message/ConsumerProtocol.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.message.ConsumerProtocol diff --git a/docs/docs/en/api/faststream/confluent/message/FakeConsumer.md b/docs/docs/en/api/faststream/confluent/message/FakeConsumer.md deleted file mode 100644 index 19e60bb461..0000000000 --- a/docs/docs/en/api/faststream/confluent/message/FakeConsumer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.message.FakeConsumer diff --git a/docs/docs/en/api/faststream/confluent/message/KafkaMessage.md b/docs/docs/en/api/faststream/confluent/message/KafkaMessage.md deleted file mode 100644 index 02004c7d37..0000000000 --- a/docs/docs/en/api/faststream/confluent/message/KafkaMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.message.KafkaMessage diff --git a/docs/docs/en/api/faststream/confluent/opentelemetry/KafkaTelemetryMiddleware.md b/docs/docs/en/api/faststream/confluent/opentelemetry/KafkaTelemetryMiddleware.md deleted file mode 100644 index 743c494591..0000000000 --- a/docs/docs/en/api/faststream/confluent/opentelemetry/KafkaTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.opentelemetry.KafkaTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/confluent/opentelemetry/middleware/KafkaTelemetryMiddleware.md b/docs/docs/en/api/faststream/confluent/opentelemetry/middleware/KafkaTelemetryMiddleware.md deleted file mode 100644 index b34265dfbb..0000000000 --- a/docs/docs/en/api/faststream/confluent/opentelemetry/middleware/KafkaTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.opentelemetry.middleware.KafkaTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BaseConfluentTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BaseConfluentTelemetrySettingsProvider.md deleted file mode 100644 index 730662fae5..0000000000 --- a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BaseConfluentTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.opentelemetry.provider.BaseConfluentTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BatchConfluentTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BatchConfluentTelemetrySettingsProvider.md deleted file mode 100644 index a6db133484..0000000000 --- a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BatchConfluentTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.opentelemetry.provider.BatchConfluentTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/ConfluentTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/ConfluentTelemetrySettingsProvider.md deleted file mode 100644 index 2c5242e6e5..0000000000 --- a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/ConfluentTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.opentelemetry.provider.ConfluentTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/telemetry_attributes_provider_factory.md b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/telemetry_attributes_provider_factory.md deleted file mode 100644 index 7dd0e1d0fd..0000000000 --- a/docs/docs/en/api/faststream/confluent/opentelemetry/provider/telemetry_attributes_provider_factory.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.opentelemetry.provider.telemetry_attributes_provider_factory diff --git a/docs/docs/en/api/faststream/confluent/parser/AsyncConfluentParser.md b/docs/docs/en/api/faststream/confluent/parser/AsyncConfluentParser.md deleted file mode 100644 index e5029a60d1..0000000000 --- a/docs/docs/en/api/faststream/confluent/parser/AsyncConfluentParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.parser.AsyncConfluentParser diff --git a/docs/docs/en/api/faststream/confluent/prometheus/KafkaPrometheusMiddleware.md b/docs/docs/en/api/faststream/confluent/prometheus/KafkaPrometheusMiddleware.md deleted file mode 100644 index e84e84acc3..0000000000 --- a/docs/docs/en/api/faststream/confluent/prometheus/KafkaPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.prometheus.KafkaPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/confluent/prometheus/middleware/KafkaPrometheusMiddleware.md b/docs/docs/en/api/faststream/confluent/prometheus/middleware/KafkaPrometheusMiddleware.md deleted file mode 100644 index 6603893f74..0000000000 --- a/docs/docs/en/api/faststream/confluent/prometheus/middleware/KafkaPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.prometheus.middleware.KafkaPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/confluent/prometheus/provider/BaseConfluentMetricsSettingsProvider.md b/docs/docs/en/api/faststream/confluent/prometheus/provider/BaseConfluentMetricsSettingsProvider.md deleted file mode 100644 index 27c186c098..0000000000 --- a/docs/docs/en/api/faststream/confluent/prometheus/provider/BaseConfluentMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.prometheus.provider.BaseConfluentMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/confluent/prometheus/provider/BatchConfluentMetricsSettingsProvider.md b/docs/docs/en/api/faststream/confluent/prometheus/provider/BatchConfluentMetricsSettingsProvider.md deleted file mode 100644 index f784a64e9f..0000000000 --- a/docs/docs/en/api/faststream/confluent/prometheus/provider/BatchConfluentMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.prometheus.provider.BatchConfluentMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/confluent/prometheus/provider/ConfluentMetricsSettingsProvider.md b/docs/docs/en/api/faststream/confluent/prometheus/provider/ConfluentMetricsSettingsProvider.md deleted file mode 100644 index 65f0a8348e..0000000000 --- a/docs/docs/en/api/faststream/confluent/prometheus/provider/ConfluentMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.prometheus.provider.ConfluentMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/confluent/prometheus/provider/settings_provider_factory.md b/docs/docs/en/api/faststream/confluent/prometheus/provider/settings_provider_factory.md deleted file mode 100644 index 78358f46e3..0000000000 --- a/docs/docs/en/api/faststream/confluent/prometheus/provider/settings_provider_factory.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.prometheus.provider.settings_provider_factory diff --git a/docs/docs/en/api/faststream/confluent/publisher/factory/create_publisher.md b/docs/docs/en/api/faststream/confluent/publisher/factory/create_publisher.md deleted file mode 100644 index 60e9664052..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/factory/create_publisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.factory.create_publisher diff --git a/docs/docs/en/api/faststream/confluent/publisher/fake/KafkaFakePublisher.md b/docs/docs/en/api/faststream/confluent/publisher/fake/KafkaFakePublisher.md deleted file mode 100644 index 019fbf855f..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/fake/KafkaFakePublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.fake.KafkaFakePublisher diff --git a/docs/docs/en/api/faststream/confluent/publisher/producer/AsyncConfluentFastProducer.md b/docs/docs/en/api/faststream/confluent/publisher/producer/AsyncConfluentFastProducer.md deleted file mode 100644 index fd614d1593..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/producer/AsyncConfluentFastProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.producer.AsyncConfluentFastProducer diff --git a/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationBatchPublisher.md b/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationBatchPublisher.md deleted file mode 100644 index 2879b0d6c3..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationBatchPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.specified.SpecificationBatchPublisher diff --git a/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationDefaultPublisher.md b/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationDefaultPublisher.md deleted file mode 100644 index 581ae19fd8..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationDefaultPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.specified.SpecificationDefaultPublisher diff --git a/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationPublisher.md b/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationPublisher.md deleted file mode 100644 index 55ed49caf5..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.specified.SpecificationPublisher diff --git a/docs/docs/en/api/faststream/confluent/publisher/state/EmptyProducerState.md b/docs/docs/en/api/faststream/confluent/publisher/state/EmptyProducerState.md deleted file mode 100644 index a72476a6d3..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/state/EmptyProducerState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.state.EmptyProducerState diff --git a/docs/docs/en/api/faststream/confluent/publisher/state/ProducerState.md b/docs/docs/en/api/faststream/confluent/publisher/state/ProducerState.md deleted file mode 100644 index 5a5a35dddd..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/state/ProducerState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.state.ProducerState diff --git a/docs/docs/en/api/faststream/confluent/publisher/state/RealProducer.md b/docs/docs/en/api/faststream/confluent/publisher/state/RealProducer.md deleted file mode 100644 index 52143d1596..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/state/RealProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.state.RealProducer diff --git a/docs/docs/en/api/faststream/confluent/publisher/usecase/BatchPublisher.md b/docs/docs/en/api/faststream/confluent/publisher/usecase/BatchPublisher.md deleted file mode 100644 index 23e8baeed9..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/usecase/BatchPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.usecase.BatchPublisher diff --git a/docs/docs/en/api/faststream/confluent/publisher/usecase/DefaultPublisher.md b/docs/docs/en/api/faststream/confluent/publisher/usecase/DefaultPublisher.md deleted file mode 100644 index faa20eaa11..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/usecase/DefaultPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.usecase.DefaultPublisher diff --git a/docs/docs/en/api/faststream/confluent/publisher/usecase/LogicPublisher.md b/docs/docs/en/api/faststream/confluent/publisher/usecase/LogicPublisher.md deleted file mode 100644 index d9a8594d12..0000000000 --- a/docs/docs/en/api/faststream/confluent/publisher/usecase/LogicPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.publisher.usecase.LogicPublisher diff --git a/docs/docs/en/api/faststream/confluent/response/KafkaPublishCommand.md b/docs/docs/en/api/faststream/confluent/response/KafkaPublishCommand.md deleted file mode 100644 index 2a4efcf180..0000000000 --- a/docs/docs/en/api/faststream/confluent/response/KafkaPublishCommand.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.response.KafkaPublishCommand diff --git a/docs/docs/en/api/faststream/confluent/response/KafkaResponse.md b/docs/docs/en/api/faststream/confluent/response/KafkaResponse.md deleted file mode 100644 index 7fa5542613..0000000000 --- a/docs/docs/en/api/faststream/confluent/response/KafkaResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.response.KafkaResponse diff --git a/docs/docs/en/api/faststream/confluent/router/KafkaPublisher.md b/docs/docs/en/api/faststream/confluent/router/KafkaPublisher.md deleted file mode 100644 index ee1c818707..0000000000 --- a/docs/docs/en/api/faststream/confluent/router/KafkaPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.router.KafkaPublisher diff --git a/docs/docs/en/api/faststream/confluent/router/KafkaRoute.md b/docs/docs/en/api/faststream/confluent/router/KafkaRoute.md deleted file mode 100644 index 60d7bb1c99..0000000000 --- a/docs/docs/en/api/faststream/confluent/router/KafkaRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.router.KafkaRoute diff --git a/docs/docs/en/api/faststream/confluent/router/KafkaRouter.md b/docs/docs/en/api/faststream/confluent/router/KafkaRouter.md deleted file mode 100644 index dac6c1a646..0000000000 --- a/docs/docs/en/api/faststream/confluent/router/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.router.KafkaRouter diff --git a/docs/docs/en/api/faststream/confluent/schemas/TopicPartition.md b/docs/docs/en/api/faststream/confluent/schemas/TopicPartition.md deleted file mode 100644 index 0c52345b4e..0000000000 --- a/docs/docs/en/api/faststream/confluent/schemas/TopicPartition.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.schemas.TopicPartition diff --git a/docs/docs/en/api/faststream/confluent/schemas/params/ConsumerConnectionParams.md b/docs/docs/en/api/faststream/confluent/schemas/params/ConsumerConnectionParams.md deleted file mode 100644 index f4ed5b2004..0000000000 --- a/docs/docs/en/api/faststream/confluent/schemas/params/ConsumerConnectionParams.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.schemas.params.ConsumerConnectionParams diff --git a/docs/docs/en/api/faststream/confluent/schemas/partition/TopicPartition.md b/docs/docs/en/api/faststream/confluent/schemas/partition/TopicPartition.md deleted file mode 100644 index 11e0bc2b3c..0000000000 --- a/docs/docs/en/api/faststream/confluent/schemas/partition/TopicPartition.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.schemas.partition.TopicPartition diff --git a/docs/docs/en/api/faststream/confluent/security/parse_security.md b/docs/docs/en/api/faststream/confluent/security/parse_security.md deleted file mode 100644 index 1eb84ceed6..0000000000 --- a/docs/docs/en/api/faststream/confluent/security/parse_security.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.security.parse_security diff --git a/docs/docs/en/api/faststream/confluent/subscriber/factory/create_subscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/factory/create_subscriber.md deleted file mode 100644 index ce811a99d9..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/factory/create_subscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.factory.create_subscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationBatchSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationBatchSubscriber.md deleted file mode 100644 index ae9e9f42e8..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationBatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.specified.SpecificationBatchSubscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md deleted file mode 100644 index a42a4cb21b..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.specified.SpecificationConcurrentDefaultSubscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationDefaultSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationDefaultSubscriber.md deleted file mode 100644 index d4dd2d304e..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationDefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.specified.SpecificationDefaultSubscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationSubscriber.md deleted file mode 100644 index 8887278921..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.specified.SpecificationSubscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/usecase/BatchSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/usecase/BatchSubscriber.md deleted file mode 100644 index 4642abd4a8..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/usecase/BatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.usecase.BatchSubscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/usecase/ConcurrentDefaultSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/usecase/ConcurrentDefaultSubscriber.md deleted file mode 100644 index 13d0f308c1..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/usecase/ConcurrentDefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.usecase.ConcurrentDefaultSubscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/usecase/DefaultSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/usecase/DefaultSubscriber.md deleted file mode 100644 index c2d7ed227e..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/usecase/DefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.usecase.DefaultSubscriber diff --git a/docs/docs/en/api/faststream/confluent/subscriber/usecase/LogicSubscriber.md b/docs/docs/en/api/faststream/confluent/subscriber/usecase/LogicSubscriber.md deleted file mode 100644 index c47daf891f..0000000000 --- a/docs/docs/en/api/faststream/confluent/subscriber/usecase/LogicSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.subscriber.usecase.LogicSubscriber diff --git a/docs/docs/en/api/faststream/confluent/testing/FakeProducer.md b/docs/docs/en/api/faststream/confluent/testing/FakeProducer.md deleted file mode 100644 index aeaee2a2d7..0000000000 --- a/docs/docs/en/api/faststream/confluent/testing/FakeProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.testing.FakeProducer diff --git a/docs/docs/en/api/faststream/confluent/testing/MockConfluentMessage.md b/docs/docs/en/api/faststream/confluent/testing/MockConfluentMessage.md deleted file mode 100644 index 78791486ab..0000000000 --- a/docs/docs/en/api/faststream/confluent/testing/MockConfluentMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.testing.MockConfluentMessage diff --git a/docs/docs/en/api/faststream/confluent/testing/TestKafkaBroker.md b/docs/docs/en/api/faststream/confluent/testing/TestKafkaBroker.md deleted file mode 100644 index 53dfed8f24..0000000000 --- a/docs/docs/en/api/faststream/confluent/testing/TestKafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.testing.TestKafkaBroker diff --git a/docs/docs/en/api/faststream/confluent/testing/build_message.md b/docs/docs/en/api/faststream/confluent/testing/build_message.md deleted file mode 100644 index 75787a13b3..0000000000 --- a/docs/docs/en/api/faststream/confluent/testing/build_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.confluent.testing.build_message diff --git a/docs/docs/en/api/faststream/exceptions/AckMessage.md b/docs/docs/en/api/faststream/exceptions/AckMessage.md deleted file mode 100644 index 175efc68ed..0000000000 --- a/docs/docs/en/api/faststream/exceptions/AckMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.AckMessage diff --git a/docs/docs/en/api/faststream/exceptions/ContextError.md b/docs/docs/en/api/faststream/exceptions/ContextError.md deleted file mode 100644 index 73b4fcdd21..0000000000 --- a/docs/docs/en/api/faststream/exceptions/ContextError.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.ContextError diff --git a/docs/docs/en/api/faststream/exceptions/FastStreamException.md b/docs/docs/en/api/faststream/exceptions/FastStreamException.md deleted file mode 100644 index bd988e9332..0000000000 --- a/docs/docs/en/api/faststream/exceptions/FastStreamException.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.FastStreamException diff --git a/docs/docs/en/api/faststream/exceptions/FeatureNotSupportedException.md b/docs/docs/en/api/faststream/exceptions/FeatureNotSupportedException.md deleted file mode 100644 index bbf1f32d2b..0000000000 --- a/docs/docs/en/api/faststream/exceptions/FeatureNotSupportedException.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.FeatureNotSupportedException diff --git a/docs/docs/en/api/faststream/exceptions/HandlerException.md b/docs/docs/en/api/faststream/exceptions/HandlerException.md deleted file mode 100644 index 64495519a4..0000000000 --- a/docs/docs/en/api/faststream/exceptions/HandlerException.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.HandlerException diff --git a/docs/docs/en/api/faststream/exceptions/IgnoredException.md b/docs/docs/en/api/faststream/exceptions/IgnoredException.md deleted file mode 100644 index 18452057c1..0000000000 --- a/docs/docs/en/api/faststream/exceptions/IgnoredException.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.IgnoredException diff --git a/docs/docs/en/api/faststream/exceptions/IncorrectState.md b/docs/docs/en/api/faststream/exceptions/IncorrectState.md deleted file mode 100644 index 2c890d5358..0000000000 --- a/docs/docs/en/api/faststream/exceptions/IncorrectState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.IncorrectState diff --git a/docs/docs/en/api/faststream/exceptions/NackMessage.md b/docs/docs/en/api/faststream/exceptions/NackMessage.md deleted file mode 100644 index 05502ca14d..0000000000 --- a/docs/docs/en/api/faststream/exceptions/NackMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.NackMessage diff --git a/docs/docs/en/api/faststream/exceptions/RejectMessage.md b/docs/docs/en/api/faststream/exceptions/RejectMessage.md deleted file mode 100644 index be491d89c1..0000000000 --- a/docs/docs/en/api/faststream/exceptions/RejectMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.RejectMessage diff --git a/docs/docs/en/api/faststream/exceptions/SetupError.md b/docs/docs/en/api/faststream/exceptions/SetupError.md deleted file mode 100644 index 588e66557f..0000000000 --- a/docs/docs/en/api/faststream/exceptions/SetupError.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.SetupError diff --git a/docs/docs/en/api/faststream/exceptions/SkipMessage.md b/docs/docs/en/api/faststream/exceptions/SkipMessage.md deleted file mode 100644 index e2a6ac135e..0000000000 --- a/docs/docs/en/api/faststream/exceptions/SkipMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.SkipMessage diff --git a/docs/docs/en/api/faststream/exceptions/StartupValidationError.md b/docs/docs/en/api/faststream/exceptions/StartupValidationError.md deleted file mode 100644 index 05b8e7b74d..0000000000 --- a/docs/docs/en/api/faststream/exceptions/StartupValidationError.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.StartupValidationError diff --git a/docs/docs/en/api/faststream/exceptions/StopApplication.md b/docs/docs/en/api/faststream/exceptions/StopApplication.md deleted file mode 100644 index 12059837a4..0000000000 --- a/docs/docs/en/api/faststream/exceptions/StopApplication.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.StopApplication diff --git a/docs/docs/en/api/faststream/exceptions/StopConsume.md b/docs/docs/en/api/faststream/exceptions/StopConsume.md deleted file mode 100644 index 9733dcc2e9..0000000000 --- a/docs/docs/en/api/faststream/exceptions/StopConsume.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.StopConsume diff --git a/docs/docs/en/api/faststream/exceptions/SubscriberNotFound.md b/docs/docs/en/api/faststream/exceptions/SubscriberNotFound.md deleted file mode 100644 index 89428f8251..0000000000 --- a/docs/docs/en/api/faststream/exceptions/SubscriberNotFound.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.exceptions.SubscriberNotFound diff --git a/docs/docs/en/api/faststream/kafka/KafkaBroker.md b/docs/docs/en/api/faststream/kafka/KafkaBroker.md deleted file mode 100644 index 7ee56a5e01..0000000000 --- a/docs/docs/en/api/faststream/kafka/KafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.KafkaBroker diff --git a/docs/docs/en/api/faststream/kafka/KafkaPublisher.md b/docs/docs/en/api/faststream/kafka/KafkaPublisher.md deleted file mode 100644 index c379528109..0000000000 --- a/docs/docs/en/api/faststream/kafka/KafkaPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.KafkaPublisher diff --git a/docs/docs/en/api/faststream/kafka/KafkaResponse.md b/docs/docs/en/api/faststream/kafka/KafkaResponse.md deleted file mode 100644 index 4aab0b965d..0000000000 --- a/docs/docs/en/api/faststream/kafka/KafkaResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.KafkaResponse diff --git a/docs/docs/en/api/faststream/kafka/KafkaRoute.md b/docs/docs/en/api/faststream/kafka/KafkaRoute.md deleted file mode 100644 index 89a8d8cca1..0000000000 --- a/docs/docs/en/api/faststream/kafka/KafkaRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.KafkaRoute diff --git a/docs/docs/en/api/faststream/kafka/KafkaRouter.md b/docs/docs/en/api/faststream/kafka/KafkaRouter.md deleted file mode 100644 index c60f3ca6f4..0000000000 --- a/docs/docs/en/api/faststream/kafka/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.KafkaRouter diff --git a/docs/docs/en/api/faststream/kafka/TestApp.md b/docs/docs/en/api/faststream/kafka/TestApp.md deleted file mode 100644 index ad101303af..0000000000 --- a/docs/docs/en/api/faststream/kafka/TestApp.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.testing.app.TestApp diff --git a/docs/docs/en/api/faststream/kafka/TestKafkaBroker.md b/docs/docs/en/api/faststream/kafka/TestKafkaBroker.md deleted file mode 100644 index 096df3b1d1..0000000000 --- a/docs/docs/en/api/faststream/kafka/TestKafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.TestKafkaBroker diff --git a/docs/docs/en/api/faststream/kafka/TopicPartition.md b/docs/docs/en/api/faststream/kafka/TopicPartition.md deleted file mode 100644 index 41fbd7f624..0000000000 --- a/docs/docs/en/api/faststream/kafka/TopicPartition.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: aiokafka.structs.TopicPartition diff --git a/docs/docs/en/api/faststream/kafka/broker/KafkaBroker.md b/docs/docs/en/api/faststream/kafka/broker/KafkaBroker.md deleted file mode 100644 index 2cee711d14..0000000000 --- a/docs/docs/en/api/faststream/kafka/broker/KafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.broker.KafkaBroker diff --git a/docs/docs/en/api/faststream/kafka/broker/broker/KafkaBroker.md b/docs/docs/en/api/faststream/kafka/broker/broker/KafkaBroker.md deleted file mode 100644 index ca32dd3865..0000000000 --- a/docs/docs/en/api/faststream/kafka/broker/broker/KafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.broker.broker.KafkaBroker diff --git a/docs/docs/en/api/faststream/kafka/broker/logging/KafkaParamsStorage.md b/docs/docs/en/api/faststream/kafka/broker/logging/KafkaParamsStorage.md deleted file mode 100644 index f7c8136115..0000000000 --- a/docs/docs/en/api/faststream/kafka/broker/logging/KafkaParamsStorage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.broker.logging.KafkaParamsStorage diff --git a/docs/docs/en/api/faststream/kafka/broker/registrator/KafkaRegistrator.md b/docs/docs/en/api/faststream/kafka/broker/registrator/KafkaRegistrator.md deleted file mode 100644 index aa06d38f65..0000000000 --- a/docs/docs/en/api/faststream/kafka/broker/registrator/KafkaRegistrator.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.broker.registrator.KafkaRegistrator diff --git a/docs/docs/en/api/faststream/kafka/fastapi/Context.md b/docs/docs/en/api/faststream/kafka/fastapi/Context.md deleted file mode 100644 index 99bf141f5c..0000000000 --- a/docs/docs/en/api/faststream/kafka/fastapi/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.fastapi.context.Context diff --git a/docs/docs/en/api/faststream/kafka/fastapi/KafkaRouter.md b/docs/docs/en/api/faststream/kafka/fastapi/KafkaRouter.md deleted file mode 100644 index 2ab7254e79..0000000000 --- a/docs/docs/en/api/faststream/kafka/fastapi/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.fastapi.KafkaRouter diff --git a/docs/docs/en/api/faststream/kafka/fastapi/fastapi/KafkaRouter.md b/docs/docs/en/api/faststream/kafka/fastapi/fastapi/KafkaRouter.md deleted file mode 100644 index 80fc17dd4a..0000000000 --- a/docs/docs/en/api/faststream/kafka/fastapi/fastapi/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.fastapi.fastapi.KafkaRouter diff --git a/docs/docs/en/api/faststream/kafka/message/ConsumerProtocol.md b/docs/docs/en/api/faststream/kafka/message/ConsumerProtocol.md deleted file mode 100644 index c9fd16a983..0000000000 --- a/docs/docs/en/api/faststream/kafka/message/ConsumerProtocol.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.message.ConsumerProtocol diff --git a/docs/docs/en/api/faststream/kafka/message/FakeConsumer.md b/docs/docs/en/api/faststream/kafka/message/FakeConsumer.md deleted file mode 100644 index d41724b288..0000000000 --- a/docs/docs/en/api/faststream/kafka/message/FakeConsumer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.message.FakeConsumer diff --git a/docs/docs/en/api/faststream/kafka/message/KafkaAckableMessage.md b/docs/docs/en/api/faststream/kafka/message/KafkaAckableMessage.md deleted file mode 100644 index 16461be675..0000000000 --- a/docs/docs/en/api/faststream/kafka/message/KafkaAckableMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.message.KafkaAckableMessage diff --git a/docs/docs/en/api/faststream/kafka/message/KafkaMessage.md b/docs/docs/en/api/faststream/kafka/message/KafkaMessage.md deleted file mode 100644 index 7a7a30bae3..0000000000 --- a/docs/docs/en/api/faststream/kafka/message/KafkaMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.message.KafkaMessage diff --git a/docs/docs/en/api/faststream/kafka/opentelemetry/KafkaTelemetryMiddleware.md b/docs/docs/en/api/faststream/kafka/opentelemetry/KafkaTelemetryMiddleware.md deleted file mode 100644 index 02fb4805ac..0000000000 --- a/docs/docs/en/api/faststream/kafka/opentelemetry/KafkaTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.opentelemetry.KafkaTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/kafka/opentelemetry/middleware/KafkaTelemetryMiddleware.md b/docs/docs/en/api/faststream/kafka/opentelemetry/middleware/KafkaTelemetryMiddleware.md deleted file mode 100644 index aba78378f2..0000000000 --- a/docs/docs/en/api/faststream/kafka/opentelemetry/middleware/KafkaTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.opentelemetry.middleware.KafkaTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BaseKafkaTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BaseKafkaTelemetrySettingsProvider.md deleted file mode 100644 index 5cb13be947..0000000000 --- a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BaseKafkaTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.opentelemetry.provider.BaseKafkaTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BatchKafkaTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BatchKafkaTelemetrySettingsProvider.md deleted file mode 100644 index d3d7080509..0000000000 --- a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BatchKafkaTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.opentelemetry.provider.BatchKafkaTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/KafkaTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/KafkaTelemetrySettingsProvider.md deleted file mode 100644 index 0859c0df3d..0000000000 --- a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/KafkaTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.opentelemetry.provider.KafkaTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/telemetry_attributes_provider_factory.md b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/telemetry_attributes_provider_factory.md deleted file mode 100644 index 3b2a1ad394..0000000000 --- a/docs/docs/en/api/faststream/kafka/opentelemetry/provider/telemetry_attributes_provider_factory.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.opentelemetry.provider.telemetry_attributes_provider_factory diff --git a/docs/docs/en/api/faststream/kafka/parser/AioKafkaBatchParser.md b/docs/docs/en/api/faststream/kafka/parser/AioKafkaBatchParser.md deleted file mode 100644 index 25df2532c6..0000000000 --- a/docs/docs/en/api/faststream/kafka/parser/AioKafkaBatchParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.parser.AioKafkaBatchParser diff --git a/docs/docs/en/api/faststream/kafka/parser/AioKafkaParser.md b/docs/docs/en/api/faststream/kafka/parser/AioKafkaParser.md deleted file mode 100644 index e7e37cce97..0000000000 --- a/docs/docs/en/api/faststream/kafka/parser/AioKafkaParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.parser.AioKafkaParser diff --git a/docs/docs/en/api/faststream/kafka/prometheus/KafkaPrometheusMiddleware.md b/docs/docs/en/api/faststream/kafka/prometheus/KafkaPrometheusMiddleware.md deleted file mode 100644 index c2ffd5356a..0000000000 --- a/docs/docs/en/api/faststream/kafka/prometheus/KafkaPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.prometheus.KafkaPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/kafka/prometheus/middleware/KafkaPrometheusMiddleware.md b/docs/docs/en/api/faststream/kafka/prometheus/middleware/KafkaPrometheusMiddleware.md deleted file mode 100644 index 451b7080c0..0000000000 --- a/docs/docs/en/api/faststream/kafka/prometheus/middleware/KafkaPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.prometheus.middleware.KafkaPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/kafka/prometheus/provider/BaseKafkaMetricsSettingsProvider.md b/docs/docs/en/api/faststream/kafka/prometheus/provider/BaseKafkaMetricsSettingsProvider.md deleted file mode 100644 index 0fd044f694..0000000000 --- a/docs/docs/en/api/faststream/kafka/prometheus/provider/BaseKafkaMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.prometheus.provider.BaseKafkaMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/kafka/prometheus/provider/BatchKafkaMetricsSettingsProvider.md b/docs/docs/en/api/faststream/kafka/prometheus/provider/BatchKafkaMetricsSettingsProvider.md deleted file mode 100644 index 9bd01d5e71..0000000000 --- a/docs/docs/en/api/faststream/kafka/prometheus/provider/BatchKafkaMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.prometheus.provider.BatchKafkaMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/kafka/prometheus/provider/KafkaMetricsSettingsProvider.md b/docs/docs/en/api/faststream/kafka/prometheus/provider/KafkaMetricsSettingsProvider.md deleted file mode 100644 index ae7c490da8..0000000000 --- a/docs/docs/en/api/faststream/kafka/prometheus/provider/KafkaMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.prometheus.provider.KafkaMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/kafka/prometheus/provider/settings_provider_factory.md b/docs/docs/en/api/faststream/kafka/prometheus/provider/settings_provider_factory.md deleted file mode 100644 index 1393fd9065..0000000000 --- a/docs/docs/en/api/faststream/kafka/prometheus/provider/settings_provider_factory.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.prometheus.provider.settings_provider_factory diff --git a/docs/docs/en/api/faststream/kafka/publisher/factory/create_publisher.md b/docs/docs/en/api/faststream/kafka/publisher/factory/create_publisher.md deleted file mode 100644 index 7ec33758af..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/factory/create_publisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.factory.create_publisher diff --git a/docs/docs/en/api/faststream/kafka/publisher/fake/KafkaFakePublisher.md b/docs/docs/en/api/faststream/kafka/publisher/fake/KafkaFakePublisher.md deleted file mode 100644 index 6bacca904e..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/fake/KafkaFakePublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.fake.KafkaFakePublisher diff --git a/docs/docs/en/api/faststream/kafka/publisher/producer/AioKafkaFastProducer.md b/docs/docs/en/api/faststream/kafka/publisher/producer/AioKafkaFastProducer.md deleted file mode 100644 index 83b116989b..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/producer/AioKafkaFastProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.producer.AioKafkaFastProducer diff --git a/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationBatchPublisher.md b/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationBatchPublisher.md deleted file mode 100644 index 795766b030..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationBatchPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.specified.SpecificationBatchPublisher diff --git a/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationDefaultPublisher.md b/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationDefaultPublisher.md deleted file mode 100644 index e191045545..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationDefaultPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.specified.SpecificationDefaultPublisher diff --git a/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationPublisher.md b/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationPublisher.md deleted file mode 100644 index ed687d7e08..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.specified.SpecificationPublisher diff --git a/docs/docs/en/api/faststream/kafka/publisher/state/EmptyProducerState.md b/docs/docs/en/api/faststream/kafka/publisher/state/EmptyProducerState.md deleted file mode 100644 index 0152ee7c2f..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/state/EmptyProducerState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.state.EmptyProducerState diff --git a/docs/docs/en/api/faststream/kafka/publisher/state/ProducerState.md b/docs/docs/en/api/faststream/kafka/publisher/state/ProducerState.md deleted file mode 100644 index c937179471..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/state/ProducerState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.state.ProducerState diff --git a/docs/docs/en/api/faststream/kafka/publisher/state/RealProducer.md b/docs/docs/en/api/faststream/kafka/publisher/state/RealProducer.md deleted file mode 100644 index a576226b3c..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/state/RealProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.state.RealProducer diff --git a/docs/docs/en/api/faststream/kafka/publisher/usecase/BatchPublisher.md b/docs/docs/en/api/faststream/kafka/publisher/usecase/BatchPublisher.md deleted file mode 100644 index 045cfbf45f..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/usecase/BatchPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.usecase.BatchPublisher diff --git a/docs/docs/en/api/faststream/kafka/publisher/usecase/DefaultPublisher.md b/docs/docs/en/api/faststream/kafka/publisher/usecase/DefaultPublisher.md deleted file mode 100644 index 07518c75b3..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/usecase/DefaultPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.usecase.DefaultPublisher diff --git a/docs/docs/en/api/faststream/kafka/publisher/usecase/LogicPublisher.md b/docs/docs/en/api/faststream/kafka/publisher/usecase/LogicPublisher.md deleted file mode 100644 index 615da58f90..0000000000 --- a/docs/docs/en/api/faststream/kafka/publisher/usecase/LogicPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.publisher.usecase.LogicPublisher diff --git a/docs/docs/en/api/faststream/kafka/response/KafkaPublishCommand.md b/docs/docs/en/api/faststream/kafka/response/KafkaPublishCommand.md deleted file mode 100644 index 4852098fcc..0000000000 --- a/docs/docs/en/api/faststream/kafka/response/KafkaPublishCommand.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.response.KafkaPublishCommand diff --git a/docs/docs/en/api/faststream/kafka/response/KafkaResponse.md b/docs/docs/en/api/faststream/kafka/response/KafkaResponse.md deleted file mode 100644 index 05ecd69c2d..0000000000 --- a/docs/docs/en/api/faststream/kafka/response/KafkaResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.response.KafkaResponse diff --git a/docs/docs/en/api/faststream/kafka/router/KafkaPublisher.md b/docs/docs/en/api/faststream/kafka/router/KafkaPublisher.md deleted file mode 100644 index 5027c18f20..0000000000 --- a/docs/docs/en/api/faststream/kafka/router/KafkaPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.router.KafkaPublisher diff --git a/docs/docs/en/api/faststream/kafka/router/KafkaRoute.md b/docs/docs/en/api/faststream/kafka/router/KafkaRoute.md deleted file mode 100644 index e7e6184deb..0000000000 --- a/docs/docs/en/api/faststream/kafka/router/KafkaRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.router.KafkaRoute diff --git a/docs/docs/en/api/faststream/kafka/router/KafkaRouter.md b/docs/docs/en/api/faststream/kafka/router/KafkaRouter.md deleted file mode 100644 index 5d7578bbfc..0000000000 --- a/docs/docs/en/api/faststream/kafka/router/KafkaRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.router.KafkaRouter diff --git a/docs/docs/en/api/faststream/kafka/schemas/params/ConsumerConnectionParams.md b/docs/docs/en/api/faststream/kafka/schemas/params/ConsumerConnectionParams.md deleted file mode 100644 index b289e61e5a..0000000000 --- a/docs/docs/en/api/faststream/kafka/schemas/params/ConsumerConnectionParams.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.schemas.params.ConsumerConnectionParams diff --git a/docs/docs/en/api/faststream/kafka/security/parse_security.md b/docs/docs/en/api/faststream/kafka/security/parse_security.md deleted file mode 100644 index e325a99ad8..0000000000 --- a/docs/docs/en/api/faststream/kafka/security/parse_security.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.security.parse_security diff --git a/docs/docs/en/api/faststream/kafka/subscriber/factory/create_subscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/factory/create_subscriber.md deleted file mode 100644 index d9e5fcb4a4..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/factory/create_subscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.factory.create_subscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationBatchSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationBatchSubscriber.md deleted file mode 100644 index 9e0ce90401..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationBatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.specified.SpecificationBatchSubscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md deleted file mode 100644 index 16f0f81d14..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.specified.SpecificationConcurrentDefaultSubscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationDefaultSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationDefaultSubscriber.md deleted file mode 100644 index fe8ac61ac2..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationDefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.specified.SpecificationDefaultSubscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationSubscriber.md deleted file mode 100644 index 79dca87d97..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.specified.SpecificationSubscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/usecase/BatchSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/usecase/BatchSubscriber.md deleted file mode 100644 index 6f8978f38b..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/usecase/BatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.usecase.BatchSubscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/usecase/ConcurrentDefaultSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/usecase/ConcurrentDefaultSubscriber.md deleted file mode 100644 index 16f09d9334..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/usecase/ConcurrentDefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.usecase.ConcurrentDefaultSubscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/usecase/DefaultSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/usecase/DefaultSubscriber.md deleted file mode 100644 index 78949c27dd..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/usecase/DefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.usecase.DefaultSubscriber diff --git a/docs/docs/en/api/faststream/kafka/subscriber/usecase/LogicSubscriber.md b/docs/docs/en/api/faststream/kafka/subscriber/usecase/LogicSubscriber.md deleted file mode 100644 index 297013e037..0000000000 --- a/docs/docs/en/api/faststream/kafka/subscriber/usecase/LogicSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.subscriber.usecase.LogicSubscriber diff --git a/docs/docs/en/api/faststream/kafka/testing/FakeProducer.md b/docs/docs/en/api/faststream/kafka/testing/FakeProducer.md deleted file mode 100644 index 63eb94c3ca..0000000000 --- a/docs/docs/en/api/faststream/kafka/testing/FakeProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.testing.FakeProducer diff --git a/docs/docs/en/api/faststream/kafka/testing/TestKafkaBroker.md b/docs/docs/en/api/faststream/kafka/testing/TestKafkaBroker.md deleted file mode 100644 index 96f257a15f..0000000000 --- a/docs/docs/en/api/faststream/kafka/testing/TestKafkaBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.testing.TestKafkaBroker diff --git a/docs/docs/en/api/faststream/kafka/testing/build_message.md b/docs/docs/en/api/faststream/kafka/testing/build_message.md deleted file mode 100644 index 354d7a82f3..0000000000 --- a/docs/docs/en/api/faststream/kafka/testing/build_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.kafka.testing.build_message diff --git a/docs/docs/en/api/faststream/message/AckStatus.md b/docs/docs/en/api/faststream/message/AckStatus.md deleted file mode 100644 index b8d3d6c6c8..0000000000 --- a/docs/docs/en/api/faststream/message/AckStatus.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.AckStatus diff --git a/docs/docs/en/api/faststream/message/SourceType.md b/docs/docs/en/api/faststream/message/SourceType.md deleted file mode 100644 index 7df391eac3..0000000000 --- a/docs/docs/en/api/faststream/message/SourceType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.SourceType diff --git a/docs/docs/en/api/faststream/message/StreamMessage.md b/docs/docs/en/api/faststream/message/StreamMessage.md deleted file mode 100644 index 5f072b2410..0000000000 --- a/docs/docs/en/api/faststream/message/StreamMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.StreamMessage diff --git a/docs/docs/en/api/faststream/message/decode_message.md b/docs/docs/en/api/faststream/message/decode_message.md deleted file mode 100644 index c0dce11670..0000000000 --- a/docs/docs/en/api/faststream/message/decode_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.decode_message diff --git a/docs/docs/en/api/faststream/message/encode_message.md b/docs/docs/en/api/faststream/message/encode_message.md deleted file mode 100644 index 7d33d8d904..0000000000 --- a/docs/docs/en/api/faststream/message/encode_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.encode_message diff --git a/docs/docs/en/api/faststream/message/gen_cor_id.md b/docs/docs/en/api/faststream/message/gen_cor_id.md deleted file mode 100644 index 0abdf298b9..0000000000 --- a/docs/docs/en/api/faststream/message/gen_cor_id.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.gen_cor_id diff --git a/docs/docs/en/api/faststream/message/message/AckStatus.md b/docs/docs/en/api/faststream/message/message/AckStatus.md deleted file mode 100644 index 80940a8ba7..0000000000 --- a/docs/docs/en/api/faststream/message/message/AckStatus.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.message.AckStatus diff --git a/docs/docs/en/api/faststream/message/message/StreamMessage.md b/docs/docs/en/api/faststream/message/message/StreamMessage.md deleted file mode 100644 index a41232b74c..0000000000 --- a/docs/docs/en/api/faststream/message/message/StreamMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.message.StreamMessage diff --git a/docs/docs/en/api/faststream/message/source_type/SourceType.md b/docs/docs/en/api/faststream/message/source_type/SourceType.md deleted file mode 100644 index 8a6fc990e4..0000000000 --- a/docs/docs/en/api/faststream/message/source_type/SourceType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.source_type.SourceType diff --git a/docs/docs/en/api/faststream/message/utils/decode_message.md b/docs/docs/en/api/faststream/message/utils/decode_message.md deleted file mode 100644 index b2ec48dac0..0000000000 --- a/docs/docs/en/api/faststream/message/utils/decode_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.utils.decode_message diff --git a/docs/docs/en/api/faststream/message/utils/encode_message.md b/docs/docs/en/api/faststream/message/utils/encode_message.md deleted file mode 100644 index 7401e07da5..0000000000 --- a/docs/docs/en/api/faststream/message/utils/encode_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.utils.encode_message diff --git a/docs/docs/en/api/faststream/message/utils/gen_cor_id.md b/docs/docs/en/api/faststream/message/utils/gen_cor_id.md deleted file mode 100644 index 74b49c30d2..0000000000 --- a/docs/docs/en/api/faststream/message/utils/gen_cor_id.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.message.utils.gen_cor_id diff --git a/docs/docs/en/api/faststream/middlewares/AckPolicy.md b/docs/docs/en/api/faststream/middlewares/AckPolicy.md deleted file mode 100644 index 82d0033dfb..0000000000 --- a/docs/docs/en/api/faststream/middlewares/AckPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.AckPolicy diff --git a/docs/docs/en/api/faststream/middlewares/AcknowledgementMiddleware.md b/docs/docs/en/api/faststream/middlewares/AcknowledgementMiddleware.md deleted file mode 100644 index d3e7d6a763..0000000000 --- a/docs/docs/en/api/faststream/middlewares/AcknowledgementMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.AcknowledgementMiddleware diff --git a/docs/docs/en/api/faststream/middlewares/BaseMiddleware.md b/docs/docs/en/api/faststream/middlewares/BaseMiddleware.md deleted file mode 100644 index 30f98187a1..0000000000 --- a/docs/docs/en/api/faststream/middlewares/BaseMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.BaseMiddleware diff --git a/docs/docs/en/api/faststream/middlewares/ExceptionMiddleware.md b/docs/docs/en/api/faststream/middlewares/ExceptionMiddleware.md deleted file mode 100644 index c1d21850c8..0000000000 --- a/docs/docs/en/api/faststream/middlewares/ExceptionMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.ExceptionMiddleware diff --git a/docs/docs/en/api/faststream/middlewares/acknowledgement/conf/AckPolicy.md b/docs/docs/en/api/faststream/middlewares/acknowledgement/conf/AckPolicy.md deleted file mode 100644 index 8a92ec0a54..0000000000 --- a/docs/docs/en/api/faststream/middlewares/acknowledgement/conf/AckPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.acknowledgement.conf.AckPolicy diff --git a/docs/docs/en/api/faststream/middlewares/acknowledgement/middleware/AcknowledgementMiddleware.md b/docs/docs/en/api/faststream/middlewares/acknowledgement/middleware/AcknowledgementMiddleware.md deleted file mode 100644 index 79b2956eb4..0000000000 --- a/docs/docs/en/api/faststream/middlewares/acknowledgement/middleware/AcknowledgementMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.acknowledgement.middleware.AcknowledgementMiddleware diff --git a/docs/docs/en/api/faststream/middlewares/base/BaseMiddleware.md b/docs/docs/en/api/faststream/middlewares/base/BaseMiddleware.md deleted file mode 100644 index d3319e7441..0000000000 --- a/docs/docs/en/api/faststream/middlewares/base/BaseMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.base.BaseMiddleware diff --git a/docs/docs/en/api/faststream/middlewares/exception/ExceptionMiddleware.md b/docs/docs/en/api/faststream/middlewares/exception/ExceptionMiddleware.md deleted file mode 100644 index da1693a722..0000000000 --- a/docs/docs/en/api/faststream/middlewares/exception/ExceptionMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.exception.ExceptionMiddleware diff --git a/docs/docs/en/api/faststream/middlewares/exception/ignore_handler.md b/docs/docs/en/api/faststream/middlewares/exception/ignore_handler.md deleted file mode 100644 index 1eea49ddbe..0000000000 --- a/docs/docs/en/api/faststream/middlewares/exception/ignore_handler.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.exception.ignore_handler diff --git a/docs/docs/en/api/faststream/middlewares/logging/CriticalLogMiddleware.md b/docs/docs/en/api/faststream/middlewares/logging/CriticalLogMiddleware.md deleted file mode 100644 index 58be3830e6..0000000000 --- a/docs/docs/en/api/faststream/middlewares/logging/CriticalLogMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.middlewares.logging.CriticalLogMiddleware diff --git a/docs/docs/en/api/faststream/nats/AckPolicy.md b/docs/docs/en/api/faststream/nats/AckPolicy.md deleted file mode 100644 index 308d12ac63..0000000000 --- a/docs/docs/en/api/faststream/nats/AckPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.AckPolicy diff --git a/docs/docs/en/api/faststream/nats/ConsumerConfig.md b/docs/docs/en/api/faststream/nats/ConsumerConfig.md deleted file mode 100644 index 56c357cc07..0000000000 --- a/docs/docs/en/api/faststream/nats/ConsumerConfig.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.ConsumerConfig diff --git a/docs/docs/en/api/faststream/nats/DeliverPolicy.md b/docs/docs/en/api/faststream/nats/DeliverPolicy.md deleted file mode 100644 index ebb664d0d9..0000000000 --- a/docs/docs/en/api/faststream/nats/DeliverPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.DeliverPolicy diff --git a/docs/docs/en/api/faststream/nats/DiscardPolicy.md b/docs/docs/en/api/faststream/nats/DiscardPolicy.md deleted file mode 100644 index 9eacd12198..0000000000 --- a/docs/docs/en/api/faststream/nats/DiscardPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.DiscardPolicy diff --git a/docs/docs/en/api/faststream/nats/ExternalStream.md b/docs/docs/en/api/faststream/nats/ExternalStream.md deleted file mode 100644 index 5ea0eacbbc..0000000000 --- a/docs/docs/en/api/faststream/nats/ExternalStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.ExternalStream diff --git a/docs/docs/en/api/faststream/nats/JStream.md b/docs/docs/en/api/faststream/nats/JStream.md deleted file mode 100644 index 70ca7cab69..0000000000 --- a/docs/docs/en/api/faststream/nats/JStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.JStream diff --git a/docs/docs/en/api/faststream/nats/KvWatch.md b/docs/docs/en/api/faststream/nats/KvWatch.md deleted file mode 100644 index 1527be51fd..0000000000 --- a/docs/docs/en/api/faststream/nats/KvWatch.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.KvWatch diff --git a/docs/docs/en/api/faststream/nats/NatsBroker.md b/docs/docs/en/api/faststream/nats/NatsBroker.md deleted file mode 100644 index 376231c4cd..0000000000 --- a/docs/docs/en/api/faststream/nats/NatsBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.NatsBroker diff --git a/docs/docs/en/api/faststream/nats/NatsPublisher.md b/docs/docs/en/api/faststream/nats/NatsPublisher.md deleted file mode 100644 index 1f1ffbca2a..0000000000 --- a/docs/docs/en/api/faststream/nats/NatsPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.NatsPublisher diff --git a/docs/docs/en/api/faststream/nats/NatsResponse.md b/docs/docs/en/api/faststream/nats/NatsResponse.md deleted file mode 100644 index 6b967b527a..0000000000 --- a/docs/docs/en/api/faststream/nats/NatsResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.NatsResponse diff --git a/docs/docs/en/api/faststream/nats/NatsRoute.md b/docs/docs/en/api/faststream/nats/NatsRoute.md deleted file mode 100644 index b76a8481dc..0000000000 --- a/docs/docs/en/api/faststream/nats/NatsRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.NatsRoute diff --git a/docs/docs/en/api/faststream/nats/NatsRouter.md b/docs/docs/en/api/faststream/nats/NatsRouter.md deleted file mode 100644 index 89e975235b..0000000000 --- a/docs/docs/en/api/faststream/nats/NatsRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.NatsRouter diff --git a/docs/docs/en/api/faststream/nats/ObjWatch.md b/docs/docs/en/api/faststream/nats/ObjWatch.md deleted file mode 100644 index 50102ecf31..0000000000 --- a/docs/docs/en/api/faststream/nats/ObjWatch.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.ObjWatch diff --git a/docs/docs/en/api/faststream/nats/Placement.md b/docs/docs/en/api/faststream/nats/Placement.md deleted file mode 100644 index bff8b3d4b8..0000000000 --- a/docs/docs/en/api/faststream/nats/Placement.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.Placement diff --git a/docs/docs/en/api/faststream/nats/PubAck.md b/docs/docs/en/api/faststream/nats/PubAck.md deleted file mode 100644 index 697f22abe6..0000000000 --- a/docs/docs/en/api/faststream/nats/PubAck.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.PubAck diff --git a/docs/docs/en/api/faststream/nats/PullSub.md b/docs/docs/en/api/faststream/nats/PullSub.md deleted file mode 100644 index dbfaf68f54..0000000000 --- a/docs/docs/en/api/faststream/nats/PullSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.PullSub diff --git a/docs/docs/en/api/faststream/nats/RePublish.md b/docs/docs/en/api/faststream/nats/RePublish.md deleted file mode 100644 index 35ad498def..0000000000 --- a/docs/docs/en/api/faststream/nats/RePublish.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.RePublish diff --git a/docs/docs/en/api/faststream/nats/ReplayPolicy.md b/docs/docs/en/api/faststream/nats/ReplayPolicy.md deleted file mode 100644 index 6430f0a22f..0000000000 --- a/docs/docs/en/api/faststream/nats/ReplayPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.ReplayPolicy diff --git a/docs/docs/en/api/faststream/nats/RetentionPolicy.md b/docs/docs/en/api/faststream/nats/RetentionPolicy.md deleted file mode 100644 index 919b818c9e..0000000000 --- a/docs/docs/en/api/faststream/nats/RetentionPolicy.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.RetentionPolicy diff --git a/docs/docs/en/api/faststream/nats/StorageType.md b/docs/docs/en/api/faststream/nats/StorageType.md deleted file mode 100644 index 78a6bc4d8f..0000000000 --- a/docs/docs/en/api/faststream/nats/StorageType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.StorageType diff --git a/docs/docs/en/api/faststream/nats/StreamConfig.md b/docs/docs/en/api/faststream/nats/StreamConfig.md deleted file mode 100644 index 3bce18f7de..0000000000 --- a/docs/docs/en/api/faststream/nats/StreamConfig.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.StreamConfig diff --git a/docs/docs/en/api/faststream/nats/StreamSource.md b/docs/docs/en/api/faststream/nats/StreamSource.md deleted file mode 100644 index 4d85db37e5..0000000000 --- a/docs/docs/en/api/faststream/nats/StreamSource.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.StreamSource diff --git a/docs/docs/en/api/faststream/nats/TestApp.md b/docs/docs/en/api/faststream/nats/TestApp.md deleted file mode 100644 index ad101303af..0000000000 --- a/docs/docs/en/api/faststream/nats/TestApp.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.testing.app.TestApp diff --git a/docs/docs/en/api/faststream/nats/TestNatsBroker.md b/docs/docs/en/api/faststream/nats/TestNatsBroker.md deleted file mode 100644 index 8557295619..0000000000 --- a/docs/docs/en/api/faststream/nats/TestNatsBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.TestNatsBroker diff --git a/docs/docs/en/api/faststream/nats/broker/NatsBroker.md b/docs/docs/en/api/faststream/nats/broker/NatsBroker.md deleted file mode 100644 index eeea31372b..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/NatsBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.NatsBroker diff --git a/docs/docs/en/api/faststream/nats/broker/broker/NatsBroker.md b/docs/docs/en/api/faststream/nats/broker/broker/NatsBroker.md deleted file mode 100644 index 7aed0de1ec..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/broker/NatsBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.broker.NatsBroker diff --git a/docs/docs/en/api/faststream/nats/broker/logging/NatsParamsStorage.md b/docs/docs/en/api/faststream/nats/broker/logging/NatsParamsStorage.md deleted file mode 100644 index 25b77d4331..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/logging/NatsParamsStorage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.logging.NatsParamsStorage diff --git a/docs/docs/en/api/faststream/nats/broker/registrator/NatsRegistrator.md b/docs/docs/en/api/faststream/nats/broker/registrator/NatsRegistrator.md deleted file mode 100644 index f7f313746a..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/registrator/NatsRegistrator.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.registrator.NatsRegistrator diff --git a/docs/docs/en/api/faststream/nats/broker/state/BrokerState.md b/docs/docs/en/api/faststream/nats/broker/state/BrokerState.md deleted file mode 100644 index ed5dc00c35..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/state/BrokerState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.state.BrokerState diff --git a/docs/docs/en/api/faststream/nats/broker/state/ConnectedState.md b/docs/docs/en/api/faststream/nats/broker/state/ConnectedState.md deleted file mode 100644 index b7bb106798..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/state/ConnectedState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.state.ConnectedState diff --git a/docs/docs/en/api/faststream/nats/broker/state/ConnectionBrokenState.md b/docs/docs/en/api/faststream/nats/broker/state/ConnectionBrokenState.md deleted file mode 100644 index 66df604330..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/state/ConnectionBrokenState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.state.ConnectionBrokenState diff --git a/docs/docs/en/api/faststream/nats/broker/state/EmptyBrokerState.md b/docs/docs/en/api/faststream/nats/broker/state/EmptyBrokerState.md deleted file mode 100644 index 88bf83710d..0000000000 --- a/docs/docs/en/api/faststream/nats/broker/state/EmptyBrokerState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.broker.state.EmptyBrokerState diff --git a/docs/docs/en/api/faststream/nats/fastapi/Context.md b/docs/docs/en/api/faststream/nats/fastapi/Context.md deleted file mode 100644 index 99bf141f5c..0000000000 --- a/docs/docs/en/api/faststream/nats/fastapi/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.fastapi.context.Context diff --git a/docs/docs/en/api/faststream/nats/fastapi/NatsRouter.md b/docs/docs/en/api/faststream/nats/fastapi/NatsRouter.md deleted file mode 100644 index 53123192c2..0000000000 --- a/docs/docs/en/api/faststream/nats/fastapi/NatsRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.fastapi.NatsRouter diff --git a/docs/docs/en/api/faststream/nats/fastapi/fastapi/NatsRouter.md b/docs/docs/en/api/faststream/nats/fastapi/fastapi/NatsRouter.md deleted file mode 100644 index 015f730b4f..0000000000 --- a/docs/docs/en/api/faststream/nats/fastapi/fastapi/NatsRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.fastapi.fastapi.NatsRouter diff --git a/docs/docs/en/api/faststream/nats/helpers/KVBucketDeclarer.md b/docs/docs/en/api/faststream/nats/helpers/KVBucketDeclarer.md deleted file mode 100644 index b24feaada6..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/KVBucketDeclarer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.KVBucketDeclarer diff --git a/docs/docs/en/api/faststream/nats/helpers/OSBucketDeclarer.md b/docs/docs/en/api/faststream/nats/helpers/OSBucketDeclarer.md deleted file mode 100644 index 3ee16a3f24..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/OSBucketDeclarer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.OSBucketDeclarer diff --git a/docs/docs/en/api/faststream/nats/helpers/StreamBuilder.md b/docs/docs/en/api/faststream/nats/helpers/StreamBuilder.md deleted file mode 100644 index 3b2a318598..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/StreamBuilder.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.StreamBuilder diff --git a/docs/docs/en/api/faststream/nats/helpers/bucket_declarer/KVBucketDeclarer.md b/docs/docs/en/api/faststream/nats/helpers/bucket_declarer/KVBucketDeclarer.md deleted file mode 100644 index fe0eaec17f..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/bucket_declarer/KVBucketDeclarer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.bucket_declarer.KVBucketDeclarer diff --git a/docs/docs/en/api/faststream/nats/helpers/obj_storage_declarer/OSBucketDeclarer.md b/docs/docs/en/api/faststream/nats/helpers/obj_storage_declarer/OSBucketDeclarer.md deleted file mode 100644 index b7663051c8..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/obj_storage_declarer/OSBucketDeclarer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.obj_storage_declarer.OSBucketDeclarer diff --git a/docs/docs/en/api/faststream/nats/helpers/object_builder/StreamBuilder.md b/docs/docs/en/api/faststream/nats/helpers/object_builder/StreamBuilder.md deleted file mode 100644 index 024daf2d14..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/object_builder/StreamBuilder.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.object_builder.StreamBuilder diff --git a/docs/docs/en/api/faststream/nats/helpers/state/ConnectedState.md b/docs/docs/en/api/faststream/nats/helpers/state/ConnectedState.md deleted file mode 100644 index 888302338b..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/state/ConnectedState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.state.ConnectedState diff --git a/docs/docs/en/api/faststream/nats/helpers/state/ConnectionState.md b/docs/docs/en/api/faststream/nats/helpers/state/ConnectionState.md deleted file mode 100644 index 0d99fb56ed..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/state/ConnectionState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.state.ConnectionState diff --git a/docs/docs/en/api/faststream/nats/helpers/state/EmptyConnectionState.md b/docs/docs/en/api/faststream/nats/helpers/state/EmptyConnectionState.md deleted file mode 100644 index 31a062d4ad..0000000000 --- a/docs/docs/en/api/faststream/nats/helpers/state/EmptyConnectionState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.helpers.state.EmptyConnectionState diff --git a/docs/docs/en/api/faststream/nats/message/NatsBatchMessage.md b/docs/docs/en/api/faststream/nats/message/NatsBatchMessage.md deleted file mode 100644 index 83017107ff..0000000000 --- a/docs/docs/en/api/faststream/nats/message/NatsBatchMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.message.NatsBatchMessage diff --git a/docs/docs/en/api/faststream/nats/message/NatsKvMessage.md b/docs/docs/en/api/faststream/nats/message/NatsKvMessage.md deleted file mode 100644 index 5ac6ed9f41..0000000000 --- a/docs/docs/en/api/faststream/nats/message/NatsKvMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.message.NatsKvMessage diff --git a/docs/docs/en/api/faststream/nats/message/NatsMessage.md b/docs/docs/en/api/faststream/nats/message/NatsMessage.md deleted file mode 100644 index 22d17ceb56..0000000000 --- a/docs/docs/en/api/faststream/nats/message/NatsMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.message.NatsMessage diff --git a/docs/docs/en/api/faststream/nats/message/NatsObjMessage.md b/docs/docs/en/api/faststream/nats/message/NatsObjMessage.md deleted file mode 100644 index 3671628da4..0000000000 --- a/docs/docs/en/api/faststream/nats/message/NatsObjMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.message.NatsObjMessage diff --git a/docs/docs/en/api/faststream/nats/opentelemetry/NatsTelemetryMiddleware.md b/docs/docs/en/api/faststream/nats/opentelemetry/NatsTelemetryMiddleware.md deleted file mode 100644 index e72f2de8ab..0000000000 --- a/docs/docs/en/api/faststream/nats/opentelemetry/NatsTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.opentelemetry.NatsTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/nats/opentelemetry/middleware/NatsTelemetryMiddleware.md b/docs/docs/en/api/faststream/nats/opentelemetry/middleware/NatsTelemetryMiddleware.md deleted file mode 100644 index b2bb226585..0000000000 --- a/docs/docs/en/api/faststream/nats/opentelemetry/middleware/NatsTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.opentelemetry.middleware.NatsTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/nats/opentelemetry/provider/BaseNatsTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/nats/opentelemetry/provider/BaseNatsTelemetrySettingsProvider.md deleted file mode 100644 index d6626c537d..0000000000 --- a/docs/docs/en/api/faststream/nats/opentelemetry/provider/BaseNatsTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.opentelemetry.provider.BaseNatsTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsBatchTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsBatchTelemetrySettingsProvider.md deleted file mode 100644 index 045996125a..0000000000 --- a/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsBatchTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.opentelemetry.provider.NatsBatchTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsTelemetrySettingsProvider.md deleted file mode 100644 index b58590c4fa..0000000000 --- a/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.opentelemetry.provider.NatsTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/nats/opentelemetry/provider/telemetry_attributes_provider_factory.md b/docs/docs/en/api/faststream/nats/opentelemetry/provider/telemetry_attributes_provider_factory.md deleted file mode 100644 index 200d333e0b..0000000000 --- a/docs/docs/en/api/faststream/nats/opentelemetry/provider/telemetry_attributes_provider_factory.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.opentelemetry.provider.telemetry_attributes_provider_factory diff --git a/docs/docs/en/api/faststream/nats/parser/BatchParser.md b/docs/docs/en/api/faststream/nats/parser/BatchParser.md deleted file mode 100644 index 03ad25f549..0000000000 --- a/docs/docs/en/api/faststream/nats/parser/BatchParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.parser.BatchParser diff --git a/docs/docs/en/api/faststream/nats/parser/JsParser.md b/docs/docs/en/api/faststream/nats/parser/JsParser.md deleted file mode 100644 index 0cd283d36e..0000000000 --- a/docs/docs/en/api/faststream/nats/parser/JsParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.parser.JsParser diff --git a/docs/docs/en/api/faststream/nats/parser/KvParser.md b/docs/docs/en/api/faststream/nats/parser/KvParser.md deleted file mode 100644 index acba65e133..0000000000 --- a/docs/docs/en/api/faststream/nats/parser/KvParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.parser.KvParser diff --git a/docs/docs/en/api/faststream/nats/parser/NatsBaseParser.md b/docs/docs/en/api/faststream/nats/parser/NatsBaseParser.md deleted file mode 100644 index 00b038738d..0000000000 --- a/docs/docs/en/api/faststream/nats/parser/NatsBaseParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.parser.NatsBaseParser diff --git a/docs/docs/en/api/faststream/nats/parser/NatsParser.md b/docs/docs/en/api/faststream/nats/parser/NatsParser.md deleted file mode 100644 index ceed3d0bdf..0000000000 --- a/docs/docs/en/api/faststream/nats/parser/NatsParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.parser.NatsParser diff --git a/docs/docs/en/api/faststream/nats/parser/ObjParser.md b/docs/docs/en/api/faststream/nats/parser/ObjParser.md deleted file mode 100644 index 50ff5d0e18..0000000000 --- a/docs/docs/en/api/faststream/nats/parser/ObjParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.parser.ObjParser diff --git a/docs/docs/en/api/faststream/nats/prometheus/NatsPrometheusMiddleware.md b/docs/docs/en/api/faststream/nats/prometheus/NatsPrometheusMiddleware.md deleted file mode 100644 index d9b179b0c4..0000000000 --- a/docs/docs/en/api/faststream/nats/prometheus/NatsPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.prometheus.NatsPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/nats/prometheus/middleware/NatsPrometheusMiddleware.md b/docs/docs/en/api/faststream/nats/prometheus/middleware/NatsPrometheusMiddleware.md deleted file mode 100644 index 7202731048..0000000000 --- a/docs/docs/en/api/faststream/nats/prometheus/middleware/NatsPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.prometheus.middleware.NatsPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/nats/prometheus/provider/BaseNatsMetricsSettingsProvider.md b/docs/docs/en/api/faststream/nats/prometheus/provider/BaseNatsMetricsSettingsProvider.md deleted file mode 100644 index 80742833bc..0000000000 --- a/docs/docs/en/api/faststream/nats/prometheus/provider/BaseNatsMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.prometheus.provider.BaseNatsMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/nats/prometheus/provider/BatchNatsMetricsSettingsProvider.md b/docs/docs/en/api/faststream/nats/prometheus/provider/BatchNatsMetricsSettingsProvider.md deleted file mode 100644 index 163ebb7bc6..0000000000 --- a/docs/docs/en/api/faststream/nats/prometheus/provider/BatchNatsMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.prometheus.provider.BatchNatsMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/nats/prometheus/provider/NatsMetricsSettingsProvider.md b/docs/docs/en/api/faststream/nats/prometheus/provider/NatsMetricsSettingsProvider.md deleted file mode 100644 index e5515a4cc5..0000000000 --- a/docs/docs/en/api/faststream/nats/prometheus/provider/NatsMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.prometheus.provider.NatsMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/nats/prometheus/provider/settings_provider_factory.md b/docs/docs/en/api/faststream/nats/prometheus/provider/settings_provider_factory.md deleted file mode 100644 index aeaa7b26e0..0000000000 --- a/docs/docs/en/api/faststream/nats/prometheus/provider/settings_provider_factory.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.prometheus.provider.settings_provider_factory diff --git a/docs/docs/en/api/faststream/nats/publisher/factory/create_publisher.md b/docs/docs/en/api/faststream/nats/publisher/factory/create_publisher.md deleted file mode 100644 index 19b23b99a5..0000000000 --- a/docs/docs/en/api/faststream/nats/publisher/factory/create_publisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.publisher.factory.create_publisher diff --git a/docs/docs/en/api/faststream/nats/publisher/fake/NatsFakePublisher.md b/docs/docs/en/api/faststream/nats/publisher/fake/NatsFakePublisher.md deleted file mode 100644 index df23cc8045..0000000000 --- a/docs/docs/en/api/faststream/nats/publisher/fake/NatsFakePublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.publisher.fake.NatsFakePublisher diff --git a/docs/docs/en/api/faststream/nats/publisher/producer/NatsFastProducer.md b/docs/docs/en/api/faststream/nats/publisher/producer/NatsFastProducer.md deleted file mode 100644 index 82ff491f16..0000000000 --- a/docs/docs/en/api/faststream/nats/publisher/producer/NatsFastProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.publisher.producer.NatsFastProducer diff --git a/docs/docs/en/api/faststream/nats/publisher/producer/NatsJSFastProducer.md b/docs/docs/en/api/faststream/nats/publisher/producer/NatsJSFastProducer.md deleted file mode 100644 index 9c0e046e61..0000000000 --- a/docs/docs/en/api/faststream/nats/publisher/producer/NatsJSFastProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.publisher.producer.NatsJSFastProducer diff --git a/docs/docs/en/api/faststream/nats/publisher/specified/SpecificationPublisher.md b/docs/docs/en/api/faststream/nats/publisher/specified/SpecificationPublisher.md deleted file mode 100644 index 3f5eec9e22..0000000000 --- a/docs/docs/en/api/faststream/nats/publisher/specified/SpecificationPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.publisher.specified.SpecificationPublisher diff --git a/docs/docs/en/api/faststream/nats/publisher/usecase/LogicPublisher.md b/docs/docs/en/api/faststream/nats/publisher/usecase/LogicPublisher.md deleted file mode 100644 index 08c7794545..0000000000 --- a/docs/docs/en/api/faststream/nats/publisher/usecase/LogicPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.publisher.usecase.LogicPublisher diff --git a/docs/docs/en/api/faststream/nats/response/NatsPublishCommand.md b/docs/docs/en/api/faststream/nats/response/NatsPublishCommand.md deleted file mode 100644 index 148119ba8a..0000000000 --- a/docs/docs/en/api/faststream/nats/response/NatsPublishCommand.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.response.NatsPublishCommand diff --git a/docs/docs/en/api/faststream/nats/response/NatsResponse.md b/docs/docs/en/api/faststream/nats/response/NatsResponse.md deleted file mode 100644 index 8a7da66982..0000000000 --- a/docs/docs/en/api/faststream/nats/response/NatsResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.response.NatsResponse diff --git a/docs/docs/en/api/faststream/nats/router/NatsPublisher.md b/docs/docs/en/api/faststream/nats/router/NatsPublisher.md deleted file mode 100644 index b025495e44..0000000000 --- a/docs/docs/en/api/faststream/nats/router/NatsPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.router.NatsPublisher diff --git a/docs/docs/en/api/faststream/nats/router/NatsRoute.md b/docs/docs/en/api/faststream/nats/router/NatsRoute.md deleted file mode 100644 index 36df33c45e..0000000000 --- a/docs/docs/en/api/faststream/nats/router/NatsRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.router.NatsRoute diff --git a/docs/docs/en/api/faststream/nats/router/NatsRouter.md b/docs/docs/en/api/faststream/nats/router/NatsRouter.md deleted file mode 100644 index 4b6dfaaf7d..0000000000 --- a/docs/docs/en/api/faststream/nats/router/NatsRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.router.NatsRouter diff --git a/docs/docs/en/api/faststream/nats/schemas/JStream.md b/docs/docs/en/api/faststream/nats/schemas/JStream.md deleted file mode 100644 index 51df9a02cc..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/JStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.JStream diff --git a/docs/docs/en/api/faststream/nats/schemas/KvWatch.md b/docs/docs/en/api/faststream/nats/schemas/KvWatch.md deleted file mode 100644 index ce99738043..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/KvWatch.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.KvWatch diff --git a/docs/docs/en/api/faststream/nats/schemas/ObjWatch.md b/docs/docs/en/api/faststream/nats/schemas/ObjWatch.md deleted file mode 100644 index 51c3628e5e..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/ObjWatch.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.ObjWatch diff --git a/docs/docs/en/api/faststream/nats/schemas/PubAck.md b/docs/docs/en/api/faststream/nats/schemas/PubAck.md deleted file mode 100644 index 697f22abe6..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/PubAck.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: nats.js.api.PubAck diff --git a/docs/docs/en/api/faststream/nats/schemas/PullSub.md b/docs/docs/en/api/faststream/nats/schemas/PullSub.md deleted file mode 100644 index cb7341340c..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/PullSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.PullSub diff --git a/docs/docs/en/api/faststream/nats/schemas/js_stream/JStream.md b/docs/docs/en/api/faststream/nats/schemas/js_stream/JStream.md deleted file mode 100644 index af375c116a..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/js_stream/JStream.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.js_stream.JStream diff --git a/docs/docs/en/api/faststream/nats/schemas/js_stream/compile_nats_wildcard.md b/docs/docs/en/api/faststream/nats/schemas/js_stream/compile_nats_wildcard.md deleted file mode 100644 index 910f034eff..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/js_stream/compile_nats_wildcard.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.js_stream.compile_nats_wildcard diff --git a/docs/docs/en/api/faststream/nats/schemas/js_stream/is_subject_match_wildcard.md b/docs/docs/en/api/faststream/nats/schemas/js_stream/is_subject_match_wildcard.md deleted file mode 100644 index f9305b94e8..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/js_stream/is_subject_match_wildcard.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.js_stream.is_subject_match_wildcard diff --git a/docs/docs/en/api/faststream/nats/schemas/kv_watch/KvWatch.md b/docs/docs/en/api/faststream/nats/schemas/kv_watch/KvWatch.md deleted file mode 100644 index ce07fa305d..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/kv_watch/KvWatch.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.kv_watch.KvWatch diff --git a/docs/docs/en/api/faststream/nats/schemas/obj_watch/ObjWatch.md b/docs/docs/en/api/faststream/nats/schemas/obj_watch/ObjWatch.md deleted file mode 100644 index 55831b8a6a..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/obj_watch/ObjWatch.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.obj_watch.ObjWatch diff --git a/docs/docs/en/api/faststream/nats/schemas/pull_sub/PullSub.md b/docs/docs/en/api/faststream/nats/schemas/pull_sub/PullSub.md deleted file mode 100644 index 673a1e8ff6..0000000000 --- a/docs/docs/en/api/faststream/nats/schemas/pull_sub/PullSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.schemas.pull_sub.PullSub diff --git a/docs/docs/en/api/faststream/nats/security/parse_security.md b/docs/docs/en/api/faststream/nats/security/parse_security.md deleted file mode 100644 index d2fe5dd0c3..0000000000 --- a/docs/docs/en/api/faststream/nats/security/parse_security.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.security.parse_security diff --git a/docs/docs/en/api/faststream/nats/subscriber/adapters/UnsubscribeAdapter.md b/docs/docs/en/api/faststream/nats/subscriber/adapters/UnsubscribeAdapter.md deleted file mode 100644 index 9b00a89428..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/adapters/UnsubscribeAdapter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.adapters.UnsubscribeAdapter diff --git a/docs/docs/en/api/faststream/nats/subscriber/adapters/Unsubscriptable.md b/docs/docs/en/api/faststream/nats/subscriber/adapters/Unsubscriptable.md deleted file mode 100644 index 4c6c6b0abe..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/adapters/Unsubscriptable.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.adapters.Unsubscriptable diff --git a/docs/docs/en/api/faststream/nats/subscriber/adapters/Watchable.md b/docs/docs/en/api/faststream/nats/subscriber/adapters/Watchable.md deleted file mode 100644 index 00dde78565..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/adapters/Watchable.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.adapters.Watchable diff --git a/docs/docs/en/api/faststream/nats/subscriber/factory/create_subscriber.md b/docs/docs/en/api/faststream/nats/subscriber/factory/create_subscriber.md deleted file mode 100644 index 0e132c3394..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/factory/create_subscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.factory.create_subscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationBatchPullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationBatchPullStreamSubscriber.md deleted file mode 100644 index d663201213..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationBatchPullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationBatchPullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentCoreSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentCoreSubscriber.md deleted file mode 100644 index 24f1a256ce..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentCoreSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationConcurrentCoreSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPullStreamSubscriber.md deleted file mode 100644 index 45d7106b98..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationConcurrentPullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPushStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPushStreamSubscriber.md deleted file mode 100644 index 4a5bebd382..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPushStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationConcurrentPushStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationCoreSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationCoreSubscriber.md deleted file mode 100644 index 5415ec6203..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationCoreSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationCoreSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationKeyValueWatchSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationKeyValueWatchSubscriber.md deleted file mode 100644 index bd9e10e9d2..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationKeyValueWatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationKeyValueWatchSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationObjStoreWatchSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationObjStoreWatchSubscriber.md deleted file mode 100644 index d2b5bfa27f..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationObjStoreWatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationObjStoreWatchSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPullStreamSubscriber.md deleted file mode 100644 index c0867b195f..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationPullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPushStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPushStreamSubscriber.md deleted file mode 100644 index ef20892652..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPushStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationPushStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationSubscriber.md deleted file mode 100644 index 613fdecd8a..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.specified.SpecificationSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/state/ConnectedSubscriberState.md b/docs/docs/en/api/faststream/nats/subscriber/state/ConnectedSubscriberState.md deleted file mode 100644 index 3398403cb2..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/state/ConnectedSubscriberState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.state.ConnectedSubscriberState diff --git a/docs/docs/en/api/faststream/nats/subscriber/state/EmptySubscriberState.md b/docs/docs/en/api/faststream/nats/subscriber/state/EmptySubscriberState.md deleted file mode 100644 index de80057014..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/state/EmptySubscriberState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.state.EmptySubscriberState diff --git a/docs/docs/en/api/faststream/nats/subscriber/state/SubscriberState.md b/docs/docs/en/api/faststream/nats/subscriber/state/SubscriberState.md deleted file mode 100644 index a61839436a..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/state/SubscriberState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.state.SubscriberState diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/BatchPullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/BatchPullStreamSubscriber.md deleted file mode 100644 index 667ff42587..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/BatchPullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.BatchPullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentCoreSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentCoreSubscriber.md deleted file mode 100644 index bbd0895a8c..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentCoreSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.ConcurrentCoreSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPullStreamSubscriber.md deleted file mode 100644 index 7bb13db682..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.ConcurrentPullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPushStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPushStreamSubscriber.md deleted file mode 100644 index c694d41369..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPushStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.ConcurrentPushStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/CoreSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/CoreSubscriber.md deleted file mode 100644 index e35ebd3f9d..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/CoreSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.CoreSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/KeyValueWatchSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/KeyValueWatchSubscriber.md deleted file mode 100644 index 507c7a33c4..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/KeyValueWatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.KeyValueWatchSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/LogicSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/LogicSubscriber.md deleted file mode 100644 index e97348563d..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/LogicSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.LogicSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/ObjStoreWatchSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/ObjStoreWatchSubscriber.md deleted file mode 100644 index 25d1434968..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/ObjStoreWatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.ObjStoreWatchSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/PullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/PullStreamSubscriber.md deleted file mode 100644 index ddc3731c6e..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/PullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.PullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/PushStreamSubscription.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/PushStreamSubscription.md deleted file mode 100644 index 9ea5735afb..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/PushStreamSubscription.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.PushStreamSubscription diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/DefaultSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/DefaultSubscriber.md deleted file mode 100644 index f0bd5e52aa..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/DefaultSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.basic.DefaultSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/LogicSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/LogicSubscriber.md deleted file mode 100644 index 9dfc93aa9b..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/LogicSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.basic.LogicSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/ConcurrentCoreSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/ConcurrentCoreSubscriber.md deleted file mode 100644 index a684452aa1..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/ConcurrentCoreSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.core_subscriber.ConcurrentCoreSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/CoreSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/CoreSubscriber.md deleted file mode 100644 index cc1905f58e..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/CoreSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.core_subscriber.CoreSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/key_value_subscriber/KeyValueWatchSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/key_value_subscriber/KeyValueWatchSubscriber.md deleted file mode 100644 index 26e1b670d0..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/key_value_subscriber/KeyValueWatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.key_value_subscriber.KeyValueWatchSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/object_storage_subscriber/ObjStoreWatchSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/object_storage_subscriber/ObjStoreWatchSubscriber.md deleted file mode 100644 index b1722e57ec..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/object_storage_subscriber/ObjStoreWatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.object_storage_subscriber.ObjStoreWatchSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_basic/StreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_basic/StreamSubscriber.md deleted file mode 100644 index b08fd2abff..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_basic/StreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.stream_basic.StreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/BatchPullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/BatchPullStreamSubscriber.md deleted file mode 100644 index 9e4973cf67..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/BatchPullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.stream_pull_subscriber.BatchPullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/ConcurrentPullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/ConcurrentPullStreamSubscriber.md deleted file mode 100644 index 6c31f93a20..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/ConcurrentPullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.stream_pull_subscriber.ConcurrentPullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/PullStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/PullStreamSubscriber.md deleted file mode 100644 index 35e7de26de..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/PullStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.stream_pull_subscriber.PullStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/ConcurrentPushStreamSubscriber.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/ConcurrentPushStreamSubscriber.md deleted file mode 100644 index 78cffa0a9f..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/ConcurrentPushStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.stream_push_subscriber.ConcurrentPushStreamSubscriber diff --git a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/PushStreamSubscription.md b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/PushStreamSubscription.md deleted file mode 100644 index eee1f7aeb7..0000000000 --- a/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/PushStreamSubscription.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.subscriber.usecases.stream_push_subscriber.PushStreamSubscription diff --git a/docs/docs/en/api/faststream/nats/testing/FakeProducer.md b/docs/docs/en/api/faststream/nats/testing/FakeProducer.md deleted file mode 100644 index f2615aeb36..0000000000 --- a/docs/docs/en/api/faststream/nats/testing/FakeProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.testing.FakeProducer diff --git a/docs/docs/en/api/faststream/nats/testing/PatchedMessage.md b/docs/docs/en/api/faststream/nats/testing/PatchedMessage.md deleted file mode 100644 index e32802d4dd..0000000000 --- a/docs/docs/en/api/faststream/nats/testing/PatchedMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.testing.PatchedMessage diff --git a/docs/docs/en/api/faststream/nats/testing/TestNatsBroker.md b/docs/docs/en/api/faststream/nats/testing/TestNatsBroker.md deleted file mode 100644 index 2abcf7f06d..0000000000 --- a/docs/docs/en/api/faststream/nats/testing/TestNatsBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.testing.TestNatsBroker diff --git a/docs/docs/en/api/faststream/nats/testing/build_message.md b/docs/docs/en/api/faststream/nats/testing/build_message.md deleted file mode 100644 index 160977893d..0000000000 --- a/docs/docs/en/api/faststream/nats/testing/build_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.nats.testing.build_message diff --git a/docs/docs/en/api/faststream/opentelemetry/Baggage.md b/docs/docs/en/api/faststream/opentelemetry/Baggage.md deleted file mode 100644 index a61cb56d97..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/Baggage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.Baggage diff --git a/docs/docs/en/api/faststream/opentelemetry/TelemetryMiddleware.md b/docs/docs/en/api/faststream/opentelemetry/TelemetryMiddleware.md deleted file mode 100644 index 914f134e60..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/TelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.TelemetryMiddleware diff --git a/docs/docs/en/api/faststream/opentelemetry/TelemetrySettingsProvider.md b/docs/docs/en/api/faststream/opentelemetry/TelemetrySettingsProvider.md deleted file mode 100644 index 7ca8b2cb6d..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/TelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.TelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/opentelemetry/baggage/Baggage.md b/docs/docs/en/api/faststream/opentelemetry/baggage/Baggage.md deleted file mode 100644 index c1c6e4efec..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/baggage/Baggage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.baggage.Baggage diff --git a/docs/docs/en/api/faststream/opentelemetry/consts/MessageAction.md b/docs/docs/en/api/faststream/opentelemetry/consts/MessageAction.md deleted file mode 100644 index cd58706774..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/consts/MessageAction.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.consts.MessageAction diff --git a/docs/docs/en/api/faststream/opentelemetry/middleware/BaseTelemetryMiddleware.md b/docs/docs/en/api/faststream/opentelemetry/middleware/BaseTelemetryMiddleware.md deleted file mode 100644 index 64a7b4a501..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/middleware/BaseTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.middleware.BaseTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/opentelemetry/middleware/TelemetryMiddleware.md b/docs/docs/en/api/faststream/opentelemetry/middleware/TelemetryMiddleware.md deleted file mode 100644 index f019b3ad61..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/middleware/TelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.middleware.TelemetryMiddleware diff --git a/docs/docs/en/api/faststream/opentelemetry/provider/TelemetrySettingsProvider.md b/docs/docs/en/api/faststream/opentelemetry/provider/TelemetrySettingsProvider.md deleted file mode 100644 index 0fefe1c0ef..0000000000 --- a/docs/docs/en/api/faststream/opentelemetry/provider/TelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.opentelemetry.provider.TelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/params/Context.md b/docs/docs/en/api/faststream/params/Context.md deleted file mode 100644 index 8eb7fc249a..0000000000 --- a/docs/docs/en/api/faststream/params/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.params.Context diff --git a/docs/docs/en/api/faststream/params/Depends.md b/docs/docs/en/api/faststream/params/Depends.md deleted file mode 100644 index c0704687e8..0000000000 --- a/docs/docs/en/api/faststream/params/Depends.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: fast_depends.use.Depends diff --git a/docs/docs/en/api/faststream/params/Header.md b/docs/docs/en/api/faststream/params/Header.md deleted file mode 100644 index f3dd71365c..0000000000 --- a/docs/docs/en/api/faststream/params/Header.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.params.Header diff --git a/docs/docs/en/api/faststream/params/Path.md b/docs/docs/en/api/faststream/params/Path.md deleted file mode 100644 index ad04fdff6e..0000000000 --- a/docs/docs/en/api/faststream/params/Path.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.params.Path diff --git a/docs/docs/en/api/faststream/params/no_cast/NoCastField.md b/docs/docs/en/api/faststream/params/no_cast/NoCastField.md deleted file mode 100644 index 56821cae8a..0000000000 --- a/docs/docs/en/api/faststream/params/no_cast/NoCastField.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.params.no_cast.NoCastField diff --git a/docs/docs/en/api/faststream/params/params/Context.md b/docs/docs/en/api/faststream/params/params/Context.md deleted file mode 100644 index 4c3ec6b4dd..0000000000 --- a/docs/docs/en/api/faststream/params/params/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.params.params.Context diff --git a/docs/docs/en/api/faststream/params/params/Header.md b/docs/docs/en/api/faststream/params/params/Header.md deleted file mode 100644 index 6b15bd1ec1..0000000000 --- a/docs/docs/en/api/faststream/params/params/Header.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.params.params.Header diff --git a/docs/docs/en/api/faststream/params/params/Path.md b/docs/docs/en/api/faststream/params/params/Path.md deleted file mode 100644 index 0903f40023..0000000000 --- a/docs/docs/en/api/faststream/params/params/Path.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.params.params.Path diff --git a/docs/docs/en/api/faststream/prometheus/ConsumeAttrs.md b/docs/docs/en/api/faststream/prometheus/ConsumeAttrs.md deleted file mode 100644 index ad8e536b7a..0000000000 --- a/docs/docs/en/api/faststream/prometheus/ConsumeAttrs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.ConsumeAttrs diff --git a/docs/docs/en/api/faststream/prometheus/MetricsSettingsProvider.md b/docs/docs/en/api/faststream/prometheus/MetricsSettingsProvider.md deleted file mode 100644 index 0f7405e44d..0000000000 --- a/docs/docs/en/api/faststream/prometheus/MetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.MetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/prometheus/PrometheusMiddleware.md b/docs/docs/en/api/faststream/prometheus/PrometheusMiddleware.md deleted file mode 100644 index c340a0cb23..0000000000 --- a/docs/docs/en/api/faststream/prometheus/PrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.PrometheusMiddleware diff --git a/docs/docs/en/api/faststream/prometheus/container/MetricsContainer.md b/docs/docs/en/api/faststream/prometheus/container/MetricsContainer.md deleted file mode 100644 index 009d88d263..0000000000 --- a/docs/docs/en/api/faststream/prometheus/container/MetricsContainer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.container.MetricsContainer diff --git a/docs/docs/en/api/faststream/prometheus/manager/MetricsManager.md b/docs/docs/en/api/faststream/prometheus/manager/MetricsManager.md deleted file mode 100644 index b1a897c717..0000000000 --- a/docs/docs/en/api/faststream/prometheus/manager/MetricsManager.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.manager.MetricsManager diff --git a/docs/docs/en/api/faststream/prometheus/middleware/BasePrometheusMiddleware.md b/docs/docs/en/api/faststream/prometheus/middleware/BasePrometheusMiddleware.md deleted file mode 100644 index 62bbd031ac..0000000000 --- a/docs/docs/en/api/faststream/prometheus/middleware/BasePrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.middleware.BasePrometheusMiddleware diff --git a/docs/docs/en/api/faststream/prometheus/middleware/PrometheusMiddleware.md b/docs/docs/en/api/faststream/prometheus/middleware/PrometheusMiddleware.md deleted file mode 100644 index 2902586e38..0000000000 --- a/docs/docs/en/api/faststream/prometheus/middleware/PrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.middleware.PrometheusMiddleware diff --git a/docs/docs/en/api/faststream/prometheus/provider/MetricsSettingsProvider.md b/docs/docs/en/api/faststream/prometheus/provider/MetricsSettingsProvider.md deleted file mode 100644 index 3511a21a5b..0000000000 --- a/docs/docs/en/api/faststream/prometheus/provider/MetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.provider.MetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/prometheus/types/ConsumeAttrs.md b/docs/docs/en/api/faststream/prometheus/types/ConsumeAttrs.md deleted file mode 100644 index d9196cab8d..0000000000 --- a/docs/docs/en/api/faststream/prometheus/types/ConsumeAttrs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.types.ConsumeAttrs diff --git a/docs/docs/en/api/faststream/prometheus/types/ProcessingStatus.md b/docs/docs/en/api/faststream/prometheus/types/ProcessingStatus.md deleted file mode 100644 index 98b6710bcd..0000000000 --- a/docs/docs/en/api/faststream/prometheus/types/ProcessingStatus.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.types.ProcessingStatus diff --git a/docs/docs/en/api/faststream/prometheus/types/PublishingStatus.md b/docs/docs/en/api/faststream/prometheus/types/PublishingStatus.md deleted file mode 100644 index 4e7435fbea..0000000000 --- a/docs/docs/en/api/faststream/prometheus/types/PublishingStatus.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.prometheus.types.PublishingStatus diff --git a/docs/docs/en/api/faststream/rabbit/ExchangeType.md b/docs/docs/en/api/faststream/rabbit/ExchangeType.md deleted file mode 100644 index 9b299b951d..0000000000 --- a/docs/docs/en/api/faststream/rabbit/ExchangeType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.ExchangeType diff --git a/docs/docs/en/api/faststream/rabbit/RabbitBroker.md b/docs/docs/en/api/faststream/rabbit/RabbitBroker.md deleted file mode 100644 index f48b2b5e78..0000000000 --- a/docs/docs/en/api/faststream/rabbit/RabbitBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.RabbitBroker diff --git a/docs/docs/en/api/faststream/rabbit/RabbitExchange.md b/docs/docs/en/api/faststream/rabbit/RabbitExchange.md deleted file mode 100644 index bbf9676e72..0000000000 --- a/docs/docs/en/api/faststream/rabbit/RabbitExchange.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.RabbitExchange diff --git a/docs/docs/en/api/faststream/rabbit/RabbitPublisher.md b/docs/docs/en/api/faststream/rabbit/RabbitPublisher.md deleted file mode 100644 index 7e0d3f674b..0000000000 --- a/docs/docs/en/api/faststream/rabbit/RabbitPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.RabbitPublisher diff --git a/docs/docs/en/api/faststream/rabbit/RabbitQueue.md b/docs/docs/en/api/faststream/rabbit/RabbitQueue.md deleted file mode 100644 index 97945b6408..0000000000 --- a/docs/docs/en/api/faststream/rabbit/RabbitQueue.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.RabbitQueue diff --git a/docs/docs/en/api/faststream/rabbit/RabbitResponse.md b/docs/docs/en/api/faststream/rabbit/RabbitResponse.md deleted file mode 100644 index 4d20d82b0e..0000000000 --- a/docs/docs/en/api/faststream/rabbit/RabbitResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.RabbitResponse diff --git a/docs/docs/en/api/faststream/rabbit/RabbitRoute.md b/docs/docs/en/api/faststream/rabbit/RabbitRoute.md deleted file mode 100644 index e11a9f058d..0000000000 --- a/docs/docs/en/api/faststream/rabbit/RabbitRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.RabbitRoute diff --git a/docs/docs/en/api/faststream/rabbit/RabbitRouter.md b/docs/docs/en/api/faststream/rabbit/RabbitRouter.md deleted file mode 100644 index 133880fc50..0000000000 --- a/docs/docs/en/api/faststream/rabbit/RabbitRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.RabbitRouter diff --git a/docs/docs/en/api/faststream/rabbit/TestApp.md b/docs/docs/en/api/faststream/rabbit/TestApp.md deleted file mode 100644 index ad101303af..0000000000 --- a/docs/docs/en/api/faststream/rabbit/TestApp.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.testing.app.TestApp diff --git a/docs/docs/en/api/faststream/rabbit/TestRabbitBroker.md b/docs/docs/en/api/faststream/rabbit/TestRabbitBroker.md deleted file mode 100644 index c4519d58b8..0000000000 --- a/docs/docs/en/api/faststream/rabbit/TestRabbitBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.TestRabbitBroker diff --git a/docs/docs/en/api/faststream/rabbit/broker/RabbitBroker.md b/docs/docs/en/api/faststream/rabbit/broker/RabbitBroker.md deleted file mode 100644 index ac72ec0ae9..0000000000 --- a/docs/docs/en/api/faststream/rabbit/broker/RabbitBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.broker.RabbitBroker diff --git a/docs/docs/en/api/faststream/rabbit/broker/broker/RabbitBroker.md b/docs/docs/en/api/faststream/rabbit/broker/broker/RabbitBroker.md deleted file mode 100644 index 9ed9170ead..0000000000 --- a/docs/docs/en/api/faststream/rabbit/broker/broker/RabbitBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.broker.broker.RabbitBroker diff --git a/docs/docs/en/api/faststream/rabbit/broker/logging/RabbitParamsStorage.md b/docs/docs/en/api/faststream/rabbit/broker/logging/RabbitParamsStorage.md deleted file mode 100644 index e9e46da6af..0000000000 --- a/docs/docs/en/api/faststream/rabbit/broker/logging/RabbitParamsStorage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.broker.logging.RabbitParamsStorage diff --git a/docs/docs/en/api/faststream/rabbit/broker/registrator/RabbitRegistrator.md b/docs/docs/en/api/faststream/rabbit/broker/registrator/RabbitRegistrator.md deleted file mode 100644 index f22385f512..0000000000 --- a/docs/docs/en/api/faststream/rabbit/broker/registrator/RabbitRegistrator.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.broker.registrator.RabbitRegistrator diff --git a/docs/docs/en/api/faststream/rabbit/fastapi/Context.md b/docs/docs/en/api/faststream/rabbit/fastapi/Context.md deleted file mode 100644 index 99bf141f5c..0000000000 --- a/docs/docs/en/api/faststream/rabbit/fastapi/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.fastapi.context.Context diff --git a/docs/docs/en/api/faststream/rabbit/fastapi/RabbitRouter.md b/docs/docs/en/api/faststream/rabbit/fastapi/RabbitRouter.md deleted file mode 100644 index 72f0a90072..0000000000 --- a/docs/docs/en/api/faststream/rabbit/fastapi/RabbitRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.fastapi.RabbitRouter diff --git a/docs/docs/en/api/faststream/rabbit/fastapi/fastapi/RabbitRouter.md b/docs/docs/en/api/faststream/rabbit/fastapi/fastapi/RabbitRouter.md deleted file mode 100644 index d70c558254..0000000000 --- a/docs/docs/en/api/faststream/rabbit/fastapi/fastapi/RabbitRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.fastapi.fastapi.RabbitRouter diff --git a/docs/docs/en/api/faststream/rabbit/helpers/declarer/RabbitDeclarer.md b/docs/docs/en/api/faststream/rabbit/helpers/declarer/RabbitDeclarer.md deleted file mode 100644 index b8fc8a0ebd..0000000000 --- a/docs/docs/en/api/faststream/rabbit/helpers/declarer/RabbitDeclarer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.helpers.declarer.RabbitDeclarer diff --git a/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectedState.md b/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectedState.md deleted file mode 100644 index db97303aa3..0000000000 --- a/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectedState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.helpers.state.ConnectedState diff --git a/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectionState.md b/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectionState.md deleted file mode 100644 index 36b3d4d4d1..0000000000 --- a/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectionState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.helpers.state.ConnectionState diff --git a/docs/docs/en/api/faststream/rabbit/helpers/state/EmptyConnectionState.md b/docs/docs/en/api/faststream/rabbit/helpers/state/EmptyConnectionState.md deleted file mode 100644 index 7b0af42897..0000000000 --- a/docs/docs/en/api/faststream/rabbit/helpers/state/EmptyConnectionState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.helpers.state.EmptyConnectionState diff --git a/docs/docs/en/api/faststream/rabbit/message/RabbitMessage.md b/docs/docs/en/api/faststream/rabbit/message/RabbitMessage.md deleted file mode 100644 index 598d43f818..0000000000 --- a/docs/docs/en/api/faststream/rabbit/message/RabbitMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.message.RabbitMessage diff --git a/docs/docs/en/api/faststream/rabbit/opentelemetry/RabbitTelemetryMiddleware.md b/docs/docs/en/api/faststream/rabbit/opentelemetry/RabbitTelemetryMiddleware.md deleted file mode 100644 index 7d5ef3de27..0000000000 --- a/docs/docs/en/api/faststream/rabbit/opentelemetry/RabbitTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.opentelemetry.RabbitTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/rabbit/opentelemetry/middleware/RabbitTelemetryMiddleware.md b/docs/docs/en/api/faststream/rabbit/opentelemetry/middleware/RabbitTelemetryMiddleware.md deleted file mode 100644 index e86771a8ba..0000000000 --- a/docs/docs/en/api/faststream/rabbit/opentelemetry/middleware/RabbitTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.opentelemetry.middleware.RabbitTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/rabbit/opentelemetry/provider/RabbitTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/rabbit/opentelemetry/provider/RabbitTelemetrySettingsProvider.md deleted file mode 100644 index ba6742ac90..0000000000 --- a/docs/docs/en/api/faststream/rabbit/opentelemetry/provider/RabbitTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.opentelemetry.provider.RabbitTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/rabbit/parser/AioPikaParser.md b/docs/docs/en/api/faststream/rabbit/parser/AioPikaParser.md deleted file mode 100644 index 0a02d90270..0000000000 --- a/docs/docs/en/api/faststream/rabbit/parser/AioPikaParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.parser.AioPikaParser diff --git a/docs/docs/en/api/faststream/rabbit/prometheus/RabbitPrometheusMiddleware.md b/docs/docs/en/api/faststream/rabbit/prometheus/RabbitPrometheusMiddleware.md deleted file mode 100644 index 2c4308fabd..0000000000 --- a/docs/docs/en/api/faststream/rabbit/prometheus/RabbitPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.prometheus.RabbitPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/rabbit/prometheus/middleware/RabbitPrometheusMiddleware.md b/docs/docs/en/api/faststream/rabbit/prometheus/middleware/RabbitPrometheusMiddleware.md deleted file mode 100644 index 45163c998a..0000000000 --- a/docs/docs/en/api/faststream/rabbit/prometheus/middleware/RabbitPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.prometheus.middleware.RabbitPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/rabbit/prometheus/provider/RabbitMetricsSettingsProvider.md b/docs/docs/en/api/faststream/rabbit/prometheus/provider/RabbitMetricsSettingsProvider.md deleted file mode 100644 index 6d63301b34..0000000000 --- a/docs/docs/en/api/faststream/rabbit/prometheus/provider/RabbitMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.prometheus.provider.RabbitMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/rabbit/publisher/factory/create_publisher.md b/docs/docs/en/api/faststream/rabbit/publisher/factory/create_publisher.md deleted file mode 100644 index bac090fa43..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/factory/create_publisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.factory.create_publisher diff --git a/docs/docs/en/api/faststream/rabbit/publisher/fake/RabbitFakePublisher.md b/docs/docs/en/api/faststream/rabbit/publisher/fake/RabbitFakePublisher.md deleted file mode 100644 index 60879c8e3a..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/fake/RabbitFakePublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.fake.RabbitFakePublisher diff --git a/docs/docs/en/api/faststream/rabbit/publisher/options/MessageOptions.md b/docs/docs/en/api/faststream/rabbit/publisher/options/MessageOptions.md deleted file mode 100644 index eaa454588a..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/options/MessageOptions.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.options.MessageOptions diff --git a/docs/docs/en/api/faststream/rabbit/publisher/options/PublishOptions.md b/docs/docs/en/api/faststream/rabbit/publisher/options/PublishOptions.md deleted file mode 100644 index c80cc9e937..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/options/PublishOptions.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.options.PublishOptions diff --git a/docs/docs/en/api/faststream/rabbit/publisher/producer/AioPikaFastProducer.md b/docs/docs/en/api/faststream/rabbit/publisher/producer/AioPikaFastProducer.md deleted file mode 100644 index 527cc5604c..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/producer/AioPikaFastProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.producer.AioPikaFastProducer diff --git a/docs/docs/en/api/faststream/rabbit/publisher/producer/LockState.md b/docs/docs/en/api/faststream/rabbit/publisher/producer/LockState.md deleted file mode 100644 index 4d7b37ba46..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/producer/LockState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.producer.LockState diff --git a/docs/docs/en/api/faststream/rabbit/publisher/producer/LockUnset.md b/docs/docs/en/api/faststream/rabbit/publisher/producer/LockUnset.md deleted file mode 100644 index 95df1a10e7..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/producer/LockUnset.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.producer.LockUnset diff --git a/docs/docs/en/api/faststream/rabbit/publisher/producer/RealLock.md b/docs/docs/en/api/faststream/rabbit/publisher/producer/RealLock.md deleted file mode 100644 index 570a279a0a..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/producer/RealLock.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.producer.RealLock diff --git a/docs/docs/en/api/faststream/rabbit/publisher/specified/SpecificationPublisher.md b/docs/docs/en/api/faststream/rabbit/publisher/specified/SpecificationPublisher.md deleted file mode 100644 index 0001c99fb7..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/specified/SpecificationPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.specified.SpecificationPublisher diff --git a/docs/docs/en/api/faststream/rabbit/publisher/usecase/LogicPublisher.md b/docs/docs/en/api/faststream/rabbit/publisher/usecase/LogicPublisher.md deleted file mode 100644 index 1ef927866e..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/usecase/LogicPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.usecase.LogicPublisher diff --git a/docs/docs/en/api/faststream/rabbit/publisher/usecase/PublishKwargs.md b/docs/docs/en/api/faststream/rabbit/publisher/usecase/PublishKwargs.md deleted file mode 100644 index 3d917891cd..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/usecase/PublishKwargs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.usecase.PublishKwargs diff --git a/docs/docs/en/api/faststream/rabbit/publisher/usecase/RequestPublishKwargs.md b/docs/docs/en/api/faststream/rabbit/publisher/usecase/RequestPublishKwargs.md deleted file mode 100644 index 5668633016..0000000000 --- a/docs/docs/en/api/faststream/rabbit/publisher/usecase/RequestPublishKwargs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.publisher.usecase.RequestPublishKwargs diff --git a/docs/docs/en/api/faststream/rabbit/response/RabbitPublishCommand.md b/docs/docs/en/api/faststream/rabbit/response/RabbitPublishCommand.md deleted file mode 100644 index 4c4bb224b6..0000000000 --- a/docs/docs/en/api/faststream/rabbit/response/RabbitPublishCommand.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.response.RabbitPublishCommand diff --git a/docs/docs/en/api/faststream/rabbit/response/RabbitResponse.md b/docs/docs/en/api/faststream/rabbit/response/RabbitResponse.md deleted file mode 100644 index 477cfb9861..0000000000 --- a/docs/docs/en/api/faststream/rabbit/response/RabbitResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.response.RabbitResponse diff --git a/docs/docs/en/api/faststream/rabbit/router/RabbitPublisher.md b/docs/docs/en/api/faststream/rabbit/router/RabbitPublisher.md deleted file mode 100644 index befbec9103..0000000000 --- a/docs/docs/en/api/faststream/rabbit/router/RabbitPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.router.RabbitPublisher diff --git a/docs/docs/en/api/faststream/rabbit/router/RabbitRoute.md b/docs/docs/en/api/faststream/rabbit/router/RabbitRoute.md deleted file mode 100644 index 8e8b0fbb6c..0000000000 --- a/docs/docs/en/api/faststream/rabbit/router/RabbitRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.router.RabbitRoute diff --git a/docs/docs/en/api/faststream/rabbit/router/RabbitRouter.md b/docs/docs/en/api/faststream/rabbit/router/RabbitRouter.md deleted file mode 100644 index eff5f6169a..0000000000 --- a/docs/docs/en/api/faststream/rabbit/router/RabbitRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.router.RabbitRouter diff --git a/docs/docs/en/api/faststream/rabbit/schemas/BaseRMQInformation.md b/docs/docs/en/api/faststream/rabbit/schemas/BaseRMQInformation.md deleted file mode 100644 index 7ff32d2cd2..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/BaseRMQInformation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.BaseRMQInformation diff --git a/docs/docs/en/api/faststream/rabbit/schemas/ExchangeType.md b/docs/docs/en/api/faststream/rabbit/schemas/ExchangeType.md deleted file mode 100644 index c6c2ef8a28..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/ExchangeType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.ExchangeType diff --git a/docs/docs/en/api/faststream/rabbit/schemas/RabbitExchange.md b/docs/docs/en/api/faststream/rabbit/schemas/RabbitExchange.md deleted file mode 100644 index 4e60ed96f5..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/RabbitExchange.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.RabbitExchange diff --git a/docs/docs/en/api/faststream/rabbit/schemas/RabbitQueue.md b/docs/docs/en/api/faststream/rabbit/schemas/RabbitQueue.md deleted file mode 100644 index 947238b788..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/RabbitQueue.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.RabbitQueue diff --git a/docs/docs/en/api/faststream/rabbit/schemas/constants/ExchangeType.md b/docs/docs/en/api/faststream/rabbit/schemas/constants/ExchangeType.md deleted file mode 100644 index 11705f35ac..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/constants/ExchangeType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.constants.ExchangeType diff --git a/docs/docs/en/api/faststream/rabbit/schemas/exchange/RabbitExchange.md b/docs/docs/en/api/faststream/rabbit/schemas/exchange/RabbitExchange.md deleted file mode 100644 index ebcb211714..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/exchange/RabbitExchange.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.exchange.RabbitExchange diff --git a/docs/docs/en/api/faststream/rabbit/schemas/proto/BaseRMQInformation.md b/docs/docs/en/api/faststream/rabbit/schemas/proto/BaseRMQInformation.md deleted file mode 100644 index 1eca00071b..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/proto/BaseRMQInformation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.proto.BaseRMQInformation diff --git a/docs/docs/en/api/faststream/rabbit/schemas/queue/RabbitQueue.md b/docs/docs/en/api/faststream/rabbit/schemas/queue/RabbitQueue.md deleted file mode 100644 index 83bc15e02f..0000000000 --- a/docs/docs/en/api/faststream/rabbit/schemas/queue/RabbitQueue.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.schemas.queue.RabbitQueue diff --git a/docs/docs/en/api/faststream/rabbit/security/parse_security.md b/docs/docs/en/api/faststream/rabbit/security/parse_security.md deleted file mode 100644 index 0b19ee5ee2..0000000000 --- a/docs/docs/en/api/faststream/rabbit/security/parse_security.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.security.parse_security diff --git a/docs/docs/en/api/faststream/rabbit/subscriber/factory/create_subscriber.md b/docs/docs/en/api/faststream/rabbit/subscriber/factory/create_subscriber.md deleted file mode 100644 index 79c7082931..0000000000 --- a/docs/docs/en/api/faststream/rabbit/subscriber/factory/create_subscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.subscriber.factory.create_subscriber diff --git a/docs/docs/en/api/faststream/rabbit/subscriber/specified/SpecificationSubscriber.md b/docs/docs/en/api/faststream/rabbit/subscriber/specified/SpecificationSubscriber.md deleted file mode 100644 index 928876011d..0000000000 --- a/docs/docs/en/api/faststream/rabbit/subscriber/specified/SpecificationSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.subscriber.specified.SpecificationSubscriber diff --git a/docs/docs/en/api/faststream/rabbit/subscriber/usecase/LogicSubscriber.md b/docs/docs/en/api/faststream/rabbit/subscriber/usecase/LogicSubscriber.md deleted file mode 100644 index 56ef70dd0d..0000000000 --- a/docs/docs/en/api/faststream/rabbit/subscriber/usecase/LogicSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.subscriber.usecase.LogicSubscriber diff --git a/docs/docs/en/api/faststream/rabbit/testing/FakeProducer.md b/docs/docs/en/api/faststream/rabbit/testing/FakeProducer.md deleted file mode 100644 index 7fa3603f60..0000000000 --- a/docs/docs/en/api/faststream/rabbit/testing/FakeProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.testing.FakeProducer diff --git a/docs/docs/en/api/faststream/rabbit/testing/PatchedMessage.md b/docs/docs/en/api/faststream/rabbit/testing/PatchedMessage.md deleted file mode 100644 index f58c1140c2..0000000000 --- a/docs/docs/en/api/faststream/rabbit/testing/PatchedMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.testing.PatchedMessage diff --git a/docs/docs/en/api/faststream/rabbit/testing/TestRabbitBroker.md b/docs/docs/en/api/faststream/rabbit/testing/TestRabbitBroker.md deleted file mode 100644 index ab2c088b39..0000000000 --- a/docs/docs/en/api/faststream/rabbit/testing/TestRabbitBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.testing.TestRabbitBroker diff --git a/docs/docs/en/api/faststream/rabbit/testing/apply_pattern.md b/docs/docs/en/api/faststream/rabbit/testing/apply_pattern.md deleted file mode 100644 index 02ffd305ef..0000000000 --- a/docs/docs/en/api/faststream/rabbit/testing/apply_pattern.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.testing.apply_pattern diff --git a/docs/docs/en/api/faststream/rabbit/testing/build_message.md b/docs/docs/en/api/faststream/rabbit/testing/build_message.md deleted file mode 100644 index 296715e46a..0000000000 --- a/docs/docs/en/api/faststream/rabbit/testing/build_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.testing.build_message diff --git a/docs/docs/en/api/faststream/rabbit/utils/build_url.md b/docs/docs/en/api/faststream/rabbit/utils/build_url.md deleted file mode 100644 index ffb6555837..0000000000 --- a/docs/docs/en/api/faststream/rabbit/utils/build_url.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.utils.build_url diff --git a/docs/docs/en/api/faststream/rabbit/utils/is_routing_exchange.md b/docs/docs/en/api/faststream/rabbit/utils/is_routing_exchange.md deleted file mode 100644 index 4ef1481a69..0000000000 --- a/docs/docs/en/api/faststream/rabbit/utils/is_routing_exchange.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.rabbit.utils.is_routing_exchange diff --git a/docs/docs/en/api/faststream/redis/ListSub.md b/docs/docs/en/api/faststream/redis/ListSub.md deleted file mode 100644 index 9c97a0afcd..0000000000 --- a/docs/docs/en/api/faststream/redis/ListSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.ListSub diff --git a/docs/docs/en/api/faststream/redis/PubSub.md b/docs/docs/en/api/faststream/redis/PubSub.md deleted file mode 100644 index d2fba00014..0000000000 --- a/docs/docs/en/api/faststream/redis/PubSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.PubSub diff --git a/docs/docs/en/api/faststream/redis/RedisBroker.md b/docs/docs/en/api/faststream/redis/RedisBroker.md deleted file mode 100644 index 7275bfb60a..0000000000 --- a/docs/docs/en/api/faststream/redis/RedisBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.RedisBroker diff --git a/docs/docs/en/api/faststream/redis/RedisPublisher.md b/docs/docs/en/api/faststream/redis/RedisPublisher.md deleted file mode 100644 index 565d857810..0000000000 --- a/docs/docs/en/api/faststream/redis/RedisPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.RedisPublisher diff --git a/docs/docs/en/api/faststream/redis/RedisResponse.md b/docs/docs/en/api/faststream/redis/RedisResponse.md deleted file mode 100644 index eedecf1ea3..0000000000 --- a/docs/docs/en/api/faststream/redis/RedisResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.RedisResponse diff --git a/docs/docs/en/api/faststream/redis/RedisRoute.md b/docs/docs/en/api/faststream/redis/RedisRoute.md deleted file mode 100644 index 14b4416ed4..0000000000 --- a/docs/docs/en/api/faststream/redis/RedisRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.RedisRoute diff --git a/docs/docs/en/api/faststream/redis/RedisRouter.md b/docs/docs/en/api/faststream/redis/RedisRouter.md deleted file mode 100644 index 9b7292e703..0000000000 --- a/docs/docs/en/api/faststream/redis/RedisRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.RedisRouter diff --git a/docs/docs/en/api/faststream/redis/StreamSub.md b/docs/docs/en/api/faststream/redis/StreamSub.md deleted file mode 100644 index d1244238b6..0000000000 --- a/docs/docs/en/api/faststream/redis/StreamSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.StreamSub diff --git a/docs/docs/en/api/faststream/redis/TestApp.md b/docs/docs/en/api/faststream/redis/TestApp.md deleted file mode 100644 index ad101303af..0000000000 --- a/docs/docs/en/api/faststream/redis/TestApp.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.testing.app.TestApp diff --git a/docs/docs/en/api/faststream/redis/TestRedisBroker.md b/docs/docs/en/api/faststream/redis/TestRedisBroker.md deleted file mode 100644 index 703490c302..0000000000 --- a/docs/docs/en/api/faststream/redis/TestRedisBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.TestRedisBroker diff --git a/docs/docs/en/api/faststream/redis/broker/broker/RedisBroker.md b/docs/docs/en/api/faststream/redis/broker/broker/RedisBroker.md deleted file mode 100644 index fdc177e868..0000000000 --- a/docs/docs/en/api/faststream/redis/broker/broker/RedisBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.broker.broker.RedisBroker diff --git a/docs/docs/en/api/faststream/redis/broker/logging/RedisParamsStorage.md b/docs/docs/en/api/faststream/redis/broker/logging/RedisParamsStorage.md deleted file mode 100644 index b7d1bb680a..0000000000 --- a/docs/docs/en/api/faststream/redis/broker/logging/RedisParamsStorage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.broker.logging.RedisParamsStorage diff --git a/docs/docs/en/api/faststream/redis/broker/registrator/RedisRegistrator.md b/docs/docs/en/api/faststream/redis/broker/registrator/RedisRegistrator.md deleted file mode 100644 index 8d040533d7..0000000000 --- a/docs/docs/en/api/faststream/redis/broker/registrator/RedisRegistrator.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.broker.registrator.RedisRegistrator diff --git a/docs/docs/en/api/faststream/redis/fastapi/Context.md b/docs/docs/en/api/faststream/redis/fastapi/Context.md deleted file mode 100644 index 99bf141f5c..0000000000 --- a/docs/docs/en/api/faststream/redis/fastapi/Context.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream._internal.fastapi.context.Context diff --git a/docs/docs/en/api/faststream/redis/fastapi/RedisRouter.md b/docs/docs/en/api/faststream/redis/fastapi/RedisRouter.md deleted file mode 100644 index 7894f88728..0000000000 --- a/docs/docs/en/api/faststream/redis/fastapi/RedisRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.fastapi.RedisRouter diff --git a/docs/docs/en/api/faststream/redis/fastapi/fastapi/RedisRouter.md b/docs/docs/en/api/faststream/redis/fastapi/fastapi/RedisRouter.md deleted file mode 100644 index 858c951f61..0000000000 --- a/docs/docs/en/api/faststream/redis/fastapi/fastapi/RedisRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.fastapi.fastapi.RedisRouter diff --git a/docs/docs/en/api/faststream/redis/helpers/state/ConnectedState.md b/docs/docs/en/api/faststream/redis/helpers/state/ConnectedState.md deleted file mode 100644 index 793fdb055e..0000000000 --- a/docs/docs/en/api/faststream/redis/helpers/state/ConnectedState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.helpers.state.ConnectedState diff --git a/docs/docs/en/api/faststream/redis/helpers/state/ConnectionState.md b/docs/docs/en/api/faststream/redis/helpers/state/ConnectionState.md deleted file mode 100644 index 0a27d849dc..0000000000 --- a/docs/docs/en/api/faststream/redis/helpers/state/ConnectionState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.helpers.state.ConnectionState diff --git a/docs/docs/en/api/faststream/redis/helpers/state/EmptyConnectionState.md b/docs/docs/en/api/faststream/redis/helpers/state/EmptyConnectionState.md deleted file mode 100644 index 70273722e0..0000000000 --- a/docs/docs/en/api/faststream/redis/helpers/state/EmptyConnectionState.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.helpers.state.EmptyConnectionState diff --git a/docs/docs/en/api/faststream/redis/message/BatchListMessage.md b/docs/docs/en/api/faststream/redis/message/BatchListMessage.md deleted file mode 100644 index c510fa09b9..0000000000 --- a/docs/docs/en/api/faststream/redis/message/BatchListMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.BatchListMessage diff --git a/docs/docs/en/api/faststream/redis/message/BatchStreamMessage.md b/docs/docs/en/api/faststream/redis/message/BatchStreamMessage.md deleted file mode 100644 index 16885fd028..0000000000 --- a/docs/docs/en/api/faststream/redis/message/BatchStreamMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.BatchStreamMessage diff --git a/docs/docs/en/api/faststream/redis/message/DefaultListMessage.md b/docs/docs/en/api/faststream/redis/message/DefaultListMessage.md deleted file mode 100644 index 8f38b34cae..0000000000 --- a/docs/docs/en/api/faststream/redis/message/DefaultListMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.DefaultListMessage diff --git a/docs/docs/en/api/faststream/redis/message/DefaultStreamMessage.md b/docs/docs/en/api/faststream/redis/message/DefaultStreamMessage.md deleted file mode 100644 index 6016bb624e..0000000000 --- a/docs/docs/en/api/faststream/redis/message/DefaultStreamMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.DefaultStreamMessage diff --git a/docs/docs/en/api/faststream/redis/message/PubSubMessage.md b/docs/docs/en/api/faststream/redis/message/PubSubMessage.md deleted file mode 100644 index 795cecb12e..0000000000 --- a/docs/docs/en/api/faststream/redis/message/PubSubMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.PubSubMessage diff --git a/docs/docs/en/api/faststream/redis/message/RedisBatchListMessage.md b/docs/docs/en/api/faststream/redis/message/RedisBatchListMessage.md deleted file mode 100644 index ec7d3983bd..0000000000 --- a/docs/docs/en/api/faststream/redis/message/RedisBatchListMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.RedisBatchListMessage diff --git a/docs/docs/en/api/faststream/redis/message/RedisBatchStreamMessage.md b/docs/docs/en/api/faststream/redis/message/RedisBatchStreamMessage.md deleted file mode 100644 index 2c66613eb7..0000000000 --- a/docs/docs/en/api/faststream/redis/message/RedisBatchStreamMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.RedisBatchStreamMessage diff --git a/docs/docs/en/api/faststream/redis/message/RedisListMessage.md b/docs/docs/en/api/faststream/redis/message/RedisListMessage.md deleted file mode 100644 index 8c996cb7f0..0000000000 --- a/docs/docs/en/api/faststream/redis/message/RedisListMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.RedisListMessage diff --git a/docs/docs/en/api/faststream/redis/message/RedisMessage.md b/docs/docs/en/api/faststream/redis/message/RedisMessage.md deleted file mode 100644 index 1b0654e7ce..0000000000 --- a/docs/docs/en/api/faststream/redis/message/RedisMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.RedisMessage diff --git a/docs/docs/en/api/faststream/redis/message/RedisStreamMessage.md b/docs/docs/en/api/faststream/redis/message/RedisStreamMessage.md deleted file mode 100644 index c36385a141..0000000000 --- a/docs/docs/en/api/faststream/redis/message/RedisStreamMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.RedisStreamMessage diff --git a/docs/docs/en/api/faststream/redis/message/UnifyRedisDict.md b/docs/docs/en/api/faststream/redis/message/UnifyRedisDict.md deleted file mode 100644 index 9485ca2848..0000000000 --- a/docs/docs/en/api/faststream/redis/message/UnifyRedisDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.UnifyRedisDict diff --git a/docs/docs/en/api/faststream/redis/message/UnifyRedisMessage.md b/docs/docs/en/api/faststream/redis/message/UnifyRedisMessage.md deleted file mode 100644 index dee09d1657..0000000000 --- a/docs/docs/en/api/faststream/redis/message/UnifyRedisMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.message.UnifyRedisMessage diff --git a/docs/docs/en/api/faststream/redis/opentelemetry/RedisTelemetryMiddleware.md b/docs/docs/en/api/faststream/redis/opentelemetry/RedisTelemetryMiddleware.md deleted file mode 100644 index 537a2dc7b9..0000000000 --- a/docs/docs/en/api/faststream/redis/opentelemetry/RedisTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.opentelemetry.RedisTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/redis/opentelemetry/middleware/RedisTelemetryMiddleware.md b/docs/docs/en/api/faststream/redis/opentelemetry/middleware/RedisTelemetryMiddleware.md deleted file mode 100644 index 4c0febf261..0000000000 --- a/docs/docs/en/api/faststream/redis/opentelemetry/middleware/RedisTelemetryMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.opentelemetry.middleware.RedisTelemetryMiddleware diff --git a/docs/docs/en/api/faststream/redis/opentelemetry/provider/RedisTelemetrySettingsProvider.md b/docs/docs/en/api/faststream/redis/opentelemetry/provider/RedisTelemetrySettingsProvider.md deleted file mode 100644 index 26e7859c34..0000000000 --- a/docs/docs/en/api/faststream/redis/opentelemetry/provider/RedisTelemetrySettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.opentelemetry.provider.RedisTelemetrySettingsProvider diff --git a/docs/docs/en/api/faststream/redis/parser/RawMessage.md b/docs/docs/en/api/faststream/redis/parser/RawMessage.md deleted file mode 100644 index 4add7b37fd..0000000000 --- a/docs/docs/en/api/faststream/redis/parser/RawMessage.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.parser.RawMessage diff --git a/docs/docs/en/api/faststream/redis/parser/RedisBatchListParser.md b/docs/docs/en/api/faststream/redis/parser/RedisBatchListParser.md deleted file mode 100644 index e3a583eee8..0000000000 --- a/docs/docs/en/api/faststream/redis/parser/RedisBatchListParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.parser.RedisBatchListParser diff --git a/docs/docs/en/api/faststream/redis/parser/RedisBatchStreamParser.md b/docs/docs/en/api/faststream/redis/parser/RedisBatchStreamParser.md deleted file mode 100644 index 28ed437573..0000000000 --- a/docs/docs/en/api/faststream/redis/parser/RedisBatchStreamParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.parser.RedisBatchStreamParser diff --git a/docs/docs/en/api/faststream/redis/parser/RedisListParser.md b/docs/docs/en/api/faststream/redis/parser/RedisListParser.md deleted file mode 100644 index fd0cf87991..0000000000 --- a/docs/docs/en/api/faststream/redis/parser/RedisListParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.parser.RedisListParser diff --git a/docs/docs/en/api/faststream/redis/parser/RedisPubSubParser.md b/docs/docs/en/api/faststream/redis/parser/RedisPubSubParser.md deleted file mode 100644 index 93ab92cfdb..0000000000 --- a/docs/docs/en/api/faststream/redis/parser/RedisPubSubParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.parser.RedisPubSubParser diff --git a/docs/docs/en/api/faststream/redis/parser/RedisStreamParser.md b/docs/docs/en/api/faststream/redis/parser/RedisStreamParser.md deleted file mode 100644 index 79633d06ad..0000000000 --- a/docs/docs/en/api/faststream/redis/parser/RedisStreamParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.parser.RedisStreamParser diff --git a/docs/docs/en/api/faststream/redis/parser/SimpleParser.md b/docs/docs/en/api/faststream/redis/parser/SimpleParser.md deleted file mode 100644 index 239d3fda25..0000000000 --- a/docs/docs/en/api/faststream/redis/parser/SimpleParser.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.parser.SimpleParser diff --git a/docs/docs/en/api/faststream/redis/prometheus/RedisPrometheusMiddleware.md b/docs/docs/en/api/faststream/redis/prometheus/RedisPrometheusMiddleware.md deleted file mode 100644 index 01b23fe4f1..0000000000 --- a/docs/docs/en/api/faststream/redis/prometheus/RedisPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.prometheus.RedisPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/redis/prometheus/middleware/RedisPrometheusMiddleware.md b/docs/docs/en/api/faststream/redis/prometheus/middleware/RedisPrometheusMiddleware.md deleted file mode 100644 index c29cc91130..0000000000 --- a/docs/docs/en/api/faststream/redis/prometheus/middleware/RedisPrometheusMiddleware.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.prometheus.middleware.RedisPrometheusMiddleware diff --git a/docs/docs/en/api/faststream/redis/prometheus/provider/BaseRedisMetricsSettingsProvider.md b/docs/docs/en/api/faststream/redis/prometheus/provider/BaseRedisMetricsSettingsProvider.md deleted file mode 100644 index 243414331b..0000000000 --- a/docs/docs/en/api/faststream/redis/prometheus/provider/BaseRedisMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.prometheus.provider.BaseRedisMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/redis/prometheus/provider/BatchRedisMetricsSettingsProvider.md b/docs/docs/en/api/faststream/redis/prometheus/provider/BatchRedisMetricsSettingsProvider.md deleted file mode 100644 index 33d1d2d3a1..0000000000 --- a/docs/docs/en/api/faststream/redis/prometheus/provider/BatchRedisMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.prometheus.provider.BatchRedisMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/redis/prometheus/provider/RedisMetricsSettingsProvider.md b/docs/docs/en/api/faststream/redis/prometheus/provider/RedisMetricsSettingsProvider.md deleted file mode 100644 index a7f5f3abe8..0000000000 --- a/docs/docs/en/api/faststream/redis/prometheus/provider/RedisMetricsSettingsProvider.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.prometheus.provider.RedisMetricsSettingsProvider diff --git a/docs/docs/en/api/faststream/redis/prometheus/provider/settings_provider_factory.md b/docs/docs/en/api/faststream/redis/prometheus/provider/settings_provider_factory.md deleted file mode 100644 index aa4812f1e2..0000000000 --- a/docs/docs/en/api/faststream/redis/prometheus/provider/settings_provider_factory.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.prometheus.provider.settings_provider_factory diff --git a/docs/docs/en/api/faststream/redis/publisher/factory/create_publisher.md b/docs/docs/en/api/faststream/redis/publisher/factory/create_publisher.md deleted file mode 100644 index e568f4120a..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/factory/create_publisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.factory.create_publisher diff --git a/docs/docs/en/api/faststream/redis/publisher/fake/RedisFakePublisher.md b/docs/docs/en/api/faststream/redis/publisher/fake/RedisFakePublisher.md deleted file mode 100644 index eb00559657..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/fake/RedisFakePublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.fake.RedisFakePublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/producer/RedisFastProducer.md b/docs/docs/en/api/faststream/redis/publisher/producer/RedisFastProducer.md deleted file mode 100644 index 3bc630cc42..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/producer/RedisFastProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.producer.RedisFastProducer diff --git a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationChannelPublisher.md b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationChannelPublisher.md deleted file mode 100644 index 93b88342e4..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationChannelPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.specified.SpecificationChannelPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListBatchPublisher.md b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListBatchPublisher.md deleted file mode 100644 index c3f9769199..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListBatchPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.specified.SpecificationListBatchPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListPublisher.md b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListPublisher.md deleted file mode 100644 index a7ed630a72..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.specified.SpecificationListPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationPublisher.md b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationPublisher.md deleted file mode 100644 index ceb47b19f6..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.specified.SpecificationPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationStreamPublisher.md b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationStreamPublisher.md deleted file mode 100644 index 5800dc96da..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationStreamPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.specified.SpecificationStreamPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/usecase/ChannelPublisher.md b/docs/docs/en/api/faststream/redis/publisher/usecase/ChannelPublisher.md deleted file mode 100644 index 8aad760800..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/usecase/ChannelPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.usecase.ChannelPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/usecase/ListBatchPublisher.md b/docs/docs/en/api/faststream/redis/publisher/usecase/ListBatchPublisher.md deleted file mode 100644 index d7a1be63e4..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/usecase/ListBatchPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.usecase.ListBatchPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/usecase/ListPublisher.md b/docs/docs/en/api/faststream/redis/publisher/usecase/ListPublisher.md deleted file mode 100644 index 59895dc001..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/usecase/ListPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.usecase.ListPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/usecase/LogicPublisher.md b/docs/docs/en/api/faststream/redis/publisher/usecase/LogicPublisher.md deleted file mode 100644 index c441bcc461..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/usecase/LogicPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.usecase.LogicPublisher diff --git a/docs/docs/en/api/faststream/redis/publisher/usecase/StreamPublisher.md b/docs/docs/en/api/faststream/redis/publisher/usecase/StreamPublisher.md deleted file mode 100644 index ea56c9d699..0000000000 --- a/docs/docs/en/api/faststream/redis/publisher/usecase/StreamPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.publisher.usecase.StreamPublisher diff --git a/docs/docs/en/api/faststream/redis/response/DestinationType.md b/docs/docs/en/api/faststream/redis/response/DestinationType.md deleted file mode 100644 index 4eda1ad154..0000000000 --- a/docs/docs/en/api/faststream/redis/response/DestinationType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.response.DestinationType diff --git a/docs/docs/en/api/faststream/redis/response/RedisPublishCommand.md b/docs/docs/en/api/faststream/redis/response/RedisPublishCommand.md deleted file mode 100644 index 14e21c799e..0000000000 --- a/docs/docs/en/api/faststream/redis/response/RedisPublishCommand.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.response.RedisPublishCommand diff --git a/docs/docs/en/api/faststream/redis/response/RedisResponse.md b/docs/docs/en/api/faststream/redis/response/RedisResponse.md deleted file mode 100644 index dd7fbe72eb..0000000000 --- a/docs/docs/en/api/faststream/redis/response/RedisResponse.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.response.RedisResponse diff --git a/docs/docs/en/api/faststream/redis/router/RedisPublisher.md b/docs/docs/en/api/faststream/redis/router/RedisPublisher.md deleted file mode 100644 index fd1cad4d37..0000000000 --- a/docs/docs/en/api/faststream/redis/router/RedisPublisher.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.router.RedisPublisher diff --git a/docs/docs/en/api/faststream/redis/router/RedisRoute.md b/docs/docs/en/api/faststream/redis/router/RedisRoute.md deleted file mode 100644 index d6e1f525a7..0000000000 --- a/docs/docs/en/api/faststream/redis/router/RedisRoute.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.router.RedisRoute diff --git a/docs/docs/en/api/faststream/redis/router/RedisRouter.md b/docs/docs/en/api/faststream/redis/router/RedisRouter.md deleted file mode 100644 index 373ceea5a8..0000000000 --- a/docs/docs/en/api/faststream/redis/router/RedisRouter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.router.RedisRouter diff --git a/docs/docs/en/api/faststream/redis/schemas/ListSub.md b/docs/docs/en/api/faststream/redis/schemas/ListSub.md deleted file mode 100644 index 3e0b448229..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/ListSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.ListSub diff --git a/docs/docs/en/api/faststream/redis/schemas/PubSub.md b/docs/docs/en/api/faststream/redis/schemas/PubSub.md deleted file mode 100644 index 078a8e2d8e..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/PubSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.PubSub diff --git a/docs/docs/en/api/faststream/redis/schemas/StreamSub.md b/docs/docs/en/api/faststream/redis/schemas/StreamSub.md deleted file mode 100644 index 396e594c0b..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/StreamSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.StreamSub diff --git a/docs/docs/en/api/faststream/redis/schemas/list_sub/ListSub.md b/docs/docs/en/api/faststream/redis/schemas/list_sub/ListSub.md deleted file mode 100644 index f4b58ff4fb..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/list_sub/ListSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.list_sub.ListSub diff --git a/docs/docs/en/api/faststream/redis/schemas/proto/RedisSpecificationProtocol.md b/docs/docs/en/api/faststream/redis/schemas/proto/RedisSpecificationProtocol.md deleted file mode 100644 index de3ab92ace..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/proto/RedisSpecificationProtocol.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.proto.RedisSpecificationProtocol diff --git a/docs/docs/en/api/faststream/redis/schemas/proto/validate_options.md b/docs/docs/en/api/faststream/redis/schemas/proto/validate_options.md deleted file mode 100644 index 7a5381120e..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/proto/validate_options.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.proto.validate_options diff --git a/docs/docs/en/api/faststream/redis/schemas/pub_sub/PubSub.md b/docs/docs/en/api/faststream/redis/schemas/pub_sub/PubSub.md deleted file mode 100644 index 08552c7b8c..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/pub_sub/PubSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.pub_sub.PubSub diff --git a/docs/docs/en/api/faststream/redis/schemas/stream_sub/StreamSub.md b/docs/docs/en/api/faststream/redis/schemas/stream_sub/StreamSub.md deleted file mode 100644 index e1a8d44d4e..0000000000 --- a/docs/docs/en/api/faststream/redis/schemas/stream_sub/StreamSub.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.schemas.stream_sub.StreamSub diff --git a/docs/docs/en/api/faststream/redis/security/parse_security.md b/docs/docs/en/api/faststream/redis/security/parse_security.md deleted file mode 100644 index d3673649db..0000000000 --- a/docs/docs/en/api/faststream/redis/security/parse_security.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.security.parse_security diff --git a/docs/docs/en/api/faststream/redis/subscriber/factory/create_subscriber.md b/docs/docs/en/api/faststream/redis/subscriber/factory/create_subscriber.md deleted file mode 100644 index d5cf7eadc8..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/factory/create_subscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.factory.create_subscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationChannelSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationChannelSubscriber.md deleted file mode 100644 index 538babd05f..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationChannelSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.specified.SpecificationChannelSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListBatchSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListBatchSubscriber.md deleted file mode 100644 index 60e7fa385d..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListBatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.specified.SpecificationListBatchSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListSubscriber.md deleted file mode 100644 index 988ffccb3c..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.specified.SpecificationListSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamBatchSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamBatchSubscriber.md deleted file mode 100644 index 76a6aff457..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamBatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.specified.SpecificationStreamBatchSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamSubscriber.md deleted file mode 100644 index f1bfe8a520..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.specified.SpecificationStreamSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationSubscriber.md deleted file mode 100644 index 90a2845dc9..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.specified.SpecificationSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/usecase/BatchListSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/usecase/BatchListSubscriber.md deleted file mode 100644 index aee1b8aa9b..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/usecase/BatchListSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.usecase.BatchListSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/usecase/ChannelSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/usecase/ChannelSubscriber.md deleted file mode 100644 index 3ab1fc045a..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/usecase/ChannelSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.usecase.ChannelSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/usecase/ListSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/usecase/ListSubscriber.md deleted file mode 100644 index f7c44e8be5..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/usecase/ListSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.usecase.ListSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/usecase/LogicSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/usecase/LogicSubscriber.md deleted file mode 100644 index e3531e7dcc..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/usecase/LogicSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.usecase.LogicSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamBatchSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamBatchSubscriber.md deleted file mode 100644 index 3500cc21e2..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamBatchSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.usecase.StreamBatchSubscriber diff --git a/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamSubscriber.md b/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamSubscriber.md deleted file mode 100644 index 6e2ac31d7f..0000000000 --- a/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamSubscriber.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.subscriber.usecase.StreamSubscriber diff --git a/docs/docs/en/api/faststream/redis/testing/ChannelVisitor.md b/docs/docs/en/api/faststream/redis/testing/ChannelVisitor.md deleted file mode 100644 index f916be2ae8..0000000000 --- a/docs/docs/en/api/faststream/redis/testing/ChannelVisitor.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.testing.ChannelVisitor diff --git a/docs/docs/en/api/faststream/redis/testing/FakeProducer.md b/docs/docs/en/api/faststream/redis/testing/FakeProducer.md deleted file mode 100644 index e05efb6448..0000000000 --- a/docs/docs/en/api/faststream/redis/testing/FakeProducer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.testing.FakeProducer diff --git a/docs/docs/en/api/faststream/redis/testing/ListVisitor.md b/docs/docs/en/api/faststream/redis/testing/ListVisitor.md deleted file mode 100644 index 414b8a0400..0000000000 --- a/docs/docs/en/api/faststream/redis/testing/ListVisitor.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.testing.ListVisitor diff --git a/docs/docs/en/api/faststream/redis/testing/StreamVisitor.md b/docs/docs/en/api/faststream/redis/testing/StreamVisitor.md deleted file mode 100644 index 0b72d99109..0000000000 --- a/docs/docs/en/api/faststream/redis/testing/StreamVisitor.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.testing.StreamVisitor diff --git a/docs/docs/en/api/faststream/redis/testing/TestRedisBroker.md b/docs/docs/en/api/faststream/redis/testing/TestRedisBroker.md deleted file mode 100644 index 22946e09f8..0000000000 --- a/docs/docs/en/api/faststream/redis/testing/TestRedisBroker.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.testing.TestRedisBroker diff --git a/docs/docs/en/api/faststream/redis/testing/Visitor.md b/docs/docs/en/api/faststream/redis/testing/Visitor.md deleted file mode 100644 index 746688710f..0000000000 --- a/docs/docs/en/api/faststream/redis/testing/Visitor.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.testing.Visitor diff --git a/docs/docs/en/api/faststream/redis/testing/build_message.md b/docs/docs/en/api/faststream/redis/testing/build_message.md deleted file mode 100644 index b2265905c6..0000000000 --- a/docs/docs/en/api/faststream/redis/testing/build_message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.redis.testing.build_message diff --git a/docs/docs/en/api/faststream/response/PublishCommand.md b/docs/docs/en/api/faststream/response/PublishCommand.md deleted file mode 100644 index 8ca17ac376..0000000000 --- a/docs/docs/en/api/faststream/response/PublishCommand.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.PublishCommand diff --git a/docs/docs/en/api/faststream/response/PublishType.md b/docs/docs/en/api/faststream/response/PublishType.md deleted file mode 100644 index 57d3cbddd7..0000000000 --- a/docs/docs/en/api/faststream/response/PublishType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.PublishType diff --git a/docs/docs/en/api/faststream/response/Response.md b/docs/docs/en/api/faststream/response/Response.md deleted file mode 100644 index e96fe35896..0000000000 --- a/docs/docs/en/api/faststream/response/Response.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.Response diff --git a/docs/docs/en/api/faststream/response/ensure_response.md b/docs/docs/en/api/faststream/response/ensure_response.md deleted file mode 100644 index e55d638acf..0000000000 --- a/docs/docs/en/api/faststream/response/ensure_response.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.ensure_response diff --git a/docs/docs/en/api/faststream/response/publish_type/PublishType.md b/docs/docs/en/api/faststream/response/publish_type/PublishType.md deleted file mode 100644 index 2ac2fcd51c..0000000000 --- a/docs/docs/en/api/faststream/response/publish_type/PublishType.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.publish_type.PublishType diff --git a/docs/docs/en/api/faststream/response/response/PublishCommand.md b/docs/docs/en/api/faststream/response/response/PublishCommand.md deleted file mode 100644 index b247a7e5d8..0000000000 --- a/docs/docs/en/api/faststream/response/response/PublishCommand.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.response.PublishCommand diff --git a/docs/docs/en/api/faststream/response/response/Response.md b/docs/docs/en/api/faststream/response/response/Response.md deleted file mode 100644 index 01a68bb486..0000000000 --- a/docs/docs/en/api/faststream/response/response/Response.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.response.Response diff --git a/docs/docs/en/api/faststream/response/utils/ensure_response.md b/docs/docs/en/api/faststream/response/utils/ensure_response.md deleted file mode 100644 index 327b9ce951..0000000000 --- a/docs/docs/en/api/faststream/response/utils/ensure_response.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.response.utils.ensure_response diff --git a/docs/docs/en/api/faststream/security/BaseSecurity.md b/docs/docs/en/api/faststream/security/BaseSecurity.md deleted file mode 100644 index 0e5abb09ae..0000000000 --- a/docs/docs/en/api/faststream/security/BaseSecurity.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.security.BaseSecurity diff --git a/docs/docs/en/api/faststream/security/SASLGSSAPI.md b/docs/docs/en/api/faststream/security/SASLGSSAPI.md deleted file mode 100644 index 8b6eec2741..0000000000 --- a/docs/docs/en/api/faststream/security/SASLGSSAPI.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.security.SASLGSSAPI diff --git a/docs/docs/en/api/faststream/security/SASLOAuthBearer.md b/docs/docs/en/api/faststream/security/SASLOAuthBearer.md deleted file mode 100644 index 9652a58840..0000000000 --- a/docs/docs/en/api/faststream/security/SASLOAuthBearer.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.security.SASLOAuthBearer diff --git a/docs/docs/en/api/faststream/security/SASLPlaintext.md b/docs/docs/en/api/faststream/security/SASLPlaintext.md deleted file mode 100644 index b4b5165f27..0000000000 --- a/docs/docs/en/api/faststream/security/SASLPlaintext.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.security.SASLPlaintext diff --git a/docs/docs/en/api/faststream/security/SASLScram256.md b/docs/docs/en/api/faststream/security/SASLScram256.md deleted file mode 100644 index 4d50681fa9..0000000000 --- a/docs/docs/en/api/faststream/security/SASLScram256.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.security.SASLScram256 diff --git a/docs/docs/en/api/faststream/security/SASLScram512.md b/docs/docs/en/api/faststream/security/SASLScram512.md deleted file mode 100644 index 115645cc8c..0000000000 --- a/docs/docs/en/api/faststream/security/SASLScram512.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.security.SASLScram512 diff --git a/docs/docs/en/api/faststream/specification/AsyncAPI.md b/docs/docs/en/api/faststream/specification/AsyncAPI.md deleted file mode 100644 index 4b23e3fa4a..0000000000 --- a/docs/docs/en/api/faststream/specification/AsyncAPI.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.AsyncAPI diff --git a/docs/docs/en/api/faststream/specification/Contact.md b/docs/docs/en/api/faststream/specification/Contact.md deleted file mode 100644 index aa8ac012ea..0000000000 --- a/docs/docs/en/api/faststream/specification/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.Contact diff --git a/docs/docs/en/api/faststream/specification/ExternalDocs.md b/docs/docs/en/api/faststream/specification/ExternalDocs.md deleted file mode 100644 index 52e0432c94..0000000000 --- a/docs/docs/en/api/faststream/specification/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/License.md b/docs/docs/en/api/faststream/specification/License.md deleted file mode 100644 index ac2365f82b..0000000000 --- a/docs/docs/en/api/faststream/specification/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.License diff --git a/docs/docs/en/api/faststream/specification/Tag.md b/docs/docs/en/api/faststream/specification/Tag.md deleted file mode 100644 index ae4f1202a1..0000000000 --- a/docs/docs/en/api/faststream/specification/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.Tag diff --git a/docs/docs/en/api/faststream/specification/asyncapi/AsyncAPI.md b/docs/docs/en/api/faststream/specification/asyncapi/AsyncAPI.md deleted file mode 100644 index f6c0b2de09..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/AsyncAPI.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.AsyncAPI diff --git a/docs/docs/en/api/faststream/specification/asyncapi/factory/AsyncAPI.md b/docs/docs/en/api/faststream/specification/asyncapi/factory/AsyncAPI.md deleted file mode 100644 index 9e68cc1f6c..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/factory/AsyncAPI.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.factory.AsyncAPI diff --git a/docs/docs/en/api/faststream/specification/asyncapi/get_asyncapi_html.md b/docs/docs/en/api/faststream/specification/asyncapi/get_asyncapi_html.md deleted file mode 100644 index 02a5bf12cb..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/get_asyncapi_html.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.get_asyncapi_html diff --git a/docs/docs/en/api/faststream/specification/asyncapi/message/get_model_schema.md b/docs/docs/en/api/faststream/specification/asyncapi/message/get_model_schema.md deleted file mode 100644 index 83b5c9026e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/message/get_model_schema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.message.get_model_schema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/message/get_response_schema.md b/docs/docs/en/api/faststream/specification/asyncapi/message/get_response_schema.md deleted file mode 100644 index d283b28902..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/message/get_response_schema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.message.get_response_schema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/message/parse_handler_params.md b/docs/docs/en/api/faststream/specification/asyncapi/message/parse_handler_params.md deleted file mode 100644 index cb6c4416f8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/message/parse_handler_params.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.message.parse_handler_params diff --git a/docs/docs/en/api/faststream/specification/asyncapi/site/get_asyncapi_html.md b/docs/docs/en/api/faststream/specification/asyncapi/site/get_asyncapi_html.md deleted file mode 100644 index 837b931af7..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/site/get_asyncapi_html.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.site.get_asyncapi_html diff --git a/docs/docs/en/api/faststream/specification/asyncapi/site/serve_app.md b/docs/docs/en/api/faststream/specification/asyncapi/site/serve_app.md deleted file mode 100644 index 279e9eb8e0..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/site/serve_app.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.site.serve_app diff --git a/docs/docs/en/api/faststream/specification/asyncapi/utils/clear_key.md b/docs/docs/en/api/faststream/specification/asyncapi/utils/clear_key.md deleted file mode 100644 index cf6103d19a..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/utils/clear_key.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.utils.clear_key diff --git a/docs/docs/en/api/faststream/specification/asyncapi/utils/move_pydantic_refs.md b/docs/docs/en/api/faststream/specification/asyncapi/utils/move_pydantic_refs.md deleted file mode 100644 index 445472f96d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/utils/move_pydantic_refs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.utils.move_pydantic_refs diff --git a/docs/docs/en/api/faststream/specification/asyncapi/utils/resolve_payloads.md b/docs/docs/en/api/faststream/specification/asyncapi/utils/resolve_payloads.md deleted file mode 100644 index d92d1850f3..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/utils/resolve_payloads.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.utils.resolve_payloads diff --git a/docs/docs/en/api/faststream/specification/asyncapi/utils/to_camelcase.md b/docs/docs/en/api/faststream/specification/asyncapi/utils/to_camelcase.md deleted file mode 100644 index 5a260c9cca..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/utils/to_camelcase.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.utils.to_camelcase diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/AsyncAPI2.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/AsyncAPI2.md deleted file mode 100644 index b6ca4b870a..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/AsyncAPI2.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.AsyncAPI2 diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/facade/AsyncAPI2.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/facade/AsyncAPI2.md deleted file mode 100644 index 1807a92056..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/facade/AsyncAPI2.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.facade.AsyncAPI2 diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_app_schema.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_app_schema.md deleted file mode 100644 index ef0e191d3d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_app_schema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.generate.get_app_schema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_channels.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_channels.md deleted file mode 100644 index 03fc069dc1..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_channels.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.generate.get_broker_channels diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_server.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_server.md deleted file mode 100644 index c7b9007c14..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_server.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.generate.get_broker_server diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/resolve_channel_messages.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/resolve_channel_messages.md deleted file mode 100644 index 91abb99b8b..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/resolve_channel_messages.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.generate.resolve_channel_messages diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/get_app_schema.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/get_app_schema.md deleted file mode 100644 index 234b4b8bda..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/get_app_schema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.get_app_schema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationInfo.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationInfo.md deleted file mode 100644 index b7aaf16515..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationInfo.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.ApplicationInfo diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationSchema.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationSchema.md deleted file mode 100644 index 614fed94e1..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationSchema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.ApplicationSchema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Channel.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Channel.md deleted file mode 100644 index 76da65a973..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Channel.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Channel diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Components.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Components.md deleted file mode 100644 index 12ba1a0a30..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Components.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Components diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Contact.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Contact.md deleted file mode 100644 index 7eba14d8b1..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Contact diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/CorrelationId.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/CorrelationId.md deleted file mode 100644 index 3173309f51..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/CorrelationId.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.CorrelationId diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ExternalDocs.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ExternalDocs.md deleted file mode 100644 index 2df43d1016..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/License.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/License.md deleted file mode 100644 index 3f17b11448..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.License diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Message.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Message.md deleted file mode 100644 index f6247931d4..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Message diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Operation.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Operation.md deleted file mode 100644 index e25d0e8ff2..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Operation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Operation diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Parameter.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Parameter.md deleted file mode 100644 index fac8aa5ee7..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Parameter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Parameter diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Reference.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Reference.md deleted file mode 100644 index c469faf891..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Reference.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Reference diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Server.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Server.md deleted file mode 100644 index 82bc1ddb32..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Server.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Server diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ServerVariable.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ServerVariable.md deleted file mode 100644 index 06639f3ec5..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ServerVariable.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.ServerVariable diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Tag.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Tag.md deleted file mode 100644 index 35baa89db7..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.Tag diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/ChannelBinding.md deleted file mode 100644 index 36874fc37c..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/OperationBinding.md deleted file mode 100644 index eb11d6b550..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/ChannelBinding.md deleted file mode 100644 index 263e89f51b..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/OperationBinding.md deleted file mode 100644 index 350a96b413..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/ChannelBinding.md deleted file mode 100644 index 6b4f8d6d93..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Exchange.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Exchange.md deleted file mode 100644 index dbd3288b64..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Exchange.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp.channel.Exchange diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Queue.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Queue.md deleted file mode 100644 index 31de312529..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Queue.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp.channel.Queue diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/operation/OperationBinding.md deleted file mode 100644 index 937cda8820..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/ChannelBinding.md deleted file mode 100644 index 7792a2bef7..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.kafka.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/OperationBinding.md deleted file mode 100644 index 21c35af99f..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.kafka.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/channel/ChannelBinding.md deleted file mode 100644 index 82b2556711..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.kafka.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/operation/OperationBinding.md deleted file mode 100644 index 49e28f86ef..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.kafka.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/ChannelBinding.md deleted file mode 100644 index a044af926c..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.main.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/OperationBinding.md deleted file mode 100644 index 9cf2d46f59..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.main.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/channel/ChannelBinding.md deleted file mode 100644 index c7d4ecef03..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.main.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/operation/OperationBinding.md deleted file mode 100644 index b464bbb356..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.main.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/ChannelBinding.md deleted file mode 100644 index 8380c4571d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.nats.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/OperationBinding.md deleted file mode 100644 index c48ff3bad7..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.nats.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/channel/ChannelBinding.md deleted file mode 100644 index ebc06a51b8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.nats.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/operation/OperationBinding.md deleted file mode 100644 index 10ebc684ce..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.nats.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/ChannelBinding.md deleted file mode 100644 index 49402a3533..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.redis.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/OperationBinding.md deleted file mode 100644 index 4a41fede12..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.redis.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/channel/ChannelBinding.md deleted file mode 100644 index 4c859b133e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.redis.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/operation/OperationBinding.md deleted file mode 100644 index 5e7ef90817..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.redis.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/ChannelBinding.md deleted file mode 100644 index efd54e587e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/OperationBinding.md deleted file mode 100644 index 4f3babf6a5..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/ChannelBinding.md deleted file mode 100644 index 274f800ea8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/from_spec.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/from_spec.md deleted file mode 100644 index 6890ca0373..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/from_spec.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.channel.from_spec diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/OperationBinding.md deleted file mode 100644 index 931067bfef..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/from_spec.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/from_spec.md deleted file mode 100644 index b8a69ffcc0..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/from_spec.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.operation.from_spec diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/channels/Channel.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/channels/Channel.md deleted file mode 100644 index 520d156b96..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/channels/Channel.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.channels.Channel diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/components/Components.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/components/Components.md deleted file mode 100644 index 215edc3e69..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/components/Components.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.components.Components diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/contact/Contact.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/contact/Contact.md deleted file mode 100644 index 14b7574d92..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/contact/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.contact.Contact diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/docs/ExternalDocs.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/docs/ExternalDocs.md deleted file mode 100644 index 8b66a2c5f3..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/docs/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.docs.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/info/ApplicationInfo.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/info/ApplicationInfo.md deleted file mode 100644 index db377ddd61..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/info/ApplicationInfo.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.info.ApplicationInfo diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/license/License.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/license/License.md deleted file mode 100644 index d9d4102522..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/license/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.license.License diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/CorrelationId.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/CorrelationId.md deleted file mode 100644 index bbfc2f40d8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/CorrelationId.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.message.CorrelationId diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/Message.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/Message.md deleted file mode 100644 index 9667e77e8e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/Message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.message.Message diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/operations/Operation.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/operations/Operation.md deleted file mode 100644 index 3d750e5f3e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/operations/Operation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.operations.Operation diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/schema/ApplicationSchema.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/schema/ApplicationSchema.md deleted file mode 100644 index 2a380a8e4d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/schema/ApplicationSchema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.schema.ApplicationSchema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/Server.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/Server.md deleted file mode 100644 index a50c1a5cf1..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/Server.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.servers.Server diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/ServerVariable.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/ServerVariable.md deleted file mode 100644 index 8606288a32..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/ServerVariable.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.servers.ServerVariable diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/tag/Tag.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/tag/Tag.md deleted file mode 100644 index c3d9025966..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/tag/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.tag.Tag diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Parameter.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Parameter.md deleted file mode 100644 index c2971d5485..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Parameter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.utils.Parameter diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Reference.md b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Reference.md deleted file mode 100644 index 2737907b0e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Reference.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.utils.Reference diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/AsyncAPI3.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/AsyncAPI3.md deleted file mode 100644 index 4eb400a450..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/AsyncAPI3.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.AsyncAPI3 diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/facade/AsyncAPI3.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/facade/AsyncAPI3.md deleted file mode 100644 index 5216f86a02..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/facade/AsyncAPI3.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.facade.AsyncAPI3 diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_app_schema.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_app_schema.md deleted file mode 100644 index 0faa97ba94..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_app_schema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.generate.get_app_schema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_channels.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_channels.md deleted file mode 100644 index d43691125d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_channels.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.generate.get_broker_channels diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_server.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_server.md deleted file mode 100644 index 1c71db1292..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_server.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.generate.get_broker_server diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/get_app_schema.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/get_app_schema.md deleted file mode 100644 index 977c46289d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/get_app_schema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.get_app_schema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationInfo.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationInfo.md deleted file mode 100644 index be7a85513c..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationInfo.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.ApplicationInfo diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationSchema.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationSchema.md deleted file mode 100644 index 0f3fa28a38..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationSchema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.ApplicationSchema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Channel.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Channel.md deleted file mode 100644 index f213110586..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Channel.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.Channel diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Components.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Components.md deleted file mode 100644 index bce8d6e93e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Components.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.Components diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Contact.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Contact.md deleted file mode 100644 index 14b7574d92..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.contact.Contact diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/CorrelationId.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/CorrelationId.md deleted file mode 100644 index bbfc2f40d8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/CorrelationId.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.message.CorrelationId diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ExternalDocs.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ExternalDocs.md deleted file mode 100644 index 8b66a2c5f3..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.docs.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/License.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/License.md deleted file mode 100644 index d9d4102522..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.license.License diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Message.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Message.md deleted file mode 100644 index 9667e77e8e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.message.Message diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Operation.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Operation.md deleted file mode 100644 index a46ecefb8d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Operation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.Operation diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Parameter.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Parameter.md deleted file mode 100644 index c2971d5485..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Parameter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.utils.Parameter diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Reference.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Reference.md deleted file mode 100644 index 2737907b0e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Reference.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.utils.Reference diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Server.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Server.md deleted file mode 100644 index d41ebe84c3..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Server.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.Server diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ServerVariable.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ServerVariable.md deleted file mode 100644 index 8606288a32..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ServerVariable.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.servers.ServerVariable diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Tag.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Tag.md deleted file mode 100644 index c3d9025966..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.tag.Tag diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/ChannelBinding.md deleted file mode 100644 index ca8431218b..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/OperationBinding.md deleted file mode 100644 index 876f866f35..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/ChannelBinding.md deleted file mode 100644 index 2777001c4d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.amqp.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/OperationBinding.md deleted file mode 100644 index 325bba3f9e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.amqp.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel/ChannelBinding.md deleted file mode 100644 index 74c10098ac..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.amqp.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation/OperationBinding.md deleted file mode 100644 index 51c5024cc7..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.amqp.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/ChannelBinding.md deleted file mode 100644 index 82b2556711..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.kafka.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/OperationBinding.md deleted file mode 100644 index 49e28f86ef..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.kafka.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/ChannelBinding.md deleted file mode 100644 index 07977ed15f..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.main.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/OperationBinding.md deleted file mode 100644 index c897790951..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.main.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/channel/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/channel/ChannelBinding.md deleted file mode 100644 index 409e449a27..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/channel/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.main.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/operation/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/operation/OperationBinding.md deleted file mode 100644 index 4e85a7f5e4..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/operation/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.bindings.main.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/ChannelBinding.md deleted file mode 100644 index ebc06a51b8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.nats.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/OperationBinding.md deleted file mode 100644 index 10ebc684ce..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.nats.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/ChannelBinding.md deleted file mode 100644 index 4c859b133e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.redis.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/OperationBinding.md deleted file mode 100644 index 5e7ef90817..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.redis.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/ChannelBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/ChannelBinding.md deleted file mode 100644 index 274f800ea8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.channel.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/OperationBinding.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/OperationBinding.md deleted file mode 100644 index 931067bfef..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.bindings.sqs.operation.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/channels/Channel.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/channels/Channel.md deleted file mode 100644 index b3b425a350..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/channels/Channel.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.channels.Channel diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/components/Components.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/components/Components.md deleted file mode 100644 index db5c489f43..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/components/Components.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.components.Components diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/contact/Contact.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/contact/Contact.md deleted file mode 100644 index 14b7574d92..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/contact/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.contact.Contact diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/docs/ExternalDocs.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/docs/ExternalDocs.md deleted file mode 100644 index 8b66a2c5f3..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/docs/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.docs.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/info/ApplicationInfo.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/info/ApplicationInfo.md deleted file mode 100644 index f0c2b0f95d..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/info/ApplicationInfo.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.info.ApplicationInfo diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/license/License.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/license/License.md deleted file mode 100644 index d9d4102522..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/license/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.license.License diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/CorrelationId.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/CorrelationId.md deleted file mode 100644 index bbfc2f40d8..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/CorrelationId.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.message.CorrelationId diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/Message.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/Message.md deleted file mode 100644 index 9667e77e8e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/Message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.message.Message diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Action.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Action.md deleted file mode 100644 index c5a9956348..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Action.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.operations.Action diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Operation.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Operation.md deleted file mode 100644 index 1ac73f73da..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Operation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.operations.Operation diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/schema/ApplicationSchema.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/schema/ApplicationSchema.md deleted file mode 100644 index 57fc00568a..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/schema/ApplicationSchema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.schema.ApplicationSchema diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/servers/Server.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/servers/Server.md deleted file mode 100644 index 1d9f1168d9..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/servers/Server.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v3_0_0.schema.servers.Server diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/tag/Tag.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/tag/Tag.md deleted file mode 100644 index c3d9025966..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/tag/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.tag.Tag diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Parameter.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Parameter.md deleted file mode 100644 index c2971d5485..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Parameter.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.utils.Parameter diff --git a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Reference.md b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Reference.md deleted file mode 100644 index 2737907b0e..0000000000 --- a/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Reference.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.asyncapi.v2_6_0.schema.utils.Reference diff --git a/docs/docs/en/api/faststream/specification/base/info/BaseApplicationInfo.md b/docs/docs/en/api/faststream/specification/base/info/BaseApplicationInfo.md deleted file mode 100644 index 324bbbcec9..0000000000 --- a/docs/docs/en/api/faststream/specification/base/info/BaseApplicationInfo.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.base.info.BaseApplicationInfo diff --git a/docs/docs/en/api/faststream/specification/base/schema/BaseApplicationSchema.md b/docs/docs/en/api/faststream/specification/base/schema/BaseApplicationSchema.md deleted file mode 100644 index 8d9291322c..0000000000 --- a/docs/docs/en/api/faststream/specification/base/schema/BaseApplicationSchema.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.base.schema.BaseApplicationSchema diff --git a/docs/docs/en/api/faststream/specification/base/specification/Specification.md b/docs/docs/en/api/faststream/specification/base/specification/Specification.md deleted file mode 100644 index 0b3f07b9f7..0000000000 --- a/docs/docs/en/api/faststream/specification/base/specification/Specification.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.base.specification.Specification diff --git a/docs/docs/en/api/faststream/specification/proto/EndpointSpecification.md b/docs/docs/en/api/faststream/specification/proto/EndpointSpecification.md deleted file mode 100644 index 3d6dcee882..0000000000 --- a/docs/docs/en/api/faststream/specification/proto/EndpointSpecification.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.proto.EndpointSpecification diff --git a/docs/docs/en/api/faststream/specification/proto/ServerSpecification.md b/docs/docs/en/api/faststream/specification/proto/ServerSpecification.md deleted file mode 100644 index d49b60e512..0000000000 --- a/docs/docs/en/api/faststream/specification/proto/ServerSpecification.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.proto.ServerSpecification diff --git a/docs/docs/en/api/faststream/specification/proto/broker/ServerSpecification.md b/docs/docs/en/api/faststream/specification/proto/broker/ServerSpecification.md deleted file mode 100644 index 6bb667f707..0000000000 --- a/docs/docs/en/api/faststream/specification/proto/broker/ServerSpecification.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.proto.broker.ServerSpecification diff --git a/docs/docs/en/api/faststream/specification/proto/endpoint/EndpointSpecification.md b/docs/docs/en/api/faststream/specification/proto/endpoint/EndpointSpecification.md deleted file mode 100644 index 491c5e3e87..0000000000 --- a/docs/docs/en/api/faststream/specification/proto/endpoint/EndpointSpecification.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.proto.endpoint.EndpointSpecification diff --git a/docs/docs/en/api/faststream/specification/schema/Contact.md b/docs/docs/en/api/faststream/specification/schema/Contact.md deleted file mode 100644 index 5c95b1d99b..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.Contact diff --git a/docs/docs/en/api/faststream/specification/schema/ContactDict.md b/docs/docs/en/api/faststream/specification/schema/ContactDict.md deleted file mode 100644 index 79d9ca5fb2..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/ContactDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.ContactDict diff --git a/docs/docs/en/api/faststream/specification/schema/ExternalDocs.md b/docs/docs/en/api/faststream/specification/schema/ExternalDocs.md deleted file mode 100644 index 242418f578..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/schema/ExternalDocsDict.md b/docs/docs/en/api/faststream/specification/schema/ExternalDocsDict.md deleted file mode 100644 index 788848b13a..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/ExternalDocsDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.ExternalDocsDict diff --git a/docs/docs/en/api/faststream/specification/schema/License.md b/docs/docs/en/api/faststream/specification/schema/License.md deleted file mode 100644 index 4e321c7aab..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.License diff --git a/docs/docs/en/api/faststream/specification/schema/LicenseDict.md b/docs/docs/en/api/faststream/specification/schema/LicenseDict.md deleted file mode 100644 index 16204a3fc8..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/LicenseDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.LicenseDict diff --git a/docs/docs/en/api/faststream/specification/schema/Message.md b/docs/docs/en/api/faststream/specification/schema/Message.md deleted file mode 100644 index d1baee52f5..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/Message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.Message diff --git a/docs/docs/en/api/faststream/specification/schema/Operation.md b/docs/docs/en/api/faststream/specification/schema/Operation.md deleted file mode 100644 index cde09d402f..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/Operation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.Operation diff --git a/docs/docs/en/api/faststream/specification/schema/PublisherSpec.md b/docs/docs/en/api/faststream/specification/schema/PublisherSpec.md deleted file mode 100644 index 5b3e7f23e5..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/PublisherSpec.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.PublisherSpec diff --git a/docs/docs/en/api/faststream/specification/schema/SubscriberSpec.md b/docs/docs/en/api/faststream/specification/schema/SubscriberSpec.md deleted file mode 100644 index 7ec1f6964b..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/SubscriberSpec.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.SubscriberSpec diff --git a/docs/docs/en/api/faststream/specification/schema/Tag.md b/docs/docs/en/api/faststream/specification/schema/Tag.md deleted file mode 100644 index 03071c314f..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.Tag diff --git a/docs/docs/en/api/faststream/specification/schema/TagDict.md b/docs/docs/en/api/faststream/specification/schema/TagDict.md deleted file mode 100644 index 02f4de9c05..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/TagDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.TagDict diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/ChannelBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/ChannelBinding.md deleted file mode 100644 index cb7f566dc1..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/OperationBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/OperationBinding.md deleted file mode 100644 index 6fcad5ea7e..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/ChannelBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/ChannelBinding.md deleted file mode 100644 index 194c68f536..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.amqp.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Exchange.md b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Exchange.md deleted file mode 100644 index 355222c2bb..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Exchange.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.amqp.Exchange diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/OperationBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/OperationBinding.md deleted file mode 100644 index 6bb90ca8ae..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.amqp.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Queue.md b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Queue.md deleted file mode 100644 index 54c9493d0e..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Queue.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.amqp.Queue diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/kafka/ChannelBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/kafka/ChannelBinding.md deleted file mode 100644 index 2561bf2e72..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/kafka/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.kafka.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/kafka/OperationBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/kafka/OperationBinding.md deleted file mode 100644 index 0746cedd33..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/kafka/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.kafka.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/main/ChannelBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/main/ChannelBinding.md deleted file mode 100644 index 73bfc4bb40..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/main/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.main.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/main/OperationBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/main/OperationBinding.md deleted file mode 100644 index f4ebb70b9c..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/main/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.main.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/nats/ChannelBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/nats/ChannelBinding.md deleted file mode 100644 index 4495e21ac2..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/nats/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.nats.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/nats/OperationBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/nats/OperationBinding.md deleted file mode 100644 index fde8061b86..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/nats/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.nats.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/redis/ChannelBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/redis/ChannelBinding.md deleted file mode 100644 index 0f991824da..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/redis/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.redis.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/redis/OperationBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/redis/OperationBinding.md deleted file mode 100644 index 95e3ca446a..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/redis/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.redis.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/sqs/ChannelBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/sqs/ChannelBinding.md deleted file mode 100644 index 521a6f5560..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/sqs/ChannelBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.sqs.ChannelBinding diff --git a/docs/docs/en/api/faststream/specification/schema/bindings/sqs/OperationBinding.md b/docs/docs/en/api/faststream/specification/schema/bindings/sqs/OperationBinding.md deleted file mode 100644 index a70995cb7f..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/bindings/sqs/OperationBinding.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.bindings.sqs.OperationBinding diff --git a/docs/docs/en/api/faststream/specification/schema/extra/Contact.md b/docs/docs/en/api/faststream/specification/schema/extra/Contact.md deleted file mode 100644 index f89be2dc65..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.Contact diff --git a/docs/docs/en/api/faststream/specification/schema/extra/ContactDict.md b/docs/docs/en/api/faststream/specification/schema/extra/ContactDict.md deleted file mode 100644 index 8f20fd396d..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/ContactDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.ContactDict diff --git a/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocs.md b/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocs.md deleted file mode 100644 index a745e15910..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocsDict.md b/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocsDict.md deleted file mode 100644 index 1110d88070..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocsDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.ExternalDocsDict diff --git a/docs/docs/en/api/faststream/specification/schema/extra/License.md b/docs/docs/en/api/faststream/specification/schema/extra/License.md deleted file mode 100644 index 033374ed25..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.License diff --git a/docs/docs/en/api/faststream/specification/schema/extra/LicenseDict.md b/docs/docs/en/api/faststream/specification/schema/extra/LicenseDict.md deleted file mode 100644 index e2994e1d88..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/LicenseDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.LicenseDict diff --git a/docs/docs/en/api/faststream/specification/schema/extra/Tag.md b/docs/docs/en/api/faststream/specification/schema/extra/Tag.md deleted file mode 100644 index cc373f1528..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.Tag diff --git a/docs/docs/en/api/faststream/specification/schema/extra/TagDict.md b/docs/docs/en/api/faststream/specification/schema/extra/TagDict.md deleted file mode 100644 index c2455e5c4f..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/TagDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.TagDict diff --git a/docs/docs/en/api/faststream/specification/schema/extra/contact/Contact.md b/docs/docs/en/api/faststream/specification/schema/extra/contact/Contact.md deleted file mode 100644 index f34ea777d3..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/contact/Contact.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.contact.Contact diff --git a/docs/docs/en/api/faststream/specification/schema/extra/contact/ContactDict.md b/docs/docs/en/api/faststream/specification/schema/extra/contact/ContactDict.md deleted file mode 100644 index 17d0d774eb..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/contact/ContactDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.contact.ContactDict diff --git a/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocs.md b/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocs.md deleted file mode 100644 index bf06e4b97c..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocs.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.external_docs.ExternalDocs diff --git a/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocsDict.md b/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocsDict.md deleted file mode 100644 index cf1c76bc2b..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocsDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.external_docs.ExternalDocsDict diff --git a/docs/docs/en/api/faststream/specification/schema/extra/license/License.md b/docs/docs/en/api/faststream/specification/schema/extra/license/License.md deleted file mode 100644 index 58cb3821e7..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/license/License.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.license.License diff --git a/docs/docs/en/api/faststream/specification/schema/extra/license/LicenseDict.md b/docs/docs/en/api/faststream/specification/schema/extra/license/LicenseDict.md deleted file mode 100644 index fb8779aa39..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/license/LicenseDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.license.LicenseDict diff --git a/docs/docs/en/api/faststream/specification/schema/extra/tag/Tag.md b/docs/docs/en/api/faststream/specification/schema/extra/tag/Tag.md deleted file mode 100644 index b25a4d5cb1..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/tag/Tag.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.tag.Tag diff --git a/docs/docs/en/api/faststream/specification/schema/extra/tag/TagDict.md b/docs/docs/en/api/faststream/specification/schema/extra/tag/TagDict.md deleted file mode 100644 index 92500cc5b2..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/extra/tag/TagDict.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.extra.tag.TagDict diff --git a/docs/docs/en/api/faststream/specification/schema/message/Message.md b/docs/docs/en/api/faststream/specification/schema/message/Message.md deleted file mode 100644 index 1c2fd0ceb8..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/message/Message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.message.Message diff --git a/docs/docs/en/api/faststream/specification/schema/message/model/Message.md b/docs/docs/en/api/faststream/specification/schema/message/model/Message.md deleted file mode 100644 index f057a4e898..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/message/model/Message.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.message.model.Message diff --git a/docs/docs/en/api/faststream/specification/schema/operation/Operation.md b/docs/docs/en/api/faststream/specification/schema/operation/Operation.md deleted file mode 100644 index 23088a80f0..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/operation/Operation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.operation.Operation diff --git a/docs/docs/en/api/faststream/specification/schema/operation/model/Operation.md b/docs/docs/en/api/faststream/specification/schema/operation/model/Operation.md deleted file mode 100644 index 17c306a8ab..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/operation/model/Operation.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.operation.model.Operation diff --git a/docs/docs/en/api/faststream/specification/schema/publisher/PublisherSpec.md b/docs/docs/en/api/faststream/specification/schema/publisher/PublisherSpec.md deleted file mode 100644 index 002bc1ecb8..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/publisher/PublisherSpec.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.publisher.PublisherSpec diff --git a/docs/docs/en/api/faststream/specification/schema/subscriber/SubscriberSpec.md b/docs/docs/en/api/faststream/specification/schema/subscriber/SubscriberSpec.md deleted file mode 100644 index 5a4e4515e2..0000000000 --- a/docs/docs/en/api/faststream/specification/schema/subscriber/SubscriberSpec.md +++ /dev/null @@ -1,11 +0,0 @@ ---- -# 0.5 - API -# 2 - Release -# 3 - Contributing -# 5 - Template Page -# 10 - Default -search: - boost: 0.5 ---- - -::: faststream.specification.schema.subscriber.SubscriberSpec diff --git a/docs/docs/en/release.md b/docs/docs/en/release.md index cfe5149109..02d814d290 100644 --- a/docs/docs/en/release.md +++ b/docs/docs/en/release.md @@ -55,7 +55,7 @@ Also, thanks to [@Sehat1137](https://github.com/Sehat1137){.external-link target Well, you (community) made a new breathtaken release for us! Thanks to all of this release contributors. -Special thanks to [@Flosckow](https://github.com/Flosckow){.external-link target="_blank"}. He promores a new perfect feature - concurrent Kafka subscriber (with autocommit mode) +Special thanks to [@Flosckow](https://github.com/Flosckow){.external-link target="_blank"} . He promotes a new perfect feature - concurrent Kafka subscriber (with autocommit mode) ```python from faststream.kafka import KafkaBroker diff --git a/faststream/kafka/broker/broker.py b/faststream/kafka/broker/broker.py index 752ca5c52d..0052ab41b5 100644 --- a/faststream/kafka/broker/broker.py +++ b/faststream/kafka/broker/broker.py @@ -10,6 +10,7 @@ Optional, TypeVar, Union, + overload, ) import aiokafka @@ -41,6 +42,7 @@ from aiokafka import ConsumerRecord from aiokafka.abc import AbstractTokenProvider + from aiokafka.structs import RecordMetadata from fast_depends.dependencies import Dependant from fast_depends.library.serializer import SerializerProto from typing_extensions import TypedDict, Unpack @@ -663,76 +665,91 @@ def _subscriber_setup_extra(self) -> "AnyDict": "builder": self._connection, } + @overload + async def publish( + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[True] = False, + ) -> "asyncio.Future[RecordMetadata]": + ... + + @overload + async def publish( + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[False] = False, + ) -> "RecordMetadata": + ... + @override - async def publish( # type: ignore[override] - self, - message: Annotated[ - "SendableMessage", - Doc("Message body to send."), - ], - topic: Annotated[ - str, - Doc("Topic where the message will be published."), - ], - *, - key: Annotated[ - Union[bytes, Any, None], - Doc( - """ - A key to associate with the message. Can be used to - determine which partition to send the message to. If partition - is `None` (and producer's partitioner config is left as default), - then messages with the same key will be delivered to the same - partition (but if key is `None`, partition is chosen randomly). - Must be type `bytes`, or be serializable to bytes via configured - `key_serializer`. - """, - ), - ] = None, - partition: Annotated[ - Optional[int], - Doc( - """ - Specify a partition. If not set, the partition will be - selected using the configured `partitioner`. - """, - ), - ] = None, - timestamp_ms: Annotated[ - Optional[int], - Doc( - """ - Epoch milliseconds (from Jan 1 1970 UTC) to use as - the message timestamp. Defaults to current time. - """, - ), - ] = None, - headers: Annotated[ - Optional[dict[str, str]], - Doc("Message headers to store metainformation."), - ] = None, - correlation_id: Annotated[ - Optional[str], - Doc( - "Manual message **correlation_id** setter. " - "**correlation_id** is a useful option to trace messages.", - ), - ] = None, - reply_to: Annotated[ - str, - Doc("Reply message topic name to send response."), - ] = "", - no_confirm: Annotated[ - bool, - Doc("Do not wait for Kafka publish confirmation."), - ] = False, - ) -> "asyncio.Future": + async def publish( + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: bool = False, + ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: """Publish message directly. This method allows you to publish message in not AsyncAPI-documented way. You can use it in another frameworks applications or to publish messages from time to time. Please, use `@broker.publisher(...)` or `broker.publisher(...).publish(...)` instead in a regular way. + + Args: + message: + Message body to send. + topic: + Topic where the message will be published. + key: + A key to associate with the message. Can be used to + determine which partition to send the message to. If partition + is `None` (and producer's partitioner config is left as default), + then messages with the same key will be delivered to the same + partition (but if key is `None`, partition is chosen randomly). + Must be type `bytes`, or be serializable to bytes via configured + `key_serializer` + partition: + Specify a partition. If not set, the partition will be + selected using the configured `partitioner` + timestamp_ms: + Epoch milliseconds (from Jan 1 1970 UTC) to use as + the message timestamp. Defaults to current time. + headers: + Message headers to store metainformation. + correlation_id: + Manual message **correlation_id** setter. + **correlation_id** is a useful option to trace messages. + reply_to: + Reply message topic name to send response. + no_confirm: + Do not wait for Kafka publish confirmation. + + Returns: + `asyncio.Future[RecordMetadata]` if no_confirm = True. + `RecordMetadata` if no_confirm = False. """ cmd = KafkaPublishCommand( message, @@ -823,54 +840,68 @@ async def request( # type: ignore[override] msg: KafkaMessage = await super()._basic_request(cmd, producer=self._producer) return msg + @overload async def publish_batch( - self, - *messages: Annotated[ - "SendableMessage", - Doc("Messages bodies to send."), - ], - topic: Annotated[ - str, - Doc("Topic where the message will be published."), - ] = "", - partition: Annotated[ - Optional[int], - Doc( - """ - Specify a partition. If not set, the partition will be - selected using the configured `partitioner`. - """, - ), - ] = None, - timestamp_ms: Annotated[ - Optional[int], - Doc( - """ - Epoch milliseconds (from Jan 1 1970 UTC) to use as - the message timestamp. Defaults to current time. - """, - ), - ] = None, - headers: Annotated[ - Optional[dict[str, str]], - Doc("Messages headers to store metainformation."), - ] = None, - reply_to: Annotated[ - str, - Doc("Reply message topic name to send response."), - ] = "", - correlation_id: Annotated[ - Optional[str], - Doc( - "Manual message **correlation_id** setter. " - "**correlation_id** is a useful option to trace messages.", - ), - ] = None, - no_confirm: Annotated[ - bool, - Doc("Do not wait for Kafka publish confirmation."), - ] = False, - ) -> "asyncio.Future": + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[True] = False, + ) -> "asyncio.Future[RecordMetadata]": ... + + @overload + async def publish_batch( + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[False] = False, + ) -> "RecordMetadata": ... + + async def publish_batch( + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: bool = False, + ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: + """Args: + *messages: + Messages bodies to send. + topic: + Topic where the message will be published. + partition: + Specify a partition. If not set, the partition will be + selected using the configured `partitioner` + timestamp_ms: + Epoch milliseconds (from Jan 1 1970 UTC) to use as + the message timestamp. Defaults to current time. + headers: + Message headers to store metainformation. + reply_to: + Reply message topic name to send response. + correlation_id: + Manual message **correlation_id** setter. + **correlation_id** is a useful option to trace messages. + no_confirm: + Do not wait for Kafka publish confirmation. + + Returns: + `asyncio.Future[RecordMetadata]` if no_confirm = True. + `RecordMetadata` if no_confirm = False. + """ assert self._producer, NOT_CONNECTED_YET # nosec B101 cmd = KafkaPublishCommand( diff --git a/faststream/kafka/publisher/producer.py b/faststream/kafka/publisher/producer.py index a6574e104d..86591617e8 100644 --- a/faststream/kafka/publisher/producer.py +++ b/faststream/kafka/publisher/producer.py @@ -1,4 +1,4 @@ -from typing import TYPE_CHECKING, Any, Optional +from typing import TYPE_CHECKING, Any, Optional, Union from typing_extensions import override @@ -15,6 +15,7 @@ import asyncio from aiokafka import AIOKafkaProducer + from aiokafka.structs import RecordMetadata from faststream._internal.types import CustomCallable from faststream.kafka.response import KafkaPublishCommand @@ -58,7 +59,7 @@ def closed(self) -> bool: async def publish( # type: ignore[override] self, cmd: "KafkaPublishCommand", - ) -> "asyncio.Future": + ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: """Publish a message to a topic.""" message, content_type = encode_message(cmd.body) @@ -77,13 +78,13 @@ async def publish( # type: ignore[override] ) if not cmd.no_confirm: - await send_future + return await send_future return send_future async def publish_batch( self, cmd: "KafkaPublishCommand", - ) -> "asyncio.Future": + ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: """Publish a batch of messages to a topic.""" batch = self._producer.producer.create_batch() @@ -113,7 +114,7 @@ async def publish_batch( partition=cmd.partition, ) if not cmd.no_confirm: - await send_future + return await send_future return send_future @override diff --git a/faststream/kafka/publisher/usecase.py b/faststream/kafka/publisher/usecase.py index bedf73a6aa..3ae0f93136 100644 --- a/faststream/kafka/publisher/usecase.py +++ b/faststream/kafka/publisher/usecase.py @@ -1,5 +1,5 @@ from collections.abc import Iterable, Sequence -from typing import TYPE_CHECKING, Annotated, Any, Optional, Union +from typing import TYPE_CHECKING, Annotated, Any, Literal, Optional, Union, overload from aiokafka import ConsumerRecord from typing_extensions import Doc, override @@ -14,6 +14,8 @@ if TYPE_CHECKING: import asyncio + from aiokafka.structs import RecordMetadata + from faststream._internal.basic_types import SendableMessage from faststream._internal.types import BrokerMiddleware, PublisherMiddleware from faststream.kafka.message import KafkaMessage @@ -151,70 +153,83 @@ def __init__( self.key = key + @overload + async def publish( + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[True] = False, + ) -> "asyncio.Future[RecordMetadata]": ... + + @overload + async def publish( + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[False] = False, + ) -> "RecordMetadata": ... + @override async def publish( self, - message: Annotated[ - "SendableMessage", - Doc("Message body to send."), - ], - topic: Annotated[ - str, - Doc("Topic where the message will be published."), - ] = "", + message: "SendableMessage", + topic: str = "", *, - key: Annotated[ - Union[bytes, Any, None], - Doc( - """ - A key to associate with the message. Can be used to - determine which partition to send the message to. If partition - is `None` (and producer's partitioner config is left as default), - then messages with the same key will be delivered to the same - partition (but if key is `None`, partition is chosen randomly). - Must be type `bytes`, or be serializable to bytes via configured - `key_serializer`. - """, - ), - ] = None, - partition: Annotated[ - Optional[int], - Doc( - """ - Specify a partition. If not set, the partition will be - selected using the configured `partitioner`. - """, - ), - ] = None, - timestamp_ms: Annotated[ - Optional[int], - Doc( - """ - Epoch milliseconds (from Jan 1 1970 UTC) to use as - the message timestamp. Defaults to current time. - """, - ), - ] = None, - headers: Annotated[ - Optional[dict[str, str]], - Doc("Message headers to store metainformation."), - ] = None, - correlation_id: Annotated[ - Optional[str], - Doc( - "Manual message **correlation_id** setter. " - "**correlation_id** is a useful option to trace messages.", - ), - ] = None, - reply_to: Annotated[ - str, - Doc("Reply message topic name to send response."), - ] = "", - no_confirm: Annotated[ - bool, - Doc("Do not wait for Kafka publish confirmation."), - ] = False, - ) -> "asyncio.Future": + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: bool = False, + ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: + """Args: + message: + Message body to send. + topic: + Topic where the message will be published. + key: + A key to associate with the message. Can be used to + determine which partition to send the message to. If partition + is `None` (and producer's partitioner config is left as default), + then messages with the same key will be delivered to the same + partition (but if key is `None`, partition is chosen randomly). + Must be type `bytes`, or be serializable to bytes via configured + `key_serializer` + partition: + Specify a partition. If not set, the partition will be + selected using the configured `partitioner` + timestamp_ms: + Epoch milliseconds (from Jan 1 1970 UTC) to use as + the message timestamp. Defaults to current time. + headers: + Message headers to store metainformation. + correlation_id: + Manual message **correlation_id** setter. + **correlation_id** is a useful option to trace messages. + reply_to: + Reply message topic name to send response. + no_confirm: + Do not wait for Kafka publish confirmation. + + Returns: + `asyncio.Future[RecordMetadata]` if no_confirm = True. + `RecordMetadata` if no_confirm = False. + """ cmd = KafkaPublishCommand( message, topic=topic or self.topic, @@ -321,55 +336,70 @@ async def request( class BatchPublisher(LogicPublisher[tuple["ConsumerRecord", ...]]): + + @overload + async def publish( + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[True] = False, + ) -> "asyncio.Future[RecordMetadata]": ... + + @overload + async def publish( + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[False] = False, + ) -> "RecordMetadata": ... + @override async def publish( self, - *messages: Annotated[ - "SendableMessage", - Doc("Messages bodies to send."), - ], - topic: Annotated[ - str, - Doc("Topic where the message will be published."), - ] = "", - partition: Annotated[ - Optional[int], - Doc( - """ - Specify a partition. If not set, the partition will be - selected using the configured `partitioner`. - """, - ), - ] = None, - timestamp_ms: Annotated[ - Optional[int], - Doc( - """ - Epoch milliseconds (from Jan 1 1970 UTC) to use as - the message timestamp. Defaults to current time. - """, - ), - ] = None, - headers: Annotated[ - Optional[dict[str, str]], - Doc("Messages headers to store metainformation."), - ] = None, - reply_to: Annotated[ - str, - Doc("Reply message topic name to send response."), - ] = "", - correlation_id: Annotated[ - Optional[str], - Doc( - "Manual message **correlation_id** setter. " - "**correlation_id** is a useful option to trace messages.", - ), - ] = None, - no_confirm: Annotated[ - bool, - Doc("Do not wait for Kafka publish confirmation."), - ] = False, - ) -> "asyncio.Future": + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: bool = False, + ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: + """Args: + *messages: + Messages bodies to send. + topic: + Topic where the message will be published. + partition: + Specify a partition. If not set, the partition will be + selected using the configured `partitioner` + timestamp_ms: + Epoch milliseconds (from Jan 1 1970 UTC) to use as + the message timestamp. Defaults to current time. + headers: + Message headers to store metainformation. + reply_to: + Reply message topic name to send response. + correlation_id: + Manual message **correlation_id** setter. + **correlation_id** is a useful option to trace messages. + no_confirm: + Do not wait for Kafka publish confirmation. + + Returns: + `asyncio.Future[RecordMetadata]` if no_confirm = True. + `RecordMetadata` if no_confirm = False. + """ cmd = KafkaPublishCommand( *messages, key=None, diff --git a/tests/brokers/kafka/test_publish.py b/tests/brokers/kafka/test_publish.py index bb884c450a..e35730547f 100644 --- a/tests/brokers/kafka/test_publish.py +++ b/tests/brokers/kafka/test_publish.py @@ -2,6 +2,7 @@ from unittest.mock import Mock import pytest +from aiokafka.structs import RecordMetadata from faststream import Context from faststream.kafka import KafkaResponse @@ -25,8 +26,7 @@ async def handler(msg) -> None: async with self.patch_broker(pub_broker) as br: await br.start() - await br.publish_batch(1, "hi", topic=queue) - + record_metadata = await br.publish_batch(1, "hi", topic=queue) result, _ = await asyncio.wait( ( asyncio.create_task(msgs_queue.get()), @@ -34,6 +34,7 @@ async def handler(msg) -> None: ), timeout=3, ) + assert isinstance(record_metadata, RecordMetadata) assert {1, "hi"} == {r.result() for r in result} @@ -82,7 +83,7 @@ async def pub(m): async with self.patch_broker(pub_broker) as br: await br.start() - await br.publish("", queue + "1") + record_metadata = await br.publish("", queue + "1") result, _ = await asyncio.wait( ( @@ -91,6 +92,7 @@ async def pub(m): ), timeout=3, ) + assert isinstance(record_metadata, RecordMetadata) assert {1, "hi"} == {r.result() for r in result} @@ -133,3 +135,23 @@ async def handle_next(msg=Context("message")) -> None: body=b"1", key=b"1", ) + + @pytest.mark.asyncio() + async def test_return_future( + self, + queue: str, + mock: Mock, + ) -> None: + pub_broker = self.get_broker() + + @pub_broker.subscriber(queue) + async def handler(m) -> None: + pass + + async with self.patch_broker(pub_broker) as br: + await br.start() + + batch_record_metadata_future = await br.publish_batch(1, "hi", topic=queue, no_confirm=True) + record_metadata_future = await br.publish("", topic=queue, no_confirm=True) + assert isinstance(batch_record_metadata_future, asyncio.Future) + assert isinstance(record_metadata_future, asyncio.Future) From d1a23763e31f31868d718fccf24d00dccb2e1283 Mon Sep 17 00:00:00 2001 From: Ivan Kirpichnikov Date: Sun, 15 Dec 2024 18:54:38 +0300 Subject: [PATCH 3/9] fix type hins in faststream/specification (#1985) --- faststream/specification/asyncapi/factory.py | 4 ++-- faststream/specification/asyncapi/message.py | 2 +- .../specification/asyncapi/v2_6_0/facade.py | 4 ++-- .../v2_6_0/schema/bindings/sqs/channel.py | 11 +++++++---- .../v2_6_0/schema/bindings/sqs/operation.py | 11 +++++++---- .../asyncapi/v2_6_0/schema/contact.py | 3 ++- .../asyncapi/v2_6_0/schema/docs.py | 3 ++- .../asyncapi/v2_6_0/schema/license.py | 3 ++- .../asyncapi/v2_6_0/schema/tag.py | 3 ++- .../specification/asyncapi/v3_0_0/facade.py | 4 ++-- .../specification/asyncapi/v3_0_0/generate.py | 18 +++++++++--------- .../asyncapi/v3_0_0/schema/__init__.py | 4 +++- .../v3_0_0/schema/bindings/amqp/operation.py | 12 ++++++++---- 13 files changed, 49 insertions(+), 33 deletions(-) diff --git a/faststream/specification/asyncapi/factory.py b/faststream/specification/asyncapi/factory.py index dc263a6b52..cb3657e6fd 100644 --- a/faststream/specification/asyncapi/factory.py +++ b/faststream/specification/asyncapi/factory.py @@ -1,4 +1,4 @@ -from collections.abc import Iterable +from collections.abc import Sequence from typing import TYPE_CHECKING, Any, Literal, Optional, Union from faststream.specification.base.specification import Specification @@ -28,7 +28,7 @@ def AsyncAPI( # noqa: N802 terms_of_service: Optional["AnyHttpUrl"] = None, license: Optional[Union["License", "LicenseDict", "AnyDict"]] = None, contact: Optional[Union["Contact", "ContactDict", "AnyDict"]] = None, - tags: Iterable[Union["Tag", "TagDict", "AnyDict"]] = (), + tags: Sequence[Union["Tag", "TagDict", "AnyDict"]] = (), external_docs: Optional[ Union["ExternalDocs", "ExternalDocsDict", "AnyDict"] ] = None, diff --git a/faststream/specification/asyncapi/message.py b/faststream/specification/asyncapi/message.py index 187cc70af0..9c4e30d1e2 100644 --- a/faststream/specification/asyncapi/message.py +++ b/faststream/specification/asyncapi/message.py @@ -18,7 +18,7 @@ def parse_handler_params(call: "CallModel", prefix: str = "") -> AnyDict: """Parses the handler parameters.""" - model = getattr(call, "serializer", call).model + model = getattr(call, "serializer", call).model # type: ignore[union-attr] assert model # nosec B101 body = get_model_schema( diff --git a/faststream/specification/asyncapi/v2_6_0/facade.py b/faststream/specification/asyncapi/v2_6_0/facade.py index d8c4b5618b..f70f071c37 100644 --- a/faststream/specification/asyncapi/v2_6_0/facade.py +++ b/faststream/specification/asyncapi/v2_6_0/facade.py @@ -1,4 +1,4 @@ -from collections.abc import Iterable +from collections.abc import Sequence from typing import TYPE_CHECKING, Any, Optional, Union from faststream.specification.base.specification import Specification @@ -34,7 +34,7 @@ def __init__( contact: Optional[Union["Contact", "ContactDict", "AnyDict"]] = None, license: Optional[Union["License", "LicenseDict", "AnyDict"]] = None, identifier: Optional[str] = None, - tags: Iterable[Union["Tag", "TagDict", "AnyDict"]] = (), + tags: Sequence[Union["Tag", "TagDict", "AnyDict"]] = (), external_docs: Optional[ Union["ExternalDocs", "ExternalDocsDict", "AnyDict"] ] = None, diff --git a/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel.py b/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel.py index 93a1c5ac80..3145805c65 100644 --- a/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel.py +++ b/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel.py @@ -22,12 +22,15 @@ class ChannelBinding(BaseModel): bindingVersion: str = "custom" @classmethod - def from_spec(cls, binding: sqs.ChannelBinding) -> Self: + def from_pub(cls, binding: sqs.ChannelBinding) -> Self: return cls( queue=binding.queue, bindingVersion=binding.bindingVersion, ) - -def from_spec(binding: sqs.ChannelBinding) -> ChannelBinding: - return ChannelBinding.from_spec(binding) + @classmethod + def from_sub(cls, binding: sqs.ChannelBinding) -> Self: + return cls( + queue=binding.queue, + bindingVersion=binding.bindingVersion, + ) diff --git a/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation.py b/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation.py index 35aa598d20..dca688bf95 100644 --- a/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation.py +++ b/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation.py @@ -24,12 +24,15 @@ class OperationBinding(BaseModel): bindingVersion: str = "custom" @classmethod - def from_spec(cls, binding: sqs.OperationBinding) -> Self: + def from_pub(cls, binding: sqs.OperationBinding) -> Self: return cls( replyTo=binding.replyTo, bindingVersion=binding.bindingVersion, ) - -def from_spec(binding: sqs.OperationBinding) -> OperationBinding: - return OperationBinding.from_spec(binding) + @classmethod + def from_sub(cls, binding: sqs.OperationBinding) -> Self: + return cls( + replyTo=binding.replyTo, + bindingVersion=binding.bindingVersion, + ) diff --git a/faststream/specification/asyncapi/v2_6_0/schema/contact.py b/faststream/specification/asyncapi/v2_6_0/schema/contact.py index 9456d7dd61..da07f90910 100644 --- a/faststream/specification/asyncapi/v2_6_0/schema/contact.py +++ b/faststream/specification/asyncapi/v2_6_0/schema/contact.py @@ -1,4 +1,4 @@ -from typing import Optional, Union, overload +from typing import Optional, Union, cast, overload from pydantic import AnyHttpUrl, BaseModel from typing_extensions import Self @@ -64,6 +64,7 @@ def from_spec( email=contact.email, ) + contact = cast(AnyDict, contact) contact_data, custom_data = filter_by_dict(ContactDict, contact) if custom_data: diff --git a/faststream/specification/asyncapi/v2_6_0/schema/docs.py b/faststream/specification/asyncapi/v2_6_0/schema/docs.py index 6ad8d6a252..5bf8ebb458 100644 --- a/faststream/specification/asyncapi/v2_6_0/schema/docs.py +++ b/faststream/specification/asyncapi/v2_6_0/schema/docs.py @@ -1,4 +1,4 @@ -from typing import Optional, Union, overload +from typing import Optional, Union, cast, overload from pydantic import AnyHttpUrl, BaseModel from typing_extensions import Self @@ -58,6 +58,7 @@ def from_spec( if isinstance(docs, SpecDocs): return cls(url=docs.url, description=docs.description) + docs = cast(AnyDict, docs) docs_data, custom_data = filter_by_dict(ExternalDocsDict, docs) if custom_data: diff --git a/faststream/specification/asyncapi/v2_6_0/schema/license.py b/faststream/specification/asyncapi/v2_6_0/schema/license.py index 1d3b778d8e..a713b75fe4 100644 --- a/faststream/specification/asyncapi/v2_6_0/schema/license.py +++ b/faststream/specification/asyncapi/v2_6_0/schema/license.py @@ -1,4 +1,4 @@ -from typing import Optional, Union, overload +from typing import Optional, Union, cast, overload from pydantic import AnyHttpUrl, BaseModel from typing_extensions import Self @@ -64,6 +64,7 @@ def from_spec( url=license.url, ) + license = cast(AnyDict, license) license_data, custom_data = filter_by_dict(LicenseDict, license) if custom_data: diff --git a/faststream/specification/asyncapi/v2_6_0/schema/tag.py b/faststream/specification/asyncapi/v2_6_0/schema/tag.py index a4fdae8d8d..ba2ac8e17f 100644 --- a/faststream/specification/asyncapi/v2_6_0/schema/tag.py +++ b/faststream/specification/asyncapi/v2_6_0/schema/tag.py @@ -1,4 +1,4 @@ -from typing import Optional, Union, overload +from typing import Optional, Union, cast, overload from pydantic import BaseModel from typing_extensions import Self @@ -56,6 +56,7 @@ def from_spec(cls, tag: Union[SpecTag, TagDict, AnyDict]) -> Union[Self, AnyDict externalDocs=ExternalDocs.from_spec(tag.external_docs), ) + tag = cast(AnyDict, tag) tag_data, custom_data = filter_by_dict(TagDict, tag) if custom_data: diff --git a/faststream/specification/asyncapi/v3_0_0/facade.py b/faststream/specification/asyncapi/v3_0_0/facade.py index 4ce47b6f90..36276e5327 100644 --- a/faststream/specification/asyncapi/v3_0_0/facade.py +++ b/faststream/specification/asyncapi/v3_0_0/facade.py @@ -1,4 +1,4 @@ -from collections.abc import Iterable +from collections.abc import Sequence from typing import TYPE_CHECKING, Any, Optional, Union from faststream.specification.base.specification import Specification @@ -34,7 +34,7 @@ def __init__( contact: Optional[Union["Contact", "ContactDict", "AnyDict"]] = None, license: Optional[Union["License", "LicenseDict", "AnyDict"]] = None, identifier: Optional[str] = None, - tags: Iterable[Union["Tag", "TagDict", "AnyDict"]] = (), + tags: Sequence[Union["Tag", "TagDict", "AnyDict"]] = (), external_docs: Optional[ Union["ExternalDocs", "ExternalDocsDict", "AnyDict"] ] = None, diff --git a/faststream/specification/asyncapi/v3_0_0/generate.py b/faststream/specification/asyncapi/v3_0_0/generate.py index 1efc8c4fdc..ddd2026e3b 100644 --- a/faststream/specification/asyncapi/v3_0_0/generate.py +++ b/faststream/specification/asyncapi/v3_0_0/generate.py @@ -87,7 +87,7 @@ def get_app_schema( termsOfService=terms_of_service, contact=Contact.from_spec(contact), license=License.from_spec(license), - tags=[Tag.from_spec(tag) for tag in tags] or None, + tags=[Tag.from_spec(tag) for tag in tags] or None if tags else None, externalDocs=ExternalDocs.from_spec(external_docs), ), asyncapi=schema_version, @@ -153,10 +153,10 @@ def get_broker_channels( operations = {} for sub in broker._subscribers: - for key, channel in sub.schema().items(): - channel_obj = Channel.from_sub(key, channel) + for sub_key, sub_channel in sub.schema().items(): + channel_obj = Channel.from_sub(sub_key, sub_channel) - channel_key = clear_key(key) + channel_key = clear_key(sub_key) # TODO: add duplication key warning channels[channel_key] = channel_obj @@ -168,14 +168,14 @@ def get_broker_channels( for msg_name in channel_obj.messages ], channel=Reference(**{"$ref": f"#/channels/{channel_key}"}), - operation=channel.operation, + operation=sub_channel.operation, ) for pub in broker._publishers: - for key, channel in pub.schema().items(): - channel_obj = Channel.from_pub(key, channel) + for pub_key, pub_channel in pub.schema().items(): + channel_obj = Channel.from_pub(pub_key, pub_channel) - channel_key = clear_key(key) + channel_key = clear_key(pub_key) # TODO: add duplication key warning channels[channel_key] = channel_obj @@ -187,7 +187,7 @@ def get_broker_channels( for msg_name in channel_obj.messages ], channel=Reference(**{"$ref": f"#/channels/{channel_key}"}), - operation=channel.operation, + operation=pub_channel.operation, ) return channels, operations diff --git a/faststream/specification/asyncapi/v3_0_0/schema/__init__.py b/faststream/specification/asyncapi/v3_0_0/schema/__init__.py index e0cbcbd7b2..7b5c98ae62 100644 --- a/faststream/specification/asyncapi/v3_0_0/schema/__init__.py +++ b/faststream/specification/asyncapi/v3_0_0/schema/__init__.py @@ -1,3 +1,5 @@ +from faststream.specification.asyncapi.v2_6_0.schema import ServerVariable + from .channels import Channel from .components import Components from .contact import Contact @@ -7,7 +9,7 @@ from .message import CorrelationId, Message from .operations import Operation from .schema import ApplicationSchema -from .servers import Server, ServerVariable +from .servers import Server from .tag import Tag from .utils import Parameter, Reference diff --git a/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation.py b/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation.py index 77ba8356a0..d6f95b68e8 100644 --- a/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation.py +++ b/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation.py @@ -5,16 +5,20 @@ from typing import Optional +from pydantic import BaseModel, PositiveInt from typing_extensions import Self -from faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp import ( - OperationBinding as V2Binding, -) from faststream.specification.schema.bindings import amqp -class OperationBinding(V2Binding): +class OperationBinding(BaseModel): cc: Optional[list[str]] = None + ack: bool + replyTo: Optional[str] = None + deliveryMode: Optional[int] = None + mandatory: Optional[bool] = None + priority: Optional[PositiveInt] = None + bindingVersion: str = "0.3.0" @classmethod From d9586553d48062d903e54ca0628b14e16e3aa249 Mon Sep 17 00:00:00 2001 From: Nikita Pastukhov Date: Sun, 15 Dec 2024 19:04:19 +0300 Subject: [PATCH 4/9] chore: polish types --- faststream/kafka/broker/broker.py | 130 +++++++++--------- faststream/kafka/publisher/producer.py | 2 +- faststream/kafka/publisher/state.py | 6 +- faststream/kafka/publisher/usecase.py | 89 ++++++------ faststream/specification/asyncapi/message.py | 4 +- .../specification/asyncapi/v2_6_0/facade.py | 2 +- .../specification/asyncapi/v3_0_0/facade.py | 2 +- .../asyncapi/v3_0_0/schema/__init__.py | 4 +- .../asyncapi/v3_0_0/schema/servers.py | 6 + .../specification/base/specification.py | 5 +- tests/brokers/kafka/test_publish.py | 4 +- 11 files changed, 135 insertions(+), 119 deletions(-) diff --git a/faststream/kafka/broker/broker.py b/faststream/kafka/broker/broker.py index 0052ab41b5..0ba6b7d75a 100644 --- a/faststream/kafka/broker/broker.py +++ b/faststream/kafka/broker/broker.py @@ -667,49 +667,47 @@ def _subscriber_setup_extra(self) -> "AnyDict": @overload async def publish( - self, - message: "SendableMessage", - topic: str = "", - *, - key: Union[bytes, Any, None] = None, - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - correlation_id: Optional[str] = None, - reply_to: str = "", - no_confirm: Literal[True] = False, - ) -> "asyncio.Future[RecordMetadata]": - ... + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[True], + ) -> "asyncio.Future[RecordMetadata]": ... @overload async def publish( - self, - message: "SendableMessage", - topic: str = "", - *, - key: Union[bytes, Any, None] = None, - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - correlation_id: Optional[str] = None, - reply_to: str = "", - no_confirm: Literal[False] = False, - ) -> "RecordMetadata": - ... + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[False] = False, + ) -> "RecordMetadata": ... @override async def publish( - self, - message: "SendableMessage", - topic: str = "", - *, - key: Union[bytes, Any, None] = None, - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - correlation_id: Optional[str] = None, - reply_to: str = "", - no_confirm: bool = False, + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: bool = False, ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: """Publish message directly. @@ -842,42 +840,44 @@ async def request( # type: ignore[override] @overload async def publish_batch( - self, - *messages: "SendableMessage", - topic: str = "", - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - reply_to: str = "", - correlation_id: Optional[str] = None, - no_confirm: Literal[True] = False, + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[True], ) -> "asyncio.Future[RecordMetadata]": ... @overload async def publish_batch( - self, - *messages: "SendableMessage", - topic: str = "", - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - reply_to: str = "", - correlation_id: Optional[str] = None, - no_confirm: Literal[False] = False, + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[False] = False, ) -> "RecordMetadata": ... async def publish_batch( - self, - *messages: "SendableMessage", - topic: str = "", - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - reply_to: str = "", - correlation_id: Optional[str] = None, - no_confirm: bool = False, + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: bool = False, ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: - """Args: + """Publish a message batch as a single request to broker. + + Args: *messages: Messages bodies to send. topic: diff --git a/faststream/kafka/publisher/producer.py b/faststream/kafka/publisher/producer.py index 86591617e8..bdd8d3677c 100644 --- a/faststream/kafka/publisher/producer.py +++ b/faststream/kafka/publisher/producer.py @@ -48,7 +48,7 @@ async def disconnect(self) -> None: await self._producer.stop() self._producer = EmptyProducerState() - def __bool__(self) -> None: + def __bool__(self) -> bool: return bool(self._producer) @property diff --git a/faststream/kafka/publisher/state.py b/faststream/kafka/publisher/state.py index 3094cf02c1..397967c696 100644 --- a/faststream/kafka/publisher/state.py +++ b/faststream/kafka/publisher/state.py @@ -1,3 +1,4 @@ +from abc import abstractmethod from typing import TYPE_CHECKING, Protocol from faststream.exceptions import IncorrectState @@ -8,7 +9,10 @@ class ProducerState(Protocol): producer: "AIOKafkaProducer" - closed: bool + + @property + @abstractmethod + def closed(self) -> bool: ... def __bool__(self) -> bool: ... diff --git a/faststream/kafka/publisher/usecase.py b/faststream/kafka/publisher/usecase.py index 3ae0f93136..a715342e9d 100644 --- a/faststream/kafka/publisher/usecase.py +++ b/faststream/kafka/publisher/usecase.py @@ -155,32 +155,32 @@ def __init__( @overload async def publish( - self, - message: "SendableMessage", - topic: str = "", - *, - key: Union[bytes, Any, None] = None, - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - correlation_id: Optional[str] = None, - reply_to: str = "", - no_confirm: Literal[True] = False, + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[True], ) -> "asyncio.Future[RecordMetadata]": ... @overload async def publish( - self, - message: "SendableMessage", - topic: str = "", - *, - key: Union[bytes, Any, None] = None, - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - correlation_id: Optional[str] = None, - reply_to: str = "", - no_confirm: Literal[False] = False, + self, + message: "SendableMessage", + topic: str = "", + *, + key: Union[bytes, Any, None] = None, + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + correlation_id: Optional[str] = None, + reply_to: str = "", + no_confirm: Literal[False] = False, ) -> "RecordMetadata": ... @override @@ -197,7 +197,9 @@ async def publish( reply_to: str = "", no_confirm: bool = False, ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: - """Args: + """Publishes a message to Kafka. + + Args: message: Message body to send. topic: @@ -336,31 +338,30 @@ async def request( class BatchPublisher(LogicPublisher[tuple["ConsumerRecord", ...]]): - @overload async def publish( - self, - *messages: "SendableMessage", - topic: str = "", - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - reply_to: str = "", - correlation_id: Optional[str] = None, - no_confirm: Literal[True] = False, + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[True], ) -> "asyncio.Future[RecordMetadata]": ... @overload async def publish( - self, - *messages: "SendableMessage", - topic: str = "", - partition: Optional[int] = None, - timestamp_ms: Optional[int] = None, - headers: Optional[dict[str, str]] = None, - reply_to: str = "", - correlation_id: Optional[str] = None, - no_confirm: Literal[False] = False, + self, + *messages: "SendableMessage", + topic: str = "", + partition: Optional[int] = None, + timestamp_ms: Optional[int] = None, + headers: Optional[dict[str, str]] = None, + reply_to: str = "", + correlation_id: Optional[str] = None, + no_confirm: Literal[False] = False, ) -> "RecordMetadata": ... @override @@ -375,7 +376,9 @@ async def publish( correlation_id: Optional[str] = None, no_confirm: bool = False, ) -> Union["asyncio.Future[RecordMetadata]", "RecordMetadata"]: - """Args: + """Publish a message batch as a single request to broker. + + Args: *messages: Messages bodies to send. topic: diff --git a/faststream/specification/asyncapi/message.py b/faststream/specification/asyncapi/message.py index 9c4e30d1e2..fe692d7085 100644 --- a/faststream/specification/asyncapi/message.py +++ b/faststream/specification/asyncapi/message.py @@ -18,11 +18,11 @@ def parse_handler_params(call: "CallModel", prefix: str = "") -> AnyDict: """Parses the handler parameters.""" - model = getattr(call, "serializer", call).model # type: ignore[union-attr] + model = getattr(call, "serializer", call).model assert model # nosec B101 body = get_model_schema( - create_model( # type: ignore[call-overload] + create_model( model.__name__, **{p.field_name: (p.field_type, p.default_value) for p in call.flat_params}, ), diff --git a/faststream/specification/asyncapi/v2_6_0/facade.py b/faststream/specification/asyncapi/v2_6_0/facade.py index f70f071c37..fcb3f66f38 100644 --- a/faststream/specification/asyncapi/v2_6_0/facade.py +++ b/faststream/specification/asyncapi/v2_6_0/facade.py @@ -61,7 +61,7 @@ def to_yaml(self) -> str: return self.schema.to_yaml() @property - def schema(self) -> ApplicationSchema: # type: ignore[override] + def schema(self) -> ApplicationSchema: return get_app_schema( self.broker, title=self.title, diff --git a/faststream/specification/asyncapi/v3_0_0/facade.py b/faststream/specification/asyncapi/v3_0_0/facade.py index 36276e5327..31542ab11b 100644 --- a/faststream/specification/asyncapi/v3_0_0/facade.py +++ b/faststream/specification/asyncapi/v3_0_0/facade.py @@ -61,7 +61,7 @@ def to_yaml(self) -> str: return self.schema.to_yaml() @property - def schema(self) -> ApplicationSchema: # type: ignore[override] + def schema(self) -> ApplicationSchema: return get_app_schema( self.broker, title=self.title, diff --git a/faststream/specification/asyncapi/v3_0_0/schema/__init__.py b/faststream/specification/asyncapi/v3_0_0/schema/__init__.py index 7b5c98ae62..e0cbcbd7b2 100644 --- a/faststream/specification/asyncapi/v3_0_0/schema/__init__.py +++ b/faststream/specification/asyncapi/v3_0_0/schema/__init__.py @@ -1,5 +1,3 @@ -from faststream.specification.asyncapi.v2_6_0.schema import ServerVariable - from .channels import Channel from .components import Components from .contact import Contact @@ -9,7 +7,7 @@ from .message import CorrelationId, Message from .operations import Operation from .schema import ApplicationSchema -from .servers import Server +from .servers import Server, ServerVariable from .tag import Tag from .utils import Parameter, Reference diff --git a/faststream/specification/asyncapi/v3_0_0/schema/servers.py b/faststream/specification/asyncapi/v3_0_0/schema/servers.py index 5951d7935b..902ebc8f9f 100644 --- a/faststream/specification/asyncapi/v3_0_0/schema/servers.py +++ b/faststream/specification/asyncapi/v3_0_0/schema/servers.py @@ -10,6 +10,12 @@ SecurityRequirement = list[dict[str, list[str]]] +__all__ = ( + "Server", + "ServerVariable", +) + + class Server(BaseModel): """A class to represent a server. diff --git a/faststream/specification/base/specification.py b/faststream/specification/base/specification.py index 0c3946e76f..e8e674b25e 100644 --- a/faststream/specification/base/specification.py +++ b/faststream/specification/base/specification.py @@ -1,3 +1,4 @@ +from abc import abstractmethod from typing import Any, Protocol, runtime_checkable from .schema import BaseApplicationSchema @@ -5,7 +6,9 @@ @runtime_checkable class Specification(Protocol): - schema: BaseApplicationSchema + @property + @abstractmethod + def schema(self) -> BaseApplicationSchema: ... def to_json(self) -> str: return self.schema.to_json() diff --git a/tests/brokers/kafka/test_publish.py b/tests/brokers/kafka/test_publish.py index e35730547f..2ad86210ee 100644 --- a/tests/brokers/kafka/test_publish.py +++ b/tests/brokers/kafka/test_publish.py @@ -151,7 +151,9 @@ async def handler(m) -> None: async with self.patch_broker(pub_broker) as br: await br.start() - batch_record_metadata_future = await br.publish_batch(1, "hi", topic=queue, no_confirm=True) + batch_record_metadata_future = await br.publish_batch( + 1, "hi", topic=queue, no_confirm=True + ) record_metadata_future = await br.publish("", topic=queue, no_confirm=True) assert isinstance(batch_record_metadata_future, asyncio.Future) assert isinstance(record_metadata_future, asyncio.Future) From 2bb82c249d7637493347271581d576f60e6687d3 Mon Sep 17 00:00:00 2001 From: Nikita Pastukhov Date: Sun, 15 Dec 2024 21:01:49 +0300 Subject: [PATCH 5/9] lint: fix top-level mypy --- faststream/asgi/app.py | 2 +- faststream/message/message.py | 6 +++--- 2 files changed, 4 insertions(+), 4 deletions(-) diff --git a/faststream/asgi/app.py b/faststream/asgi/app.py index 4cbaae0e64..33ffec16d7 100644 --- a/faststream/asgi/app.py +++ b/faststream/asgi/app.py @@ -172,7 +172,7 @@ async def run( config = uvicorn.Config( app=self, log_level=log_level, - **{ + **{ # type: ignore[arg-type] key: v for key, v in run_extra_options.items() if key in uvicorn_config_params diff --git a/faststream/message/message.py b/faststream/message/message.py index a7db6f895d..2037e7dc98 100644 --- a/faststream/message/message.py +++ b/faststream/message/message.py @@ -12,7 +12,7 @@ from .source_type import SourceType if TYPE_CHECKING: - from faststream._internal.basic_types import AnyDict, DecodedMessage + from faststream._internal.basic_types import AnyDict from faststream._internal.types import AsyncCallable # prevent circular imports @@ -74,7 +74,7 @@ def __repr__(self) -> str: filter( bool, ( - f"body={self.body}", + f"body={self.body!r}", f"content_type={self.content_type}", f"message_id={self.message_id}", f"correlation_id={self.correlation_id}", @@ -89,7 +89,7 @@ def __repr__(self) -> str: return f"{self.__class__.__name__}({inner})" - async def decode(self) -> Optional["DecodedMessage"]: + async def decode(self) -> Optional["Any"]: """Serialize the message by lazy decoder. Returns a cache after first usage. To prevent such behavior, please call From c7f4bc38e66a560a3b2052d76e497139ed6df6d6 Mon Sep 17 00:00:00 2001 From: Nikita Pastukhov Date: Sun, 15 Dec 2024 22:00:51 +0300 Subject: [PATCH 6/9] lint: fix rabbit otel & prometheus mypy --- faststream/_internal/types.py | 14 +++++++++++-- faststream/middlewares/base.py | 22 +++++++-------------- faststream/opentelemetry/middleware.py | 18 ++++++++--------- faststream/opentelemetry/provider.py | 18 +++++++++++++---- faststream/prometheus/middleware.py | 21 +++++++++++--------- faststream/prometheus/provider.py | 16 ++++++++++++--- faststream/rabbit/opentelemetry/provider.py | 6 ++++-- faststream/rabbit/prometheus/provider.py | 8 +++++--- 8 files changed, 76 insertions(+), 47 deletions(-) diff --git a/faststream/_internal/types.py b/faststream/_internal/types.py index b90aad9cd1..5aa5c1d63a 100644 --- a/faststream/_internal/types.py +++ b/faststream/_internal/types.py @@ -8,7 +8,11 @@ Union, ) -from typing_extensions import ParamSpec, TypeAlias +from typing_extensions import ( + ParamSpec, + TypeAlias, + TypeVar as TypeVar313, +) from faststream._internal.basic_types import AsyncFuncAny from faststream._internal.context.repository import ContextRepo @@ -21,7 +25,6 @@ StreamMsg = TypeVar("StreamMsg", bound=StreamMessage[Any]) ConnectionType = TypeVar("ConnectionType") - SyncFilter: TypeAlias = Callable[[StreamMsg], bool] AsyncFilter: TypeAlias = Callable[[StreamMsg], Awaitable[bool]] Filter: TypeAlias = Union[ @@ -82,6 +85,13 @@ def __call__( ] +PublishCommandType = TypeVar313( + "PublishCommandType", + bound=PublishCommand, + default=PublishCommand, +) + + class PublisherMiddleware(Protocol): """Publisher middleware interface.""" diff --git a/faststream/middlewares/base.py b/faststream/middlewares/base.py index 9604d7b5da..ca78b03ad1 100644 --- a/faststream/middlewares/base.py +++ b/faststream/middlewares/base.py @@ -1,10 +1,9 @@ from collections.abc import Awaitable from typing import TYPE_CHECKING, Any, Callable, Generic, Optional -# We should use typing_extensions.TypeVar until python3.13 due default -from typing_extensions import Self, TypeVar +from typing_extensions import Self -from faststream.response.response import PublishCommand +from faststream._internal.types import PublishCommandType if TYPE_CHECKING: from types import TracebackType @@ -14,14 +13,7 @@ from faststream.message import StreamMessage -PublishCommand_T = TypeVar( - "PublishCommand_T", - bound=PublishCommand, - default=PublishCommand, -) - - -class BaseMiddleware(Generic[PublishCommand_T]): +class BaseMiddleware(Generic[PublishCommandType]): """A base middleware class.""" def __init__( @@ -92,8 +84,8 @@ async def consume_scope( async def on_publish( self, - msg: PublishCommand_T, - ) -> PublishCommand_T: + msg: PublishCommandType, + ) -> PublishCommandType: """This option was deprecated and will be removed in 0.6.10. Please, use `publish_scope` instead.""" return msg @@ -107,8 +99,8 @@ async def after_publish( async def publish_scope( self, - call_next: Callable[[PublishCommand_T], Awaitable[Any]], - cmd: PublishCommand_T, + call_next: Callable[[PublishCommandType], Awaitable[Any]], + cmd: PublishCommandType, ) -> Any: """Publish a message and return an async iterator.""" err: Optional[Exception] = None diff --git a/faststream/opentelemetry/middleware.py b/faststream/opentelemetry/middleware.py index 247bd4ff75..42e323c85a 100644 --- a/faststream/opentelemetry/middleware.py +++ b/faststream/opentelemetry/middleware.py @@ -10,7 +10,8 @@ from opentelemetry.trace import Link, Span from opentelemetry.trace.propagation.tracecontext import TraceContextTextMapPropagator -from faststream.middlewares.base import BaseMiddleware, PublishCommand_T +from faststream._internal.types import PublishCommandType +from faststream.middlewares.base import BaseMiddleware from faststream.opentelemetry.baggage import Baggage from faststream.opentelemetry.consts import ( ERROR_TYPE, @@ -32,14 +33,13 @@ from faststream._internal.context.repository import ContextRepo from faststream.message import StreamMessage from faststream.opentelemetry.provider import TelemetrySettingsProvider - from faststream.response.response import PublishCommand _BAGGAGE_PROPAGATOR = W3CBaggagePropagator() _TRACE_PROPAGATOR = TraceContextTextMapPropagator() -class TelemetryMiddleware(Generic[PublishCommand_T]): +class TelemetryMiddleware(Generic[PublishCommandType]): __slots__ = ( "_meter", "_metrics", @@ -52,7 +52,7 @@ def __init__( *, settings_provider_factory: Callable[ [Any], - Optional["TelemetrySettingsProvider[Any]"], + Optional["TelemetrySettingsProvider[Any, PublishCommandType]"], ], tracer_provider: Optional["TracerProvider"] = None, meter_provider: Optional["MeterProvider"] = None, @@ -70,8 +70,8 @@ def __call__( /, *, context: "ContextRepo", - ) -> "BaseTelemetryMiddleware[PublishCommand_T]": - return BaseTelemetryMiddleware[PublishCommand_T]( + ) -> "BaseTelemetryMiddleware[PublishCommandType]": + return BaseTelemetryMiddleware[PublishCommandType]( msg, tracer=self._tracer, metrics_container=self._metrics, @@ -152,7 +152,7 @@ def observe_consume( ) -class BaseTelemetryMiddleware(BaseMiddleware[PublishCommand_T]): +class BaseTelemetryMiddleware(BaseMiddleware[PublishCommandType]): def __init__( self, msg: Optional[Any], @@ -161,7 +161,7 @@ def __init__( tracer: "Tracer", settings_provider_factory: Callable[ [Any], - Optional["TelemetrySettingsProvider[Any]"], + Optional["TelemetrySettingsProvider[Any, PublishCommandType]"], ], metrics_container: _MetricsContainer, context: "ContextRepo", @@ -178,7 +178,7 @@ def __init__( async def publish_scope( self, call_next: "AsyncFunc", - msg: "PublishCommand", + msg: "PublishCommandType", ) -> Any: if (provider := self.__settings_provider) is None: return await call_next(msg) diff --git a/faststream/opentelemetry/provider.py b/faststream/opentelemetry/provider.py index 6e2aaa90b6..0cedf1bd8c 100644 --- a/faststream/opentelemetry/provider.py +++ b/faststream/opentelemetry/provider.py @@ -1,14 +1,24 @@ from typing import TYPE_CHECKING, Protocol +from typing_extensions import TypeVar as TypeVar313 + from faststream._internal.types import MsgType +from faststream.response import PublishCommand if TYPE_CHECKING: from faststream._internal.basic_types import AnyDict from faststream.message import StreamMessage - from faststream.response.response import PublishCommand -class TelemetrySettingsProvider(Protocol[MsgType]): +PublishCommandType_contra = TypeVar313( + "PublishCommandType_contra", + bound=PublishCommand, + default=PublishCommand, + contravariant=True, +) + + +class TelemetrySettingsProvider(Protocol[MsgType, PublishCommandType_contra]): messaging_system: str def get_consume_attrs_from_message( @@ -23,10 +33,10 @@ def get_consume_destination_name( def get_publish_attrs_from_cmd( self, - cmd: "PublishCommand", + cmd: PublishCommandType_contra, ) -> "AnyDict": ... def get_publish_destination_name( self, - cmd: "PublishCommand", + cmd: PublishCommandType_contra, ) -> str: ... diff --git a/faststream/prometheus/middleware.py b/faststream/prometheus/middleware.py index 91b4df6382..33d4950e62 100644 --- a/faststream/prometheus/middleware.py +++ b/faststream/prometheus/middleware.py @@ -3,9 +3,10 @@ from typing import TYPE_CHECKING, Any, Callable, Generic, Optional from faststream._internal.constants import EMPTY +from faststream._internal.types import PublishCommandType from faststream.exceptions import IgnoredException from faststream.message import SourceType -from faststream.middlewares.base import BaseMiddleware, PublishCommand_T +from faststream.middlewares.base import BaseMiddleware from faststream.prometheus.consts import ( PROCESSING_STATUS_BY_ACK_STATUS, PROCESSING_STATUS_BY_HANDLER_EXCEPTION_MAP, @@ -24,14 +25,15 @@ from faststream.message.message import StreamMessage -class PrometheusMiddleware(Generic[PublishCommand_T]): +class PrometheusMiddleware(Generic[PublishCommandType]): __slots__ = ("_metrics_container", "_metrics_manager", "_settings_provider_factory") def __init__( self, *, settings_provider_factory: Callable[ - [Any], Optional[MetricsSettingsProvider[Any]] + [Any], + Optional[MetricsSettingsProvider[Any, PublishCommandType]], ], registry: "CollectorRegistry", app_name: str = EMPTY, @@ -58,8 +60,8 @@ def __call__( /, *, context: "ContextRepo", - ) -> "BasePrometheusMiddleware[PublishCommand_T]": - return BasePrometheusMiddleware[PublishCommand_T]( + ) -> "BasePrometheusMiddleware[PublishCommandType]": + return BasePrometheusMiddleware[PublishCommandType]( msg, metrics_manager=self._metrics_manager, settings_provider_factory=self._settings_provider_factory, @@ -67,14 +69,15 @@ def __call__( ) -class BasePrometheusMiddleware(BaseMiddleware[PublishCommand_T]): +class BasePrometheusMiddleware(BaseMiddleware[PublishCommandType]): def __init__( self, msg: Optional[Any], /, *, settings_provider_factory: Callable[ - [Any], Optional[MetricsSettingsProvider[Any]] + [Any], + Optional[MetricsSettingsProvider[Any, PublishCommandType]], ], metrics_manager: MetricsManager, context: "ContextRepo", @@ -164,8 +167,8 @@ async def consume_scope( async def publish_scope( self, - call_next: Callable[[PublishCommand_T], Awaitable[Any]], - cmd: PublishCommand_T, + call_next: Callable[[PublishCommandType], Awaitable[Any]], + cmd: PublishCommandType, ) -> Any: if self._settings_provider is None or cmd.publish_type is PublishType.REPLY: return await call_next(cmd) diff --git a/faststream/prometheus/provider.py b/faststream/prometheus/provider.py index acbf68702f..d8de081a1f 100644 --- a/faststream/prometheus/provider.py +++ b/faststream/prometheus/provider.py @@ -1,13 +1,23 @@ from typing import TYPE_CHECKING, Protocol +from typing_extensions import TypeVar as TypeVar313 + from faststream.message.message import MsgType, StreamMessage +from faststream.response.response import PublishCommand if TYPE_CHECKING: from faststream.prometheus import ConsumeAttrs - from faststream.response.response import PublishCommand -class MetricsSettingsProvider(Protocol[MsgType]): +PublishCommandType_contra = TypeVar313( + "PublishCommandType_contra", + bound=PublishCommand, + default=PublishCommand, + contravariant=True, +) + + +class MetricsSettingsProvider(Protocol[MsgType, PublishCommandType_contra]): messaging_system: str def get_consume_attrs_from_message( @@ -17,5 +27,5 @@ def get_consume_attrs_from_message( def get_publish_destination_name_from_cmd( self, - cmd: "PublishCommand", + cmd: PublishCommandType_contra, ) -> str: ... diff --git a/faststream/rabbit/opentelemetry/provider.py b/faststream/rabbit/opentelemetry/provider.py index e9bd12c7fd..374285d932 100644 --- a/faststream/rabbit/opentelemetry/provider.py +++ b/faststream/rabbit/opentelemetry/provider.py @@ -4,16 +4,18 @@ from faststream.opentelemetry import TelemetrySettingsProvider from faststream.opentelemetry.consts import MESSAGING_DESTINATION_PUBLISH_NAME +from faststream.rabbit.response import RabbitPublishCommand if TYPE_CHECKING: from aio_pika import IncomingMessage from faststream._internal.basic_types import AnyDict from faststream.message import StreamMessage - from faststream.rabbit.response import RabbitPublishCommand -class RabbitTelemetrySettingsProvider(TelemetrySettingsProvider["IncomingMessage"]): +class RabbitTelemetrySettingsProvider( + TelemetrySettingsProvider["IncomingMessage", RabbitPublishCommand], +): __slots__ = ("messaging_system",) def __init__(self) -> None: diff --git a/faststream/rabbit/prometheus/provider.py b/faststream/rabbit/prometheus/provider.py index f4fa0d977f..14427f977d 100644 --- a/faststream/rabbit/prometheus/provider.py +++ b/faststream/rabbit/prometheus/provider.py @@ -4,15 +4,17 @@ ConsumeAttrs, MetricsSettingsProvider, ) +from faststream.rabbit.response import RabbitPublishCommand if TYPE_CHECKING: from aio_pika import IncomingMessage from faststream.message.message import StreamMessage - from faststream.rabbit.response import RabbitPublishCommand -class RabbitMetricsSettingsProvider(MetricsSettingsProvider["IncomingMessage"]): +class RabbitMetricsSettingsProvider( + MetricsSettingsProvider["IncomingMessage", RabbitPublishCommand], +): __slots__ = ("messaging_system",) def __init__(self) -> None: @@ -33,6 +35,6 @@ def get_consume_attrs_from_message( def get_publish_destination_name_from_cmd( self, - cmd: "RabbitPublishCommand", + cmd: RabbitPublishCommand, ) -> str: return f"{cmd.exchange.name or 'default'}.{cmd.destination}" From 195035e6d8eb88323bc4d2ca20448afbdd47c6fb Mon Sep 17 00:00:00 2001 From: Nikita Pastukhov Date: Sun, 15 Dec 2024 23:08:23 +0300 Subject: [PATCH 7/9] lint: fix rabbit response types --- faststream/_internal/types.py | 8 -------- faststream/middlewares/base.py | 14 ++++++++++++-- faststream/opentelemetry/middleware.py | 3 +-- faststream/prometheus/middleware.py | 3 +-- faststream/rabbit/response.py | 15 +++++++++++---- faststream/rabbit/schemas/proto.py | 2 +- 6 files changed, 26 insertions(+), 19 deletions(-) diff --git a/faststream/_internal/types.py b/faststream/_internal/types.py index 5aa5c1d63a..489d1b94b3 100644 --- a/faststream/_internal/types.py +++ b/faststream/_internal/types.py @@ -11,7 +11,6 @@ from typing_extensions import ( ParamSpec, TypeAlias, - TypeVar as TypeVar313, ) from faststream._internal.basic_types import AsyncFuncAny @@ -85,13 +84,6 @@ def __call__( ] -PublishCommandType = TypeVar313( - "PublishCommandType", - bound=PublishCommand, - default=PublishCommand, -) - - class PublisherMiddleware(Protocol): """Publisher middleware interface.""" diff --git a/faststream/middlewares/base.py b/faststream/middlewares/base.py index ca78b03ad1..131da032b4 100644 --- a/faststream/middlewares/base.py +++ b/faststream/middlewares/base.py @@ -1,9 +1,12 @@ from collections.abc import Awaitable from typing import TYPE_CHECKING, Any, Callable, Generic, Optional -from typing_extensions import Self +from typing_extensions import ( + Self, + TypeVar as TypeVar313, +) -from faststream._internal.types import PublishCommandType +from faststream.response import PublishCommand if TYPE_CHECKING: from types import TracebackType @@ -13,6 +16,13 @@ from faststream.message import StreamMessage +PublishCommandType = TypeVar313( + "PublishCommandType", + bound=PublishCommand, + default=PublishCommand, +) + + class BaseMiddleware(Generic[PublishCommandType]): """A base middleware class.""" diff --git a/faststream/opentelemetry/middleware.py b/faststream/opentelemetry/middleware.py index 42e323c85a..e1f07b4527 100644 --- a/faststream/opentelemetry/middleware.py +++ b/faststream/opentelemetry/middleware.py @@ -10,8 +10,7 @@ from opentelemetry.trace import Link, Span from opentelemetry.trace.propagation.tracecontext import TraceContextTextMapPropagator -from faststream._internal.types import PublishCommandType -from faststream.middlewares.base import BaseMiddleware +from faststream.middlewares.base import BaseMiddleware, PublishCommandType from faststream.opentelemetry.baggage import Baggage from faststream.opentelemetry.consts import ( ERROR_TYPE, diff --git a/faststream/prometheus/middleware.py b/faststream/prometheus/middleware.py index 33d4950e62..db146eb4a1 100644 --- a/faststream/prometheus/middleware.py +++ b/faststream/prometheus/middleware.py @@ -3,10 +3,9 @@ from typing import TYPE_CHECKING, Any, Callable, Generic, Optional from faststream._internal.constants import EMPTY -from faststream._internal.types import PublishCommandType from faststream.exceptions import IgnoredException from faststream.message import SourceType -from faststream.middlewares.base import BaseMiddleware +from faststream.middlewares.base import BaseMiddleware, PublishCommandType from faststream.prometheus.consts import ( PROCESSING_STATUS_BY_ACK_STATUS, PROCESSING_STATUS_BY_HANDLER_EXCEPTION_MAP, diff --git a/faststream/rabbit/response.py b/faststream/rabbit/response.py index 9bac3f6417..f45cbb07ce 100644 --- a/faststream/rabbit/response.py +++ b/faststream/rabbit/response.py @@ -7,11 +7,18 @@ from faststream.response.publish_type import PublishType if TYPE_CHECKING: + from typing import TypedDict + from aio_pika.abc import TimeoutType from faststream.rabbit.publisher.options import MessageOptions from faststream.rabbit.types import AioPikaSendableMessage + class _PublishOptions(TypedDict): + timeout: TimeoutType + mandatory: bool + immediate: bool + class RabbitResponse(Response): def __init__( @@ -33,7 +40,7 @@ def __init__( ) self.message_options = message_options - self.publish_options = { + self.publish_options: _PublishOptions = { "mandatory": mandatory, "immediate": immediate, "timeout": timeout, @@ -41,7 +48,7 @@ def __init__( @override def as_publish_command(self) -> "RabbitPublishCommand": - return RabbitPublishCommand( + return RabbitPublishCommand( # type: ignore[misc] message=self.body, headers=self.headers, correlation_id=self.correlation_id, @@ -65,11 +72,11 @@ def __init__( mandatory: bool = True, immediate: bool = False, timeout: "TimeoutType" = None, - correlation_id: Optional[str] = None, **message_options: Unpack["MessageOptions"], ) -> None: headers = message_options.pop("headers", {}) - reply_to = message_options.pop("reply_to", "") + reply_to = message_options.pop("reply_to") or "" + correlation_id = message_options.pop("correlation_id", None) super().__init__( body=message, diff --git a/faststream/rabbit/schemas/proto.py b/faststream/rabbit/schemas/proto.py index 2109772124..2929ce7c4f 100644 --- a/faststream/rabbit/schemas/proto.py +++ b/faststream/rabbit/schemas/proto.py @@ -37,4 +37,4 @@ def _setup( self.virtual_host = virtual_host # Setup next parent class - super()._setup(**kwargs) + super()._setup(**kwargs) # type: ignore[misc] From a728ba7024b0377f2b7a94748e806376515df9c9 Mon Sep 17 00:00:00 2001 From: Spataphore <93342746+spataphore1337@users.noreply.github.com> Date: Mon, 16 Dec 2024 12:25:54 +0300 Subject: [PATCH 8/9] feat: add raise BatchBufferOverflowException (#1989) * feat: add raise BatchBufferOverflowException * Update producer.py --------- Co-authored-by: Pastukhov Nikita --- faststream/kafka/exceptions.py | 13 +++++++++++++ faststream/kafka/publisher/producer.py | 8 +++++--- 2 files changed, 18 insertions(+), 3 deletions(-) create mode 100644 faststream/kafka/exceptions.py diff --git a/faststream/kafka/exceptions.py b/faststream/kafka/exceptions.py new file mode 100644 index 0000000000..8d398706b9 --- /dev/null +++ b/faststream/kafka/exceptions.py @@ -0,0 +1,13 @@ +from faststream.exceptions import FastStreamException + + +class BatchBufferOverflowException(FastStreamException): + """Exception raised when a buffer overflow occurs when adding a new message to the batches.""" + + def __init__(self, + message_position: int) -> None: + self.message_position = message_position + + def __str__(self) -> str: + return f"The batch buffer is full. The position of the message" \ + f" in the transferred collection at which the overflow occurred: {self.message_position}" diff --git a/faststream/kafka/publisher/producer.py b/faststream/kafka/publisher/producer.py index bdd8d3677c..e0764bf96a 100644 --- a/faststream/kafka/publisher/producer.py +++ b/faststream/kafka/publisher/producer.py @@ -5,12 +5,12 @@ from faststream._internal.publisher.proto import ProducerProto from faststream._internal.subscriber.utils import resolve_custom_func from faststream.exceptions import FeatureNotSupportedException +from faststream.kafka.exceptions import BatchBufferOverflowException from faststream.kafka.message import KafkaMessage from faststream.kafka.parser import AioKafkaParser from faststream.message import encode_message from .state import EmptyProducerState, ProducerState, RealProducer - if TYPE_CHECKING: import asyncio @@ -90,7 +90,7 @@ async def publish_batch( headers_to_send = cmd.headers_to_publish() - for body in cmd.batch_bodies: + for message_position, body in enumerate(cmd.batch_bodies): message, content_type = encode_message(body) if content_type: @@ -101,12 +101,14 @@ async def publish_batch( else: final_headers = headers_to_send.copy() - batch.append( + metadata = batch.append( key=None, value=message, timestamp=cmd.timestamp_ms, headers=[(i, j.encode()) for i, j in final_headers.items()], ) + if metadata is None: + raise BatchBufferOverflowException(message_position=message_position) send_future = await self._producer.producer.send_batch( batch, From 5f9c7b6b22bc29c1d728cacad6e5472d10a63a12 Mon Sep 17 00:00:00 2001 From: Apostol Fet <90645107+ApostolFet@users.noreply.github.com> Date: Fri, 20 Dec 2024 00:31:19 +0300 Subject: [PATCH 9/9] fix: KeyError 'reply_to' in rabbit (#1999) --- faststream/rabbit/publisher/usecase.py | 2 +- faststream/rabbit/response.py | 2 +- 2 files changed, 2 insertions(+), 2 deletions(-) diff --git a/faststream/rabbit/publisher/usecase.py b/faststream/rabbit/publisher/usecase.py index abb48bb1b1..d4b736cfa4 100644 --- a/faststream/rabbit/publisher/usecase.py +++ b/faststream/rabbit/publisher/usecase.py @@ -72,7 +72,7 @@ def __init__( request_options = dict(message_kwargs) self.headers = request_options.pop("headers") or {} - self.reply_to = request_options.pop("reply_to", "") + self.reply_to = request_options.pop("reply_to", None) or "" self.timeout = request_options.pop("timeout", None) message_options, _ = filter_by_dict(MessageOptions, request_options) diff --git a/faststream/rabbit/response.py b/faststream/rabbit/response.py index f45cbb07ce..ffb1ad3b31 100644 --- a/faststream/rabbit/response.py +++ b/faststream/rabbit/response.py @@ -75,7 +75,7 @@ def __init__( **message_options: Unpack["MessageOptions"], ) -> None: headers = message_options.pop("headers", {}) - reply_to = message_options.pop("reply_to") or "" + reply_to = message_options.pop("reply_to", None) or "" correlation_id = message_options.pop("correlation_id", None) super().__init__(