userver: Class Hierarchy
⚠️ This is the documentation for an old userver version. Click here to switch to the latest version.
All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Macros Modules Pages Concepts
Class Hierarchy

Go to the graphical class hierarchy

This inheritance list is sorted roughly, but not completely, alphabetically:
[detail level 1234567]
 Cpytest_userver.client._StateReflects the (supposed) current service state
 Cpytest_userver.client._StateManagerUsed for computing the requests that we need to automatically align the service state with the test fixtures state
 Cdynamic_config::AdditionalKeysTokenDefines the scope where DynamicConfigClientUpdater requests additional configs
 Cutils::ip::AddressBase< N >Base class for IPv4/IPv6 addresses
 Cstorages::postgres::io::traits::AddTupleConstRef< T >
 Cstorages::postgres::io::traits::AddTupleConstRef< std::tuple< T... > >
 Cstorages::mongo::operations::AggregateRuns an aggregation pipeline
 Cutils::statistics::AggregatedValues< Length >
 Cstorages::mongo::options::AllowPartialResultsSuppresses errors on querying a sharded collection with unavailable shards
 Cutils::AnyMovableReplacement for std::any that is not copyable. It allows to store non-copyable and even non-movable types
 Cutils::AnyStorage< StorageTag >Map-like heterogeneous data storage
 Cutils::AnyStorageDataTag< StorageTag, Data >
 Cstorages::mongo::options::ArrayFiltersSpecifies an array of filter documents that determine which array elements to modify for an update operation on an array field
 Cformats::json::StringBuilder::ArrayGuard
 Cconcurrent::impl::AsyncEventSourceBase
 Cconcurrent::AsyncEventSubscriberScopeManages the subscription to events from an AsyncEventSource
 Cutils::AtomicFlags< Enum >Wrapper to extend enum with atomic flags interface
 Cserver::handlers::auth::AuthCheckerBase
 Cserver::handlers::auth::AuthCheckerFactoryBaseBase class for all the authorization factory checkers
 Cserver::handlers::auth::AuthCheckerSettings
 Cserver::handlers::auth::digest::AuthCheckerSettingsStruct of directives for digest authentication server settings per RFC 2617
 Cserver::handlers::auth::AuthCheckResult
 Curabbitmq::AuthSettings
 Cconcurrent::BackgroundTaskStorage
 Cconcurrent::BackgroundTaskStorageCore
 Cstd::bad_any_cast
 Cbaggage::BaggageBaggage header. Contains entries (key, value, optional<properties>)
 Cbaggage::BaggageEntryBaggage Entry. Has required key and value, optional list of properties. Keys shouldn't contain '=' and ','. Values shouldn't contains ',' and ';'
 Cbaggage::BaggageEntryPropertyProperty of entry. Has required key and optional value. Keys shouldn't contain '=', ';' and ','. Values shouldn't contains ',' and ';'
 Cbaggage::BaggageManager
 Cbaggage::BaggageSettings
 CBase
 Cutils::statistics::BaseFormatBuilder
 Cpytest_userver.chaos.BaseGateThis base class maintain endpoints of two types:
 Cformats::json::parser::BaseParserBase class for SAX parser
 Cformats::json::parser::BaseValidator< T >
 Cformats::bson::BinaryBSON Binary
 Cstorages::postgres::io::traits::BitContainerTraits< BitContainer, Enable >
 Cstorages::postgres::io::traits::BitContainerTraits< BitContainer, std::enable_if_t< std::is_integral_v< BitContainer > > >
 Cstorages::postgres::io::traits::BitContainerTraits< std::array< bool, N > >
 Cstorages::postgres::io::traits::BitContainerTraits< std::bitset< N > >
 Cstorages::postgres::BitStringWrapper< BitContainer, BitStringType >
 Cstd::bool_constant
 CBoolConstant
 Cstorages::postgres::BoundedRange< T >
 Cformats::bson::BsonString
 CBufferCategoryConstant
 Cstorages::postgres::io::BufferCategoryHash
 Cengine::io::BufferedReaderWrapper for buffered input
 Cstorages::postgres::io::BufferFormatter< T, Enable >Primary template for Postgre buffer formatter Specialisations should provide call operators that write to a buffer
 Cstorages::postgres::io::BufferFormatter< bool >
 Cstorages::postgres::io::BufferFormatter< char >
 Cstorages::postgres::io::BufferFormatter< char[N]>
 Cstorages::postgres::io::BufferFormatter< const char * >
 Cstorages::postgres::io::BufferFormatter< Date >Binary formatter for utils::datetime::Date
 Cstorages::postgres::io::BufferFormatter< MultiPrecision< Precision > >
 Cstorages::postgres::io::BufferFormatter< Null< T > >
 Cstorages::postgres::io::BufferFormatter< std::chrono::time_point< ClockType, Duration > >Binary formatter for std::chrono::time_point
 Cstorages::postgres::io::BufferFormatter< std::string >
 Cstorages::postgres::io::detail::BufferFormatterBase< T >
 Cstorages::postgres::io::detail::BufferFormatterBase< ::utils::datetime::TimeOfDay< Duration > >
 Cstorages::postgres::io::detail::BufferFormatterBase< ::utils::StrongTypedef< Tag, T, Ops, Enable > >
 Cstorages::postgres::io::detail::BufferFormatterBase< boost::uuids::uuid >
 Cstorages::postgres::io::detail::BufferFormatterBase< decimal64::Decimal< Prec, RoundPolicy > >
 Cstorages::postgres::io::detail::BufferFormatterBase< Optional< T > >
 Cstorages::postgres::io::detail::BufferFormatterBase< postgres::BitStringWrapper< BitContainer, kBitStringType > >
 Cstorages::postgres::io::detail::BufferFormatterBase< postgres::ByteaWrapper< ByteContainer > >
 Cstorages::postgres::io::detail::BufferFormatterBase< std::bitset< N > >
 Cstorages::postgres::io::detail::BufferFormatterBase< std::string_view >
 Cstorages::postgres::io::detail::BufferFormatterBase< UserType >
 Cstorages::postgres::io::BufferParser< T, Enable >Primary template for Postgre buffer parser. Specialisations should provide call operators that parse FieldBuffer
 Cstorages::postgres::io::BufferParser< bool >
 Cstorages::postgres::io::BufferParser< char >
 Cstorages::postgres::io::BufferParser< std::string >
 Cstorages::postgres::io::detail::BufferParserBase< T >
 Cstorages::postgres::io::detail::BufferParserBase< ::utils::datetime::TimeOfDay< Duration > >
 Cstorages::postgres::io::detail::BufferParserBase< boost::uuids::uuid >
 Cstorages::postgres::io::detail::BufferParserBase< Date >
 Cstorages::postgres::io::detail::BufferParserBase< decimal64::Decimal< Prec, RoundPolicy > >
 Cstorages::postgres::io::detail::BufferParserBase< MultiPrecision< Precision > >
 Cstorages::postgres::io::detail::BufferParserBase< Optional< T > >
 Cstorages::postgres::io::detail::BufferParserBase< postgres::BitStringWrapper< BitContainer, kBitStringType > >
 Cstorages::postgres::io::detail::BufferParserBase< postgres::ByteaWrapper< ByteContainer > >
 Cstorages::postgres::io::detail::BufferParserBase< std::bitset< N > >
 Cstorages::postgres::io::detail::BufferParserBase< std::chrono::time_point< ClockType, Duration > >
 Cstorages::postgres::io::detail::BufferParserBase< std::string_view >
 Cstorages::postgres::io::detail::BufferParserBase< StrongTypedef >
 Cstorages::postgres::io::detail::BufferParserBase< UserType >
 Cstorages::mongo::operations::BulkEfficiently executes a number of operations over a single collection
 Cutils::statistics::BusyMarker
 Cutils::statistics::BusyStorage
 Cstorages::mongo::CancelledException::ByDeadlinePropagation
 Cstorages::postgres::ByteaWrapper< ByteContainer >Wrapper for binary data container
 Ctestsuite::CacheControlPeriodically updated caches control interface for testsuite
 Cutils::CachedHash< Key >Holds the key and its hash for faster comparisons and hashing
 Cutils::CachedHashKeyEqual< Equal, std::false_type >
 Ctestsuite::CacheInvalidatorHolderRAII helper for testsuite registration
 Ccache::CacheUpdateTraitBase class for periodically updated caches
 Cugrpc::client::CallAnyBaseBase class for any RPC
 Cugrpc::server::CallAnyBaseA non-typed base class for any gRPC call
 Cengine::CancellableSemaphoreClass that allows up to max_simultaneous_locks concurrent accesses to the critical section. It honours task cancellation, unlike Semaphore
 Cpytest_userver.plugins.log_capture.CaptureControl
 Cpytest_userver.plugins.log_capture.CapturedLogs
 Cdecimal64::CeilingRoundPolicyRound towards +infinity
 Ccrypto::Certificate
 Cfs::blocking::CFileA std::FILE* wrapper
 Cutils::CheckedPtr< T >Utility template for returning a pointer to an object that is owned by someone else; throws std::runtime_error if nullptr is stored
 Cutils::CheckedPtr< T & >
 Cengine::subprocess::ChildProcess
 Cengine::subprocess::ChildProcessStatusStatus of finished subprocess
 Cstorages::clickhouse::io::columns::ClickhouseColumn< ColumnType >Base class for every typed ClickHouse column. To add new columns one should derive from this class, define types aliases:
 Cstorages::clickhouse::io::columns::ClickhouseColumn< DateTime64Column< Precision, Duration< Rep, Period > > >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< DateTimeColumn >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< Float32Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< Float64Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< Int32Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< Int64Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< Int8Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< MismatchedEndiannessUuidColumn >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< NullableColumn< T > >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< StringColumn >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< UInt16Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< UInt32Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< UInt64Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< UInt8Column >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< UuidColumn >
 Cstorages::clickhouse::io::columns::ClickhouseColumn< UuidRfc4122Column >
 Cclients::http::ClientHTTP client that returns a HTTP request builder from CreateRequest()
 Cdynamic_config::ClientClient for the configs service
 Cstorages::redis::ClientRedis client
 Cdynamic_config::ClientConfig
 Cugrpc::client::ClientFactoryCreates generated gRPC clients. Has a minimal built-in channel cache: as long as a channel to the same endpoint is used somewhere, the same channel is given out
 Cugrpc::client::ClientFactoryConfigSettings relating to the ClientFactory
 Curabbitmq::ClientSettings
 Cpytest_userver.client.ClientWrapperBase asyncio userver client that implements HTTP requests to service
 Cstorages::clickhouse::ClusterInterface for executing queries on a cluster of ClickHouse servers
 Cstorages::mysql::ClusterClient interface for a cluster of MySQL servers. Usually retrieved from components::MySQL
 Cstorages::postgres::ClusterInterface for executing queries on a cluster of PostgreSQL servers
 Cstorages::postgres::ClusterHostTypeHash
 Cstorages::postgres::ClusterSettingsSettings for storages::postgres::Cluster
 Cstorages::postgres::ClusterStatisticsCluster statistics storage
 Credis::CmdArgs
 Cstorages::mongo::CollectionMongoDB collection handle, the main way to operate with MongoDB
 Cpytest_userver.utils.colorize.Colorizer
 Cpytest_userver.utils.colorize.Colors
 Cstorages::clickhouse::io::columns::ColumnIterator< ColumnType >Forward-iterator for iterating over column of type ColumnType
 Cstorages::clickhouse::io::ColumnsMapper< MappedType >
 Credis::CommandControlRedis command execution options
 Cstorages::clickhouse::CommandControl
 Cstorages::mysql::CommandControl
 Cstorages::postgres::CommandControl
 Cstorages::mysql::CommandResultSetA wrapper for command result set
 Credis::CommandsBufferingSettings
 Cstorages::mongo::options::CommentSets a comment for the operation, which would be visible in profile data
 Ccomponents::impl::ComponentBaseDon't use it for application components, use LoggableComponentBase instead
 Ccomponents::ComponentContextClass to retrieve other components
 Ctestsuite::ComponentControlComponent control interface for testsuite
 Ctestsuite::ComponentInvalidatorHolderRAII helper for testsuite registration
 Ccomponents::ComponentListA list to keep a unique list of components to start with components::Run(), utils::DaemonMain() or components::RunOnce()
 Cstorages::postgres::CompositeFieldDefDescription of a field in a user-defined composite type, for type checking
 Cstorages::postgres::CompositeTypeDescriptionPostgreSQL composite type description
 Cmoodycamel::ConcurrentQueue< T, Traits >
 Cmoodycamel::ConcurrentQueue< T >
 Cstd::conditional_t
 Cengine::ConditionVariableStd::condition_variable replacement for asynchronous tasks
 Ccache::Config
 Ccongestion_control::v2::Config
 Ccongestion_control::v2::Controller::Config
 Cdump::Config
 Cserver::websocket::Config
 Cstorages::redis::Config
 Ccache::ConfigPatch
 Cdump::ConfigPatch
 Credis::ConnectionInfo
 Cstorages::postgres::ConnectionSettings
 Cstorages::postgres::ConnectionStatistics< Counter, MmaAccumulator >Template connection statistics storage
 Cclients::http::ConnectToCURLOPT_CONNECT_TO argument for curl's connect_to()
 Chttp::headers::HeaderMap::ConstIterator
 Cconcurrent::Consumer< QueueType, ConsumerToken, EmplaceEnablerType >
 Curabbitmq::ConsumerBaseBase class for your consumers. You should derive from it and override Process method, which gets called when a new message arrives from the broker
 Curabbitmq::ConsumerSettingsConsumer settings struct
 Chttp::ContentTypeContent-Type representation
 Chttp::ContentTypeHash
 Cserver::handlers::auth::digest::ContextFromClient
 Cserver::handlers::auth::digest::ContextFromServer
 Ccongestion_control::Controller
 Ccongestion_control::v2::Controller
 Ccongestion_control::ControllerInfo
 Cserver::http::CookieHTTP response cookie
 Cstorages::mongo::operations::CountCounts documents matching the filter
 Cstorages::redis::ScanOptionsBase::Count
 Cstorages::mongo::operations::CountApproxReturns approximate number of documents in a collection
 Cstorages::clickhouse::io::CppToClickhouse< T >
 Cstorages::postgres::io::CppToPg< T, Enable >Detect mapping of a C++ type to Postgres type
 Cstorages::postgres::io::CppToPg< std::underlying_type_t< T > >
 Cstorages::postgres::io::CppToSystemPg< T >Primary template for declaring mapping to a PostgreSQL system type
 Cstorages::postgres::io::CppToUserPg< T >Primary template for declaring mapping to a PostgreSQL user type
 Cutils::CpuRelax
 Cutils::statistics::MinMaxAvg< ValueType, AverageType >::Current
 Cutils::CurrentThreadNameGuardRAII helper to run some code with a temporary current thread name
 Cstorages::mongo::CursorInterface for MongoDB query cursors
 Cstorages::mysql::CursorResultSet< T >A wrapper for read-only cursor
 Ccongestion_control::Sensor::Data
 Ccongestion_control::v2::Sensor::Data
 Cstorages::postgres::DatabaseObject for accessing PostgreSQL database instance (sharded or not)
 CDataType
 Cstorages::mysql::DateClass that represent MySQL DATE type
 Cutils::datetime::DateDate in format YYYY-MM-DD, std::chrono::year_month_day like type
 Cstorages::mysql::DateTimeClass that represents MySQL DATETIME type
 Cstorages::clickhouse::io::columns::DateTime64Column< Precision, T >Helper class for instantiating DateTime64 columns
 Cstorages::postgres::DBTypeDescriptionDescription of a PostgreSQL type. The structure is selected from the pg_catalog.pg_type table (not all, only appropriate fields). See https://www.postgresql.org/docs/12/catalog-pg-type.html
 Cstorages::postgres::DBTypeNameIdentity for a PostgreSQL type name
 Cengine::DeadlineInternal representation of a deadline time point
 Cserver::request::DeadlinePropagationBlockerStops deadline propagation within its scope
 Cserver::request::DeadlineSignalSignals when an operation has detected deadline expiration
 Cdecimal64::Decimal< Prec, RoundPolicy_ >Fixed-point decimal data type for use in deterministic calculations, oftentimes involving money
 Cformats::bson::Decimal128BSON Decimal128
 Cformats::bson::Value::DefaultConstructed
 Cformats::json::Value::DefaultConstructed
 Cformats::yaml::Value::DefaultConstructed
 Cyaml_config::YamlConfig::DefaultConstructed
 Clogging::DefaultLoggerGuardAtomically replaces the default logger
 Clogging::DefaultLoggerLevelScopeAllows to override default log level within a scope. Primarily for use in tests
 Crcu::DefaultRcuMapTraits< Key, Value >
 Crcu::DefaultRcuTraits< T >
 Cdecimal64::DefRoundPolicyDefault rounding. Fast, rounds to nearest
 Cstorages::mongo::bulk_ops::DeleteDeletes documents as part of bulk operation
 Cstorages::mongo::operations::DeleteDeletes documents
 Cdecltypedetail::DetectBufferCategory
 Cdynamic_config::DiffHelper class for subscribing to dynamic-config updates with a custom callback
 Cdist_lock::DistLockedWorker
 Cdist_lock::DistLockSettingsDistributed lock settings
 Cdist_lock::DistLockStrategyBaseInterface for distributed lock strategies
 Cutest::DnsServerMock::DnsAnswer
 Cutest::DnsServerMock::DnsQuery
 Cutest::DnsServerMock
 Cstorages::mongo::Cursor::Iterator::DocHolder
 Cdynamic_config::DocsMap
 Cstorages::mongo::operations::Drop
 Cstorages::postgres::DsnOptions
 Cdump::DumpableEntity
 Ctestsuite::DumpControlDumper control interface for testsuite
 Cdump::DumperManages dumps of a cache-like component
 Ctestsuite::DumperRegistrationHolderRAII helper for testsuite registration
 Cdump::DynamicConfig
 Cpytest_userver.plugins.dynamic_config.DynamicConfigSimple dynamic config backend
 Cstd::enable_shared_from_this
 Curabbitmq::EndpointInfo
 Cutils::statistics::EntryStatistics registration holder, used to unregister a metric source before it is destroyed
 Cstorages::postgres::io::EnumMappingBase< Enum >
 Cengine::subprocess::EnvironmentVariablesEnvironment variables representation
 Cengine::subprocess::EnvironmentVariablesUpdateIterable environment variables wrapper to update values
 CEqual
 Cstorages::redis::RequestEvalSha< ScriptResult, ReplyType >::EvalShaResult
 CException
 Cstd::exceptionSTL class
 Cstorages::clickhouse::ExecutionResult
 Cstorages::mysql::ExecutionResultMetadata for an execution of a statement that doesn't expect a result set (INSERT, UPDATE, DELETE)
 Cutils::expected< S, E >For holding a value or an error
 Ccache::ExpirableLruCache< Key, Value, Hash, Equal >Class for expirable LRU cache. Use cache::LruMap for not expirable LRU Cache
 Ccache::ExpirableLruCache< std::string, TimePoint >
 Credis::ExpireReply
 Cserver::handlers::ExternalBody
 Cstorages::postgres::io::traits::ExtractionTag< T, Enable >
 Cstorages::postgres::io::traits::ExtractionTag< T, std::enable_if_t< kIsRowType< T > > >
 Cserver::handlers::ExtraHeaders
 Cpytest_userver.plugins.service_runner.ServiceRunnerModule.FakeModule
 Cstd::false_type
 Cutils::FastPimpl< T, Size, Alignment, Strict >Implements pimpl idiom without dynamic memory allocation
 Cutils::FastPimpl< ChildProcessImpl, kImplSize, kImplAlignment >
 Cutils::FastPimpl< ClientImpl, 232, 8 >
 Cutils::FastPimpl< ConnectionPtr, 32, 8 >
 Cutils::FastPimpl< header_map::Map, 272, 8 >
 Cutils::FastPimpl< Impl, 1056, 16 >
 Cutils::FastPimpl< Impl, 112, 8 >
 Cutils::FastPimpl< Impl, 1136, 16 >
 Cutils::FastPimpl< Impl, 127, 8 >
 Cutils::FastPimpl< Impl, 144, 16 >
 Cutils::FastPimpl< Impl, 144, 8 >
 Cutils::FastPimpl< Impl, 16, 8 >
 Cutils::FastPimpl< Impl, 24, 8 >
 Cutils::FastPimpl< Impl, 32, 16 >
 Cutils::FastPimpl< Impl, 4224, 8 >
 Cutils::FastPimpl< Impl, 560, 8 >
 Cutils::FastPimpl< Impl, 600, 8 >
 Cutils::FastPimpl< Impl, 632, 8 >
 Cutils::FastPimpl< Impl, 72, 8 >
 Cutils::FastPimpl< Impl, 792, 8 >
 Cutils::FastPimpl< Impl, 96, alignof(void *)>
 Cutils::FastPimpl< Impl, kImplSize, kImplAlign >
 Cutils::FastPimpl< Impl, kPimplSize, alignof(void *), utils::kStrictMatch >
 Cutils::FastPimpl< Impl, kSize, alignof(void *)>
 Cutils::FastPimpl< Impl, kSize, kAlignment >
 Cutils::FastPimpl< Impl, kSize, kAlignment, false >
 Cutils::FastPimpl< Impl, kSize, kAlignment, utils::kStrictMatch >
 Cutils::FastPimpl< Impl, sizeof(char *), alignof(char *)>
 Cutils::FastPimpl< impl::Buffer, kBufferSize, kBufferAlignment, true >
 Cutils::FastPimpl< impl::JsonStringImpl, kSize, kAlignment, utils::kStrictMatch >
 Cutils::FastPimpl< infra::ConnectionPtr, 24, 8 >
 Cutils::FastPimpl< Map, kPimplSize, alignof(void *)>
 Cutils::FastPimpl< moodycamel::ConcurrentQueue, kIdleQueueSize, kIdleQueueAlignment >
 Cutils::FastPimpl< typename iter_traits::native_iter, kNativeIterSize, kNativeIterAlignment >
 Cutils::FastPimpl< WaitList, 88, alignof(void *)>
 Cutils::FastPimpl< WaitListLight, 16, 16 >
 Cutils::FastPimpl< YAML::Node, kNativeNodeSize, kNativeAlignment >
 Cutils::FastScopeGuard< Callback >Helper class to perform actions on scope exit
 Cengine::io::FdPollerLow-level poller that can wait for read, write, and read/write operations on a file descriptor. It does not provide read/write operations
 Cstorages::postgres::FieldAccessor to a single field in a result set's row
 Cstorages::postgres::io::FieldBuffer
 Cstorages::postgres::FieldDescription
 Cstorages::mysql::FieldTagUsed for extracting statement results as a single field
 Cstorages::postgres::FieldTagTag type to disambiguate reading the first value of a row to a user's composite type (PostgreSQL composite type in the row initializes user's type)
 Cfs::blocking::FileDescriptorA file descriptor wrapper
 Cfs::FileInfoWithDataStruct file with load data
 Cutils::FilterBloom< T, Counter, Hash1, Hash2 >Space-efficient probabilistic data structure
 Cstorages::mongo::operations::FindRetrieves documents matching the filter
 Cstorages::mongo::operations::FindAndModifyAtomically updates a document and returns either previous or new version
 Cstorages::mongo::operations::FindAndRemoveAtomically removes a document and returns it
 Cutils::FixedArray< T >A fixed-size array with the size determined at runtime
 Cutils::FixedArray< int64_t >
 Cutils::FixedArray< MutexDatum >
 Cutils::FixedArray< unsigned >
 Cutils::Flags< Enum >Wrapper to extend enum with flags interface
 Cutils::Flags< Flags >
 Cutils::Flags< RangeBound >
 Cstorages::postgres::io::detail::FloatingPointBinaryFormatter< double >
 Cstorages::postgres::io::detail::FloatingPointBinaryFormatter< float >
 Cdecimal64::FloorRoundPolicyRound towards -infinity
 Cclients::http::Form
 Cdecimal64::FormatOptionsParameters for flexible decimal formatting
 Cserver::handlers::FormattedErrorData
 Cfmt::formatter
 Cfmt::formatter< boost::uuids::uuid >
 Cfmt::formatter<::decimal64::Decimal< Prec, RoundPolicy >, Char >Fmt support
 Cfmt::formatter<::engine::io::Sockaddr >Socket address fmt formatter
 Cfmt::formatter<::server::http::HttpMethod >
 Cfmt::formatter<::server::http::HttpStatus >
 Cfmt::formatter<::utils::statistics::LabelsSpan >
 Cfmt::formatter<::utils::statistics::LabelView >
 Cfmt::formatter<::utils::statistics::MetricValue >
 Cfmt::formatter<::utils::statistics::Rate >
 Cserver::http::FormDataArgArgument of a multipart/form-data request
 Cfs::FsCacheClientClass client for storing files in memory Usually retrieved from components::FsCache
 Cconcurrent::FunctionId
 Cengine::Future< T >Std::future replacement for asynchronous tasks that works in pair with engine::Promise
 Cengine::Future< ReplyPtr >
 Cengine::Future< std::shared_ptr< clients::http::Response > >
 Cengine::Future< void >
 Cpytest_userver.chaos.GateRouteClass that describes the route for TcpGate or UdpGate
 Crapidjson::GenericDocument< Encoding, Allocator, StackAllocator >
 Crapidjson::GenericValue< Encoding, Allocator >
 Credis::GeoaddArg
 Cstorages::redis::GeoPoint
 Credis::GeoradiusOptions
 Credis::GeosearchOptions
 Cstorages::postgres::io::traits::GetSetNull< T >
 Cstorages::postgres::io::traits::GetSetNull< ::utils::StrongTypedef< Tag, T, Ops, Enable > >
 Cstorages::postgres::io::traits::GetSetNull< boost::optional< T > >
 Cstorages::postgres::io::traits::GetSetNull< Null< T > >
 Cstorages::postgres::io::traits::GetSetNull< std::optional< T > >
 Cstorages::postgres::io::traits::GetSetNull<::utils::OptionalRef< T > >
 Ctestsuite::GrpcControl
 Cpytest_userver.plugins.grpc.mockserver.GrpcServiceMock
 Cdecimal64::impl::HalfRoundPolicyBase< impl::HalfDownPolicy >
 Cdecimal64::impl::HalfRoundPolicyBase< impl::HalfEvenPolicy >
 Cdecimal64::impl::HalfRoundPolicyBase< impl::HalfUpPolicy >
 Cserver::handlers::HandlerConfig
 Cserver::handlers::HandlerErrorCodeHashHasher class for HandlerErrorCode
 Cconcurrent::FunctionId::Hash
 Cstd::hash
 Cstd::hash<::decimal64::Decimal< Prec, RoundPolicy > >Std::hash support
 Cstd::hash<::storages::postgres::DBTypeName >
 Cstd::hash<::storages::postgres::io::PredefinedOids >
 Cstd::hash<::storages::postgres::SqlState >Specialization of std::hash template for SqlState
 Cstd::hash<::utils::CachedHash< T > >
 Cstd::hash<::utils::SmallString< N > >
 Cserver::handlers::auth::digest::HasherUsed for data hashing and "nonce" generating
 Cutils::HashSeedThe seed structure used by underlying hashing implementation
 Chttp::headers::HeaderMapContainer that maps case-insensitive header name into header value
 Cpytest_userver.utils.net.HealthChecksClass that holds all the info for health checks
 Clogging::impl::HexBase
 Cstorages::mongo::options::HintSpecifies an index to use for the query
 Cutils::AnyMovable::HolderBase
 Cerror_injection::Hook
 Cpytest_userver.utils.net.HostPortClass that holds a host and port
 Csecdist::RedisSettings::HostPort
 Ctestsuite::HttpAllowedUrlsExtra
 Cserver::http::HttpRequestHTTP Request data
 Cutest::HttpServerMock::HttpRequest
 Cserver::request::HttpRequestConfig
 Cutest::HttpServerMock::HttpResponse
 Cutest::HttpServerMock
 Curabbitmq::IAdminInterfaceAdministrative interface for the broker. This class is merely an interface for convenience and you are not expected to use it directly (use Client/AdminChannel instead)
 Curabbitmq::IChannelInterfacePublisher interface for the broker. This class is merely an interface for convenience and you are not expected to use it directly (use Client/Channel instead)
 Cutils::ip::InetNetworkINET IPv4/IPv4 network
 Ctracing::InPlaceSpanAvoids an extra allocation by storing tracing::Span data in-place
 Cstorages::postgres::io::traits::Input< T, Enable >Customisation point for parsers
 Cstorages::postgres::io::traits::Input< BoundedRange< T >, std::enable_if_t< kHasParser< T > > >
 Cstorages::postgres::io::traits::Input< formats::json::Value >
 Cstorages::postgres::io::traits::Input< Range< T >, std::enable_if_t< kHasParser< T > > >
 Cstorages::postgres::io::traits::Input< std::chrono::duration< Rep, Period > >Binary parser for std::chrono::duration
 Cstorages::postgres::io::traits::Input< T, EnableIfCanUseEnumAsStrongTypedef< T > >
 Cstorages::mongo::operations::InsertManyInserts multiple documents
 Cstorages::mongo::bulk_ops::InsertOneInserts a single document as part of bulk operation
 Cstorages::mongo::operations::InsertOneInserts a single document
 Crcu::RcuMap< Key, Value, RcuMapTraits >::InsertReturnTypeImpl< ValuePtrType >
 Cstorages::postgres::InstanceStatisticsTemplate< Counter, PercentileAccumulator, MmaAccumulator >Template instance statistics storage
 Cstorages::postgres::InstanceStatsDescriptorInstance statistics with description
 Cstorages::postgres::InstanceTopologyStatistics< MmaAccumulator >Template instance topology statistics storage
 Cstd::integral_constant
 Cstorages::postgres::io::detail::IntegralBinaryFormatter< Bigint >
 Cstorages::postgres::io::detail::IntegralBinaryFormatter< Integer >
 Cstorages::postgres::io::detail::IntegralBinaryFormatter< Smallint >
 Cformats::json::parser::IntegralParser< T >
 Cserver::handlers::InternalMessage
 Cpytest_userver.plugins.caches.InvalidationState
 Cstorages::postgres::io::traits::IO< T >A default deducer of parsers/formatters for a type/data format. Can be specialised for a type/format pair providing custom parsers/formatters
 Cengine::io::IoDataIoData for vector send
 Curabbitmq::IReliableChannelInterfaceReliable publisher interface for the broker. This class is merely an interface for convenience and you are not expected to use it directly (use Client/ReliableChannel instead)
 Cstd::is_integral
 Cutils::IsDeclComplete
 Cdump::IsDumpedAggregate< T >
 Cconcurrent::ItemMutex< Key, Equal >
 Cformats::common::ItemsWrapper< Value >Wrapper for handy python-like iteration over a map
 Cformats::bson::Iterator< ValueType, Direction >Iterator for BSON values
 Cformats::common::ItemsWrapper< Value >::Iterator
 Cformats::json::Iterator< Traits, Direction >Iterator for formats::json::Value
 Cformats::yaml::Iterator< iter_traits >Iterator for formats::yaml::Value
 Chttp::headers::HeaderMap::Iterator
 Cstorages::clickhouse::io::RowsMapper< Row >::Iterator
 Cstorages::mongo::Cursor::Iterator
 Cstorages::redis::ScanRequest< scan_tag >::Iterator
 Cyaml_config::Iterator< iter_traits >
 Cformats::json::Value::IterTraits
 Cformats::json::ValueBuilder::IterTraits
 Cformats::yaml::Value::IterTraits
 Cformats::yaml::ValueBuilder::IterTraits
 Cyaml_config::YamlConfig::IterTraits
 Cformats::common::ItemsWrapper< Value >::Iterator::ItValue
 Cjson.JSONEncoder
 Cserver::handlers::JsonErrorBuilder
 Cdynamic_config::Client::JsonReply
 Cformats::bson::JsonString
 Cdynamic_config::Key< Parser >A config key is a unique identifier for a config variable
 Credis::KeyShard
 Credis::KeyShardFactory
 Cdynamic_config::KeyValueA type-erased config key-value pair
 Credis::ReplyData::KeyValues::KeyValue
 Credis::ReplyData::KeyValues::KeyValueIt
 Credis::ReplyData::KeyValues
 Cutils::statistics::LabelLabel name+value storage
 Cutils::statistics::LabelsSpanView over a continuous range of LabelView
 Cutils::statistics::LabelViewNon owning label name+value storage
 Cutils::LazyPrvalue< Func >Can be used with various emplace functions to allow in-place constructing a non-movable value using a callable
 Cutils::LazySharedPtr< T >A lazy wrapper around utils::SharedReadablePtr that fetches the data on first access
 Cconcurrent::LazyValue< T >Lazy value computation with multiple users
 Cserver::handlers::LegacyJsonErrorBuilder
 Ccongestion_control::Limit
 Cstorages::mongo::options::LimitSpecifies the number of documents to request from the server
 Cserver::congestion_control::Limitee
 Ccongestion_control::Limiter
 Cclients::http::LocalStatsRepresents all the local timings and statistics
 Cconcurrent::LockedPtr< Lock, Data >Proxy class for locked access to data protected with locking::SharedLock<T>
 Clogging::LogExtraExtra tskv fields storage
 Clogger.Logger
 Clogging::LogHelper
 Cclients::dns::Resolver::LookupSourceCounters
 Ccache::LruCacheConfig
 Ccache::LruCacheConfigStatic
 Ccache::LruCacheWrapper< Key, Value, Hash, Equal >
 Ccache::LruMap< T, U, Hash, Equal >
 Ccache::LruMap< T, U, Hash, Equal >
 Ccache::LruSet< T, Hash, Equal >
 Cutils::MacaddrBase< N >Base class for Macaddr/Macaddr8
 Cstorages::mysql::MappedStatementResultSet< DbType >An interface for on-the-flight mapping statement result set from DbType into whatever type you provide without additional allocations
 Cstorages::redis::ScanOptionsBase::Match
 Cformats::bson::MaxKeyBSON MaxKey
 Cstorages::mongo::options::MaxServerTimeSpecifies the server-side time limit for the operation
 Cstorages::redis::MemberScore
 Cserver::websocket::MessageWebSocket message
 Cstorages::postgres::Message
 Cpytest_userver.metrics.MetricMetric type that contains the labels: typing.Dict[str, str] and value: int
 Cpytest_userver.client.MetricsDifferA helper class for computing metric differences
 Credis::MetricsSettings
 Cpytest_userver.metrics.MetricsSnapshotSnapshot of captured metrics that mimics the dict interface
 Cutils::statistics::MetricsStorageStorage of metrics registered with MetricTag<Metric>
 Cutils::statistics::MetricTag< Metric >Metric description
 Cutils::statistics::MetricValueThe value of a metric. Only integer and floating-point metrics are allowed
 Cugrpc::client::MiddlewareBaseBase class for server gRPC middleware
 Cugrpc::server::MiddlewareBaseBase class for server gRPC middleware
 Cugrpc::client::MiddlewareCallContextContext for middleware-specific data during gRPC call
 Cugrpc::server::MiddlewareCallContextContext for middleware-specific data during gRPC call
 Cugrpc::client::MiddlewareFactoryBaseFactory that creates specific client middlewares for clients
 Cformats::bson::MinKeyBSON MinKey
 Cutils::statistics::MinMaxAvg< ValueType, AverageType >Class for concurrent safe calculation of minimum, maximum and average over series of values
 Cpytest.Module
 Cstorages::mongo::MongoErrorMongoDB error
 Credis::ReplyData::MovableKeyValues::MovableKeyValue
 Credis::ReplyData::MovableKeyValues::MovableKeyValueIt
 Credis::ReplyData::MovableKeyValues
 Cconcurrent::GenericQueue< T, QueuePolicy >::MultiConsumerSide
 Cstorages::mongo::MultiMongo
 Cconcurrent::GenericQueue< T, QueuePolicy >::MultiProducerSide
 Cengine::MutexStd::mutex replacement for asynchronous tasks
 Ccrypto::NamedAlgoBase class for a crypto algorithm implementation
 Cstorages::postgres::DBTypeDescription::NameHash
 Cstorages::postgres::DBTypeDescription::NamesEqual
 Cutils::ip::NetworkBase< Address, typename >Base class for IPv4/IPv6 network
 Cengine::SingleConsumerEvent::NoAutoReset
 Ccomponents::DynamicConfig::NoblockSubscriberAllows to subscribe to DynamicConfig updates without waiting for the first update to complete. Primarily intended for internal use
 Cserver::handlers::auth::digest::NonceCacheSettings
 Cserver::handlers::auth::digest::NonceInfo
 Cmeta::NotDetected
 Cutils::NotNull< T >Restricts a pointer or smart pointer to only hold non-null values
 Cutils::NotNull< cache::CacheUpdateTrait * >
 Cutils::NotNull< const tracing::TracingManagerBase * >
 Cutils::NotNull< dump::Dumper * >
 Cutils::NotNull< engine::TaskProcessor * >
 Cutils::NotNull< server::congestion_control::Limitee * >
 Cstorages::postgres::Null< T >Type to represent a null value
 Cstorages::clickhouse::io::columns::NullableColumnMeta
 Cstorages::clickhouse::io::columns::NullableColumn< T >::NullableDataHolder
 Ccache::NWayLRU< T, U, Hash, Equal >
 Cformats::json::StringBuilder::ObjectGuard
 Cformats::bson::OidBSON ObjectId
 Cdump::OperationsFactoryAn abstract Reader/Writer factory
 Cutils::OptionalRef< T >Class that behaves as a nullable reference. Main difference from the pointer - value comparison of pointed values
 Cstorages::postgres::io::traits::Output< T, Enable >Customisation point for formatters
 Cstorages::postgres::io::traits::Output< BoundedRange< T >, std::enable_if_t< kHasFormatter< T > > >
 Cstorages::postgres::io::traits::Output< formats::json::Value >
 Cstorages::postgres::io::traits::Output< PlainJson >
 Cstorages::postgres::io::traits::Output< Range< T >, std::enable_if_t< kHasFormatter< T > > >
 Cstorages::postgres::io::traits::Output< std::chrono::duration< Rep, Period > >Binary formatter for std::chrono::duration
 Cstorages::postgres::io::traits::Output< T, EnableIfCanUseEnumAsStrongTypedef< T > >
 Cstorages::postgres::ParameterStoreClass for dynamic PostgreSQL parameter list construction
 Cserver::handlers::auth::digest::ParserClass for parsing Authorization header directives from client request
 Cformats::json::parser::ParserHandler
 Cformats::json::parser::ParserState
 Cformats::common::Path
 Cutils::statistics::Percentile< M, Counter, ExtraBuckets, ExtraBucketSize >Class stores M buckets of type Counter and allows easy calculation of percentiles
 Cutils::PeriodicTaskTask that periodically runs a user callback. Callback is started after the previous callback execution is finished every period + A - B, where:
 Ctestsuite::PeriodicTaskControlPeriodic task control interface for testsuite
 Ctestsuite::PeriodicTaskRegistrationHolderRAII helper for testsuite registration
 Cpytest_userver.client.PeriodicTasksState
 Cstorages::postgres::io::PgToCpp< oid, T >
 Cengine::io::PipeUnidirectional pipe representation
 Cclients::http::PluginBase class for HTTP Client plugins
 Cclients::http::PluginRequestAuxiliary entity that allows editing request to a client from plugins
 Cstorages::redis::Point
 Ccongestion_control::Policy
 Ccongestion_control::PolicyState
 Cstorages::mongo::PoolMongoDB client pool
 Cstorages::mongo::PoolConfigMongoDB connection pool configuration
 Cstorages::mongo::MultiMongo::PoolSetDatabase set builder
 Cstorages::postgres::PoolSettingsPostgreSQL connection pool options
 Curabbitmq::PoolSettings
 Cstorages::postgres::Portal
 Ctestsuite::PostgresControl
 Chttp::headers::PredefinedHeaderA struct to represent compile-time known header name
 CPredefinedOid
 Cutest::PrintTestNameTest name printer for parameterized tests written in gtest
 Ccrypto::PrivateKey
 Cos_signals::ProcessorA client that allows to subscribe to OS signals SIGUSR1 andSIGUSR2`
 Cos_signals::ProcessorMockProvides Processor for use in tests
 Cengine::subprocess::ProcessStarterCreates a new OS subprocess and executes a command in it
 Cconcurrent::Producer< QueueType, ProducerToken, EmplaceEnablerType >
 Cstorages::mongo::options::ProjectionSelects fields to be returned
 Cengine::Promise< T >Std::promise replacement for asynchronous tasks that works in pair with engine::Future
 Cengine::Promise< void >
 Ccrypto::PublicKey
 Credis::PubsubMetricsSettings
 Cugrpc::client::Qos
 Cstorages::clickhouse::QueryHolds a query and its name. In case query is expected to be executed with parameters, query text should conform to fmt format
 Cstorages::mysql::QueryQuery class, which driver executes
 Cstorages::postgres::QueryHolds a query, its name and logging mode
 Cugrpc::client::QueueHolderManages a gRPC completion queue, usable only in clients
 Clogging::QuotedFormats a string as quoted, escaping the '\' and '"' symbols
 Curabbitmq::RabbitEndpoints
 Curabbitmq::RabbitEndpointsMulti
 Cutils::RandomBaseVirtualized standard UniformRandomBitGenerator concept, for use with random number distributions
 Cstorages::postgres::Range< T >
 Credis::RangeOptions
 Credis::RangeScoreOptions
 Cutils::statistics::Rate
 Cutils::statistics::RateCounterAtomic counter of type Rate with relaxed memory ordering
 Crcu::RcuMap< Key, Value, RcuMapTraits >Map-like structure allowing RCU keyset updates
 Crcu::RcuMap< std::string, concurrent::Variable< server::handlers::auth::digest::NonceInfo > >
 Crcu::RcuMap< std::string, const fs::FileInfoWithData >
 Crcu::RcuMapIterator< Key, Value, IterValue, RcuMapTraits >Forward iterator for the rcu::RcuMap
 Cengine::io::ReadableBase
 Crcu::ReadablePtr< T, RcuTraits >
 Cdump::ReaderA general interface for binary data input
 Cstorages::mongo::options::ReadPreferenceRead preference
 Cutils::statistics::RecentPeriod< Counter, Result, Timer >Class maintains circular buffer of Counters
 Cengine::io::Socket::RecvFromResult
 Ctestsuite::RedisControl
 Csecdist::RedisSettings
 Credis::RedisWaitConnected
 Cutils::TokenBucket::RefillPolicyToken bucket refill policy
 Cutils::regexSmall alias for boost::regex / std::regex without huge includes
 Cutils::statistics::RelaxedCounter< T >Atomic counter of type T with relaxed memory ordering
 Cutils::statistics::RelaxedCounter< size_t >
 Cstorages::postgres::io::traits::RemoveTupleReferences< T >
 Cstorages::postgres::io::traits::RemoveTupleReferences< std::tuple< T... > >
 Cstorages::mongo::bulk_ops::ReplaceOneReplaces a single document as part of bulk operation
 Cstorages::mongo::operations::ReplaceOneReplaces a single document
 Credis::ReplicationMonitoringSettings
 Cdynamic_config::Client::Reply
 Credis::Reply
 Credis::ReplyData
 Cstorages::redis::ScanRequest< scan_tag >::Iterator::ReplyElemHolder
 Cclients::http::RequestClass for creating and performing new http requests
 Credis::Request
 Cstorages::redis::Request< Result, ReplyType >
 Cutils::statistics::RequestClass describing the request for metrics data
 Cstorages::redis::Request< ReplyData >
 Cserver::request::RequestBase
 Cserver::request::RequestContextStores request-specific data during request processing
 Cstorages::redis::RequestDataBase< ReplyType >
 Cstorages::redis::RequestDataBase< ReplyData >
 Cstorages::redis::RequestDataBase< Result >
 Cstorages::redis::RequestEval< ScriptResult, ReplyType >
 Cstorages::redis::RequestEvalSha< ScriptResult, ReplyType >
 Cstorages::redis::RequestScanData< scan_tag >
 Cstorages::redis::RequestScanDataBase< scan_tag >
 Cclients::http::RequestTracingEditorAuxiliary entity that allows editing request to a client from plugins
 Cclients::dns::ResolverCaching DNS resolver implementation
 Cclients::dns::ResolverConfigCaching DNS resolver static configuration
 Cclients::http::ResponseClass that will be returned for successful request
 Cutest::SimpleServer::Response
 Cserver::request::ResponseBaseBase class for all the server responses
 Cserver::http::ResponseBodyStream
 Cserver::request::ResponseDataAccounter
 Cclients::http::ResponseFutureAllows to perform a request concurrently with other work without creating an extra coroutine for waiting
 Cstorages::postgres::ResultSetPostgreSQL result set
 Cutils::ResultStore< T >
 Cutils::ResultStore< void >
 Cstorages::mongo::options::RetryDuplicateKeyEnables automatic one-time retry of duplicate key errors
 Credis::RetryNilFromMaster
 Cstorages::mongo::options::ReturnNewSpecifies that FindAndModify should return the new version of an object
 Cdecimal64::RoundDownRoundPolicyRound towards zero. The fastest rounding
 Cdecimal64::RoundUpRoundPolicyRound away from zero
 Cstorages::postgres::Row
 Cstorages::postgres::RowDescriptionA wrapper for PGresult to access field descriptions
 Cstorages::clickhouse::io::RowsMapper< Row >
 Cstorages::mysql::RowTagUsed for extracting statement results as rows
 Cstorages::postgres::RowTagTag type to disambiguate reading the row to a user's row type (values of the row initialize user's type data members)
 Cstorages::postgres::io::detail::RowTypeImpl< T, traits::kRowCategory< T > >
 Cformats::serialize::SaxStream
 Credis::ScanOptions
 Cstorages::redis::ScanOptionsBase
 Cstorages::redis::ScanReplyElem< ScanTag >
 Cstorages::redis::ScanReplyElem< ScanTag::kHscan >
 Cstorages::redis::ScanReplyElem< ScanTag::kScan >
 Cstorages::redis::ScanReplyElem< ScanTag::kSscan >
 Cstorages::redis::ScanReplyElem< ScanTag::kZscan >
 Cstorages::redis::ScanRequest< scan_tag >
 Cyaml_config::SchemaJSON Schema-like type definition
 Cyaml_config::SchemaPtr
 Cutils::ScopeGuardHelper class to perform actions on scope exit
 Ctracing::ScopeTimeType to measure execution time of a scope
 Cutils::ScopeTimePauseUtility to easily pause ScopeTime, e.g. when yielding
 Credis::ScoreOptions
 Cstorages::secdist::SecdistClient to retrieve credentials from the components::Secdist and to subscribe to their updates
 Cstorages::secdist::SecdistConfigClient to retrieve credentials from the components::Secdist
 Cstorages::secdist::SecdistProvider
 Ccompiler::SelectValue< T >Selects the proper value for the current compiler and standard library
 Cengine::SemaphoreClass that allows up to max_simultaneous_locks concurrent accesses to the critical section. It ignores task cancellation, unlike CancellableSemaphore
 Cengine::SemaphoreLockA replacement for std::shared_lock that accepts Deadline arguments
 Ccongestion_control::Sensor
 Ccongestion_control::v2::Sensor
 Cugrpc::server::ServerManages the gRPC server
 Cugrpc::server::ServerConfigSettings relating to the whole gRPC server
 Credis::ServerIdOpaque Id of Redis server instance / any server instance
 Credis::ServerIdHasher
 Cugrpc::server::ServiceBaseThe type-erased base class for all gRPC service implementations
 Cugrpc::server::ServiceConfigPer-service settings
 Cserver::handlers::ServiceErrorCode
 Credis::SetOptions
 Cerror_injection::SettingsArtificial error injection settings
 Cstorages::secdist::DefaultLoader::Settings
 Cstorages::secdist::SecdistConfig::Settings
 Cutils::PeriodicTask::SettingsConfiguration parameters for PeriodicTask
 Cengine::SharedMutexStd::shared_mutex replacement for asynchronous tasks
 Cutils::SharedReadablePtr< T >std::shared_ptr<const T> wrapper that makes sure that the pointer is stored before dereferencing. Protects from dangling references:
 Cutest::SimpleServer
 Cengine::SingleConsumerEventA multiple-producers, single-consumer event
 Cconcurrent::GenericQueue< T, QueuePolicy >::SingleConsumerSide
 Cconcurrent::GenericQueue< T, QueuePolicy >::SingleProducerSide
 Cengine::SingleThreadedTaskProcessorsPool
 Cengine::SingleUseEventA single-producer, single-consumer event
 Cengine::SingleWaitingTaskMutexLighter version of Mutex with not more than 1 waiting task
 CSizeConstant
 Cstorages::mongo::options::SkipSpecifies the number of documents to skip
 Cutils::SlidingInterval< T >Sliding interval of values that provides functions to compute average, min and max values from the last window_size values of interval
 Cutils::SlidingInterval< int64_t >
 Cutils::SmallString< N >An alternative to std::string with a custom SSO (small string optimization) container size. Unlike std::string, SmallString is not null-terminated thus it has no c_str(), data() returns a not null-terminated buffer
 Cdynamic_config::SnapshotThe storage for a snapshot of configs
 Cutils::statistics::SnapshotA snapshot of metrics from utils::statistics::Storage
 Cengine::io::SockaddrNative socket address wrapper
 Cstorages::mongo::options::SortSorts the results
 Cdynamic_config::SourceA client for easy dynamic config fetching in components
 Ctracing::SpanMeasures the execution time of the current code block, links it with the parent tracing::Spans and stores that info in the log
 Ctracing::SpanBuilderProvides interface for editing Span, before final building
 Clogging::stacktrace_cache::StacktraceGuard
 Credis::Stat
 Cstorages::postgres::StatementMetricsSettingsPostgreSQL statements metrics options
 Cstorages::mysql::StatementResultSetA wrapper for statement execution result
 Cdist_lock::Statistics
 Cserver::websocket::Statistics
 Cutils::statistics::StatisticsRequestUsed in legacy statistics extenders
 Ccongestion_control::Stats
 Ccongestion_control::v2::Stats
 Cstd::chrono::steady_clock
 Cutils::datetime::SteadyCoarseClockSteady clock with up to a few millisecond resolution that is slightly faster than the std::chrono::steady_clock
 Cutils::statistics::Storage
 Cdynamic_config::StorageMockBacking storage for dynamic_config::Source in tests and benchmarks
 Cutils::StrCaseHashCase sensitive ASCII hashing functor
 Cclients::http::StreamedResponseHTTP response for streamed API
 Cutils::StreamingCpuRelax
 Cugrpc::client::StreamReadFuture< RPC >StreamReadFuture for waiting a single read response from stream
 Cutils::StrIcaseCompareThreeWayCase insensitive ASCII 3-way comparison functor
 Cutils::StrIcaseEqualCase insensitive ASCII equality comparison functor
 Cutils::StrIcaseHashCase insensitive ASCII hashing functor
 Cutils::StrIcaseLessCase insensitive ASCII less comparison functor
 Ccrypto::algorithm::StringsEqualConstTimeComparatorPerforms constant-time string comparison comparator
 Cstorages::postgres::utils::StringViewHash
 Cutils::impl::strong_typedef::StrongTypedefTag
 Cstorages::redis::SubscribeClientClient that allows subscribing to Redis channel messages
 Cformats::json::parser::Subscriber< T >
 Cformats::json::parser::Subscriber< bool >
 Cformats::json::parser::Subscriber< Item >
 Cformats::json::parser::Subscriber< Map >
 Cformats::json::parser::Subscriber< Map::mapped_type >
 Cformats::json::parser::Subscriber< Number >
 Cformats::json::parser::Subscriber< std::int32_t >
 Cformats::json::parser::Subscriber< std::int64_t >
 Cformats::json::parser::Subscriber< std::optional< T > >
 Cformats::json::parser::Subscriber< std::string >
 Cformats::json::parser::Subscriber< std::vector< Item > >
 Cformats::json::parser::Subscriber< Value >
 Cstorages::redis::SubscriptionTokenRAII subscription guard, that is usually retrieved from storages::redis::SubscribeClient
 Cstorages::mongo::options::SuppressServerExceptionsDisables exception throw on server errors, should be checked manually in WriteResult
 Cutils::SwappingSmart< T >
 Cutils::SwappingSmart< const curl::easy >
 Cstorages::clickhouse::io::columns::DateTime64Column< Precision, Duration< Rep, Period > >::Tag
 Cstorages::mongo::options::TailableEnables tailable cursor, which block at the end of capped collections
 Cengine::TaskBaseBase class for all the asynchronous tasks (engine::Task, engine::SharedTask, engine::SharedTaskWithResult, engine::TaskWithResult, dist_lock::DistLockedTask, ...)
 Cengine::TaskCancellationBlocker
 Cengine::TaskCancellationTokenCancellation token to given task object
 Cserver::request::TaskInheritedDataPer-request data that should be available inside handlers
 Cengine::TaskInheritedVariable< T >TaskInheritedVariable is a per-coroutine variable of arbitrary type
 Cengine::TaskLocalVariable< T >TaskLocalVariable is a per-coroutine variable of arbitrary type
 Cengine::TaskProcessorPoolsConfigA lightweight TaskProcessor config for engine::RunStandalone
 Cfs::blocking::TempDirectoryA unique directory for temporary files. The directory is deleted when the TempDirectory is destroyed
 Cfs::blocking::TempFileA unique temporary file. The file is deleted when the TempFile object is destroyed
 Cfs::TempFileA unique temporary file. The file is deleted when the TempFile object is destroyed
 Ctestsuite::TestpointClientBaseBase testpoint client. Used to report TESTPOINT executions to testsuite
 Cpytest_userver.plugins.testpoint.TestpointControl
 Ctestsuite::TestpointControlTestpoint control interface for testsuite
 Cpytest_userver.client.TestsuiteClientConfig
 Ctestsuite::TestsuiteTasksTestsuite tasks support
 Credis::ThreadPools
 Cutils::datetime::TimeOfDay< Duration >A simple implementation of a "time since midnight" datatype
 Cutils::datetime::TimeOfDay< std::chrono::duration< Rep, Period > >
 Cgrpc::TimePoint<::engine::Deadline >
 Cformats::bson::TimestampBSON Timestamp
 Cdump::To< T >A marker type used in ADL-found Read
 Cformats::parse::To< T >
 Cformats::serialize::To< T >
 Cstorages::mysql::convert::To< T >
 Cstorages::redis::To< Result, ReplyType >
 Cutils::TokenBucket
 Cstorages::postgres::TopologySettings
 Cutils::TracefulExceptionBaseBase class implementing backtrace storage and message builder, published only for documentation purposes, please inherit from utils::TracefulException instead
 Ctracing::TracingManagerBaseBase class for propagating trace context information in headers
 Cstorages::mysql::TransactionRAII transaction wrapper, auto-ROLLBACKs on destruction if no prior Commit/Rollback call was made
 Cstorages::postgres::TransactionPostgreSQL transaction
 Cstorages::redis::Transaction
 Cstorages::postgres::TransactionOptionsPostgreSQL transaction options
 Cstorages::postgres::TransactionStatistics< Counter, PercentileAccumulator >Template transaction statistics storage
 Cformats::common::TransferTagThis tag class is used to move a ValueBuilder object without copying
 Cutils::TrivialBiMap< BuilderFunc >Bidirectional unordered map for trivial types, including string literals; could be efficiently used as a unordered non-bidirectional map
 Cutils::TrivialSet< BuilderFunc >Unordered set for trivial types, including string literals
 Cstd::true_type
 Credis::TtlReply
 Cstorages::postgres::io::traits::TupleHasFormatters< Tuple >
 Cstorages::postgres::io::traits::TupleHasParsers< Tuple >
 Cstd::conditional_t::type
 Cstorages::postgres::DBTypeDescription::TypeCategoryHash
 Cstorages::postgres::TypedResultSet< T, ExtractionTag >
 Cugrpc::client::UnaryFutureUnaryFuture for waiting a single response RPC
 Cstorages::postgres::UnboundedType
 Cutils::unexpected< E >
 Cstorages::mongo::options::UnorderedDisables ordering on bulk operations causing them to continue after an error
 Cstorages::mongo::bulk_ops::UpdateUpdates documents as part of bulk operation
 Cstorages::mongo::operations::UpdateUpdates documents
 Ccache::UpdateStatisticsScopeAllows a specific cache to fill cache statistics during an Update
 Ccache::UpdateStatisticsScopeMockAllows to test helper functions of CacheUpdateTrait::Update that use UpdateStatisticsScope
 Cstorages::mongo::options::UpsertEnables insertion of a new document when update selector matches nothing
 Cserver::auth::UserAuthInfo
 Cserver::handlers::auth::digest::UserDataContains information about the user
 Cserver::auth::UserScope
 Cstorages::postgres::UserTypesContainer for connection-specific user data types
 Cpytest_userver.plugins.service_runner.UserviceRunner
 Crapidjson::UTF8< CharType >
 Cdynamic_config::Value< T >
 Cformats::bson::ValueNon-mutable BSON value representation
 Cformats::json::ValueNon-mutable JSON value representation
 Cformats::yaml::ValueNon-mutable YAML value representation
 Cdynamic_config::Value< bool >
 Cdynamic_config::Value< redis::CommandControl >
 Cdynamic_config::Value< redis::CommandsBufferingSettings >
 Cdynamic_config::Value< redis::MetricsSettings >
 Cdynamic_config::Value< redis::PubsubMetricsSettings >
 Cdynamic_config::Value< redis::RedisWaitConnected >
 Cdynamic_config::Value< size_t >
 Cformats::bson::ValueBuilderBuilder for BSON
 Cformats::json::ValueBuilderBuilder for JSON
 Cformats::yaml::ValueBuilderBuilder for YAML
 Cdynamic_config::ValueDict< ValueType >
 Cdynamic_config::ValueDict< redis::ReplicationMonitoringSettings >
 Cconcurrent::Variable< Data, Mutex >
 Crcu::Variable< T, RcuTraits >Read-Copy-Update variable
 Cconcurrent::Variable< AdditionalDocsMapKeys >
 Cconcurrent::Variable< ListenersData >
 Crcu::Variable< logging::DynamicDebugConfig >
 Crcu::Variable< PoolMap >
 Crcu::Variable< RawMap, RcuTraits >
 Crcu::Variable< redis::MetricsSettings >
 Crcu::Variable< redis::PubsubMetricsSettings >
 Cconcurrent::Variable< SpawnedMap >
 Crcu::Variable< std::shared_ptr< const dynamic_config::DocsMap > >
 Crcu::Variable< std::shared_ptr< const MongoCacheTraits::DataType > >
 Crcu::Variable< std::shared_ptr< const T > >
 Crcu::Variable< std::string >
 Cconcurrent::Variable< std::unordered_map< std::string, utils::NotNull< dump::Dumper * > > >
 Cconcurrent::Variable< std::unordered_map< std::string, utils::PeriodicTask & > >
 Crcu::Variable< std::vector< std::string > >
 Cconcurrent::Variable< std::vector< utils::NotNull< server::congestion_control::Limitee * > >, std::mutex >
 Crcu::Variable< storages::postgres::CommandControl >
 Cconcurrent::Variable< TasksMap >
 Crcu::Variable< utils::PeriodicTask::Settings >
 Cdynamic_config::VariableSnapshotPtr< Key >
 Cutils::datetime::WallCoarseClockSystem clock with up to a few millisecond resolution that is slightly faster than the std::chrono::system_clock
 Cutils::statistics::Warning
 Cserver::websocket::WebSocketConnectionMain class for Websocket connection
 Cengine::io::WritableBase
 Crcu::WritablePtr< T, RcuTraits >
 Cstorages::mongo::options::WriteConcernWrite concern
 Cdump::WriterA general interface for binary data output
 Cutils::statistics::WriterClass for writing metrics
 Cstorages::mongo::WriteResultMongoDB write operation result
 Cyaml_config::YamlConfigDatatype that represents YAML with substituted variables
 Credis::ZaddOptions
 Cutils::Ts