From baf617855ddf47f78c89b0634ac11f342fff3cbc Mon Sep 17 00:00:00 2001 From: Ruslan Alimov Date: Tue, 10 Dec 2024 19:40:25 +0300 Subject: [PATCH 1/2] feat: init_routes added routes to init broker (#1981) * feat: init_routes added routes to init broker * docs: generate API References --------- Co-authored-by: Rusich90 --- docs/docs/SUMMARY.md | 1276 +++++++++++++++++ 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 + faststream/_internal/broker/abc_broker.py | 3 + faststream/_internal/broker/broker.py | 5 + faststream/_internal/broker/router.py | 2 + faststream/confluent/broker/broker.py | 6 + faststream/confluent/router.py | 6 + faststream/kafka/broker/broker.py | 6 + faststream/kafka/router.py | 6 + faststream/nats/broker/broker.py | 6 + faststream/nats/router.py | 6 + faststream/rabbit/broker/broker.py | 5 + faststream/rabbit/router.py | 6 + faststream/redis/broker/broker.py | 6 + faststream/redis/router.py | 6 + tests/brokers/base/router.py | 28 + 754 files changed, 9502 insertions(+) create mode 100644 docs/docs/SUMMARY.md create mode 100644 docs/docs/en/api/faststream/AckPolicy.md create mode 100644 docs/docs/en/api/faststream/BaseMiddleware.md create mode 100644 docs/docs/en/api/faststream/Context.md create mode 100644 docs/docs/en/api/faststream/Depends.md create mode 100644 docs/docs/en/api/faststream/ExceptionMiddleware.md create mode 100644 docs/docs/en/api/faststream/FastStream.md create mode 100644 docs/docs/en/api/faststream/Header.md create mode 100644 docs/docs/en/api/faststream/Path.md create mode 100644 docs/docs/en/api/faststream/Response.md create mode 100644 docs/docs/en/api/faststream/TestApp.md create mode 100644 docs/docs/en/api/faststream/app/FastStream.md create mode 100644 docs/docs/en/api/faststream/apply_types.md create mode 100644 docs/docs/en/api/faststream/asgi/AsgiFastStream.md create mode 100644 docs/docs/en/api/faststream/asgi/AsgiResponse.md create mode 100644 docs/docs/en/api/faststream/asgi/app/AsgiFastStream.md create mode 100644 docs/docs/en/api/faststream/asgi/app/CliRunState.md create mode 100644 docs/docs/en/api/faststream/asgi/app/OuterRunState.md create mode 100644 docs/docs/en/api/faststream/asgi/app/ServerState.md create mode 100644 docs/docs/en/api/faststream/asgi/app/cast_uvicorn_params.md create mode 100644 docs/docs/en/api/faststream/asgi/factories/make_asyncapi_asgi.md create mode 100644 docs/docs/en/api/faststream/asgi/factories/make_ping_asgi.md create mode 100644 docs/docs/en/api/faststream/asgi/get.md create mode 100644 docs/docs/en/api/faststream/asgi/handlers/get.md create mode 100644 docs/docs/en/api/faststream/asgi/make_asyncapi_asgi.md create mode 100644 docs/docs/en/api/faststream/asgi/make_ping_asgi.md create mode 100644 docs/docs/en/api/faststream/asgi/response/AsgiResponse.md create mode 100644 docs/docs/en/api/faststream/asgi/websocket/WebSocketClose.md create mode 100644 docs/docs/en/api/faststream/confluent/KafkaBroker.md create mode 100644 docs/docs/en/api/faststream/confluent/KafkaPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/KafkaResponse.md create mode 100644 docs/docs/en/api/faststream/confluent/KafkaRoute.md create mode 100644 docs/docs/en/api/faststream/confluent/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/confluent/TestApp.md create mode 100644 docs/docs/en/api/faststream/confluent/TestKafkaBroker.md create mode 100644 docs/docs/en/api/faststream/confluent/TopicPartition.md create mode 100644 docs/docs/en/api/faststream/confluent/broker/KafkaBroker.md create mode 100644 docs/docs/en/api/faststream/confluent/broker/broker/KafkaBroker.md create mode 100644 docs/docs/en/api/faststream/confluent/broker/logging/KafkaParamsStorage.md create mode 100644 docs/docs/en/api/faststream/confluent/broker/registrator/KafkaRegistrator.md create mode 100644 docs/docs/en/api/faststream/confluent/client/AsyncConfluentConsumer.md create mode 100644 docs/docs/en/api/faststream/confluent/client/AsyncConfluentProducer.md create mode 100644 docs/docs/en/api/faststream/confluent/client/BatchBuilder.md create mode 100644 docs/docs/en/api/faststream/confluent/client/check_msg_error.md create mode 100644 docs/docs/en/api/faststream/confluent/client/create_topics.md create mode 100644 docs/docs/en/api/faststream/confluent/config/BrokerAddressFamily.md create mode 100644 docs/docs/en/api/faststream/confluent/config/BuiltinFeatures.md create mode 100644 docs/docs/en/api/faststream/confluent/config/ClientDNSLookup.md create mode 100644 docs/docs/en/api/faststream/confluent/config/CompressionCodec.md create mode 100644 docs/docs/en/api/faststream/confluent/config/CompressionType.md create mode 100644 docs/docs/en/api/faststream/confluent/config/ConfluentConfig.md create mode 100644 docs/docs/en/api/faststream/confluent/config/ConfluentFastConfig.md create mode 100644 docs/docs/en/api/faststream/confluent/config/Debug.md create mode 100644 docs/docs/en/api/faststream/confluent/config/GroupProtocol.md create mode 100644 docs/docs/en/api/faststream/confluent/config/IsolationLevel.md create mode 100644 docs/docs/en/api/faststream/confluent/config/OffsetStoreMethod.md create mode 100644 docs/docs/en/api/faststream/confluent/config/SASLOAUTHBearerMethod.md create mode 100644 docs/docs/en/api/faststream/confluent/config/SecurityProtocol.md create mode 100644 docs/docs/en/api/faststream/confluent/fastapi/Context.md create mode 100644 docs/docs/en/api/faststream/confluent/fastapi/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/confluent/fastapi/fastapi/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/confluent/message/ConsumerProtocol.md create mode 100644 docs/docs/en/api/faststream/confluent/message/FakeConsumer.md create mode 100644 docs/docs/en/api/faststream/confluent/message/KafkaMessage.md create mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/KafkaTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/middleware/KafkaTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/BaseConfluentTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/BatchConfluentTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/ConfluentTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/confluent/opentelemetry/provider/telemetry_attributes_provider_factory.md create mode 100644 docs/docs/en/api/faststream/confluent/parser/AsyncConfluentParser.md create mode 100644 docs/docs/en/api/faststream/confluent/prometheus/KafkaPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/confluent/prometheus/middleware/KafkaPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/BaseConfluentMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/BatchConfluentMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/ConfluentMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/confluent/prometheus/provider/settings_provider_factory.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/factory/create_publisher.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/fake/KafkaFakePublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/producer/AsyncConfluentFastProducer.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationBatchPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationDefaultPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/state/EmptyProducerState.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/state/ProducerState.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/state/RealProducer.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/usecase/BatchPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/usecase/DefaultPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/publisher/usecase/LogicPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/response/KafkaPublishCommand.md create mode 100644 docs/docs/en/api/faststream/confluent/response/KafkaResponse.md create mode 100644 docs/docs/en/api/faststream/confluent/router/KafkaPublisher.md create mode 100644 docs/docs/en/api/faststream/confluent/router/KafkaRoute.md create mode 100644 docs/docs/en/api/faststream/confluent/router/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/confluent/schemas/TopicPartition.md create mode 100644 docs/docs/en/api/faststream/confluent/schemas/params/ConsumerConnectionParams.md create mode 100644 docs/docs/en/api/faststream/confluent/schemas/partition/TopicPartition.md create mode 100644 docs/docs/en/api/faststream/confluent/security/parse_security.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/factory/create_subscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationBatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationDefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/BatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/ConcurrentDefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/DefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/subscriber/usecase/LogicSubscriber.md create mode 100644 docs/docs/en/api/faststream/confluent/testing/FakeProducer.md create mode 100644 docs/docs/en/api/faststream/confluent/testing/MockConfluentMessage.md create mode 100644 docs/docs/en/api/faststream/confluent/testing/TestKafkaBroker.md create mode 100644 docs/docs/en/api/faststream/confluent/testing/build_message.md create mode 100644 docs/docs/en/api/faststream/exceptions/AckMessage.md create mode 100644 docs/docs/en/api/faststream/exceptions/ContextError.md create mode 100644 docs/docs/en/api/faststream/exceptions/FastStreamException.md create mode 100644 docs/docs/en/api/faststream/exceptions/FeatureNotSupportedException.md create mode 100644 docs/docs/en/api/faststream/exceptions/HandlerException.md create mode 100644 docs/docs/en/api/faststream/exceptions/IgnoredException.md create mode 100644 docs/docs/en/api/faststream/exceptions/IncorrectState.md create mode 100644 docs/docs/en/api/faststream/exceptions/NackMessage.md create mode 100644 docs/docs/en/api/faststream/exceptions/RejectMessage.md create mode 100644 docs/docs/en/api/faststream/exceptions/SetupError.md create mode 100644 docs/docs/en/api/faststream/exceptions/SkipMessage.md create mode 100644 docs/docs/en/api/faststream/exceptions/StartupValidationError.md create mode 100644 docs/docs/en/api/faststream/exceptions/StopApplication.md create mode 100644 docs/docs/en/api/faststream/exceptions/StopConsume.md create mode 100644 docs/docs/en/api/faststream/exceptions/SubscriberNotFound.md create mode 100644 docs/docs/en/api/faststream/kafka/KafkaBroker.md create mode 100644 docs/docs/en/api/faststream/kafka/KafkaPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/KafkaResponse.md create mode 100644 docs/docs/en/api/faststream/kafka/KafkaRoute.md create mode 100644 docs/docs/en/api/faststream/kafka/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/kafka/TestApp.md create mode 100644 docs/docs/en/api/faststream/kafka/TestKafkaBroker.md create mode 100644 docs/docs/en/api/faststream/kafka/TopicPartition.md create mode 100644 docs/docs/en/api/faststream/kafka/broker/KafkaBroker.md create mode 100644 docs/docs/en/api/faststream/kafka/broker/broker/KafkaBroker.md create mode 100644 docs/docs/en/api/faststream/kafka/broker/logging/KafkaParamsStorage.md create mode 100644 docs/docs/en/api/faststream/kafka/broker/registrator/KafkaRegistrator.md create mode 100644 docs/docs/en/api/faststream/kafka/fastapi/Context.md create mode 100644 docs/docs/en/api/faststream/kafka/fastapi/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/kafka/fastapi/fastapi/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/kafka/message/ConsumerProtocol.md create mode 100644 docs/docs/en/api/faststream/kafka/message/FakeConsumer.md create mode 100644 docs/docs/en/api/faststream/kafka/message/KafkaAckableMessage.md create mode 100644 docs/docs/en/api/faststream/kafka/message/KafkaMessage.md create mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/KafkaTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/middleware/KafkaTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/BaseKafkaTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/BatchKafkaTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/KafkaTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/kafka/opentelemetry/provider/telemetry_attributes_provider_factory.md create mode 100644 docs/docs/en/api/faststream/kafka/parser/AioKafkaBatchParser.md create mode 100644 docs/docs/en/api/faststream/kafka/parser/AioKafkaParser.md create mode 100644 docs/docs/en/api/faststream/kafka/prometheus/KafkaPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/kafka/prometheus/middleware/KafkaPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/BaseKafkaMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/BatchKafkaMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/KafkaMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/kafka/prometheus/provider/settings_provider_factory.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/factory/create_publisher.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/fake/KafkaFakePublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/producer/AioKafkaFastProducer.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationBatchPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationDefaultPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/state/EmptyProducerState.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/state/ProducerState.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/state/RealProducer.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/usecase/BatchPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/usecase/DefaultPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/publisher/usecase/LogicPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/response/KafkaPublishCommand.md create mode 100644 docs/docs/en/api/faststream/kafka/response/KafkaResponse.md create mode 100644 docs/docs/en/api/faststream/kafka/router/KafkaPublisher.md create mode 100644 docs/docs/en/api/faststream/kafka/router/KafkaRoute.md create mode 100644 docs/docs/en/api/faststream/kafka/router/KafkaRouter.md create mode 100644 docs/docs/en/api/faststream/kafka/schemas/params/ConsumerConnectionParams.md create mode 100644 docs/docs/en/api/faststream/kafka/security/parse_security.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/factory/create_subscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationBatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationDefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/BatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/ConcurrentDefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/DefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/subscriber/usecase/LogicSubscriber.md create mode 100644 docs/docs/en/api/faststream/kafka/testing/FakeProducer.md create mode 100644 docs/docs/en/api/faststream/kafka/testing/TestKafkaBroker.md create mode 100644 docs/docs/en/api/faststream/kafka/testing/build_message.md create mode 100644 docs/docs/en/api/faststream/message/AckStatus.md create mode 100644 docs/docs/en/api/faststream/message/SourceType.md create mode 100644 docs/docs/en/api/faststream/message/StreamMessage.md create mode 100644 docs/docs/en/api/faststream/message/decode_message.md create mode 100644 docs/docs/en/api/faststream/message/encode_message.md create mode 100644 docs/docs/en/api/faststream/message/gen_cor_id.md create mode 100644 docs/docs/en/api/faststream/message/message/AckStatus.md create mode 100644 docs/docs/en/api/faststream/message/message/StreamMessage.md create mode 100644 docs/docs/en/api/faststream/message/source_type/SourceType.md create mode 100644 docs/docs/en/api/faststream/message/utils/decode_message.md create mode 100644 docs/docs/en/api/faststream/message/utils/encode_message.md create mode 100644 docs/docs/en/api/faststream/message/utils/gen_cor_id.md create mode 100644 docs/docs/en/api/faststream/middlewares/AckPolicy.md create mode 100644 docs/docs/en/api/faststream/middlewares/AcknowledgementMiddleware.md create mode 100644 docs/docs/en/api/faststream/middlewares/BaseMiddleware.md create mode 100644 docs/docs/en/api/faststream/middlewares/ExceptionMiddleware.md create mode 100644 docs/docs/en/api/faststream/middlewares/acknowledgement/conf/AckPolicy.md create mode 100644 docs/docs/en/api/faststream/middlewares/acknowledgement/middleware/AcknowledgementMiddleware.md create mode 100644 docs/docs/en/api/faststream/middlewares/base/BaseMiddleware.md create mode 100644 docs/docs/en/api/faststream/middlewares/exception/ExceptionMiddleware.md create mode 100644 docs/docs/en/api/faststream/middlewares/exception/ignore_handler.md create mode 100644 docs/docs/en/api/faststream/middlewares/logging/CriticalLogMiddleware.md create mode 100644 docs/docs/en/api/faststream/nats/AckPolicy.md create mode 100644 docs/docs/en/api/faststream/nats/ConsumerConfig.md create mode 100644 docs/docs/en/api/faststream/nats/DeliverPolicy.md create mode 100644 docs/docs/en/api/faststream/nats/DiscardPolicy.md create mode 100644 docs/docs/en/api/faststream/nats/ExternalStream.md create mode 100644 docs/docs/en/api/faststream/nats/JStream.md create mode 100644 docs/docs/en/api/faststream/nats/KvWatch.md create mode 100644 docs/docs/en/api/faststream/nats/NatsBroker.md create mode 100644 docs/docs/en/api/faststream/nats/NatsPublisher.md create mode 100644 docs/docs/en/api/faststream/nats/NatsResponse.md create mode 100644 docs/docs/en/api/faststream/nats/NatsRoute.md create mode 100644 docs/docs/en/api/faststream/nats/NatsRouter.md create mode 100644 docs/docs/en/api/faststream/nats/ObjWatch.md create mode 100644 docs/docs/en/api/faststream/nats/Placement.md create mode 100644 docs/docs/en/api/faststream/nats/PubAck.md create mode 100644 docs/docs/en/api/faststream/nats/PullSub.md create mode 100644 docs/docs/en/api/faststream/nats/RePublish.md create mode 100644 docs/docs/en/api/faststream/nats/ReplayPolicy.md create mode 100644 docs/docs/en/api/faststream/nats/RetentionPolicy.md create mode 100644 docs/docs/en/api/faststream/nats/StorageType.md create mode 100644 docs/docs/en/api/faststream/nats/StreamConfig.md create mode 100644 docs/docs/en/api/faststream/nats/StreamSource.md create mode 100644 docs/docs/en/api/faststream/nats/TestApp.md create mode 100644 docs/docs/en/api/faststream/nats/TestNatsBroker.md create mode 100644 docs/docs/en/api/faststream/nats/broker/NatsBroker.md create mode 100644 docs/docs/en/api/faststream/nats/broker/broker/NatsBroker.md create mode 100644 docs/docs/en/api/faststream/nats/broker/logging/NatsParamsStorage.md create mode 100644 docs/docs/en/api/faststream/nats/broker/registrator/NatsRegistrator.md create mode 100644 docs/docs/en/api/faststream/nats/broker/state/BrokerState.md create mode 100644 docs/docs/en/api/faststream/nats/broker/state/ConnectedState.md create mode 100644 docs/docs/en/api/faststream/nats/broker/state/ConnectionBrokenState.md create mode 100644 docs/docs/en/api/faststream/nats/broker/state/EmptyBrokerState.md create mode 100644 docs/docs/en/api/faststream/nats/fastapi/Context.md create mode 100644 docs/docs/en/api/faststream/nats/fastapi/NatsRouter.md create mode 100644 docs/docs/en/api/faststream/nats/fastapi/fastapi/NatsRouter.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/KVBucketDeclarer.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/OSBucketDeclarer.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/StreamBuilder.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/bucket_declarer/KVBucketDeclarer.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/obj_storage_declarer/OSBucketDeclarer.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/object_builder/StreamBuilder.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/state/ConnectedState.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/state/ConnectionState.md create mode 100644 docs/docs/en/api/faststream/nats/helpers/state/EmptyConnectionState.md create mode 100644 docs/docs/en/api/faststream/nats/message/NatsBatchMessage.md create mode 100644 docs/docs/en/api/faststream/nats/message/NatsKvMessage.md create mode 100644 docs/docs/en/api/faststream/nats/message/NatsMessage.md create mode 100644 docs/docs/en/api/faststream/nats/message/NatsObjMessage.md create mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/NatsTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/middleware/NatsTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/BaseNatsTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsBatchTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/nats/opentelemetry/provider/telemetry_attributes_provider_factory.md create mode 100644 docs/docs/en/api/faststream/nats/parser/BatchParser.md create mode 100644 docs/docs/en/api/faststream/nats/parser/JsParser.md create mode 100644 docs/docs/en/api/faststream/nats/parser/KvParser.md create mode 100644 docs/docs/en/api/faststream/nats/parser/NatsBaseParser.md create mode 100644 docs/docs/en/api/faststream/nats/parser/NatsParser.md create mode 100644 docs/docs/en/api/faststream/nats/parser/ObjParser.md create mode 100644 docs/docs/en/api/faststream/nats/prometheus/NatsPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/nats/prometheus/middleware/NatsPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/BaseNatsMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/BatchNatsMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/NatsMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/nats/prometheus/provider/settings_provider_factory.md create mode 100644 docs/docs/en/api/faststream/nats/publisher/factory/create_publisher.md create mode 100644 docs/docs/en/api/faststream/nats/publisher/fake/NatsFakePublisher.md create mode 100644 docs/docs/en/api/faststream/nats/publisher/producer/NatsFastProducer.md create mode 100644 docs/docs/en/api/faststream/nats/publisher/producer/NatsJSFastProducer.md create mode 100644 docs/docs/en/api/faststream/nats/publisher/specified/SpecificationPublisher.md create mode 100644 docs/docs/en/api/faststream/nats/publisher/usecase/LogicPublisher.md create mode 100644 docs/docs/en/api/faststream/nats/response/NatsPublishCommand.md create mode 100644 docs/docs/en/api/faststream/nats/response/NatsResponse.md create mode 100644 docs/docs/en/api/faststream/nats/router/NatsPublisher.md create mode 100644 docs/docs/en/api/faststream/nats/router/NatsRoute.md create mode 100644 docs/docs/en/api/faststream/nats/router/NatsRouter.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/JStream.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/KvWatch.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/ObjWatch.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/PubAck.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/PullSub.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/js_stream/JStream.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/js_stream/compile_nats_wildcard.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/js_stream/is_subject_match_wildcard.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/kv_watch/KvWatch.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/obj_watch/ObjWatch.md create mode 100644 docs/docs/en/api/faststream/nats/schemas/pull_sub/PullSub.md create mode 100644 docs/docs/en/api/faststream/nats/security/parse_security.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/adapters/UnsubscribeAdapter.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/adapters/Unsubscriptable.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/adapters/Watchable.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/factory/create_subscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationBatchPullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentCoreSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPushStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationCoreSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationKeyValueWatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationObjStoreWatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPushStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/state/ConnectedSubscriberState.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/state/EmptySubscriberState.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/state/SubscriberState.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/BatchPullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentCoreSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPushStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/CoreSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/KeyValueWatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/LogicSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/ObjStoreWatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/PullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/PushStreamSubscription.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/basic/DefaultSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/basic/LogicSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/ConcurrentCoreSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/CoreSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/key_value_subscriber/KeyValueWatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/object_storage_subscriber/ObjStoreWatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_basic/StreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/BatchPullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/ConcurrentPullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/PullStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/ConcurrentPushStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/PushStreamSubscription.md create mode 100644 docs/docs/en/api/faststream/nats/testing/FakeProducer.md create mode 100644 docs/docs/en/api/faststream/nats/testing/PatchedMessage.md create mode 100644 docs/docs/en/api/faststream/nats/testing/TestNatsBroker.md create mode 100644 docs/docs/en/api/faststream/nats/testing/build_message.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/Baggage.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/TelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/TelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/baggage/Baggage.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/consts/MessageAction.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/middleware/BaseTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/middleware/TelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/opentelemetry/provider/TelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/params/Context.md create mode 100644 docs/docs/en/api/faststream/params/Depends.md create mode 100644 docs/docs/en/api/faststream/params/Header.md create mode 100644 docs/docs/en/api/faststream/params/Path.md create mode 100644 docs/docs/en/api/faststream/params/no_cast/NoCastField.md create mode 100644 docs/docs/en/api/faststream/params/params/Context.md create mode 100644 docs/docs/en/api/faststream/params/params/Header.md create mode 100644 docs/docs/en/api/faststream/params/params/Path.md create mode 100644 docs/docs/en/api/faststream/prometheus/ConsumeAttrs.md create mode 100644 docs/docs/en/api/faststream/prometheus/MetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/prometheus/PrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/prometheus/container/MetricsContainer.md create mode 100644 docs/docs/en/api/faststream/prometheus/manager/MetricsManager.md create mode 100644 docs/docs/en/api/faststream/prometheus/middleware/BasePrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/prometheus/middleware/PrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/prometheus/provider/MetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/prometheus/types/ConsumeAttrs.md create mode 100644 docs/docs/en/api/faststream/prometheus/types/ProcessingStatus.md create mode 100644 docs/docs/en/api/faststream/prometheus/types/PublishingStatus.md create mode 100644 docs/docs/en/api/faststream/rabbit/ExchangeType.md create mode 100644 docs/docs/en/api/faststream/rabbit/RabbitBroker.md create mode 100644 docs/docs/en/api/faststream/rabbit/RabbitExchange.md create mode 100644 docs/docs/en/api/faststream/rabbit/RabbitPublisher.md create mode 100644 docs/docs/en/api/faststream/rabbit/RabbitQueue.md create mode 100644 docs/docs/en/api/faststream/rabbit/RabbitResponse.md create mode 100644 docs/docs/en/api/faststream/rabbit/RabbitRoute.md create mode 100644 docs/docs/en/api/faststream/rabbit/RabbitRouter.md create mode 100644 docs/docs/en/api/faststream/rabbit/TestApp.md create mode 100644 docs/docs/en/api/faststream/rabbit/TestRabbitBroker.md create mode 100644 docs/docs/en/api/faststream/rabbit/broker/RabbitBroker.md create mode 100644 docs/docs/en/api/faststream/rabbit/broker/broker/RabbitBroker.md create mode 100644 docs/docs/en/api/faststream/rabbit/broker/logging/RabbitParamsStorage.md create mode 100644 docs/docs/en/api/faststream/rabbit/broker/registrator/RabbitRegistrator.md create mode 100644 docs/docs/en/api/faststream/rabbit/fastapi/Context.md create mode 100644 docs/docs/en/api/faststream/rabbit/fastapi/RabbitRouter.md create mode 100644 docs/docs/en/api/faststream/rabbit/fastapi/fastapi/RabbitRouter.md create mode 100644 docs/docs/en/api/faststream/rabbit/helpers/declarer/RabbitDeclarer.md create mode 100644 docs/docs/en/api/faststream/rabbit/helpers/state/ConnectedState.md create mode 100644 docs/docs/en/api/faststream/rabbit/helpers/state/ConnectionState.md create mode 100644 docs/docs/en/api/faststream/rabbit/helpers/state/EmptyConnectionState.md create mode 100644 docs/docs/en/api/faststream/rabbit/message/RabbitMessage.md create mode 100644 docs/docs/en/api/faststream/rabbit/opentelemetry/RabbitTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/rabbit/opentelemetry/middleware/RabbitTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/rabbit/opentelemetry/provider/RabbitTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/rabbit/parser/AioPikaParser.md create mode 100644 docs/docs/en/api/faststream/rabbit/prometheus/RabbitPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/rabbit/prometheus/middleware/RabbitPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/rabbit/prometheus/provider/RabbitMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/factory/create_publisher.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/fake/RabbitFakePublisher.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/options/MessageOptions.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/options/PublishOptions.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/AioPikaFastProducer.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/LockState.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/LockUnset.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/producer/RealLock.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/specified/SpecificationPublisher.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/usecase/LogicPublisher.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/usecase/PublishKwargs.md create mode 100644 docs/docs/en/api/faststream/rabbit/publisher/usecase/RequestPublishKwargs.md create mode 100644 docs/docs/en/api/faststream/rabbit/response/RabbitPublishCommand.md create mode 100644 docs/docs/en/api/faststream/rabbit/response/RabbitResponse.md create mode 100644 docs/docs/en/api/faststream/rabbit/router/RabbitPublisher.md create mode 100644 docs/docs/en/api/faststream/rabbit/router/RabbitRoute.md create mode 100644 docs/docs/en/api/faststream/rabbit/router/RabbitRouter.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/BaseRMQInformation.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/ExchangeType.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/RabbitExchange.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/RabbitQueue.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/constants/ExchangeType.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/exchange/RabbitExchange.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/proto/BaseRMQInformation.md create mode 100644 docs/docs/en/api/faststream/rabbit/schemas/queue/RabbitQueue.md create mode 100644 docs/docs/en/api/faststream/rabbit/security/parse_security.md create mode 100644 docs/docs/en/api/faststream/rabbit/subscriber/factory/create_subscriber.md create mode 100644 docs/docs/en/api/faststream/rabbit/subscriber/specified/SpecificationSubscriber.md create mode 100644 docs/docs/en/api/faststream/rabbit/subscriber/usecase/LogicSubscriber.md create mode 100644 docs/docs/en/api/faststream/rabbit/testing/FakeProducer.md create mode 100644 docs/docs/en/api/faststream/rabbit/testing/PatchedMessage.md create mode 100644 docs/docs/en/api/faststream/rabbit/testing/TestRabbitBroker.md create mode 100644 docs/docs/en/api/faststream/rabbit/testing/apply_pattern.md create mode 100644 docs/docs/en/api/faststream/rabbit/testing/build_message.md create mode 100644 docs/docs/en/api/faststream/rabbit/utils/build_url.md create mode 100644 docs/docs/en/api/faststream/rabbit/utils/is_routing_exchange.md create mode 100644 docs/docs/en/api/faststream/redis/ListSub.md create mode 100644 docs/docs/en/api/faststream/redis/PubSub.md create mode 100644 docs/docs/en/api/faststream/redis/RedisBroker.md create mode 100644 docs/docs/en/api/faststream/redis/RedisPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/RedisResponse.md create mode 100644 docs/docs/en/api/faststream/redis/RedisRoute.md create mode 100644 docs/docs/en/api/faststream/redis/RedisRouter.md create mode 100644 docs/docs/en/api/faststream/redis/StreamSub.md create mode 100644 docs/docs/en/api/faststream/redis/TestApp.md create mode 100644 docs/docs/en/api/faststream/redis/TestRedisBroker.md create mode 100644 docs/docs/en/api/faststream/redis/broker/broker/RedisBroker.md create mode 100644 docs/docs/en/api/faststream/redis/broker/logging/RedisParamsStorage.md create mode 100644 docs/docs/en/api/faststream/redis/broker/registrator/RedisRegistrator.md create mode 100644 docs/docs/en/api/faststream/redis/fastapi/Context.md create mode 100644 docs/docs/en/api/faststream/redis/fastapi/RedisRouter.md create mode 100644 docs/docs/en/api/faststream/redis/fastapi/fastapi/RedisRouter.md create mode 100644 docs/docs/en/api/faststream/redis/helpers/state/ConnectedState.md create mode 100644 docs/docs/en/api/faststream/redis/helpers/state/ConnectionState.md create mode 100644 docs/docs/en/api/faststream/redis/helpers/state/EmptyConnectionState.md create mode 100644 docs/docs/en/api/faststream/redis/message/BatchListMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/BatchStreamMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/DefaultListMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/DefaultStreamMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/PubSubMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/RedisBatchListMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/RedisBatchStreamMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/RedisListMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/RedisMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/RedisStreamMessage.md create mode 100644 docs/docs/en/api/faststream/redis/message/UnifyRedisDict.md create mode 100644 docs/docs/en/api/faststream/redis/message/UnifyRedisMessage.md create mode 100644 docs/docs/en/api/faststream/redis/opentelemetry/RedisTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/redis/opentelemetry/middleware/RedisTelemetryMiddleware.md create mode 100644 docs/docs/en/api/faststream/redis/opentelemetry/provider/RedisTelemetrySettingsProvider.md create mode 100644 docs/docs/en/api/faststream/redis/parser/RawMessage.md create mode 100644 docs/docs/en/api/faststream/redis/parser/RedisBatchListParser.md create mode 100644 docs/docs/en/api/faststream/redis/parser/RedisBatchStreamParser.md create mode 100644 docs/docs/en/api/faststream/redis/parser/RedisListParser.md create mode 100644 docs/docs/en/api/faststream/redis/parser/RedisPubSubParser.md create mode 100644 docs/docs/en/api/faststream/redis/parser/RedisStreamParser.md create mode 100644 docs/docs/en/api/faststream/redis/parser/SimpleParser.md create mode 100644 docs/docs/en/api/faststream/redis/prometheus/RedisPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/redis/prometheus/middleware/RedisPrometheusMiddleware.md create mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/BaseRedisMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/BatchRedisMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/RedisMetricsSettingsProvider.md create mode 100644 docs/docs/en/api/faststream/redis/prometheus/provider/settings_provider_factory.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/factory/create_publisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/fake/RedisFakePublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/producer/RedisFastProducer.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationChannelPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListBatchPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/specified/SpecificationStreamPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/ChannelPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/ListBatchPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/ListPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/LogicPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/publisher/usecase/StreamPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/response/DestinationType.md create mode 100644 docs/docs/en/api/faststream/redis/response/RedisPublishCommand.md create mode 100644 docs/docs/en/api/faststream/redis/response/RedisResponse.md create mode 100644 docs/docs/en/api/faststream/redis/router/RedisPublisher.md create mode 100644 docs/docs/en/api/faststream/redis/router/RedisRoute.md create mode 100644 docs/docs/en/api/faststream/redis/router/RedisRouter.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/ListSub.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/PubSub.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/StreamSub.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/list_sub/ListSub.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/proto/RedisSpecificationProtocol.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/proto/validate_options.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/pub_sub/PubSub.md create mode 100644 docs/docs/en/api/faststream/redis/schemas/stream_sub/StreamSub.md create mode 100644 docs/docs/en/api/faststream/redis/security/parse_security.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/factory/create_subscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationChannelSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListBatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamBatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/BatchListSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/ChannelSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/ListSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/LogicSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/StreamBatchSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/subscriber/usecase/StreamSubscriber.md create mode 100644 docs/docs/en/api/faststream/redis/testing/ChannelVisitor.md create mode 100644 docs/docs/en/api/faststream/redis/testing/FakeProducer.md create mode 100644 docs/docs/en/api/faststream/redis/testing/ListVisitor.md create mode 100644 docs/docs/en/api/faststream/redis/testing/StreamVisitor.md create mode 100644 docs/docs/en/api/faststream/redis/testing/TestRedisBroker.md create mode 100644 docs/docs/en/api/faststream/redis/testing/Visitor.md create mode 100644 docs/docs/en/api/faststream/redis/testing/build_message.md create mode 100644 docs/docs/en/api/faststream/response/PublishCommand.md create mode 100644 docs/docs/en/api/faststream/response/PublishType.md create mode 100644 docs/docs/en/api/faststream/response/Response.md create mode 100644 docs/docs/en/api/faststream/response/ensure_response.md create mode 100644 docs/docs/en/api/faststream/response/publish_type/PublishType.md create mode 100644 docs/docs/en/api/faststream/response/response/PublishCommand.md create mode 100644 docs/docs/en/api/faststream/response/response/Response.md create mode 100644 docs/docs/en/api/faststream/response/utils/ensure_response.md create mode 100644 docs/docs/en/api/faststream/security/BaseSecurity.md create mode 100644 docs/docs/en/api/faststream/security/SASLGSSAPI.md create mode 100644 docs/docs/en/api/faststream/security/SASLOAuthBearer.md create mode 100644 docs/docs/en/api/faststream/security/SASLPlaintext.md create mode 100644 docs/docs/en/api/faststream/security/SASLScram256.md create mode 100644 docs/docs/en/api/faststream/security/SASLScram512.md create mode 100644 docs/docs/en/api/faststream/specification/AsyncAPI.md create mode 100644 docs/docs/en/api/faststream/specification/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/License.md create mode 100644 docs/docs/en/api/faststream/specification/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/AsyncAPI.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/factory/AsyncAPI.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/get_asyncapi_html.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/message/get_model_schema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/message/get_response_schema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/message/parse_handler_params.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/site/get_asyncapi_html.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/site/serve_app.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/clear_key.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/move_pydantic_refs.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/resolve_payloads.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/utils/to_camelcase.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/AsyncAPI2.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/facade/AsyncAPI2.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_app_schema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_channels.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_server.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/resolve_channel_messages.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/get_app_schema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationInfo.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationSchema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Channel.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Components.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/CorrelationId.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/License.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Message.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Operation.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Parameter.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Reference.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Server.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ServerVariable.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Exchange.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Queue.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/from_spec.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/from_spec.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/channels/Channel.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/components/Components.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/contact/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/docs/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/info/ApplicationInfo.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/license/License.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/CorrelationId.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/Message.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/operations/Operation.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/schema/ApplicationSchema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/Server.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/ServerVariable.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/tag/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Parameter.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Reference.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/AsyncAPI3.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/facade/AsyncAPI3.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_app_schema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_channels.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_server.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/get_app_schema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationInfo.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationSchema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Channel.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Components.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/CorrelationId.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/License.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Message.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Operation.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Parameter.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Reference.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Server.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ServerVariable.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/channel/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/operation/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/channels/Channel.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/components/Components.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/contact/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/docs/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/info/ApplicationInfo.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/license/License.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/CorrelationId.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/Message.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Action.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Operation.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/schema/ApplicationSchema.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/servers/Server.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/tag/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Parameter.md create mode 100644 docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Reference.md create mode 100644 docs/docs/en/api/faststream/specification/base/info/BaseApplicationInfo.md create mode 100644 docs/docs/en/api/faststream/specification/base/schema/BaseApplicationSchema.md create mode 100644 docs/docs/en/api/faststream/specification/base/specification/Specification.md create mode 100644 docs/docs/en/api/faststream/specification/proto/EndpointSpecification.md create mode 100644 docs/docs/en/api/faststream/specification/proto/ServerSpecification.md create mode 100644 docs/docs/en/api/faststream/specification/proto/broker/ServerSpecification.md create mode 100644 docs/docs/en/api/faststream/specification/proto/endpoint/EndpointSpecification.md create mode 100644 docs/docs/en/api/faststream/specification/schema/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/schema/ContactDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/schema/ExternalDocsDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/License.md create mode 100644 docs/docs/en/api/faststream/specification/schema/LicenseDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/Message.md create mode 100644 docs/docs/en/api/faststream/specification/schema/Operation.md create mode 100644 docs/docs/en/api/faststream/specification/schema/PublisherSpec.md create mode 100644 docs/docs/en/api/faststream/specification/schema/SubscriberSpec.md create mode 100644 docs/docs/en/api/faststream/specification/schema/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/schema/TagDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/Exchange.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/amqp/Queue.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/kafka/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/kafka/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/main/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/main/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/nats/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/nats/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/redis/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/redis/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/sqs/ChannelBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/bindings/sqs/OperationBinding.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/ContactDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/ExternalDocsDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/License.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/LicenseDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/TagDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/contact/Contact.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/contact/ContactDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocs.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocsDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/license/License.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/license/LicenseDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/tag/Tag.md create mode 100644 docs/docs/en/api/faststream/specification/schema/extra/tag/TagDict.md create mode 100644 docs/docs/en/api/faststream/specification/schema/message/Message.md create mode 100644 docs/docs/en/api/faststream/specification/schema/message/model/Message.md create mode 100644 docs/docs/en/api/faststream/specification/schema/operation/Operation.md create mode 100644 docs/docs/en/api/faststream/specification/schema/operation/model/Operation.md create mode 100644 docs/docs/en/api/faststream/specification/schema/publisher/PublisherSpec.md create mode 100644 docs/docs/en/api/faststream/specification/schema/subscriber/SubscriberSpec.md diff --git a/docs/docs/SUMMARY.md b/docs/docs/SUMMARY.md new file mode 100644 index 0000000000..a859135d0e --- /dev/null +++ b/docs/docs/SUMMARY.md @@ -0,0 +1,1276 @@ +--- +search: + exclude: true +--- +- [Features](faststream.md) +- Tutorial + - [Getting Started](getting-started/index.md) + - [Subscription and Serialization](getting-started/subscription/index.md) + - [Annotation Serialization](getting-started/subscription/annotation.md) + - [Pydantic Serialization](getting-started/subscription/pydantic.md) + - [Filtering](getting-started/subscription/filtering.md) + - [Testing](getting-started/subscription/test.md) + - [Publishing](getting-started/publishing/index.md) + - [Broker Publish](getting-started/publishing/broker.md) + - [Decorator](getting-started/publishing/decorator.md) + - [Object Decorator](getting-started/publishing/object.md) + - [Direct Publishing](getting-started/publishing/direct.md) + - [Testing](getting-started/publishing/test.md) + - [Routers](getting-started/routers/index.md) + - [Dependencies](getting-started/dependencies/index.md) + - [Context](getting-started/context/index.md) + - [Existing Fields](getting-started/context/existed.md) + - [Custom Context](getting-started/context/custom.md) + - [Fields Access](getting-started/context/fields.md) + - [Extra Options](getting-started/context/extra.md) + - [Custom Serialization](getting-started/serialization/index.md) + - [Parser](getting-started/serialization/parser.md) + - [Decoder](getting-started/serialization/decoder.md) + - [Examples](getting-started/serialization/examples.md) + - [Lifespan](getting-started/lifespan/index.md) + - [Hooks](getting-started/lifespan/hooks.md) + - [Context](getting-started/lifespan/context.md) + - [Testing](getting-started/lifespan/test.md) + - [Middlewares](getting-started/middlewares/index.md) + - [Exception Middleware](getting-started/middlewares/exception.md) + - AsyncAPI + - [Schema Export](getting-started/asyncapi/export.md) + - [Schema Hosting](getting-started/asyncapi/hosting.md) + - [Customize Information](getting-started/asyncapi/custom.md) + - Integrations + - [HTTP Async Frameworks](getting-started/integrations/frameworks/index.md) + - [FastAPI Plugin](getting-started/integrations/fastapi/index.md) + - [Django](getting-started/integrations/django/index.md) + - [CLI](getting-started/cli/index.md) + - [ASGI](getting-started/asgi.md) + - [OpenTelemetry](getting-started/opentelemetry/index.md) + - [Prometheus](getting-started/prometheus/index.md) + - [Logging](getting-started/logging.md) + - [Config Management](getting-started/config/index.md) + - [Task Scheduling](scheduling.md) + - [FastStream Project Template](getting-started/template/index.md) +- [Kafka](kafka/kafka.md) + - [AIOKafka](kafka/index.md) + - [Subscription](kafka/Subscriber/index.md) + - [Batch Subscriber](kafka/Subscriber/batch_subscriber.md) + - [Publishing](kafka/Publisher/index.md) + - [Batch Publishing](kafka/Publisher/batch_publisher.md) + - [Publish With Key](kafka/Publisher/using_a_key.md) + - [Acknowledgement](kafka/ack.md) + - [Message Information](kafka/message.md) + - [Security Configuration](kafka/security.md) + - [Confluent](confluent/index.md) + - [Subscription](confluent/Subscriber/index.md) + - [Batch Subscriber](confluent/Subscriber/batch_subscriber.md) + - [Publishing](confluent/Publisher/index.md) + - [Batch Publishing](confluent/Publisher/batch_publisher.md) + - [Publish With Key](confluent/Publisher/using_a_key.md) + - [Acknowledgement](confluent/ack.md) + - [Message Information](confluent/message.md) + - [Security Configuration](confluent/security.md) + - [Additional Configuration](confluent/additional-configuration.md) + - [How-To](howto/kafka/index.md) + - [Kafka RPC](howto/kafka/rpc.md) +- [RabbitMQ](rabbit/index.md) + - [Subscription](rabbit/examples/index.md) + - [Direct](rabbit/examples/direct.md) + - [Fanout](rabbit/examples/fanout.md) + - [Topic](rabbit/examples/topic.md) + - [Headers](rabbit/examples/headers.md) + - [Stream](rabbit/examples/stream.md) + - [Publishing](rabbit/publishing.md) + - [RPC](rabbit/rpc.md) + - [Acknowledgement](rabbit/ack.md) + - [Declare Queue/Exchange](rabbit/declare.md) + - [Message Information](rabbit/message.md) + - [Security Configuration](rabbit/security.md) +- [NATS](nats/index.md) + - Subscription + - [Direct](nats/examples/direct.md) + - [Pattern](nats/examples/pattern.md) + - [JetStream](nats/jetstream/index.md) + - [Pull Subscriber](nats/jetstream/pull.md) + - [Key-Value Storage](nats/jetstream/key-value.md) + - [Object Storage](nats/jetstream/object.md) + - [Acknowledgement](nats/jetstream/ack.md) + - [Publishing](nats/publishing/index.md) + - [RPC](nats/rpc.md) + - [Message Information](nats/message.md) + - [How-To](howto/nats/index.md) + - [DynaConf](howto/nats/dynaconf.md) + - [In-Progess](howto/nats/in-progress.md) +- [Redis](redis/index.md) + - [Pub/Sub](redis/pubsub/index.md) + - [Subscription](redis/pubsub/subscription.md) + - [Publishing](redis/pubsub/publishing.md) + - [List](redis/list/index.md) + - [Subscription](redis/list/subscription.md) + - [Publishing](redis/list/publishing.md) + - [Batching](redis/list/batch.md) + - [Streams](redis/streams/index.md) + - [Subscription](redis/streams/subscription.md) + - [Publishing](redis/streams/publishing.md) + - [Groups](redis/streams/groups.md) + - [Batching](redis/streams/batch.md) + - [Acknowledgement](redis/streams/ack.md) + - [RPC](redis/rpc.md) + - [Message Information](redis/message.md) + - [Security Configuration](redis/security.md) +- [Reference - Code API](api/index.md) + - Public API + - faststream + - [AckPolicy](public_api/faststream/AckPolicy.md) + - [BaseMiddleware](public_api/faststream/BaseMiddleware.md) + - [Context](public_api/faststream/Context.md) + - [Depends](public_api/faststream/Depends.md) + - [ExceptionMiddleware](public_api/faststream/ExceptionMiddleware.md) + - [FastStream](public_api/faststream/FastStream.md) + - [Header](public_api/faststream/Header.md) + - [Path](public_api/faststream/Path.md) + - [Response](public_api/faststream/Response.md) + - [TestApp](public_api/faststream/TestApp.md) + - [apply_types](public_api/faststream/apply_types.md) + - asgi + - [AsgiFastStream](public_api/faststream/asgi/AsgiFastStream.md) + - [AsgiResponse](public_api/faststream/asgi/AsgiResponse.md) + - [get](public_api/faststream/asgi/get.md) + - [make_asyncapi_asgi](public_api/faststream/asgi/make_asyncapi_asgi.md) + - [make_ping_asgi](public_api/faststream/asgi/make_ping_asgi.md) + - confluent + - [KafkaBroker](public_api/faststream/confluent/KafkaBroker.md) + - [KafkaPublisher](public_api/faststream/confluent/KafkaPublisher.md) + - [KafkaResponse](public_api/faststream/confluent/KafkaResponse.md) + - [KafkaRoute](public_api/faststream/confluent/KafkaRoute.md) + - [KafkaRouter](public_api/faststream/confluent/KafkaRouter.md) + - [TestApp](public_api/faststream/confluent/TestApp.md) + - [TestKafkaBroker](public_api/faststream/confluent/TestKafkaBroker.md) + - [TopicPartition](public_api/faststream/confluent/TopicPartition.md) + - kafka + - [KafkaBroker](public_api/faststream/kafka/KafkaBroker.md) + - [KafkaPublisher](public_api/faststream/kafka/KafkaPublisher.md) + - [KafkaResponse](public_api/faststream/kafka/KafkaResponse.md) + - [KafkaRoute](public_api/faststream/kafka/KafkaRoute.md) + - [KafkaRouter](public_api/faststream/kafka/KafkaRouter.md) + - [TestApp](public_api/faststream/kafka/TestApp.md) + - [TestKafkaBroker](public_api/faststream/kafka/TestKafkaBroker.md) + - [TopicPartition](public_api/faststream/kafka/TopicPartition.md) + - nats + - [AckPolicy](public_api/faststream/nats/AckPolicy.md) + - [ConsumerConfig](public_api/faststream/nats/ConsumerConfig.md) + - [DeliverPolicy](public_api/faststream/nats/DeliverPolicy.md) + - [DiscardPolicy](public_api/faststream/nats/DiscardPolicy.md) + - [ExternalStream](public_api/faststream/nats/ExternalStream.md) + - [JStream](public_api/faststream/nats/JStream.md) + - [KvWatch](public_api/faststream/nats/KvWatch.md) + - [NatsBroker](public_api/faststream/nats/NatsBroker.md) + - [NatsPublisher](public_api/faststream/nats/NatsPublisher.md) + - [NatsResponse](public_api/faststream/nats/NatsResponse.md) + - [NatsRoute](public_api/faststream/nats/NatsRoute.md) + - [NatsRouter](public_api/faststream/nats/NatsRouter.md) + - [ObjWatch](public_api/faststream/nats/ObjWatch.md) + - [Placement](public_api/faststream/nats/Placement.md) + - [PubAck](public_api/faststream/nats/PubAck.md) + - [PullSub](public_api/faststream/nats/PullSub.md) + - [RePublish](public_api/faststream/nats/RePublish.md) + - [ReplayPolicy](public_api/faststream/nats/ReplayPolicy.md) + - [RetentionPolicy](public_api/faststream/nats/RetentionPolicy.md) + - [StorageType](public_api/faststream/nats/StorageType.md) + - [StreamConfig](public_api/faststream/nats/StreamConfig.md) + - [StreamSource](public_api/faststream/nats/StreamSource.md) + - [TestApp](public_api/faststream/nats/TestApp.md) + - [TestNatsBroker](public_api/faststream/nats/TestNatsBroker.md) + - opentelemetry + - [Baggage](public_api/faststream/opentelemetry/Baggage.md) + - [TelemetryMiddleware](public_api/faststream/opentelemetry/TelemetryMiddleware.md) + - [TelemetrySettingsProvider](public_api/faststream/opentelemetry/TelemetrySettingsProvider.md) + - rabbit + - [ExchangeType](public_api/faststream/rabbit/ExchangeType.md) + - [RabbitBroker](public_api/faststream/rabbit/RabbitBroker.md) + - [RabbitExchange](public_api/faststream/rabbit/RabbitExchange.md) + - [RabbitPublisher](public_api/faststream/rabbit/RabbitPublisher.md) + - [RabbitQueue](public_api/faststream/rabbit/RabbitQueue.md) + - [RabbitResponse](public_api/faststream/rabbit/RabbitResponse.md) + - [RabbitRoute](public_api/faststream/rabbit/RabbitRoute.md) + - [RabbitRouter](public_api/faststream/rabbit/RabbitRouter.md) + - [TestApp](public_api/faststream/rabbit/TestApp.md) + - [TestRabbitBroker](public_api/faststream/rabbit/TestRabbitBroker.md) + - redis + - [ListSub](public_api/faststream/redis/ListSub.md) + - [PubSub](public_api/faststream/redis/PubSub.md) + - [RedisBroker](public_api/faststream/redis/RedisBroker.md) + - [RedisPublisher](public_api/faststream/redis/RedisPublisher.md) + - [RedisResponse](public_api/faststream/redis/RedisResponse.md) + - [RedisRoute](public_api/faststream/redis/RedisRoute.md) + - [RedisRouter](public_api/faststream/redis/RedisRouter.md) + - [StreamSub](public_api/faststream/redis/StreamSub.md) + - [TestApp](public_api/faststream/redis/TestApp.md) + - [TestRedisBroker](public_api/faststream/redis/TestRedisBroker.md) + - All API + - faststream + - [AckPolicy](api/faststream/AckPolicy.md) + - [BaseMiddleware](api/faststream/BaseMiddleware.md) + - [Context](api/faststream/Context.md) + - [Depends](api/faststream/Depends.md) + - [ExceptionMiddleware](api/faststream/ExceptionMiddleware.md) + - [FastStream](api/faststream/FastStream.md) + - [Header](api/faststream/Header.md) + - [Path](api/faststream/Path.md) + - [Response](api/faststream/Response.md) + - [TestApp](api/faststream/TestApp.md) + - [apply_types](api/faststream/apply_types.md) + - app + - [FastStream](api/faststream/app/FastStream.md) + - asgi + - [AsgiFastStream](api/faststream/asgi/AsgiFastStream.md) + - [AsgiResponse](api/faststream/asgi/AsgiResponse.md) + - [get](api/faststream/asgi/get.md) + - [make_asyncapi_asgi](api/faststream/asgi/make_asyncapi_asgi.md) + - [make_ping_asgi](api/faststream/asgi/make_ping_asgi.md) + - app + - [AsgiFastStream](api/faststream/asgi/app/AsgiFastStream.md) + - [CliRunState](api/faststream/asgi/app/CliRunState.md) + - [OuterRunState](api/faststream/asgi/app/OuterRunState.md) + - [ServerState](api/faststream/asgi/app/ServerState.md) + - [cast_uvicorn_params](api/faststream/asgi/app/cast_uvicorn_params.md) + - factories + - [make_asyncapi_asgi](api/faststream/asgi/factories/make_asyncapi_asgi.md) + - [make_ping_asgi](api/faststream/asgi/factories/make_ping_asgi.md) + - handlers + - [get](api/faststream/asgi/handlers/get.md) + - response + - [AsgiResponse](api/faststream/asgi/response/AsgiResponse.md) + - websocket + - [WebSocketClose](api/faststream/asgi/websocket/WebSocketClose.md) + - confluent + - [KafkaBroker](api/faststream/confluent/KafkaBroker.md) + - [KafkaPublisher](api/faststream/confluent/KafkaPublisher.md) + - [KafkaResponse](api/faststream/confluent/KafkaResponse.md) + - [KafkaRoute](api/faststream/confluent/KafkaRoute.md) + - [KafkaRouter](api/faststream/confluent/KafkaRouter.md) + - [TestApp](api/faststream/confluent/TestApp.md) + - [TestKafkaBroker](api/faststream/confluent/TestKafkaBroker.md) + - [TopicPartition](api/faststream/confluent/TopicPartition.md) + - broker + - [KafkaBroker](api/faststream/confluent/broker/KafkaBroker.md) + - broker + - [KafkaBroker](api/faststream/confluent/broker/broker/KafkaBroker.md) + - logging + - [KafkaParamsStorage](api/faststream/confluent/broker/logging/KafkaParamsStorage.md) + - registrator + - [KafkaRegistrator](api/faststream/confluent/broker/registrator/KafkaRegistrator.md) + - client + - [AsyncConfluentConsumer](api/faststream/confluent/client/AsyncConfluentConsumer.md) + - [AsyncConfluentProducer](api/faststream/confluent/client/AsyncConfluentProducer.md) + - [BatchBuilder](api/faststream/confluent/client/BatchBuilder.md) + - [check_msg_error](api/faststream/confluent/client/check_msg_error.md) + - [create_topics](api/faststream/confluent/client/create_topics.md) + - config + - [BrokerAddressFamily](api/faststream/confluent/config/BrokerAddressFamily.md) + - [BuiltinFeatures](api/faststream/confluent/config/BuiltinFeatures.md) + - [ClientDNSLookup](api/faststream/confluent/config/ClientDNSLookup.md) + - [CompressionCodec](api/faststream/confluent/config/CompressionCodec.md) + - [CompressionType](api/faststream/confluent/config/CompressionType.md) + - [ConfluentConfig](api/faststream/confluent/config/ConfluentConfig.md) + - [ConfluentFastConfig](api/faststream/confluent/config/ConfluentFastConfig.md) + - [Debug](api/faststream/confluent/config/Debug.md) + - [GroupProtocol](api/faststream/confluent/config/GroupProtocol.md) + - [IsolationLevel](api/faststream/confluent/config/IsolationLevel.md) + - [OffsetStoreMethod](api/faststream/confluent/config/OffsetStoreMethod.md) + - [SASLOAUTHBearerMethod](api/faststream/confluent/config/SASLOAUTHBearerMethod.md) + - [SecurityProtocol](api/faststream/confluent/config/SecurityProtocol.md) + - fastapi + - [Context](api/faststream/confluent/fastapi/Context.md) + - [KafkaRouter](api/faststream/confluent/fastapi/KafkaRouter.md) + - fastapi + - [KafkaRouter](api/faststream/confluent/fastapi/fastapi/KafkaRouter.md) + - message + - [ConsumerProtocol](api/faststream/confluent/message/ConsumerProtocol.md) + - [FakeConsumer](api/faststream/confluent/message/FakeConsumer.md) + - [KafkaMessage](api/faststream/confluent/message/KafkaMessage.md) + - opentelemetry + - [KafkaTelemetryMiddleware](api/faststream/confluent/opentelemetry/KafkaTelemetryMiddleware.md) + - middleware + - [KafkaTelemetryMiddleware](api/faststream/confluent/opentelemetry/middleware/KafkaTelemetryMiddleware.md) + - provider + - [BaseConfluentTelemetrySettingsProvider](api/faststream/confluent/opentelemetry/provider/BaseConfluentTelemetrySettingsProvider.md) + - [BatchConfluentTelemetrySettingsProvider](api/faststream/confluent/opentelemetry/provider/BatchConfluentTelemetrySettingsProvider.md) + - [ConfluentTelemetrySettingsProvider](api/faststream/confluent/opentelemetry/provider/ConfluentTelemetrySettingsProvider.md) + - [telemetry_attributes_provider_factory](api/faststream/confluent/opentelemetry/provider/telemetry_attributes_provider_factory.md) + - parser + - [AsyncConfluentParser](api/faststream/confluent/parser/AsyncConfluentParser.md) + - prometheus + - [KafkaPrometheusMiddleware](api/faststream/confluent/prometheus/KafkaPrometheusMiddleware.md) + - middleware + - [KafkaPrometheusMiddleware](api/faststream/confluent/prometheus/middleware/KafkaPrometheusMiddleware.md) + - provider + - [BaseConfluentMetricsSettingsProvider](api/faststream/confluent/prometheus/provider/BaseConfluentMetricsSettingsProvider.md) + - [BatchConfluentMetricsSettingsProvider](api/faststream/confluent/prometheus/provider/BatchConfluentMetricsSettingsProvider.md) + - [ConfluentMetricsSettingsProvider](api/faststream/confluent/prometheus/provider/ConfluentMetricsSettingsProvider.md) + - [settings_provider_factory](api/faststream/confluent/prometheus/provider/settings_provider_factory.md) + - publisher + - factory + - [create_publisher](api/faststream/confluent/publisher/factory/create_publisher.md) + - fake + - [KafkaFakePublisher](api/faststream/confluent/publisher/fake/KafkaFakePublisher.md) + - producer + - [AsyncConfluentFastProducer](api/faststream/confluent/publisher/producer/AsyncConfluentFastProducer.md) + - specified + - [SpecificationBatchPublisher](api/faststream/confluent/publisher/specified/SpecificationBatchPublisher.md) + - [SpecificationDefaultPublisher](api/faststream/confluent/publisher/specified/SpecificationDefaultPublisher.md) + - [SpecificationPublisher](api/faststream/confluent/publisher/specified/SpecificationPublisher.md) + - state + - [EmptyProducerState](api/faststream/confluent/publisher/state/EmptyProducerState.md) + - [ProducerState](api/faststream/confluent/publisher/state/ProducerState.md) + - [RealProducer](api/faststream/confluent/publisher/state/RealProducer.md) + - usecase + - [BatchPublisher](api/faststream/confluent/publisher/usecase/BatchPublisher.md) + - [DefaultPublisher](api/faststream/confluent/publisher/usecase/DefaultPublisher.md) + - [LogicPublisher](api/faststream/confluent/publisher/usecase/LogicPublisher.md) + - response + - [KafkaPublishCommand](api/faststream/confluent/response/KafkaPublishCommand.md) + - [KafkaResponse](api/faststream/confluent/response/KafkaResponse.md) + - router + - [KafkaPublisher](api/faststream/confluent/router/KafkaPublisher.md) + - [KafkaRoute](api/faststream/confluent/router/KafkaRoute.md) + - [KafkaRouter](api/faststream/confluent/router/KafkaRouter.md) + - schemas + - [TopicPartition](api/faststream/confluent/schemas/TopicPartition.md) + - params + - [ConsumerConnectionParams](api/faststream/confluent/schemas/params/ConsumerConnectionParams.md) + - partition + - [TopicPartition](api/faststream/confluent/schemas/partition/TopicPartition.md) + - security + - [parse_security](api/faststream/confluent/security/parse_security.md) + - subscriber + - factory + - [create_subscriber](api/faststream/confluent/subscriber/factory/create_subscriber.md) + - specified + - [SpecificationBatchSubscriber](api/faststream/confluent/subscriber/specified/SpecificationBatchSubscriber.md) + - [SpecificationConcurrentDefaultSubscriber](api/faststream/confluent/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md) + - [SpecificationDefaultSubscriber](api/faststream/confluent/subscriber/specified/SpecificationDefaultSubscriber.md) + - [SpecificationSubscriber](api/faststream/confluent/subscriber/specified/SpecificationSubscriber.md) + - usecase + - [BatchSubscriber](api/faststream/confluent/subscriber/usecase/BatchSubscriber.md) + - [ConcurrentDefaultSubscriber](api/faststream/confluent/subscriber/usecase/ConcurrentDefaultSubscriber.md) + - [DefaultSubscriber](api/faststream/confluent/subscriber/usecase/DefaultSubscriber.md) + - [LogicSubscriber](api/faststream/confluent/subscriber/usecase/LogicSubscriber.md) + - testing + - [FakeProducer](api/faststream/confluent/testing/FakeProducer.md) + - [MockConfluentMessage](api/faststream/confluent/testing/MockConfluentMessage.md) + - [TestKafkaBroker](api/faststream/confluent/testing/TestKafkaBroker.md) + - [build_message](api/faststream/confluent/testing/build_message.md) + - exceptions + - [AckMessage](api/faststream/exceptions/AckMessage.md) + - [ContextError](api/faststream/exceptions/ContextError.md) + - [FastStreamException](api/faststream/exceptions/FastStreamException.md) + - [FeatureNotSupportedException](api/faststream/exceptions/FeatureNotSupportedException.md) + - [HandlerException](api/faststream/exceptions/HandlerException.md) + - [IgnoredException](api/faststream/exceptions/IgnoredException.md) + - [IncorrectState](api/faststream/exceptions/IncorrectState.md) + - [NackMessage](api/faststream/exceptions/NackMessage.md) + - [RejectMessage](api/faststream/exceptions/RejectMessage.md) + - [SetupError](api/faststream/exceptions/SetupError.md) + - [SkipMessage](api/faststream/exceptions/SkipMessage.md) + - [StartupValidationError](api/faststream/exceptions/StartupValidationError.md) + - [StopApplication](api/faststream/exceptions/StopApplication.md) + - [StopConsume](api/faststream/exceptions/StopConsume.md) + - [SubscriberNotFound](api/faststream/exceptions/SubscriberNotFound.md) + - kafka + - [KafkaBroker](api/faststream/kafka/KafkaBroker.md) + - [KafkaPublisher](api/faststream/kafka/KafkaPublisher.md) + - [KafkaResponse](api/faststream/kafka/KafkaResponse.md) + - [KafkaRoute](api/faststream/kafka/KafkaRoute.md) + - [KafkaRouter](api/faststream/kafka/KafkaRouter.md) + - [TestApp](api/faststream/kafka/TestApp.md) + - [TestKafkaBroker](api/faststream/kafka/TestKafkaBroker.md) + - [TopicPartition](api/faststream/kafka/TopicPartition.md) + - broker + - [KafkaBroker](api/faststream/kafka/broker/KafkaBroker.md) + - broker + - [KafkaBroker](api/faststream/kafka/broker/broker/KafkaBroker.md) + - logging + - [KafkaParamsStorage](api/faststream/kafka/broker/logging/KafkaParamsStorage.md) + - registrator + - [KafkaRegistrator](api/faststream/kafka/broker/registrator/KafkaRegistrator.md) + - fastapi + - [Context](api/faststream/kafka/fastapi/Context.md) + - [KafkaRouter](api/faststream/kafka/fastapi/KafkaRouter.md) + - fastapi + - [KafkaRouter](api/faststream/kafka/fastapi/fastapi/KafkaRouter.md) + - message + - [ConsumerProtocol](api/faststream/kafka/message/ConsumerProtocol.md) + - [FakeConsumer](api/faststream/kafka/message/FakeConsumer.md) + - [KafkaAckableMessage](api/faststream/kafka/message/KafkaAckableMessage.md) + - [KafkaMessage](api/faststream/kafka/message/KafkaMessage.md) + - opentelemetry + - [KafkaTelemetryMiddleware](api/faststream/kafka/opentelemetry/KafkaTelemetryMiddleware.md) + - middleware + - [KafkaTelemetryMiddleware](api/faststream/kafka/opentelemetry/middleware/KafkaTelemetryMiddleware.md) + - provider + - [BaseKafkaTelemetrySettingsProvider](api/faststream/kafka/opentelemetry/provider/BaseKafkaTelemetrySettingsProvider.md) + - [BatchKafkaTelemetrySettingsProvider](api/faststream/kafka/opentelemetry/provider/BatchKafkaTelemetrySettingsProvider.md) + - [KafkaTelemetrySettingsProvider](api/faststream/kafka/opentelemetry/provider/KafkaTelemetrySettingsProvider.md) + - [telemetry_attributes_provider_factory](api/faststream/kafka/opentelemetry/provider/telemetry_attributes_provider_factory.md) + - parser + - [AioKafkaBatchParser](api/faststream/kafka/parser/AioKafkaBatchParser.md) + - [AioKafkaParser](api/faststream/kafka/parser/AioKafkaParser.md) + - prometheus + - [KafkaPrometheusMiddleware](api/faststream/kafka/prometheus/KafkaPrometheusMiddleware.md) + - middleware + - [KafkaPrometheusMiddleware](api/faststream/kafka/prometheus/middleware/KafkaPrometheusMiddleware.md) + - provider + - [BaseKafkaMetricsSettingsProvider](api/faststream/kafka/prometheus/provider/BaseKafkaMetricsSettingsProvider.md) + - [BatchKafkaMetricsSettingsProvider](api/faststream/kafka/prometheus/provider/BatchKafkaMetricsSettingsProvider.md) + - [KafkaMetricsSettingsProvider](api/faststream/kafka/prometheus/provider/KafkaMetricsSettingsProvider.md) + - [settings_provider_factory](api/faststream/kafka/prometheus/provider/settings_provider_factory.md) + - publisher + - factory + - [create_publisher](api/faststream/kafka/publisher/factory/create_publisher.md) + - fake + - [KafkaFakePublisher](api/faststream/kafka/publisher/fake/KafkaFakePublisher.md) + - producer + - [AioKafkaFastProducer](api/faststream/kafka/publisher/producer/AioKafkaFastProducer.md) + - specified + - [SpecificationBatchPublisher](api/faststream/kafka/publisher/specified/SpecificationBatchPublisher.md) + - [SpecificationDefaultPublisher](api/faststream/kafka/publisher/specified/SpecificationDefaultPublisher.md) + - [SpecificationPublisher](api/faststream/kafka/publisher/specified/SpecificationPublisher.md) + - state + - [EmptyProducerState](api/faststream/kafka/publisher/state/EmptyProducerState.md) + - [ProducerState](api/faststream/kafka/publisher/state/ProducerState.md) + - [RealProducer](api/faststream/kafka/publisher/state/RealProducer.md) + - usecase + - [BatchPublisher](api/faststream/kafka/publisher/usecase/BatchPublisher.md) + - [DefaultPublisher](api/faststream/kafka/publisher/usecase/DefaultPublisher.md) + - [LogicPublisher](api/faststream/kafka/publisher/usecase/LogicPublisher.md) + - response + - [KafkaPublishCommand](api/faststream/kafka/response/KafkaPublishCommand.md) + - [KafkaResponse](api/faststream/kafka/response/KafkaResponse.md) + - router + - [KafkaPublisher](api/faststream/kafka/router/KafkaPublisher.md) + - [KafkaRoute](api/faststream/kafka/router/KafkaRoute.md) + - [KafkaRouter](api/faststream/kafka/router/KafkaRouter.md) + - schemas + - params + - [ConsumerConnectionParams](api/faststream/kafka/schemas/params/ConsumerConnectionParams.md) + - security + - [parse_security](api/faststream/kafka/security/parse_security.md) + - subscriber + - factory + - [create_subscriber](api/faststream/kafka/subscriber/factory/create_subscriber.md) + - specified + - [SpecificationBatchSubscriber](api/faststream/kafka/subscriber/specified/SpecificationBatchSubscriber.md) + - [SpecificationConcurrentDefaultSubscriber](api/faststream/kafka/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md) + - [SpecificationDefaultSubscriber](api/faststream/kafka/subscriber/specified/SpecificationDefaultSubscriber.md) + - [SpecificationSubscriber](api/faststream/kafka/subscriber/specified/SpecificationSubscriber.md) + - usecase + - [BatchSubscriber](api/faststream/kafka/subscriber/usecase/BatchSubscriber.md) + - [ConcurrentDefaultSubscriber](api/faststream/kafka/subscriber/usecase/ConcurrentDefaultSubscriber.md) + - [DefaultSubscriber](api/faststream/kafka/subscriber/usecase/DefaultSubscriber.md) + - [LogicSubscriber](api/faststream/kafka/subscriber/usecase/LogicSubscriber.md) + - testing + - [FakeProducer](api/faststream/kafka/testing/FakeProducer.md) + - [TestKafkaBroker](api/faststream/kafka/testing/TestKafkaBroker.md) + - [build_message](api/faststream/kafka/testing/build_message.md) + - message + - [AckStatus](api/faststream/message/AckStatus.md) + - [SourceType](api/faststream/message/SourceType.md) + - [StreamMessage](api/faststream/message/StreamMessage.md) + - [decode_message](api/faststream/message/decode_message.md) + - [encode_message](api/faststream/message/encode_message.md) + - [gen_cor_id](api/faststream/message/gen_cor_id.md) + - message + - [AckStatus](api/faststream/message/message/AckStatus.md) + - [StreamMessage](api/faststream/message/message/StreamMessage.md) + - source_type + - [SourceType](api/faststream/message/source_type/SourceType.md) + - utils + - [decode_message](api/faststream/message/utils/decode_message.md) + - [encode_message](api/faststream/message/utils/encode_message.md) + - [gen_cor_id](api/faststream/message/utils/gen_cor_id.md) + - middlewares + - [AckPolicy](api/faststream/middlewares/AckPolicy.md) + - [AcknowledgementMiddleware](api/faststream/middlewares/AcknowledgementMiddleware.md) + - [BaseMiddleware](api/faststream/middlewares/BaseMiddleware.md) + - [ExceptionMiddleware](api/faststream/middlewares/ExceptionMiddleware.md) + - acknowledgement + - conf + - [AckPolicy](api/faststream/middlewares/acknowledgement/conf/AckPolicy.md) + - middleware + - [AcknowledgementMiddleware](api/faststream/middlewares/acknowledgement/middleware/AcknowledgementMiddleware.md) + - base + - [BaseMiddleware](api/faststream/middlewares/base/BaseMiddleware.md) + - exception + - [ExceptionMiddleware](api/faststream/middlewares/exception/ExceptionMiddleware.md) + - [ignore_handler](api/faststream/middlewares/exception/ignore_handler.md) + - logging + - [CriticalLogMiddleware](api/faststream/middlewares/logging/CriticalLogMiddleware.md) + - nats + - [AckPolicy](api/faststream/nats/AckPolicy.md) + - [ConsumerConfig](api/faststream/nats/ConsumerConfig.md) + - [DeliverPolicy](api/faststream/nats/DeliverPolicy.md) + - [DiscardPolicy](api/faststream/nats/DiscardPolicy.md) + - [ExternalStream](api/faststream/nats/ExternalStream.md) + - [JStream](api/faststream/nats/JStream.md) + - [KvWatch](api/faststream/nats/KvWatch.md) + - [NatsBroker](api/faststream/nats/NatsBroker.md) + - [NatsPublisher](api/faststream/nats/NatsPublisher.md) + - [NatsResponse](api/faststream/nats/NatsResponse.md) + - [NatsRoute](api/faststream/nats/NatsRoute.md) + - [NatsRouter](api/faststream/nats/NatsRouter.md) + - [ObjWatch](api/faststream/nats/ObjWatch.md) + - [Placement](api/faststream/nats/Placement.md) + - [PubAck](api/faststream/nats/PubAck.md) + - [PullSub](api/faststream/nats/PullSub.md) + - [RePublish](api/faststream/nats/RePublish.md) + - [ReplayPolicy](api/faststream/nats/ReplayPolicy.md) + - [RetentionPolicy](api/faststream/nats/RetentionPolicy.md) + - [StorageType](api/faststream/nats/StorageType.md) + - [StreamConfig](api/faststream/nats/StreamConfig.md) + - [StreamSource](api/faststream/nats/StreamSource.md) + - [TestApp](api/faststream/nats/TestApp.md) + - [TestNatsBroker](api/faststream/nats/TestNatsBroker.md) + - broker + - [NatsBroker](api/faststream/nats/broker/NatsBroker.md) + - broker + - [NatsBroker](api/faststream/nats/broker/broker/NatsBroker.md) + - logging + - [NatsParamsStorage](api/faststream/nats/broker/logging/NatsParamsStorage.md) + - registrator + - [NatsRegistrator](api/faststream/nats/broker/registrator/NatsRegistrator.md) + - state + - [BrokerState](api/faststream/nats/broker/state/BrokerState.md) + - [ConnectedState](api/faststream/nats/broker/state/ConnectedState.md) + - [ConnectionBrokenState](api/faststream/nats/broker/state/ConnectionBrokenState.md) + - [EmptyBrokerState](api/faststream/nats/broker/state/EmptyBrokerState.md) + - fastapi + - [Context](api/faststream/nats/fastapi/Context.md) + - [NatsRouter](api/faststream/nats/fastapi/NatsRouter.md) + - fastapi + - [NatsRouter](api/faststream/nats/fastapi/fastapi/NatsRouter.md) + - helpers + - [KVBucketDeclarer](api/faststream/nats/helpers/KVBucketDeclarer.md) + - [OSBucketDeclarer](api/faststream/nats/helpers/OSBucketDeclarer.md) + - [StreamBuilder](api/faststream/nats/helpers/StreamBuilder.md) + - bucket_declarer + - [KVBucketDeclarer](api/faststream/nats/helpers/bucket_declarer/KVBucketDeclarer.md) + - obj_storage_declarer + - [OSBucketDeclarer](api/faststream/nats/helpers/obj_storage_declarer/OSBucketDeclarer.md) + - object_builder + - [StreamBuilder](api/faststream/nats/helpers/object_builder/StreamBuilder.md) + - state + - [ConnectedState](api/faststream/nats/helpers/state/ConnectedState.md) + - [ConnectionState](api/faststream/nats/helpers/state/ConnectionState.md) + - [EmptyConnectionState](api/faststream/nats/helpers/state/EmptyConnectionState.md) + - message + - [NatsBatchMessage](api/faststream/nats/message/NatsBatchMessage.md) + - [NatsKvMessage](api/faststream/nats/message/NatsKvMessage.md) + - [NatsMessage](api/faststream/nats/message/NatsMessage.md) + - [NatsObjMessage](api/faststream/nats/message/NatsObjMessage.md) + - opentelemetry + - [NatsTelemetryMiddleware](api/faststream/nats/opentelemetry/NatsTelemetryMiddleware.md) + - middleware + - [NatsTelemetryMiddleware](api/faststream/nats/opentelemetry/middleware/NatsTelemetryMiddleware.md) + - provider + - [BaseNatsTelemetrySettingsProvider](api/faststream/nats/opentelemetry/provider/BaseNatsTelemetrySettingsProvider.md) + - [NatsBatchTelemetrySettingsProvider](api/faststream/nats/opentelemetry/provider/NatsBatchTelemetrySettingsProvider.md) + - [NatsTelemetrySettingsProvider](api/faststream/nats/opentelemetry/provider/NatsTelemetrySettingsProvider.md) + - [telemetry_attributes_provider_factory](api/faststream/nats/opentelemetry/provider/telemetry_attributes_provider_factory.md) + - parser + - [BatchParser](api/faststream/nats/parser/BatchParser.md) + - [JsParser](api/faststream/nats/parser/JsParser.md) + - [KvParser](api/faststream/nats/parser/KvParser.md) + - [NatsBaseParser](api/faststream/nats/parser/NatsBaseParser.md) + - [NatsParser](api/faststream/nats/parser/NatsParser.md) + - [ObjParser](api/faststream/nats/parser/ObjParser.md) + - prometheus + - [NatsPrometheusMiddleware](api/faststream/nats/prometheus/NatsPrometheusMiddleware.md) + - middleware + - [NatsPrometheusMiddleware](api/faststream/nats/prometheus/middleware/NatsPrometheusMiddleware.md) + - provider + - [BaseNatsMetricsSettingsProvider](api/faststream/nats/prometheus/provider/BaseNatsMetricsSettingsProvider.md) + - [BatchNatsMetricsSettingsProvider](api/faststream/nats/prometheus/provider/BatchNatsMetricsSettingsProvider.md) + - [NatsMetricsSettingsProvider](api/faststream/nats/prometheus/provider/NatsMetricsSettingsProvider.md) + - [settings_provider_factory](api/faststream/nats/prometheus/provider/settings_provider_factory.md) + - publisher + - factory + - [create_publisher](api/faststream/nats/publisher/factory/create_publisher.md) + - fake + - [NatsFakePublisher](api/faststream/nats/publisher/fake/NatsFakePublisher.md) + - producer + - [NatsFastProducer](api/faststream/nats/publisher/producer/NatsFastProducer.md) + - [NatsJSFastProducer](api/faststream/nats/publisher/producer/NatsJSFastProducer.md) + - specified + - [SpecificationPublisher](api/faststream/nats/publisher/specified/SpecificationPublisher.md) + - usecase + - [LogicPublisher](api/faststream/nats/publisher/usecase/LogicPublisher.md) + - response + - [NatsPublishCommand](api/faststream/nats/response/NatsPublishCommand.md) + - [NatsResponse](api/faststream/nats/response/NatsResponse.md) + - router + - [NatsPublisher](api/faststream/nats/router/NatsPublisher.md) + - [NatsRoute](api/faststream/nats/router/NatsRoute.md) + - [NatsRouter](api/faststream/nats/router/NatsRouter.md) + - schemas + - [JStream](api/faststream/nats/schemas/JStream.md) + - [KvWatch](api/faststream/nats/schemas/KvWatch.md) + - [ObjWatch](api/faststream/nats/schemas/ObjWatch.md) + - [PubAck](api/faststream/nats/schemas/PubAck.md) + - [PullSub](api/faststream/nats/schemas/PullSub.md) + - js_stream + - [JStream](api/faststream/nats/schemas/js_stream/JStream.md) + - [compile_nats_wildcard](api/faststream/nats/schemas/js_stream/compile_nats_wildcard.md) + - [is_subject_match_wildcard](api/faststream/nats/schemas/js_stream/is_subject_match_wildcard.md) + - kv_watch + - [KvWatch](api/faststream/nats/schemas/kv_watch/KvWatch.md) + - obj_watch + - [ObjWatch](api/faststream/nats/schemas/obj_watch/ObjWatch.md) + - pull_sub + - [PullSub](api/faststream/nats/schemas/pull_sub/PullSub.md) + - security + - [parse_security](api/faststream/nats/security/parse_security.md) + - subscriber + - adapters + - [UnsubscribeAdapter](api/faststream/nats/subscriber/adapters/UnsubscribeAdapter.md) + - [Unsubscriptable](api/faststream/nats/subscriber/adapters/Unsubscriptable.md) + - [Watchable](api/faststream/nats/subscriber/adapters/Watchable.md) + - factory + - [create_subscriber](api/faststream/nats/subscriber/factory/create_subscriber.md) + - specified + - [SpecificationBatchPullStreamSubscriber](api/faststream/nats/subscriber/specified/SpecificationBatchPullStreamSubscriber.md) + - [SpecificationConcurrentCoreSubscriber](api/faststream/nats/subscriber/specified/SpecificationConcurrentCoreSubscriber.md) + - [SpecificationConcurrentPullStreamSubscriber](api/faststream/nats/subscriber/specified/SpecificationConcurrentPullStreamSubscriber.md) + - [SpecificationConcurrentPushStreamSubscriber](api/faststream/nats/subscriber/specified/SpecificationConcurrentPushStreamSubscriber.md) + - [SpecificationCoreSubscriber](api/faststream/nats/subscriber/specified/SpecificationCoreSubscriber.md) + - [SpecificationKeyValueWatchSubscriber](api/faststream/nats/subscriber/specified/SpecificationKeyValueWatchSubscriber.md) + - [SpecificationObjStoreWatchSubscriber](api/faststream/nats/subscriber/specified/SpecificationObjStoreWatchSubscriber.md) + - [SpecificationPullStreamSubscriber](api/faststream/nats/subscriber/specified/SpecificationPullStreamSubscriber.md) + - [SpecificationPushStreamSubscriber](api/faststream/nats/subscriber/specified/SpecificationPushStreamSubscriber.md) + - [SpecificationSubscriber](api/faststream/nats/subscriber/specified/SpecificationSubscriber.md) + - state + - [ConnectedSubscriberState](api/faststream/nats/subscriber/state/ConnectedSubscriberState.md) + - [EmptySubscriberState](api/faststream/nats/subscriber/state/EmptySubscriberState.md) + - [SubscriberState](api/faststream/nats/subscriber/state/SubscriberState.md) + - usecases + - [BatchPullStreamSubscriber](api/faststream/nats/subscriber/usecases/BatchPullStreamSubscriber.md) + - [ConcurrentCoreSubscriber](api/faststream/nats/subscriber/usecases/ConcurrentCoreSubscriber.md) + - [ConcurrentPullStreamSubscriber](api/faststream/nats/subscriber/usecases/ConcurrentPullStreamSubscriber.md) + - [ConcurrentPushStreamSubscriber](api/faststream/nats/subscriber/usecases/ConcurrentPushStreamSubscriber.md) + - [CoreSubscriber](api/faststream/nats/subscriber/usecases/CoreSubscriber.md) + - [KeyValueWatchSubscriber](api/faststream/nats/subscriber/usecases/KeyValueWatchSubscriber.md) + - [LogicSubscriber](api/faststream/nats/subscriber/usecases/LogicSubscriber.md) + - [ObjStoreWatchSubscriber](api/faststream/nats/subscriber/usecases/ObjStoreWatchSubscriber.md) + - [PullStreamSubscriber](api/faststream/nats/subscriber/usecases/PullStreamSubscriber.md) + - [PushStreamSubscription](api/faststream/nats/subscriber/usecases/PushStreamSubscription.md) + - basic + - [DefaultSubscriber](api/faststream/nats/subscriber/usecases/basic/DefaultSubscriber.md) + - [LogicSubscriber](api/faststream/nats/subscriber/usecases/basic/LogicSubscriber.md) + - core_subscriber + - [ConcurrentCoreSubscriber](api/faststream/nats/subscriber/usecases/core_subscriber/ConcurrentCoreSubscriber.md) + - [CoreSubscriber](api/faststream/nats/subscriber/usecases/core_subscriber/CoreSubscriber.md) + - key_value_subscriber + - [KeyValueWatchSubscriber](api/faststream/nats/subscriber/usecases/key_value_subscriber/KeyValueWatchSubscriber.md) + - object_storage_subscriber + - [ObjStoreWatchSubscriber](api/faststream/nats/subscriber/usecases/object_storage_subscriber/ObjStoreWatchSubscriber.md) + - stream_basic + - [StreamSubscriber](api/faststream/nats/subscriber/usecases/stream_basic/StreamSubscriber.md) + - stream_pull_subscriber + - [BatchPullStreamSubscriber](api/faststream/nats/subscriber/usecases/stream_pull_subscriber/BatchPullStreamSubscriber.md) + - [ConcurrentPullStreamSubscriber](api/faststream/nats/subscriber/usecases/stream_pull_subscriber/ConcurrentPullStreamSubscriber.md) + - [PullStreamSubscriber](api/faststream/nats/subscriber/usecases/stream_pull_subscriber/PullStreamSubscriber.md) + - stream_push_subscriber + - [ConcurrentPushStreamSubscriber](api/faststream/nats/subscriber/usecases/stream_push_subscriber/ConcurrentPushStreamSubscriber.md) + - [PushStreamSubscription](api/faststream/nats/subscriber/usecases/stream_push_subscriber/PushStreamSubscription.md) + - testing + - [FakeProducer](api/faststream/nats/testing/FakeProducer.md) + - [PatchedMessage](api/faststream/nats/testing/PatchedMessage.md) + - [TestNatsBroker](api/faststream/nats/testing/TestNatsBroker.md) + - [build_message](api/faststream/nats/testing/build_message.md) + - opentelemetry + - [Baggage](api/faststream/opentelemetry/Baggage.md) + - [TelemetryMiddleware](api/faststream/opentelemetry/TelemetryMiddleware.md) + - [TelemetrySettingsProvider](api/faststream/opentelemetry/TelemetrySettingsProvider.md) + - baggage + - [Baggage](api/faststream/opentelemetry/baggage/Baggage.md) + - consts + - [MessageAction](api/faststream/opentelemetry/consts/MessageAction.md) + - middleware + - [BaseTelemetryMiddleware](api/faststream/opentelemetry/middleware/BaseTelemetryMiddleware.md) + - [TelemetryMiddleware](api/faststream/opentelemetry/middleware/TelemetryMiddleware.md) + - provider + - [TelemetrySettingsProvider](api/faststream/opentelemetry/provider/TelemetrySettingsProvider.md) + - params + - [Context](api/faststream/params/Context.md) + - [Depends](api/faststream/params/Depends.md) + - [Header](api/faststream/params/Header.md) + - [Path](api/faststream/params/Path.md) + - no_cast + - [NoCastField](api/faststream/params/no_cast/NoCastField.md) + - params + - [Context](api/faststream/params/params/Context.md) + - [Header](api/faststream/params/params/Header.md) + - [Path](api/faststream/params/params/Path.md) + - prometheus + - [ConsumeAttrs](api/faststream/prometheus/ConsumeAttrs.md) + - [MetricsSettingsProvider](api/faststream/prometheus/MetricsSettingsProvider.md) + - [PrometheusMiddleware](api/faststream/prometheus/PrometheusMiddleware.md) + - container + - [MetricsContainer](api/faststream/prometheus/container/MetricsContainer.md) + - manager + - [MetricsManager](api/faststream/prometheus/manager/MetricsManager.md) + - middleware + - [BasePrometheusMiddleware](api/faststream/prometheus/middleware/BasePrometheusMiddleware.md) + - [PrometheusMiddleware](api/faststream/prometheus/middleware/PrometheusMiddleware.md) + - provider + - [MetricsSettingsProvider](api/faststream/prometheus/provider/MetricsSettingsProvider.md) + - types + - [ConsumeAttrs](api/faststream/prometheus/types/ConsumeAttrs.md) + - [ProcessingStatus](api/faststream/prometheus/types/ProcessingStatus.md) + - [PublishingStatus](api/faststream/prometheus/types/PublishingStatus.md) + - rabbit + - [ExchangeType](api/faststream/rabbit/ExchangeType.md) + - [RabbitBroker](api/faststream/rabbit/RabbitBroker.md) + - [RabbitExchange](api/faststream/rabbit/RabbitExchange.md) + - [RabbitPublisher](api/faststream/rabbit/RabbitPublisher.md) + - [RabbitQueue](api/faststream/rabbit/RabbitQueue.md) + - [RabbitResponse](api/faststream/rabbit/RabbitResponse.md) + - [RabbitRoute](api/faststream/rabbit/RabbitRoute.md) + - [RabbitRouter](api/faststream/rabbit/RabbitRouter.md) + - [TestApp](api/faststream/rabbit/TestApp.md) + - [TestRabbitBroker](api/faststream/rabbit/TestRabbitBroker.md) + - broker + - [RabbitBroker](api/faststream/rabbit/broker/RabbitBroker.md) + - broker + - [RabbitBroker](api/faststream/rabbit/broker/broker/RabbitBroker.md) + - logging + - [RabbitParamsStorage](api/faststream/rabbit/broker/logging/RabbitParamsStorage.md) + - registrator + - [RabbitRegistrator](api/faststream/rabbit/broker/registrator/RabbitRegistrator.md) + - fastapi + - [Context](api/faststream/rabbit/fastapi/Context.md) + - [RabbitRouter](api/faststream/rabbit/fastapi/RabbitRouter.md) + - fastapi + - [RabbitRouter](api/faststream/rabbit/fastapi/fastapi/RabbitRouter.md) + - helpers + - declarer + - [RabbitDeclarer](api/faststream/rabbit/helpers/declarer/RabbitDeclarer.md) + - state + - [ConnectedState](api/faststream/rabbit/helpers/state/ConnectedState.md) + - [ConnectionState](api/faststream/rabbit/helpers/state/ConnectionState.md) + - [EmptyConnectionState](api/faststream/rabbit/helpers/state/EmptyConnectionState.md) + - message + - [RabbitMessage](api/faststream/rabbit/message/RabbitMessage.md) + - opentelemetry + - [RabbitTelemetryMiddleware](api/faststream/rabbit/opentelemetry/RabbitTelemetryMiddleware.md) + - middleware + - [RabbitTelemetryMiddleware](api/faststream/rabbit/opentelemetry/middleware/RabbitTelemetryMiddleware.md) + - provider + - [RabbitTelemetrySettingsProvider](api/faststream/rabbit/opentelemetry/provider/RabbitTelemetrySettingsProvider.md) + - parser + - [AioPikaParser](api/faststream/rabbit/parser/AioPikaParser.md) + - prometheus + - [RabbitPrometheusMiddleware](api/faststream/rabbit/prometheus/RabbitPrometheusMiddleware.md) + - middleware + - [RabbitPrometheusMiddleware](api/faststream/rabbit/prometheus/middleware/RabbitPrometheusMiddleware.md) + - provider + - [RabbitMetricsSettingsProvider](api/faststream/rabbit/prometheus/provider/RabbitMetricsSettingsProvider.md) + - publisher + - factory + - [create_publisher](api/faststream/rabbit/publisher/factory/create_publisher.md) + - fake + - [RabbitFakePublisher](api/faststream/rabbit/publisher/fake/RabbitFakePublisher.md) + - options + - [MessageOptions](api/faststream/rabbit/publisher/options/MessageOptions.md) + - [PublishOptions](api/faststream/rabbit/publisher/options/PublishOptions.md) + - producer + - [AioPikaFastProducer](api/faststream/rabbit/publisher/producer/AioPikaFastProducer.md) + - [LockState](api/faststream/rabbit/publisher/producer/LockState.md) + - [LockUnset](api/faststream/rabbit/publisher/producer/LockUnset.md) + - [RealLock](api/faststream/rabbit/publisher/producer/RealLock.md) + - specified + - [SpecificationPublisher](api/faststream/rabbit/publisher/specified/SpecificationPublisher.md) + - usecase + - [LogicPublisher](api/faststream/rabbit/publisher/usecase/LogicPublisher.md) + - [PublishKwargs](api/faststream/rabbit/publisher/usecase/PublishKwargs.md) + - [RequestPublishKwargs](api/faststream/rabbit/publisher/usecase/RequestPublishKwargs.md) + - response + - [RabbitPublishCommand](api/faststream/rabbit/response/RabbitPublishCommand.md) + - [RabbitResponse](api/faststream/rabbit/response/RabbitResponse.md) + - router + - [RabbitPublisher](api/faststream/rabbit/router/RabbitPublisher.md) + - [RabbitRoute](api/faststream/rabbit/router/RabbitRoute.md) + - [RabbitRouter](api/faststream/rabbit/router/RabbitRouter.md) + - schemas + - [BaseRMQInformation](api/faststream/rabbit/schemas/BaseRMQInformation.md) + - [ExchangeType](api/faststream/rabbit/schemas/ExchangeType.md) + - [RabbitExchange](api/faststream/rabbit/schemas/RabbitExchange.md) + - [RabbitQueue](api/faststream/rabbit/schemas/RabbitQueue.md) + - constants + - [ExchangeType](api/faststream/rabbit/schemas/constants/ExchangeType.md) + - exchange + - [RabbitExchange](api/faststream/rabbit/schemas/exchange/RabbitExchange.md) + - proto + - [BaseRMQInformation](api/faststream/rabbit/schemas/proto/BaseRMQInformation.md) + - queue + - [RabbitQueue](api/faststream/rabbit/schemas/queue/RabbitQueue.md) + - security + - [parse_security](api/faststream/rabbit/security/parse_security.md) + - subscriber + - factory + - [create_subscriber](api/faststream/rabbit/subscriber/factory/create_subscriber.md) + - specified + - [SpecificationSubscriber](api/faststream/rabbit/subscriber/specified/SpecificationSubscriber.md) + - usecase + - [LogicSubscriber](api/faststream/rabbit/subscriber/usecase/LogicSubscriber.md) + - testing + - [FakeProducer](api/faststream/rabbit/testing/FakeProducer.md) + - [PatchedMessage](api/faststream/rabbit/testing/PatchedMessage.md) + - [TestRabbitBroker](api/faststream/rabbit/testing/TestRabbitBroker.md) + - [apply_pattern](api/faststream/rabbit/testing/apply_pattern.md) + - [build_message](api/faststream/rabbit/testing/build_message.md) + - utils + - [build_url](api/faststream/rabbit/utils/build_url.md) + - [is_routing_exchange](api/faststream/rabbit/utils/is_routing_exchange.md) + - redis + - [ListSub](api/faststream/redis/ListSub.md) + - [PubSub](api/faststream/redis/PubSub.md) + - [RedisBroker](api/faststream/redis/RedisBroker.md) + - [RedisPublisher](api/faststream/redis/RedisPublisher.md) + - [RedisResponse](api/faststream/redis/RedisResponse.md) + - [RedisRoute](api/faststream/redis/RedisRoute.md) + - [RedisRouter](api/faststream/redis/RedisRouter.md) + - [StreamSub](api/faststream/redis/StreamSub.md) + - [TestApp](api/faststream/redis/TestApp.md) + - [TestRedisBroker](api/faststream/redis/TestRedisBroker.md) + - broker + - broker + - [RedisBroker](api/faststream/redis/broker/broker/RedisBroker.md) + - logging + - [RedisParamsStorage](api/faststream/redis/broker/logging/RedisParamsStorage.md) + - registrator + - [RedisRegistrator](api/faststream/redis/broker/registrator/RedisRegistrator.md) + - fastapi + - [Context](api/faststream/redis/fastapi/Context.md) + - [RedisRouter](api/faststream/redis/fastapi/RedisRouter.md) + - fastapi + - [RedisRouter](api/faststream/redis/fastapi/fastapi/RedisRouter.md) + - helpers + - state + - [ConnectedState](api/faststream/redis/helpers/state/ConnectedState.md) + - [ConnectionState](api/faststream/redis/helpers/state/ConnectionState.md) + - [EmptyConnectionState](api/faststream/redis/helpers/state/EmptyConnectionState.md) + - message + - [BatchListMessage](api/faststream/redis/message/BatchListMessage.md) + - [BatchStreamMessage](api/faststream/redis/message/BatchStreamMessage.md) + - [DefaultListMessage](api/faststream/redis/message/DefaultListMessage.md) + - [DefaultStreamMessage](api/faststream/redis/message/DefaultStreamMessage.md) + - [PubSubMessage](api/faststream/redis/message/PubSubMessage.md) + - [RedisBatchListMessage](api/faststream/redis/message/RedisBatchListMessage.md) + - [RedisBatchStreamMessage](api/faststream/redis/message/RedisBatchStreamMessage.md) + - [RedisListMessage](api/faststream/redis/message/RedisListMessage.md) + - [RedisMessage](api/faststream/redis/message/RedisMessage.md) + - [RedisStreamMessage](api/faststream/redis/message/RedisStreamMessage.md) + - [UnifyRedisDict](api/faststream/redis/message/UnifyRedisDict.md) + - [UnifyRedisMessage](api/faststream/redis/message/UnifyRedisMessage.md) + - opentelemetry + - [RedisTelemetryMiddleware](api/faststream/redis/opentelemetry/RedisTelemetryMiddleware.md) + - middleware + - [RedisTelemetryMiddleware](api/faststream/redis/opentelemetry/middleware/RedisTelemetryMiddleware.md) + - provider + - [RedisTelemetrySettingsProvider](api/faststream/redis/opentelemetry/provider/RedisTelemetrySettingsProvider.md) + - parser + - [RawMessage](api/faststream/redis/parser/RawMessage.md) + - [RedisBatchListParser](api/faststream/redis/parser/RedisBatchListParser.md) + - [RedisBatchStreamParser](api/faststream/redis/parser/RedisBatchStreamParser.md) + - [RedisListParser](api/faststream/redis/parser/RedisListParser.md) + - [RedisPubSubParser](api/faststream/redis/parser/RedisPubSubParser.md) + - [RedisStreamParser](api/faststream/redis/parser/RedisStreamParser.md) + - [SimpleParser](api/faststream/redis/parser/SimpleParser.md) + - prometheus + - [RedisPrometheusMiddleware](api/faststream/redis/prometheus/RedisPrometheusMiddleware.md) + - middleware + - [RedisPrometheusMiddleware](api/faststream/redis/prometheus/middleware/RedisPrometheusMiddleware.md) + - provider + - [BaseRedisMetricsSettingsProvider](api/faststream/redis/prometheus/provider/BaseRedisMetricsSettingsProvider.md) + - [BatchRedisMetricsSettingsProvider](api/faststream/redis/prometheus/provider/BatchRedisMetricsSettingsProvider.md) + - [RedisMetricsSettingsProvider](api/faststream/redis/prometheus/provider/RedisMetricsSettingsProvider.md) + - [settings_provider_factory](api/faststream/redis/prometheus/provider/settings_provider_factory.md) + - publisher + - factory + - [create_publisher](api/faststream/redis/publisher/factory/create_publisher.md) + - fake + - [RedisFakePublisher](api/faststream/redis/publisher/fake/RedisFakePublisher.md) + - producer + - [RedisFastProducer](api/faststream/redis/publisher/producer/RedisFastProducer.md) + - specified + - [SpecificationChannelPublisher](api/faststream/redis/publisher/specified/SpecificationChannelPublisher.md) + - [SpecificationListBatchPublisher](api/faststream/redis/publisher/specified/SpecificationListBatchPublisher.md) + - [SpecificationListPublisher](api/faststream/redis/publisher/specified/SpecificationListPublisher.md) + - [SpecificationPublisher](api/faststream/redis/publisher/specified/SpecificationPublisher.md) + - [SpecificationStreamPublisher](api/faststream/redis/publisher/specified/SpecificationStreamPublisher.md) + - usecase + - [ChannelPublisher](api/faststream/redis/publisher/usecase/ChannelPublisher.md) + - [ListBatchPublisher](api/faststream/redis/publisher/usecase/ListBatchPublisher.md) + - [ListPublisher](api/faststream/redis/publisher/usecase/ListPublisher.md) + - [LogicPublisher](api/faststream/redis/publisher/usecase/LogicPublisher.md) + - [StreamPublisher](api/faststream/redis/publisher/usecase/StreamPublisher.md) + - response + - [DestinationType](api/faststream/redis/response/DestinationType.md) + - [RedisPublishCommand](api/faststream/redis/response/RedisPublishCommand.md) + - [RedisResponse](api/faststream/redis/response/RedisResponse.md) + - router + - [RedisPublisher](api/faststream/redis/router/RedisPublisher.md) + - [RedisRoute](api/faststream/redis/router/RedisRoute.md) + - [RedisRouter](api/faststream/redis/router/RedisRouter.md) + - schemas + - [ListSub](api/faststream/redis/schemas/ListSub.md) + - [PubSub](api/faststream/redis/schemas/PubSub.md) + - [StreamSub](api/faststream/redis/schemas/StreamSub.md) + - list_sub + - [ListSub](api/faststream/redis/schemas/list_sub/ListSub.md) + - proto + - [RedisSpecificationProtocol](api/faststream/redis/schemas/proto/RedisSpecificationProtocol.md) + - [validate_options](api/faststream/redis/schemas/proto/validate_options.md) + - pub_sub + - [PubSub](api/faststream/redis/schemas/pub_sub/PubSub.md) + - stream_sub + - [StreamSub](api/faststream/redis/schemas/stream_sub/StreamSub.md) + - security + - [parse_security](api/faststream/redis/security/parse_security.md) + - subscriber + - factory + - [create_subscriber](api/faststream/redis/subscriber/factory/create_subscriber.md) + - specified + - [SpecificationChannelSubscriber](api/faststream/redis/subscriber/specified/SpecificationChannelSubscriber.md) + - [SpecificationListBatchSubscriber](api/faststream/redis/subscriber/specified/SpecificationListBatchSubscriber.md) + - [SpecificationListSubscriber](api/faststream/redis/subscriber/specified/SpecificationListSubscriber.md) + - [SpecificationStreamBatchSubscriber](api/faststream/redis/subscriber/specified/SpecificationStreamBatchSubscriber.md) + - [SpecificationStreamSubscriber](api/faststream/redis/subscriber/specified/SpecificationStreamSubscriber.md) + - [SpecificationSubscriber](api/faststream/redis/subscriber/specified/SpecificationSubscriber.md) + - usecase + - [BatchListSubscriber](api/faststream/redis/subscriber/usecase/BatchListSubscriber.md) + - [ChannelSubscriber](api/faststream/redis/subscriber/usecase/ChannelSubscriber.md) + - [ListSubscriber](api/faststream/redis/subscriber/usecase/ListSubscriber.md) + - [LogicSubscriber](api/faststream/redis/subscriber/usecase/LogicSubscriber.md) + - [StreamBatchSubscriber](api/faststream/redis/subscriber/usecase/StreamBatchSubscriber.md) + - [StreamSubscriber](api/faststream/redis/subscriber/usecase/StreamSubscriber.md) + - testing + - [ChannelVisitor](api/faststream/redis/testing/ChannelVisitor.md) + - [FakeProducer](api/faststream/redis/testing/FakeProducer.md) + - [ListVisitor](api/faststream/redis/testing/ListVisitor.md) + - [StreamVisitor](api/faststream/redis/testing/StreamVisitor.md) + - [TestRedisBroker](api/faststream/redis/testing/TestRedisBroker.md) + - [Visitor](api/faststream/redis/testing/Visitor.md) + - [build_message](api/faststream/redis/testing/build_message.md) + - response + - [PublishCommand](api/faststream/response/PublishCommand.md) + - [PublishType](api/faststream/response/PublishType.md) + - [Response](api/faststream/response/Response.md) + - [ensure_response](api/faststream/response/ensure_response.md) + - publish_type + - [PublishType](api/faststream/response/publish_type/PublishType.md) + - response + - [PublishCommand](api/faststream/response/response/PublishCommand.md) + - [Response](api/faststream/response/response/Response.md) + - utils + - [ensure_response](api/faststream/response/utils/ensure_response.md) + - security + - [BaseSecurity](api/faststream/security/BaseSecurity.md) + - [SASLGSSAPI](api/faststream/security/SASLGSSAPI.md) + - [SASLOAuthBearer](api/faststream/security/SASLOAuthBearer.md) + - [SASLPlaintext](api/faststream/security/SASLPlaintext.md) + - [SASLScram256](api/faststream/security/SASLScram256.md) + - [SASLScram512](api/faststream/security/SASLScram512.md) + - specification + - [AsyncAPI](api/faststream/specification/AsyncAPI.md) + - [Contact](api/faststream/specification/Contact.md) + - [ExternalDocs](api/faststream/specification/ExternalDocs.md) + - [License](api/faststream/specification/License.md) + - [Tag](api/faststream/specification/Tag.md) + - asyncapi + - [AsyncAPI](api/faststream/specification/asyncapi/AsyncAPI.md) + - [get_asyncapi_html](api/faststream/specification/asyncapi/get_asyncapi_html.md) + - factory + - [AsyncAPI](api/faststream/specification/asyncapi/factory/AsyncAPI.md) + - message + - [get_model_schema](api/faststream/specification/asyncapi/message/get_model_schema.md) + - [get_response_schema](api/faststream/specification/asyncapi/message/get_response_schema.md) + - [parse_handler_params](api/faststream/specification/asyncapi/message/parse_handler_params.md) + - site + - [get_asyncapi_html](api/faststream/specification/asyncapi/site/get_asyncapi_html.md) + - [serve_app](api/faststream/specification/asyncapi/site/serve_app.md) + - utils + - [clear_key](api/faststream/specification/asyncapi/utils/clear_key.md) + - [move_pydantic_refs](api/faststream/specification/asyncapi/utils/move_pydantic_refs.md) + - [resolve_payloads](api/faststream/specification/asyncapi/utils/resolve_payloads.md) + - [to_camelcase](api/faststream/specification/asyncapi/utils/to_camelcase.md) + - v2_6_0 + - [AsyncAPI2](api/faststream/specification/asyncapi/v2_6_0/AsyncAPI2.md) + - [get_app_schema](api/faststream/specification/asyncapi/v2_6_0/get_app_schema.md) + - facade + - [AsyncAPI2](api/faststream/specification/asyncapi/v2_6_0/facade/AsyncAPI2.md) + - generate + - [get_app_schema](api/faststream/specification/asyncapi/v2_6_0/generate/get_app_schema.md) + - [get_broker_channels](api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_channels.md) + - [get_broker_server](api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_server.md) + - [resolve_channel_messages](api/faststream/specification/asyncapi/v2_6_0/generate/resolve_channel_messages.md) + - schema + - [ApplicationInfo](api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationInfo.md) + - [ApplicationSchema](api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationSchema.md) + - [Channel](api/faststream/specification/asyncapi/v2_6_0/schema/Channel.md) + - [Components](api/faststream/specification/asyncapi/v2_6_0/schema/Components.md) + - [Contact](api/faststream/specification/asyncapi/v2_6_0/schema/Contact.md) + - [CorrelationId](api/faststream/specification/asyncapi/v2_6_0/schema/CorrelationId.md) + - [ExternalDocs](api/faststream/specification/asyncapi/v2_6_0/schema/ExternalDocs.md) + - [License](api/faststream/specification/asyncapi/v2_6_0/schema/License.md) + - [Message](api/faststream/specification/asyncapi/v2_6_0/schema/Message.md) + - [Operation](api/faststream/specification/asyncapi/v2_6_0/schema/Operation.md) + - [Parameter](api/faststream/specification/asyncapi/v2_6_0/schema/Parameter.md) + - [Reference](api/faststream/specification/asyncapi/v2_6_0/schema/Reference.md) + - [Server](api/faststream/specification/asyncapi/v2_6_0/schema/Server.md) + - [ServerVariable](api/faststream/specification/asyncapi/v2_6_0/schema/ServerVariable.md) + - [Tag](api/faststream/specification/asyncapi/v2_6_0/schema/Tag.md) + - bindings + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/OperationBinding.md) + - amqp + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/ChannelBinding.md) + - [Exchange](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Exchange.md) + - [Queue](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Queue.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/operation/OperationBinding.md) + - kafka + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/channel/ChannelBinding.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/operation/OperationBinding.md) + - main + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/channel/ChannelBinding.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/operation/OperationBinding.md) + - nats + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/channel/ChannelBinding.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/operation/OperationBinding.md) + - redis + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/channel/ChannelBinding.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/operation/OperationBinding.md) + - sqs + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/ChannelBinding.md) + - [from_spec](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/from_spec.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/OperationBinding.md) + - [from_spec](api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/from_spec.md) + - channels + - [Channel](api/faststream/specification/asyncapi/v2_6_0/schema/channels/Channel.md) + - components + - [Components](api/faststream/specification/asyncapi/v2_6_0/schema/components/Components.md) + - contact + - [Contact](api/faststream/specification/asyncapi/v2_6_0/schema/contact/Contact.md) + - docs + - [ExternalDocs](api/faststream/specification/asyncapi/v2_6_0/schema/docs/ExternalDocs.md) + - info + - [ApplicationInfo](api/faststream/specification/asyncapi/v2_6_0/schema/info/ApplicationInfo.md) + - license + - [License](api/faststream/specification/asyncapi/v2_6_0/schema/license/License.md) + - message + - [CorrelationId](api/faststream/specification/asyncapi/v2_6_0/schema/message/CorrelationId.md) + - [Message](api/faststream/specification/asyncapi/v2_6_0/schema/message/Message.md) + - operations + - [Operation](api/faststream/specification/asyncapi/v2_6_0/schema/operations/Operation.md) + - schema + - [ApplicationSchema](api/faststream/specification/asyncapi/v2_6_0/schema/schema/ApplicationSchema.md) + - servers + - [Server](api/faststream/specification/asyncapi/v2_6_0/schema/servers/Server.md) + - [ServerVariable](api/faststream/specification/asyncapi/v2_6_0/schema/servers/ServerVariable.md) + - tag + - [Tag](api/faststream/specification/asyncapi/v2_6_0/schema/tag/Tag.md) + - utils + - [Parameter](api/faststream/specification/asyncapi/v2_6_0/schema/utils/Parameter.md) + - [Reference](api/faststream/specification/asyncapi/v2_6_0/schema/utils/Reference.md) + - v3_0_0 + - [AsyncAPI3](api/faststream/specification/asyncapi/v3_0_0/AsyncAPI3.md) + - [get_app_schema](api/faststream/specification/asyncapi/v3_0_0/get_app_schema.md) + - facade + - [AsyncAPI3](api/faststream/specification/asyncapi/v3_0_0/facade/AsyncAPI3.md) + - generate + - [get_app_schema](api/faststream/specification/asyncapi/v3_0_0/generate/get_app_schema.md) + - [get_broker_channels](api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_channels.md) + - [get_broker_server](api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_server.md) + - schema + - [ApplicationInfo](api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationInfo.md) + - [ApplicationSchema](api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationSchema.md) + - [Channel](api/faststream/specification/asyncapi/v3_0_0/schema/Channel.md) + - [Components](api/faststream/specification/asyncapi/v3_0_0/schema/Components.md) + - [Contact](api/faststream/specification/asyncapi/v3_0_0/schema/Contact.md) + - [CorrelationId](api/faststream/specification/asyncapi/v3_0_0/schema/CorrelationId.md) + - [ExternalDocs](api/faststream/specification/asyncapi/v3_0_0/schema/ExternalDocs.md) + - [License](api/faststream/specification/asyncapi/v3_0_0/schema/License.md) + - [Message](api/faststream/specification/asyncapi/v3_0_0/schema/Message.md) + - [Operation](api/faststream/specification/asyncapi/v3_0_0/schema/Operation.md) + - [Parameter](api/faststream/specification/asyncapi/v3_0_0/schema/Parameter.md) + - [Reference](api/faststream/specification/asyncapi/v3_0_0/schema/Reference.md) + - [Server](api/faststream/specification/asyncapi/v3_0_0/schema/Server.md) + - [ServerVariable](api/faststream/specification/asyncapi/v3_0_0/schema/ServerVariable.md) + - [Tag](api/faststream/specification/asyncapi/v3_0_0/schema/Tag.md) + - bindings + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/OperationBinding.md) + - amqp + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel/ChannelBinding.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation/OperationBinding.md) + - kafka + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/OperationBinding.md) + - main + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/OperationBinding.md) + - channel + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/channel/ChannelBinding.md) + - operation + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/operation/OperationBinding.md) + - nats + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/OperationBinding.md) + - redis + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/OperationBinding.md) + - sqs + - [ChannelBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/OperationBinding.md) + - channels + - [Channel](api/faststream/specification/asyncapi/v3_0_0/schema/channels/Channel.md) + - components + - [Components](api/faststream/specification/asyncapi/v3_0_0/schema/components/Components.md) + - contact + - [Contact](api/faststream/specification/asyncapi/v3_0_0/schema/contact/Contact.md) + - docs + - [ExternalDocs](api/faststream/specification/asyncapi/v3_0_0/schema/docs/ExternalDocs.md) + - info + - [ApplicationInfo](api/faststream/specification/asyncapi/v3_0_0/schema/info/ApplicationInfo.md) + - license + - [License](api/faststream/specification/asyncapi/v3_0_0/schema/license/License.md) + - message + - [CorrelationId](api/faststream/specification/asyncapi/v3_0_0/schema/message/CorrelationId.md) + - [Message](api/faststream/specification/asyncapi/v3_0_0/schema/message/Message.md) + - operations + - [Action](api/faststream/specification/asyncapi/v3_0_0/schema/operations/Action.md) + - [Operation](api/faststream/specification/asyncapi/v3_0_0/schema/operations/Operation.md) + - schema + - [ApplicationSchema](api/faststream/specification/asyncapi/v3_0_0/schema/schema/ApplicationSchema.md) + - servers + - [Server](api/faststream/specification/asyncapi/v3_0_0/schema/servers/Server.md) + - tag + - [Tag](api/faststream/specification/asyncapi/v3_0_0/schema/tag/Tag.md) + - utils + - [Parameter](api/faststream/specification/asyncapi/v3_0_0/schema/utils/Parameter.md) + - [Reference](api/faststream/specification/asyncapi/v3_0_0/schema/utils/Reference.md) + - base + - info + - [BaseApplicationInfo](api/faststream/specification/base/info/BaseApplicationInfo.md) + - schema + - [BaseApplicationSchema](api/faststream/specification/base/schema/BaseApplicationSchema.md) + - specification + - [Specification](api/faststream/specification/base/specification/Specification.md) + - proto + - [EndpointSpecification](api/faststream/specification/proto/EndpointSpecification.md) + - [ServerSpecification](api/faststream/specification/proto/ServerSpecification.md) + - broker + - [ServerSpecification](api/faststream/specification/proto/broker/ServerSpecification.md) + - endpoint + - [EndpointSpecification](api/faststream/specification/proto/endpoint/EndpointSpecification.md) + - schema + - [Contact](api/faststream/specification/schema/Contact.md) + - [ContactDict](api/faststream/specification/schema/ContactDict.md) + - [ExternalDocs](api/faststream/specification/schema/ExternalDocs.md) + - [ExternalDocsDict](api/faststream/specification/schema/ExternalDocsDict.md) + - [License](api/faststream/specification/schema/License.md) + - [LicenseDict](api/faststream/specification/schema/LicenseDict.md) + - [Message](api/faststream/specification/schema/Message.md) + - [Operation](api/faststream/specification/schema/Operation.md) + - [PublisherSpec](api/faststream/specification/schema/PublisherSpec.md) + - [SubscriberSpec](api/faststream/specification/schema/SubscriberSpec.md) + - [Tag](api/faststream/specification/schema/Tag.md) + - [TagDict](api/faststream/specification/schema/TagDict.md) + - bindings + - [ChannelBinding](api/faststream/specification/schema/bindings/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/schema/bindings/OperationBinding.md) + - amqp + - [ChannelBinding](api/faststream/specification/schema/bindings/amqp/ChannelBinding.md) + - [Exchange](api/faststream/specification/schema/bindings/amqp/Exchange.md) + - [OperationBinding](api/faststream/specification/schema/bindings/amqp/OperationBinding.md) + - [Queue](api/faststream/specification/schema/bindings/amqp/Queue.md) + - kafka + - [ChannelBinding](api/faststream/specification/schema/bindings/kafka/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/schema/bindings/kafka/OperationBinding.md) + - main + - [ChannelBinding](api/faststream/specification/schema/bindings/main/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/schema/bindings/main/OperationBinding.md) + - nats + - [ChannelBinding](api/faststream/specification/schema/bindings/nats/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/schema/bindings/nats/OperationBinding.md) + - redis + - [ChannelBinding](api/faststream/specification/schema/bindings/redis/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/schema/bindings/redis/OperationBinding.md) + - sqs + - [ChannelBinding](api/faststream/specification/schema/bindings/sqs/ChannelBinding.md) + - [OperationBinding](api/faststream/specification/schema/bindings/sqs/OperationBinding.md) + - extra + - [Contact](api/faststream/specification/schema/extra/Contact.md) + - [ContactDict](api/faststream/specification/schema/extra/ContactDict.md) + - [ExternalDocs](api/faststream/specification/schema/extra/ExternalDocs.md) + - [ExternalDocsDict](api/faststream/specification/schema/extra/ExternalDocsDict.md) + - [License](api/faststream/specification/schema/extra/License.md) + - [LicenseDict](api/faststream/specification/schema/extra/LicenseDict.md) + - [Tag](api/faststream/specification/schema/extra/Tag.md) + - [TagDict](api/faststream/specification/schema/extra/TagDict.md) + - contact + - [Contact](api/faststream/specification/schema/extra/contact/Contact.md) + - [ContactDict](api/faststream/specification/schema/extra/contact/ContactDict.md) + - external_docs + - [ExternalDocs](api/faststream/specification/schema/extra/external_docs/ExternalDocs.md) + - [ExternalDocsDict](api/faststream/specification/schema/extra/external_docs/ExternalDocsDict.md) + - license + - [License](api/faststream/specification/schema/extra/license/License.md) + - [LicenseDict](api/faststream/specification/schema/extra/license/LicenseDict.md) + - tag + - [Tag](api/faststream/specification/schema/extra/tag/Tag.md) + - [TagDict](api/faststream/specification/schema/extra/tag/TagDict.md) + - message + - [Message](api/faststream/specification/schema/message/Message.md) + - model + - [Message](api/faststream/specification/schema/message/model/Message.md) + - operation + - [Operation](api/faststream/specification/schema/operation/Operation.md) + - model + - [Operation](api/faststream/specification/schema/operation/model/Operation.md) + - publisher + - [PublisherSpec](api/faststream/specification/schema/publisher/PublisherSpec.md) + - subscriber + - [SubscriberSpec](api/faststream/specification/schema/subscriber/SubscriberSpec.md) +- [FastStream People](faststream-people.md) +- Contributing + - [Development](getting-started/contributing/CONTRIBUTING.md) + - [Documentation](getting-started/contributing/docs.md) +- [Release Notes](release.md) \ No newline at end of file diff --git a/docs/docs/en/api/faststream/AckPolicy.md b/docs/docs/en/api/faststream/AckPolicy.md new file mode 100644 index 0000000000..4d7218c81b --- /dev/null +++ b/docs/docs/en/api/faststream/AckPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..21145bf983 --- /dev/null +++ b/docs/docs/en/api/faststream/BaseMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c6400b1e56 --- /dev/null +++ b/docs/docs/en/api/faststream/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c0704687e8 --- /dev/null +++ b/docs/docs/en/api/faststream/Depends.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a5e2038f22 --- /dev/null +++ b/docs/docs/en/api/faststream/ExceptionMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8d79ba3921 --- /dev/null +++ b/docs/docs/en/api/faststream/FastStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..98bdb592a7 --- /dev/null +++ b/docs/docs/en/api/faststream/Header.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7716f47c23 --- /dev/null +++ b/docs/docs/en/api/faststream/Path.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3475e3f584 --- /dev/null +++ b/docs/docs/en/api/faststream/Response.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2301790c21 --- /dev/null +++ b/docs/docs/en/api/faststream/TestApp.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..24235253c2 --- /dev/null +++ b/docs/docs/en/api/faststream/app/FastStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9dc4603bd2 --- /dev/null +++ b/docs/docs/en/api/faststream/apply_types.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..49a94bd574 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/AsgiFastStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4814f18557 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/AsgiResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9d58b9576c --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/app/AsgiFastStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1124f2d50b --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/app/CliRunState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3789ea0461 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/app/OuterRunState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6d5e2c20c6 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/app/ServerState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1431e2c833 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/app/cast_uvicorn_params.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e96de51b01 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/factories/make_asyncapi_asgi.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fb163d02a1 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/factories/make_ping_asgi.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..044c05ed81 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/get.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8f3c04a050 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/handlers/get.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5e57a1a2db --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/make_asyncapi_asgi.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5c24aaef19 --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/make_ping_asgi.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..037739b09d --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/response/AsgiResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..130ee9a59a --- /dev/null +++ b/docs/docs/en/api/faststream/asgi/websocket/WebSocketClose.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..99fd644946 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/KafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..73e485fcc5 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/KafkaPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eb0eab479c --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/KafkaResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..723012794f --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/KafkaRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b9e7b0d991 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ad101303af --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/TestApp.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0a24384f69 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/TestKafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9b5e09bdf9 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/TopicPartition.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cdfdbc6ef1 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/broker/KafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..05c8356f26 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/broker/broker/KafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..900f945037 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/broker/logging/KafkaParamsStorage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..80068d2349 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/broker/registrator/KafkaRegistrator.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..25374c405d --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/client/AsyncConfluentConsumer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..29bfac283f --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/client/AsyncConfluentProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..232f9ecdf2 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/client/BatchBuilder.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..71ac291b6e --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/client/check_msg_error.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8efc1a80c4 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/client/create_topics.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bf5cfbaca7 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/BrokerAddressFamily.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..41e324305d --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/BuiltinFeatures.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..15f67688f1 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/ClientDNSLookup.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..dd9640afd4 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/CompressionCodec.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8139bfcdda --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/CompressionType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9ebd97c1ff --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/ConfluentConfig.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..27861ffd5b --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/ConfluentFastConfig.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2036046f5d --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/Debug.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a5cab4b1d9 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/GroupProtocol.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d122261f0f --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/IsolationLevel.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4b203e65e9 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/OffsetStoreMethod.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2cb635c6b0 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/SASLOAUTHBearerMethod.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8415d3214e --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/config/SecurityProtocol.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..99bf141f5c --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/fastapi/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..034203e103 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/fastapi/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..87edcc2c3d --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/fastapi/fastapi/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..18971d0829 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/message/ConsumerProtocol.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..19e60bb461 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/message/FakeConsumer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..02004c7d37 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/message/KafkaMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..743c494591 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/opentelemetry/KafkaTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b34265dfbb --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/opentelemetry/middleware/KafkaTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..730662fae5 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BaseConfluentTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a6db133484 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/BatchConfluentTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2c5242e6e5 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/ConfluentTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7dd0e1d0fd --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/opentelemetry/provider/telemetry_attributes_provider_factory.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e5029a60d1 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/parser/AsyncConfluentParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e84e84acc3 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/prometheus/KafkaPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6603893f74 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/prometheus/middleware/KafkaPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..27c186c098 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/prometheus/provider/BaseConfluentMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f784a64e9f --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/prometheus/provider/BatchConfluentMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..65f0a8348e --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/prometheus/provider/ConfluentMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..78358f46e3 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/prometheus/provider/settings_provider_factory.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..60e9664052 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/factory/create_publisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..019fbf855f --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/fake/KafkaFakePublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fd614d1593 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/producer/AsyncConfluentFastProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2879b0d6c3 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationBatchPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..581ae19fd8 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationDefaultPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..55ed49caf5 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/specified/SpecificationPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a72476a6d3 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/state/EmptyProducerState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5a5a35dddd --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/state/ProducerState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..52143d1596 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/state/RealProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..23e8baeed9 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/usecase/BatchPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..faa20eaa11 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/usecase/DefaultPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d9a8594d12 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/publisher/usecase/LogicPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2a4efcf180 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/response/KafkaPublishCommand.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7fa5542613 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/response/KafkaResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ee1c818707 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/router/KafkaPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..60d7bb1c99 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/router/KafkaRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..dac6c1a646 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/router/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0c52345b4e --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/schemas/TopicPartition.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f4ed5b2004 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/schemas/params/ConsumerConnectionParams.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..11e0bc2b3c --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/schemas/partition/TopicPartition.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1eb84ceed6 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/security/parse_security.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ce811a99d9 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/factory/create_subscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ae9e9f42e8 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationBatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a42a4cb21b --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d4dd2d304e --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationDefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8887278921 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/specified/SpecificationSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4642abd4a8 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/usecase/BatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..13d0f308c1 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/usecase/ConcurrentDefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c2d7ed227e --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/usecase/DefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c47daf891f --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/subscriber/usecase/LogicSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..aeaee2a2d7 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/testing/FakeProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..78791486ab --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/testing/MockConfluentMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..53dfed8f24 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/testing/TestKafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..75787a13b3 --- /dev/null +++ b/docs/docs/en/api/faststream/confluent/testing/build_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..175efc68ed --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/AckMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..73b4fcdd21 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/ContextError.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bd988e9332 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/FastStreamException.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bbf1f32d2b --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/FeatureNotSupportedException.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..64495519a4 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/HandlerException.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..18452057c1 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/IgnoredException.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2c890d5358 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/IncorrectState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..05502ca14d --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/NackMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..be491d89c1 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/RejectMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..588e66557f --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/SetupError.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e2a6ac135e --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/SkipMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..05b8e7b74d --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/StartupValidationError.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..12059837a4 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/StopApplication.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9733dcc2e9 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/StopConsume.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..89428f8251 --- /dev/null +++ b/docs/docs/en/api/faststream/exceptions/SubscriberNotFound.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7ee56a5e01 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/KafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c379528109 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/KafkaPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4aab0b965d --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/KafkaResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..89a8d8cca1 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/KafkaRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c60f3ca6f4 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ad101303af --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/TestApp.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..096df3b1d1 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/TestKafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..41fbd7f624 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/TopicPartition.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2cee711d14 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/broker/KafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ca32dd3865 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/broker/broker/KafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f7c8136115 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/broker/logging/KafkaParamsStorage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..aa06d38f65 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/broker/registrator/KafkaRegistrator.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..99bf141f5c --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/fastapi/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2ab7254e79 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/fastapi/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..80fc17dd4a --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/fastapi/fastapi/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c9fd16a983 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/message/ConsumerProtocol.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d41724b288 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/message/FakeConsumer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..16461be675 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/message/KafkaAckableMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7a7a30bae3 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/message/KafkaMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..02fb4805ac --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/opentelemetry/KafkaTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..aba78378f2 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/opentelemetry/middleware/KafkaTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5cb13be947 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BaseKafkaTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d3d7080509 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/BatchKafkaTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0859c0df3d --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/KafkaTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3b2a1ad394 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/opentelemetry/provider/telemetry_attributes_provider_factory.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..25df2532c6 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/parser/AioKafkaBatchParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e7e37cce97 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/parser/AioKafkaParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c2ffd5356a --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/prometheus/KafkaPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..451b7080c0 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/prometheus/middleware/KafkaPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0fd044f694 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/prometheus/provider/BaseKafkaMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9bd01d5e71 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/prometheus/provider/BatchKafkaMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ae7c490da8 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/prometheus/provider/KafkaMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1393fd9065 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/prometheus/provider/settings_provider_factory.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7ec33758af --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/factory/create_publisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6bacca904e --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/fake/KafkaFakePublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..83b116989b --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/producer/AioKafkaFastProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..795766b030 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationBatchPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e191045545 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationDefaultPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ed687d7e08 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/specified/SpecificationPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0152ee7c2f --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/state/EmptyProducerState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c937179471 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/state/ProducerState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a576226b3c --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/state/RealProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..045cfbf45f --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/usecase/BatchPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..07518c75b3 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/usecase/DefaultPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..615da58f90 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/publisher/usecase/LogicPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4852098fcc --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/response/KafkaPublishCommand.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..05ecd69c2d --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/response/KafkaResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5027c18f20 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/router/KafkaPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e7e6184deb --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/router/KafkaRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5d7578bbfc --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/router/KafkaRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b289e61e5a --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/schemas/params/ConsumerConnectionParams.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e325a99ad8 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/security/parse_security.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d9e5fcb4a4 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/factory/create_subscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9e0ce90401 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationBatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..16f0f81d14 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationConcurrentDefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fe8ac61ac2 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationDefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..79dca87d97 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/specified/SpecificationSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6f8978f38b --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/usecase/BatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..16f09d9334 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/usecase/ConcurrentDefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..78949c27dd --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/usecase/DefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..297013e037 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/subscriber/usecase/LogicSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..63eb94c3ca --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/testing/FakeProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..96f257a15f --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/testing/TestKafkaBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..354d7a82f3 --- /dev/null +++ b/docs/docs/en/api/faststream/kafka/testing/build_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b8d3d6c6c8 --- /dev/null +++ b/docs/docs/en/api/faststream/message/AckStatus.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7df391eac3 --- /dev/null +++ b/docs/docs/en/api/faststream/message/SourceType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5f072b2410 --- /dev/null +++ b/docs/docs/en/api/faststream/message/StreamMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c0dce11670 --- /dev/null +++ b/docs/docs/en/api/faststream/message/decode_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7d33d8d904 --- /dev/null +++ b/docs/docs/en/api/faststream/message/encode_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0abdf298b9 --- /dev/null +++ b/docs/docs/en/api/faststream/message/gen_cor_id.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..80940a8ba7 --- /dev/null +++ b/docs/docs/en/api/faststream/message/message/AckStatus.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a41232b74c --- /dev/null +++ b/docs/docs/en/api/faststream/message/message/StreamMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8a6fc990e4 --- /dev/null +++ b/docs/docs/en/api/faststream/message/source_type/SourceType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b2ec48dac0 --- /dev/null +++ b/docs/docs/en/api/faststream/message/utils/decode_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7401e07da5 --- /dev/null +++ b/docs/docs/en/api/faststream/message/utils/encode_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..74b49c30d2 --- /dev/null +++ b/docs/docs/en/api/faststream/message/utils/gen_cor_id.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..82d0033dfb --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/AckPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d3e7d6a763 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/AcknowledgementMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..30f98187a1 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/BaseMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c1d21850c8 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/ExceptionMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8a92ec0a54 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/acknowledgement/conf/AckPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..79b2956eb4 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/acknowledgement/middleware/AcknowledgementMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d3319e7441 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/base/BaseMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..da1693a722 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/exception/ExceptionMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1eea49ddbe --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/exception/ignore_handler.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..58be3830e6 --- /dev/null +++ b/docs/docs/en/api/faststream/middlewares/logging/CriticalLogMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..308d12ac63 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/AckPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..56c357cc07 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/ConsumerConfig.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ebb664d0d9 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/DeliverPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9eacd12198 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/DiscardPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5ea0eacbbc --- /dev/null +++ b/docs/docs/en/api/faststream/nats/ExternalStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..70ca7cab69 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/JStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1527be51fd --- /dev/null +++ b/docs/docs/en/api/faststream/nats/KvWatch.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..376231c4cd --- /dev/null +++ b/docs/docs/en/api/faststream/nats/NatsBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1f1ffbca2a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/NatsPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6b967b527a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/NatsResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b76a8481dc --- /dev/null +++ b/docs/docs/en/api/faststream/nats/NatsRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..89e975235b --- /dev/null +++ b/docs/docs/en/api/faststream/nats/NatsRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..50102ecf31 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/ObjWatch.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bff8b3d4b8 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/Placement.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..697f22abe6 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/PubAck.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..dbfaf68f54 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/PullSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..35ad498def --- /dev/null +++ b/docs/docs/en/api/faststream/nats/RePublish.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6430f0a22f --- /dev/null +++ b/docs/docs/en/api/faststream/nats/ReplayPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..919b818c9e --- /dev/null +++ b/docs/docs/en/api/faststream/nats/RetentionPolicy.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..78a6bc4d8f --- /dev/null +++ b/docs/docs/en/api/faststream/nats/StorageType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3bce18f7de --- /dev/null +++ b/docs/docs/en/api/faststream/nats/StreamConfig.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4d85db37e5 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/StreamSource.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ad101303af --- /dev/null +++ b/docs/docs/en/api/faststream/nats/TestApp.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8557295619 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/TestNatsBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eeea31372b --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/NatsBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7aed0de1ec --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/broker/NatsBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..25b77d4331 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/logging/NatsParamsStorage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f7f313746a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/registrator/NatsRegistrator.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ed5dc00c35 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/state/BrokerState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b7bb106798 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/state/ConnectedState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..66df604330 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/state/ConnectionBrokenState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..88bf83710d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/broker/state/EmptyBrokerState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..99bf141f5c --- /dev/null +++ b/docs/docs/en/api/faststream/nats/fastapi/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..53123192c2 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/fastapi/NatsRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..015f730b4f --- /dev/null +++ b/docs/docs/en/api/faststream/nats/fastapi/fastapi/NatsRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b24feaada6 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/KVBucketDeclarer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3ee16a3f24 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/OSBucketDeclarer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3b2a318598 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/StreamBuilder.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fe0eaec17f --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/bucket_declarer/KVBucketDeclarer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b7663051c8 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/obj_storage_declarer/OSBucketDeclarer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..024daf2d14 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/object_builder/StreamBuilder.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..888302338b --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/state/ConnectedState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0d99fb56ed --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/state/ConnectionState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..31a062d4ad --- /dev/null +++ b/docs/docs/en/api/faststream/nats/helpers/state/EmptyConnectionState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..83017107ff --- /dev/null +++ b/docs/docs/en/api/faststream/nats/message/NatsBatchMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5ac6ed9f41 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/message/NatsKvMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..22d17ceb56 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/message/NatsMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3671628da4 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/message/NatsObjMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e72f2de8ab --- /dev/null +++ b/docs/docs/en/api/faststream/nats/opentelemetry/NatsTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b2bb226585 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/opentelemetry/middleware/NatsTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d6626c537d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/opentelemetry/provider/BaseNatsTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..045996125a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsBatchTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b58590c4fa --- /dev/null +++ b/docs/docs/en/api/faststream/nats/opentelemetry/provider/NatsTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..200d333e0b --- /dev/null +++ b/docs/docs/en/api/faststream/nats/opentelemetry/provider/telemetry_attributes_provider_factory.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..03ad25f549 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/parser/BatchParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0cd283d36e --- /dev/null +++ b/docs/docs/en/api/faststream/nats/parser/JsParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..acba65e133 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/parser/KvParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..00b038738d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/parser/NatsBaseParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ceed3d0bdf --- /dev/null +++ b/docs/docs/en/api/faststream/nats/parser/NatsParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..50ff5d0e18 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/parser/ObjParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d9b179b0c4 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/prometheus/NatsPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7202731048 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/prometheus/middleware/NatsPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..80742833bc --- /dev/null +++ b/docs/docs/en/api/faststream/nats/prometheus/provider/BaseNatsMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..163ebb7bc6 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/prometheus/provider/BatchNatsMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e5515a4cc5 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/prometheus/provider/NatsMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..aeaa7b26e0 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/prometheus/provider/settings_provider_factory.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..19b23b99a5 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/publisher/factory/create_publisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..df23cc8045 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/publisher/fake/NatsFakePublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..82ff491f16 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/publisher/producer/NatsFastProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9c0e046e61 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/publisher/producer/NatsJSFastProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3f5eec9e22 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/publisher/specified/SpecificationPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..08c7794545 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/publisher/usecase/LogicPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..148119ba8a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/response/NatsPublishCommand.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8a7da66982 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/response/NatsResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b025495e44 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/router/NatsPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..36df33c45e --- /dev/null +++ b/docs/docs/en/api/faststream/nats/router/NatsRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4b6dfaaf7d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/router/NatsRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..51df9a02cc --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/JStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ce99738043 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/KvWatch.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..51c3628e5e --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/ObjWatch.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..697f22abe6 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/PubAck.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cb7341340c --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/PullSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..af375c116a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/js_stream/JStream.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..910f034eff --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/js_stream/compile_nats_wildcard.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f9305b94e8 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/js_stream/is_subject_match_wildcard.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ce07fa305d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/kv_watch/KvWatch.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..55831b8a6a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/obj_watch/ObjWatch.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..673a1e8ff6 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/schemas/pull_sub/PullSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d2fe5dd0c3 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/security/parse_security.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9b00a89428 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/adapters/UnsubscribeAdapter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4c6c6b0abe --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/adapters/Unsubscriptable.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..00dde78565 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/adapters/Watchable.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0e132c3394 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/factory/create_subscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d663201213 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationBatchPullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..24f1a256ce --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentCoreSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..45d7106b98 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4a5bebd382 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationConcurrentPushStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5415ec6203 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationCoreSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bd9e10e9d2 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationKeyValueWatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d2b5bfa27f --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationObjStoreWatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c0867b195f --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ef20892652 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationPushStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..613fdecd8a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/specified/SpecificationSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3398403cb2 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/state/ConnectedSubscriberState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..de80057014 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/state/EmptySubscriberState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a61839436a --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/state/SubscriberState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..667ff42587 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/BatchPullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bbd0895a8c --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentCoreSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7bb13db682 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c694d41369 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/ConcurrentPushStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e35ebd3f9d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/CoreSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..507c7a33c4 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/KeyValueWatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e97348563d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/LogicSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..25d1434968 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/ObjStoreWatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ddc3731c6e --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/PullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9ea5735afb --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/PushStreamSubscription.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f0bd5e52aa --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/DefaultSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9dfc93aa9b --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/basic/LogicSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a684452aa1 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/ConcurrentCoreSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cc1905f58e --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/core_subscriber/CoreSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..26e1b670d0 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/key_value_subscriber/KeyValueWatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b1722e57ec --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/object_storage_subscriber/ObjStoreWatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b08fd2abff --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_basic/StreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9e4973cf67 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/BatchPullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6c31f93a20 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/ConcurrentPullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..35e7de26de --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_pull_subscriber/PullStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..78cffa0a9f --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/ConcurrentPushStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eee1f7aeb7 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/subscriber/usecases/stream_push_subscriber/PushStreamSubscription.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f2615aeb36 --- /dev/null +++ b/docs/docs/en/api/faststream/nats/testing/FakeProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e32802d4dd --- /dev/null +++ b/docs/docs/en/api/faststream/nats/testing/PatchedMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2abcf7f06d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/testing/TestNatsBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..160977893d --- /dev/null +++ b/docs/docs/en/api/faststream/nats/testing/build_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a61cb56d97 --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/Baggage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..914f134e60 --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/TelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7ca8b2cb6d --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/TelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c1c6e4efec --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/baggage/Baggage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cd58706774 --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/consts/MessageAction.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..64a7b4a501 --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/middleware/BaseTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f019b3ad61 --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/middleware/TelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0fefe1c0ef --- /dev/null +++ b/docs/docs/en/api/faststream/opentelemetry/provider/TelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8eb7fc249a --- /dev/null +++ b/docs/docs/en/api/faststream/params/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c0704687e8 --- /dev/null +++ b/docs/docs/en/api/faststream/params/Depends.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f3dd71365c --- /dev/null +++ b/docs/docs/en/api/faststream/params/Header.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ad04fdff6e --- /dev/null +++ b/docs/docs/en/api/faststream/params/Path.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..56821cae8a --- /dev/null +++ b/docs/docs/en/api/faststream/params/no_cast/NoCastField.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4c3ec6b4dd --- /dev/null +++ b/docs/docs/en/api/faststream/params/params/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6b15bd1ec1 --- /dev/null +++ b/docs/docs/en/api/faststream/params/params/Header.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0903f40023 --- /dev/null +++ b/docs/docs/en/api/faststream/params/params/Path.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ad8e536b7a --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/ConsumeAttrs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0f7405e44d --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/MetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c340a0cb23 --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/PrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..009d88d263 --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/container/MetricsContainer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b1a897c717 --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/manager/MetricsManager.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..62bbd031ac --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/middleware/BasePrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2902586e38 --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/middleware/PrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3511a21a5b --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/provider/MetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d9196cab8d --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/types/ConsumeAttrs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..98b6710bcd --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/types/ProcessingStatus.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4e7435fbea --- /dev/null +++ b/docs/docs/en/api/faststream/prometheus/types/PublishingStatus.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9b299b951d --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/ExchangeType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f48b2b5e78 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/RabbitBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bbf9676e72 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/RabbitExchange.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7e0d3f674b --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/RabbitPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..97945b6408 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/RabbitQueue.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4d20d82b0e --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/RabbitResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e11a9f058d --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/RabbitRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..133880fc50 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/RabbitRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ad101303af --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/TestApp.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c4519d58b8 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/TestRabbitBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ac72ec0ae9 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/broker/RabbitBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9ed9170ead --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/broker/broker/RabbitBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e9e46da6af --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/broker/logging/RabbitParamsStorage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f22385f512 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/broker/registrator/RabbitRegistrator.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..99bf141f5c --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/fastapi/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..72f0a90072 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/fastapi/RabbitRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d70c558254 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/fastapi/fastapi/RabbitRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b8fc8a0ebd --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/helpers/declarer/RabbitDeclarer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..db97303aa3 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectedState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..36b3d4d4d1 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/helpers/state/ConnectionState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7b0af42897 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/helpers/state/EmptyConnectionState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..598d43f818 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/message/RabbitMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7d5ef3de27 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/opentelemetry/RabbitTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e86771a8ba --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/opentelemetry/middleware/RabbitTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ba6742ac90 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/opentelemetry/provider/RabbitTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0a02d90270 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/parser/AioPikaParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2c4308fabd --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/prometheus/RabbitPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..45163c998a --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/prometheus/middleware/RabbitPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6d63301b34 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/prometheus/provider/RabbitMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bac090fa43 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/factory/create_publisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..60879c8e3a --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/fake/RabbitFakePublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eaa454588a --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/options/MessageOptions.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c80cc9e937 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/options/PublishOptions.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..527cc5604c --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/producer/AioPikaFastProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4d7b37ba46 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/producer/LockState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..95df1a10e7 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/producer/LockUnset.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..570a279a0a --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/producer/RealLock.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0001c99fb7 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/specified/SpecificationPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1ef927866e --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/usecase/LogicPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3d917891cd --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/usecase/PublishKwargs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5668633016 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/publisher/usecase/RequestPublishKwargs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4c4bb224b6 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/response/RabbitPublishCommand.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..477cfb9861 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/response/RabbitResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..befbec9103 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/router/RabbitPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8e8b0fbb6c --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/router/RabbitRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eff5f6169a --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/router/RabbitRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7ff32d2cd2 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/BaseRMQInformation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c6c2ef8a28 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/ExchangeType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4e60ed96f5 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/RabbitExchange.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..947238b788 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/RabbitQueue.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..11705f35ac --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/constants/ExchangeType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ebcb211714 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/exchange/RabbitExchange.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1eca00071b --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/proto/BaseRMQInformation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..83bc15e02f --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/schemas/queue/RabbitQueue.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0b19ee5ee2 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/security/parse_security.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..79c7082931 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/subscriber/factory/create_subscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..928876011d --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/subscriber/specified/SpecificationSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..56ef70dd0d --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/subscriber/usecase/LogicSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7fa3603f60 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/testing/FakeProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f58c1140c2 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/testing/PatchedMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ab2c088b39 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/testing/TestRabbitBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..02ffd305ef --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/testing/apply_pattern.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..296715e46a --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/testing/build_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ffb6555837 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/utils/build_url.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4ef1481a69 --- /dev/null +++ b/docs/docs/en/api/faststream/rabbit/utils/is_routing_exchange.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9c97a0afcd --- /dev/null +++ b/docs/docs/en/api/faststream/redis/ListSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d2fba00014 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/PubSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7275bfb60a --- /dev/null +++ b/docs/docs/en/api/faststream/redis/RedisBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..565d857810 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/RedisPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eedecf1ea3 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/RedisResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..14b4416ed4 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/RedisRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9b7292e703 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/RedisRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d1244238b6 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/StreamSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ad101303af --- /dev/null +++ b/docs/docs/en/api/faststream/redis/TestApp.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..703490c302 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/TestRedisBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fdc177e868 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/broker/broker/RedisBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b7d1bb680a --- /dev/null +++ b/docs/docs/en/api/faststream/redis/broker/logging/RedisParamsStorage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8d040533d7 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/broker/registrator/RedisRegistrator.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..99bf141f5c --- /dev/null +++ b/docs/docs/en/api/faststream/redis/fastapi/Context.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7894f88728 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/fastapi/RedisRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..858c951f61 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/fastapi/fastapi/RedisRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..793fdb055e --- /dev/null +++ b/docs/docs/en/api/faststream/redis/helpers/state/ConnectedState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0a27d849dc --- /dev/null +++ b/docs/docs/en/api/faststream/redis/helpers/state/ConnectionState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..70273722e0 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/helpers/state/EmptyConnectionState.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c510fa09b9 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/BatchListMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..16885fd028 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/BatchStreamMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8f38b34cae --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/DefaultListMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6016bb624e --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/DefaultStreamMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..795cecb12e --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/PubSubMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ec7d3983bd --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/RedisBatchListMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2c66613eb7 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/RedisBatchStreamMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8c996cb7f0 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/RedisListMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1b0654e7ce --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/RedisMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c36385a141 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/RedisStreamMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9485ca2848 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/UnifyRedisDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..dee09d1657 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/message/UnifyRedisMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..537a2dc7b9 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/opentelemetry/RedisTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4c0febf261 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/opentelemetry/middleware/RedisTelemetryMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..26e7859c34 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/opentelemetry/provider/RedisTelemetrySettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4add7b37fd --- /dev/null +++ b/docs/docs/en/api/faststream/redis/parser/RawMessage.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e3a583eee8 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/parser/RedisBatchListParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..28ed437573 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/parser/RedisBatchStreamParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fd0cf87991 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/parser/RedisListParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..93ab92cfdb --- /dev/null +++ b/docs/docs/en/api/faststream/redis/parser/RedisPubSubParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..79633d06ad --- /dev/null +++ b/docs/docs/en/api/faststream/redis/parser/RedisStreamParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..239d3fda25 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/parser/SimpleParser.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..01b23fe4f1 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/prometheus/RedisPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c29cc91130 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/prometheus/middleware/RedisPrometheusMiddleware.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..243414331b --- /dev/null +++ b/docs/docs/en/api/faststream/redis/prometheus/provider/BaseRedisMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..33d1d2d3a1 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/prometheus/provider/BatchRedisMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a7f5f3abe8 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/prometheus/provider/RedisMetricsSettingsProvider.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..aa4812f1e2 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/prometheus/provider/settings_provider_factory.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e568f4120a --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/factory/create_publisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eb00559657 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/fake/RedisFakePublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3bc630cc42 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/producer/RedisFastProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..93b88342e4 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationChannelPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c3f9769199 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListBatchPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a7ed630a72 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationListPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ceb47b19f6 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5800dc96da --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/specified/SpecificationStreamPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8aad760800 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/usecase/ChannelPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d7a1be63e4 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/usecase/ListBatchPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..59895dc001 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/usecase/ListPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c441bcc461 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/usecase/LogicPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ea56c9d699 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/publisher/usecase/StreamPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4eda1ad154 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/response/DestinationType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..14e21c799e --- /dev/null +++ b/docs/docs/en/api/faststream/redis/response/RedisPublishCommand.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..dd7fbe72eb --- /dev/null +++ b/docs/docs/en/api/faststream/redis/response/RedisResponse.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fd1cad4d37 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/router/RedisPublisher.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d6e1f525a7 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/router/RedisRoute.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..373ceea5a8 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/router/RedisRouter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3e0b448229 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/ListSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..078a8e2d8e --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/PubSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..396e594c0b --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/StreamSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f4b58ff4fb --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/list_sub/ListSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..de3ab92ace --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/proto/RedisSpecificationProtocol.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7a5381120e --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/proto/validate_options.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..08552c7b8c --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/pub_sub/PubSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e1a8d44d4e --- /dev/null +++ b/docs/docs/en/api/faststream/redis/schemas/stream_sub/StreamSub.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d3673649db --- /dev/null +++ b/docs/docs/en/api/faststream/redis/security/parse_security.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d5cf7eadc8 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/factory/create_subscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..538babd05f --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationChannelSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..60e7fa385d --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListBatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..988ffccb3c --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationListSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..76a6aff457 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamBatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f1bfe8a520 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationStreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..90a2845dc9 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/specified/SpecificationSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..aee1b8aa9b --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/usecase/BatchListSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3ab1fc045a --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/usecase/ChannelSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f7c44e8be5 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/usecase/ListSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e3531e7dcc --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/usecase/LogicSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3500cc21e2 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamBatchSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6e2ac31d7f --- /dev/null +++ b/docs/docs/en/api/faststream/redis/subscriber/usecase/StreamSubscriber.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f916be2ae8 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/testing/ChannelVisitor.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e05efb6448 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/testing/FakeProducer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..414b8a0400 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/testing/ListVisitor.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0b72d99109 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/testing/StreamVisitor.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..22946e09f8 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/testing/TestRedisBroker.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..746688710f --- /dev/null +++ b/docs/docs/en/api/faststream/redis/testing/Visitor.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b2265905c6 --- /dev/null +++ b/docs/docs/en/api/faststream/redis/testing/build_message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8ca17ac376 --- /dev/null +++ b/docs/docs/en/api/faststream/response/PublishCommand.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..57d3cbddd7 --- /dev/null +++ b/docs/docs/en/api/faststream/response/PublishType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e96fe35896 --- /dev/null +++ b/docs/docs/en/api/faststream/response/Response.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e55d638acf --- /dev/null +++ b/docs/docs/en/api/faststream/response/ensure_response.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2ac2fcd51c --- /dev/null +++ b/docs/docs/en/api/faststream/response/publish_type/PublishType.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b247a7e5d8 --- /dev/null +++ b/docs/docs/en/api/faststream/response/response/PublishCommand.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..01a68bb486 --- /dev/null +++ b/docs/docs/en/api/faststream/response/response/Response.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..327b9ce951 --- /dev/null +++ b/docs/docs/en/api/faststream/response/utils/ensure_response.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0e5abb09ae --- /dev/null +++ b/docs/docs/en/api/faststream/security/BaseSecurity.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8b6eec2741 --- /dev/null +++ b/docs/docs/en/api/faststream/security/SASLGSSAPI.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9652a58840 --- /dev/null +++ b/docs/docs/en/api/faststream/security/SASLOAuthBearer.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b4b5165f27 --- /dev/null +++ b/docs/docs/en/api/faststream/security/SASLPlaintext.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4d50681fa9 --- /dev/null +++ b/docs/docs/en/api/faststream/security/SASLScram256.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..115645cc8c --- /dev/null +++ b/docs/docs/en/api/faststream/security/SASLScram512.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4b23e3fa4a --- /dev/null +++ b/docs/docs/en/api/faststream/specification/AsyncAPI.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..aa8ac012ea --- /dev/null +++ b/docs/docs/en/api/faststream/specification/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..52e0432c94 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ac2365f82b --- /dev/null +++ b/docs/docs/en/api/faststream/specification/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ae4f1202a1 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f6c0b2de09 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/AsyncAPI.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9e68cc1f6c --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/factory/AsyncAPI.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..02a5bf12cb --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/get_asyncapi_html.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..83b5c9026e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/message/get_model_schema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d283b28902 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/message/get_response_schema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cb6c4416f8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/message/parse_handler_params.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..837b931af7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/site/get_asyncapi_html.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..279e9eb8e0 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/site/serve_app.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cf6103d19a --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/utils/clear_key.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..445472f96d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/utils/move_pydantic_refs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d92d1850f3 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/utils/resolve_payloads.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5a260c9cca --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/utils/to_camelcase.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b6ca4b870a --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/AsyncAPI2.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1807a92056 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/facade/AsyncAPI2.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ef0e191d3d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_app_schema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..03fc069dc1 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_channels.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c7b9007c14 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/get_broker_server.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..91abb99b8b --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/generate/resolve_channel_messages.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..234b4b8bda --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/get_app_schema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b7aaf16515 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationInfo.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..614fed94e1 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ApplicationSchema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..76da65a973 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Channel.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..12ba1a0a30 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Components.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7eba14d8b1 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3173309f51 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/CorrelationId.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2df43d1016 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3f17b11448 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f6247931d4 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e25d0e8ff2 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Operation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fac8aa5ee7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Parameter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c469faf891 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Reference.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..82bc1ddb32 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Server.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..06639f3ec5 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/ServerVariable.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..35baa89db7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..36874fc37c --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..eb11d6b550 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..263e89f51b --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..350a96b413 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6b4f8d6d93 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..dbd3288b64 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Exchange.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..31de312529 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/channel/Queue.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..937cda8820 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/amqp/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7792a2bef7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..21c35af99f --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..82b2556711 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..49e28f86ef --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/kafka/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a044af926c --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9cf2d46f59 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c7d4ecef03 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b464bbb356 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/main/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8380c4571d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c48ff3bad7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ebc06a51b8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..10ebc684ce --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/nats/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..49402a3533 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4a41fede12 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4c859b133e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5e7ef90817 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/redis/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..efd54e587e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4f3babf6a5 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..274f800ea8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6890ca0373 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/channel/from_spec.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..931067bfef --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b8a69ffcc0 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/bindings/sqs/operation/from_spec.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..520d156b96 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/channels/Channel.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..215edc3e69 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/components/Components.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..14b7574d92 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/contact/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8b66a2c5f3 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/docs/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..db377ddd61 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/info/ApplicationInfo.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d9d4102522 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/license/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bbfc2f40d8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/CorrelationId.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9667e77e8e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/message/Message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3d750e5f3e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/operations/Operation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2a380a8e4d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/schema/ApplicationSchema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a50c1a5cf1 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/Server.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8606288a32 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/servers/ServerVariable.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c3d9025966 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/tag/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c2971d5485 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Parameter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2737907b0e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v2_6_0/schema/utils/Reference.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4eb400a450 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/AsyncAPI3.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5216f86a02 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/facade/AsyncAPI3.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0faa97ba94 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_app_schema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d43691125d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_channels.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1c71db1292 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/generate/get_broker_server.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..977c46289d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/get_app_schema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..be7a85513c --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationInfo.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0f3fa28a38 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ApplicationSchema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f213110586 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Channel.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bce8d6e93e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Components.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..14b7574d92 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bbfc2f40d8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/CorrelationId.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8b66a2c5f3 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d9d4102522 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9667e77e8e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a46ecefb8d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Operation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c2971d5485 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Parameter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2737907b0e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Reference.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d41ebe84c3 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Server.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8606288a32 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/ServerVariable.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c3d9025966 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ca8431218b --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..876f866f35 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2777001c4d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..325bba3f9e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..74c10098ac --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..51c5024cc7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..82b2556711 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..49e28f86ef --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/kafka/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..07977ed15f --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c897790951 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..409e449a27 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/channel/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4e85a7f5e4 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/main/operation/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..ebc06a51b8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..10ebc684ce --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/nats/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4c859b133e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5e7ef90817 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/redis/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..274f800ea8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..931067bfef --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/bindings/sqs/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b3b425a350 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/channels/Channel.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..db5c489f43 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/components/Components.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..14b7574d92 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/contact/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8b66a2c5f3 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/docs/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f0c2b0f95d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/info/ApplicationInfo.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d9d4102522 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/license/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bbfc2f40d8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/CorrelationId.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..9667e77e8e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/message/Message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c5a9956348 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Action.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1ac73f73da --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/operations/Operation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..57fc00568a --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/schema/ApplicationSchema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1d9f1168d9 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/servers/Server.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c3d9025966 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/tag/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c2971d5485 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Parameter.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2737907b0e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/asyncapi/v3_0_0/schema/utils/Reference.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..324bbbcec9 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/base/info/BaseApplicationInfo.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8d9291322c --- /dev/null +++ b/docs/docs/en/api/faststream/specification/base/schema/BaseApplicationSchema.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0b3f07b9f7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/base/specification/Specification.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..3d6dcee882 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/proto/EndpointSpecification.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d49b60e512 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/proto/ServerSpecification.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6bb667f707 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/proto/broker/ServerSpecification.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..491c5e3e87 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/proto/endpoint/EndpointSpecification.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5c95b1d99b --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..79d9ca5fb2 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/ContactDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..242418f578 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..788848b13a --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/ExternalDocsDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4e321c7aab --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..16204a3fc8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/LicenseDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..d1baee52f5 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/Message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cde09d402f --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/Operation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5b3e7f23e5 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/PublisherSpec.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..7ec1f6964b --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/SubscriberSpec.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..03071c314f --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..02f4de9c05 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/TagDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cb7f566dc1 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6fcad5ea7e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..194c68f536 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..355222c2bb --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Exchange.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..6bb90ca8ae --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..54c9493d0e --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/amqp/Queue.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..2561bf2e72 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/kafka/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0746cedd33 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/kafka/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..73bfc4bb40 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/main/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f4ebb70b9c --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/main/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..4495e21ac2 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/nats/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fde8061b86 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/nats/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..0f991824da --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/redis/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..95e3ca446a --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/redis/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..521a6f5560 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/sqs/ChannelBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a70995cb7f --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/bindings/sqs/OperationBinding.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f89be2dc65 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..8f20fd396d --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/ContactDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..a745e15910 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1110d88070 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/ExternalDocsDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..033374ed25 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..e2994e1d88 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/LicenseDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cc373f1528 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..c2455e5c4f --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/TagDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f34ea777d3 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/contact/Contact.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..17d0d774eb --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/contact/ContactDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..bf06e4b97c --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocs.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..cf1c76bc2b --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/external_docs/ExternalDocsDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..58cb3821e7 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/license/License.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..fb8779aa39 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/license/LicenseDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..b25a4d5cb1 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/tag/Tag.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..92500cc5b2 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/extra/tag/TagDict.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..1c2fd0ceb8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/message/Message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..f057a4e898 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/message/model/Message.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..23088a80f0 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/operation/Operation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..17c306a8ab --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/operation/model/Operation.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..002bc1ecb8 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/publisher/PublisherSpec.md @@ -0,0 +1,11 @@ +--- +# 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 new file mode 100644 index 0000000000..5a4e4515e2 --- /dev/null +++ b/docs/docs/en/api/faststream/specification/schema/subscriber/SubscriberSpec.md @@ -0,0 +1,11 @@ +--- +# 0.5 - API +# 2 - Release +# 3 - Contributing +# 5 - Template Page +# 10 - Default +search: + boost: 0.5 +--- + +::: faststream.specification.schema.subscriber.SubscriberSpec diff --git a/faststream/_internal/broker/abc_broker.py b/faststream/_internal/broker/abc_broker.py index 93d62accf0..97ace30b81 100644 --- a/faststream/_internal/broker/abc_broker.py +++ b/faststream/_internal/broker/abc_broker.py @@ -46,6 +46,7 @@ def __init__( decoder: Optional["CustomCallable"], include_in_schema: Optional[bool], state: "BrokerState", + routers: Sequence["ABCBroker[Any]"], ) -> None: self.prefix = prefix self.include_in_schema = include_in_schema @@ -60,6 +61,8 @@ def __init__( self._state = Pointer(state) + self.include_routers(*routers) + def add_middleware(self, middleware: "BrokerMiddleware[MsgType]") -> None: """Append BrokerMiddleware to the end of middlewares list. diff --git a/faststream/_internal/broker/broker.py b/faststream/_internal/broker/broker.py index db0d81e839..fa59569e30 100644 --- a/faststream/_internal/broker/broker.py +++ b/faststream/_internal/broker/broker.py @@ -93,6 +93,10 @@ def __init__( "Graceful shutdown timeout. Broker waits for all running subscribers completion before shut down.", ), ], + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ], # Logging args logger_state: LoggerState, # FastDepends args @@ -163,6 +167,7 @@ def __init__( Optional["AsyncCustomCallable"], to_async(parser) if parser else None, ), + routers=routers, # Broker is a root router include_in_schema=True, prefix="", diff --git a/faststream/_internal/broker/router.py b/faststream/_internal/broker/router.py index ee2f28602a..81f4a2998a 100644 --- a/faststream/_internal/broker/router.py +++ b/faststream/_internal/broker/router.py @@ -74,6 +74,7 @@ def __init__( parser: Optional["CustomCallable"], decoder: Optional["CustomCallable"], include_in_schema: Optional[bool], + routers: Sequence["ABCBroker[Any]"], ) -> None: super().__init__( prefix=prefix, @@ -83,6 +84,7 @@ def __init__( decoder=decoder, include_in_schema=include_in_schema, state=EmptyBrokerState("You should include router to any broker."), + routers=routers ) for h in handlers: diff --git a/faststream/confluent/broker/broker.py b/faststream/confluent/broker/broker.py index 8a930fea91..1b96a46126 100644 --- a/faststream/confluent/broker/broker.py +++ b/faststream/confluent/broker/broker.py @@ -46,6 +46,7 @@ LoggerProto, SendableMessage, ) + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -280,6 +281,10 @@ def __init__( ], Doc("Middlewares to apply to all broker publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), # AsyncAPI args security: Annotated[ Optional["BaseSecurity"], @@ -379,6 +384,7 @@ def __init__( decoder=decoder, parser=parser, middlewares=middlewares, + routers=routers, # AsyncAPI args description=description, specification_url=specification_url, diff --git a/faststream/confluent/router.py b/faststream/confluent/router.py index 53a3d97426..ed6ca3bce8 100644 --- a/faststream/confluent/router.py +++ b/faststream/confluent/router.py @@ -25,6 +25,7 @@ from fast_depends.dependencies import Dependant from faststream._internal.basic_types import SendableMessage + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -508,6 +509,10 @@ def __init__( ], Doc("Router middlewares to apply to all routers' publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), parser: Annotated[ Optional["CustomCallable"], Doc("Parser to map original **Message** object to FastStream one."), @@ -527,6 +532,7 @@ def __init__( prefix=prefix, dependencies=dependencies, middlewares=middlewares, # type: ignore[arg-type] + routers=routers, parser=parser, decoder=decoder, include_in_schema=include_in_schema, diff --git a/faststream/kafka/broker/broker.py b/faststream/kafka/broker/broker.py index 5b4f74b8a8..292f3a566b 100644 --- a/faststream/kafka/broker/broker.py +++ b/faststream/kafka/broker/broker.py @@ -51,6 +51,7 @@ LoggerProto, SendableMessage, ) + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -453,6 +454,10 @@ def __init__( ], Doc("Middlewares to apply to all broker publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), # AsyncAPI args security: Annotated[ Optional["BaseSecurity"], @@ -559,6 +564,7 @@ def __init__( decoder=decoder, parser=parser, middlewares=middlewares, + routers=routers, # AsyncAPI args description=description, specification_url=specification_url, diff --git a/faststream/kafka/router.py b/faststream/kafka/router.py index 31b21fccf0..a9d51af57f 100644 --- a/faststream/kafka/router.py +++ b/faststream/kafka/router.py @@ -28,6 +28,7 @@ from fast_depends.dependencies import Dependant from faststream._internal.basic_types import SendableMessage + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -618,6 +619,10 @@ def __init__( ], Doc("Router middlewares to apply to all routers' publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), parser: Annotated[ Optional["CustomCallable"], Doc("Parser to map original **ConsumerRecord** object to FastStream one."), @@ -637,6 +642,7 @@ def __init__( prefix=prefix, dependencies=dependencies, middlewares=middlewares, + routers=routers, parser=parser, decoder=decoder, include_in_schema=include_in_schema, diff --git a/faststream/nats/broker/broker.py b/faststream/nats/broker/broker.py index 1055f4f60d..0940225a29 100644 --- a/faststream/nats/broker/broker.py +++ b/faststream/nats/broker/broker.py @@ -66,6 +66,7 @@ LoggerProto, SendableMessage, ) + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -376,6 +377,10 @@ def __init__( Sequence["BrokerMiddleware[Msg]"], Doc("Middlewares to apply to all broker publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), # AsyncAPI args security: Annotated[ Optional["BaseSecurity"], @@ -485,6 +490,7 @@ def __init__( decoder=decoder, parser=parser, middlewares=middlewares, + routers=routers, # AsyncAPI description=description, specification_url=specification_url, diff --git a/faststream/nats/router.py b/faststream/nats/router.py index 556bfb7f66..101026e00b 100644 --- a/faststream/nats/router.py +++ b/faststream/nats/router.py @@ -25,6 +25,7 @@ from nats.aio.msg import Msg from faststream._internal.basic_types import SendableMessage + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -360,6 +361,10 @@ def __init__( Sequence["BrokerMiddleware[Msg]"], Doc("Router middlewares to apply to all routers' publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), parser: Annotated[ Optional["CustomCallable"], Doc("Parser to map original **IncomingMessage** Msg to FastStream one."), @@ -379,6 +384,7 @@ def __init__( prefix=prefix, dependencies=dependencies, middlewares=middlewares, + routers=routers, parser=parser, decoder=decoder, include_in_schema=include_in_schema, diff --git a/faststream/rabbit/broker/broker.py b/faststream/rabbit/broker/broker.py index 789ac5b931..a171755cf1 100644 --- a/faststream/rabbit/broker/broker.py +++ b/faststream/rabbit/broker/broker.py @@ -172,6 +172,10 @@ def __init__( Sequence["BrokerMiddleware[IncomingMessage]"], Doc("Middlewares to apply to all broker publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), # AsyncAPI args security: Annotated[ Optional["BaseSecurity"], @@ -266,6 +270,7 @@ def __init__( decoder=decoder, parser=parser, middlewares=middlewares, + routers=routers, # AsyncAPI args description=description, specification_url=specification_url, diff --git a/faststream/rabbit/router.py b/faststream/rabbit/router.py index d272dd0ae8..59aac51eb0 100644 --- a/faststream/rabbit/router.py +++ b/faststream/rabbit/router.py @@ -18,6 +18,7 @@ from fast_depends.dependencies import Dependant from faststream._internal.basic_types import AnyDict + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -314,6 +315,10 @@ def __init__( Sequence["BrokerMiddleware[IncomingMessage]"], Doc("Router middlewares to apply to all routers' publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), parser: Annotated[ Optional["CustomCallable"], Doc("Parser to map original **IncomingMessage** Msg to FastStream one."), @@ -333,6 +338,7 @@ def __init__( prefix=prefix, dependencies=dependencies, middlewares=middlewares, + routers=routers, parser=parser, decoder=decoder, include_in_schema=include_in_schema, diff --git a/faststream/redis/broker/broker.py b/faststream/redis/broker/broker.py index c0e0f89192..b47845e296 100644 --- a/faststream/redis/broker/broker.py +++ b/faststream/redis/broker/broker.py @@ -50,6 +50,7 @@ LoggerProto, SendableMessage, ) + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -138,6 +139,10 @@ def __init__( Sequence["BrokerMiddleware[BaseMessage]"], Doc("Middlewares to apply to all broker publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), # AsyncAPI args security: Annotated[ Optional["BaseSecurity"], @@ -228,6 +233,7 @@ def __init__( decoder=decoder, parser=parser, middlewares=middlewares, + routers=routers, # AsyncAPI description=description, specification_url=specification_url, diff --git a/faststream/redis/router.py b/faststream/redis/router.py index 0c048b4e2e..a7c33875dc 100644 --- a/faststream/redis/router.py +++ b/faststream/redis/router.py @@ -17,6 +17,7 @@ from fast_depends.dependencies import Dependant from faststream._internal.basic_types import AnyDict, SendableMessage + from faststream._internal.broker.abc_broker import ABCBroker from faststream._internal.types import ( BrokerMiddleware, CustomCallable, @@ -232,6 +233,10 @@ def __init__( Sequence["BrokerMiddleware[BaseMessage]"], Doc("Router middlewares to apply to all routers' publishers/subscribers."), ] = (), + routers: Annotated[ + Sequence["ABCBroker[Any]"], + Doc("Routers to apply to broker."), + ] = (), parser: Annotated[ Optional["CustomCallable"], Doc("Parser to map original **IncomingMessage** Msg to FastStream one."), @@ -251,6 +256,7 @@ def __init__( prefix=prefix, dependencies=dependencies, middlewares=middlewares, + routers=routers, parser=parser, decoder=decoder, include_in_schema=include_in_schema, diff --git a/tests/brokers/base/router.py b/tests/brokers/base/router.py index 382f54dc0c..a29c8e63ec 100644 --- a/tests/brokers/base/router.py +++ b/tests/brokers/base/router.py @@ -593,6 +593,34 @@ def subscriber(s) -> None: mock.parser.assert_called_once() mock.decoder.assert_called_once() + async def test_router_in_init( + self, + router: BrokerRouter, + queue: str, + ) -> None: + event = asyncio.Event() + + args, kwargs = self.get_subscriber_params(queue) + + @router.subscriber(*args, **kwargs) + def subscriber(m) -> None: + event.set() + + pub_broker = self.get_broker(routers=[router]) + + async with self.patch_broker(pub_broker) as br: + await br.start() + + await asyncio.wait( + ( + asyncio.create_task(br.publish("hello", queue)), + asyncio.create_task(event.wait()), + ), + timeout=self.timeout, + ) + + assert event.is_set() + @pytest.mark.asyncio() class RouterLocalTestcase(RouterTestcase): From 5f4c9f462694ad5a4854946572e5f8cd44f99f70 Mon Sep 17 00:00:00 2001 From: Flosckow <66554425+Flosckow@users.noreply.github.com> Date: Wed, 11 Dec 2024 02:29:14 +0700 Subject: [PATCH 2/2] Fix: return logger (#1982) * Fix: return logger, typing * Fix: lint * chore: fix tests --------- Co-authored-by: Daniil Dumchenko Co-authored-by: Nikita Pastukhov --- faststream/_internal/broker/router.py | 2 +- faststream/confluent/broker/broker.py | 1 + faststream/confluent/client.py | 7 +++++-- faststream/rabbit/broker/broker.py | 2 +- .../asyncapi/v3_0_0/schema/bindings/amqp/channel.py | 4 +++- tests/brokers/kafka/test_consume.py | 8 ++++++-- tests/prometheus/confluent/basic.py | 4 ---- tests/prometheus/kafka/basic.py | 4 ---- tests/prometheus/nats/basic.py | 3 ++- tests/prometheus/nats/test_nats.py | 4 +++- tests/prometheus/nats/test_provider.py | 3 ++- tests/prometheus/rabbit/basic.py | 4 ---- tests/prometheus/rabbit/test_provider.py | 6 +----- tests/prometheus/redis/basic.py | 4 ---- 14 files changed, 25 insertions(+), 31 deletions(-) diff --git a/faststream/_internal/broker/router.py b/faststream/_internal/broker/router.py index 81f4a2998a..8c02459095 100644 --- a/faststream/_internal/broker/router.py +++ b/faststream/_internal/broker/router.py @@ -84,7 +84,7 @@ def __init__( decoder=decoder, include_in_schema=include_in_schema, state=EmptyBrokerState("You should include router to any broker."), - routers=routers + routers=routers, ) for h in handlers: diff --git a/faststream/confluent/broker/broker.py b/faststream/confluent/broker/broker.py index 1b96a46126..0262dbd9c3 100644 --- a/faststream/confluent/broker/broker.py +++ b/faststream/confluent/broker/broker.py @@ -454,6 +454,7 @@ async def _connect( # type: ignore[override] **kwargs, client_id=client_id, config=self.config, + logger=self._state.get().logger_state, ) self._producer.connect(native_producer) diff --git a/faststream/confluent/client.py b/faststream/confluent/client.py index 05a0210a6a..385a1b4389 100644 --- a/faststream/confluent/client.py +++ b/faststream/confluent/client.py @@ -43,6 +43,7 @@ class AsyncConfluentProducer: def __init__( self, *, + logger: "LoggerState", config: config_module.ConfluentFastConfig, bootstrap_servers: Union[str, list[str]] = "localhost", client_id: Optional[str] = None, @@ -64,6 +65,8 @@ def __init__( sasl_plain_password: Optional[str] = None, sasl_plain_username: Optional[str] = None, ) -> None: + self.logger_state = logger + if isinstance(bootstrap_servers, Iterable) and not isinstance( bootstrap_servers, str, @@ -107,7 +110,7 @@ def __init__( }, ) - self.producer = Producer(final_config, logger=self.logger) # type: ignore[call-arg] + self.producer = Producer(final_config, logger=self.logger_state.logger.logger) # type: ignore[call-arg] self.__running = True self._poll_task = asyncio.create_task(self._poll_loop()) @@ -309,7 +312,7 @@ def __init__( ) self.config = final_config - self.consumer = Consumer(final_config, logger=self.logger) # type: ignore[call-arg] + self.consumer = Consumer(final_config, logger=self.logger_state.logger.logger) # type: ignore[call-arg] # We shouldn't read messages and close consumer concurrently # https://github.com/airtai/faststream/issues/1904#issuecomment-2506990895 diff --git a/faststream/rabbit/broker/broker.py b/faststream/rabbit/broker/broker.py index a171755cf1..04d2c2cd4f 100644 --- a/faststream/rabbit/broker/broker.py +++ b/faststream/rabbit/broker/broker.py @@ -16,7 +16,7 @@ from typing_extensions import Doc, override from faststream.__about__ import SERVICE_NAME -from faststream._internal.broker.broker import BrokerUsecase +from faststream._internal.broker.broker import ABCBroker, BrokerUsecase from faststream._internal.constants import EMPTY from faststream._internal.publisher.proto import PublisherProto from faststream.message import gen_cor_id diff --git a/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel.py b/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel.py index 3d2bcc23ad..bfadb4c0f4 100644 --- a/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel.py +++ b/faststream/specification/asyncapi/v3_0_0/schema/bindings/amqp/channel.py @@ -1,4 +1,6 @@ -from typing import Optional, Self +from typing import Optional + +from typing_extensions import Self from faststream.specification.asyncapi.v2_6_0.schema.bindings.amqp import ( ChannelBinding as V2Binding, diff --git a/tests/brokers/kafka/test_consume.py b/tests/brokers/kafka/test_consume.py index 3c9bd4ca90..1c8ee55f99 100644 --- a/tests/brokers/kafka/test_consume.py +++ b/tests/brokers/kafka/test_consume.py @@ -399,7 +399,9 @@ async def handler(msg): await asyncio.wait( ( - asyncio.create_task(br._producer._producer.producer.send(queue, key=b"")), + asyncio.create_task( + br._producer._producer.producer.send(queue, key=b"") + ), asyncio.create_task(event.wait()), ), timeout=3, @@ -426,7 +428,9 @@ async def handler(msg): await asyncio.wait( ( - asyncio.create_task(br._producer._producer.producer.send(queue, key=b"")), + asyncio.create_task( + br._producer._producer.producer.send(queue, key=b"") + ), asyncio.create_task(event.wait()), ), timeout=3, diff --git a/tests/prometheus/confluent/basic.py b/tests/prometheus/confluent/basic.py index 92df8e38f4..facea2efec 100644 --- a/tests/prometheus/confluent/basic.py +++ b/tests/prometheus/confluent/basic.py @@ -1,7 +1,6 @@ from typing import Any from faststream import AckPolicy -from faststream.confluent import KafkaBroker from faststream.confluent.prometheus import KafkaPrometheusMiddleware from tests.brokers.confluent.basic import ConfluentTestcaseConfig @@ -9,9 +8,6 @@ class KafkaPrometheusSettings(ConfluentTestcaseConfig): messaging_system = "kafka" - def get_broker(self, apply_types=False, **kwargs: Any) -> KafkaBroker: - return KafkaBroker(apply_types=apply_types, **kwargs) - def get_middleware(self, **kwargs: Any) -> KafkaPrometheusMiddleware: return KafkaPrometheusMiddleware(**kwargs) diff --git a/tests/prometheus/kafka/basic.py b/tests/prometheus/kafka/basic.py index 0225f7053a..9fdd8795dc 100644 --- a/tests/prometheus/kafka/basic.py +++ b/tests/prometheus/kafka/basic.py @@ -1,7 +1,6 @@ from typing import Any from faststream import AckPolicy -from faststream.kafka import KafkaBroker from faststream.kafka.prometheus import KafkaPrometheusMiddleware from tests.brokers.kafka.basic import KafkaTestcaseConfig @@ -9,9 +8,6 @@ class KafkaPrometheusSettings(KafkaTestcaseConfig): messaging_system = "kafka" - def get_broker(self, apply_types=False, **kwargs: Any) -> KafkaBroker: - return KafkaBroker(apply_types=apply_types, **kwargs) - def get_middleware(self, **kwargs: Any) -> KafkaPrometheusMiddleware: return KafkaPrometheusMiddleware(**kwargs) diff --git a/tests/prometheus/nats/basic.py b/tests/prometheus/nats/basic.py index 2bb3abbad9..5199ee84ef 100644 --- a/tests/prometheus/nats/basic.py +++ b/tests/prometheus/nats/basic.py @@ -2,9 +2,10 @@ from faststream.nats import NatsBroker from faststream.nats.prometheus import NatsPrometheusMiddleware +from tests.brokers.nats.basic import NatsTestcaseConfig -class NatsPrometheusSettings: +class NatsPrometheusSettings(NatsTestcaseConfig): messaging_system = "nats" def get_broker(self, apply_types=False, **kwargs: Any) -> NatsBroker: diff --git a/tests/prometheus/nats/test_nats.py b/tests/prometheus/nats/test_nats.py index a3bdbed2e0..edb07ad20b 100644 --- a/tests/prometheus/nats/test_nats.py +++ b/tests/prometheus/nats/test_nats.py @@ -22,7 +22,9 @@ def stream(queue): @pytest.mark.nats() class TestPrometheus( - NatsPrometheusSettings, LocalPrometheusTestcase, LocalRPCPrometheusTestcase + NatsPrometheusSettings, + LocalPrometheusTestcase, + LocalRPCPrometheusTestcase, ): async def test_metrics_batch( self, diff --git a/tests/prometheus/nats/test_provider.py b/tests/prometheus/nats/test_provider.py index c8ce53dc72..10410b95f8 100644 --- a/tests/prometheus/nats/test_provider.py +++ b/tests/prometheus/nats/test_provider.py @@ -16,7 +16,8 @@ class LocalBaseNatsMetricsSettingsProviderTestcase( - NatsPrometheusSettings, LocalMetricsSettingsProviderTestcase + NatsPrometheusSettings, + LocalMetricsSettingsProviderTestcase, ): def test_get_publish_destination_name_from_cmd(self, queue: str) -> None: expected_destination_name = queue diff --git a/tests/prometheus/rabbit/basic.py b/tests/prometheus/rabbit/basic.py index d1d192e459..a489fcb2e8 100644 --- a/tests/prometheus/rabbit/basic.py +++ b/tests/prometheus/rabbit/basic.py @@ -1,6 +1,5 @@ from typing import Any -from faststream.rabbit import RabbitBroker from faststream.rabbit.prometheus import RabbitPrometheusMiddleware from tests.brokers.rabbit.basic import RabbitTestcaseConfig @@ -8,8 +7,5 @@ class RabbitPrometheusSettings(RabbitTestcaseConfig): messaging_system = "rabbitmq" - def get_broker(self, apply_types=False, **kwargs: Any) -> RabbitBroker: - return RabbitBroker(apply_types=apply_types, **kwargs) - def get_middleware(self, **kwargs: Any) -> RabbitPrometheusMiddleware: return RabbitPrometheusMiddleware(**kwargs) diff --git a/tests/prometheus/rabbit/test_provider.py b/tests/prometheus/rabbit/test_provider.py index 9b6eb0b7bf..88f4c506bb 100644 --- a/tests/prometheus/rabbit/test_provider.py +++ b/tests/prometheus/rabbit/test_provider.py @@ -5,10 +5,7 @@ from faststream.prometheus import MetricsSettingsProvider from faststream.rabbit.prometheus.provider import RabbitMetricsSettingsProvider -from tests.prometheus.basic import ( - LocalMetricsSettingsProviderTestcase, - LocalRPCPrometheusTestcase, -) +from tests.prometheus.basic import LocalMetricsSettingsProviderTestcase from .basic import RabbitPrometheusSettings @@ -16,7 +13,6 @@ class TestRabbitMetricsSettingsProvider( RabbitPrometheusSettings, LocalMetricsSettingsProviderTestcase, - LocalRPCPrometheusTestcase, ): @staticmethod def get_provider() -> MetricsSettingsProvider: diff --git a/tests/prometheus/redis/basic.py b/tests/prometheus/redis/basic.py index 1a6ed6cfeb..a1f89f3ead 100644 --- a/tests/prometheus/redis/basic.py +++ b/tests/prometheus/redis/basic.py @@ -1,6 +1,5 @@ from typing import Any -from faststream.redis import RedisBroker from faststream.redis.prometheus import RedisPrometheusMiddleware from tests.brokers.redis.basic import RedisTestcaseConfig @@ -8,8 +7,5 @@ class RedisPrometheusSettings(RedisTestcaseConfig): messaging_system = "redis" - def get_broker(self, apply_types=False, **kwargs: Any) -> RedisBroker: - return RedisBroker(apply_types=apply_types, **kwargs) - def get_middleware(self, **kwargs: Any) -> RedisPrometheusMiddleware: return RedisPrometheusMiddleware(**kwargs)