| docker | |
| ► en | |
| ► cpp | |
| def_groups.hpp | |
| ► functional_tests | |
| ► golden_path | |
| ► tests | |
| conftest.py | |
| test_grpc_reflection.py | |
| main.cpp | |
| ► proto-structs | |
| ► codegen-tests | |
| ► src | |
| ► enums | |
| names_test.cpp | |
| ► maps | |
| basic_test.cpp | |
| ► oneof | |
| basic_test.cpp | |
| proto2_test.cpp | |
| cycles_test.cpp | |
| simple_test.cpp | |
| ► include | |
| ► userver | |
| ► proto-structs | |
| any.hpp | Class to access google.protobuf.Any stored message as a struct |
| convert.hpp | Functions for protobuf message to/from struct conversion |
| exceptions.hpp | Exceptions thrown by the library |
| fwd.hpp | Forward declarations of types in userver proto-structs library |
| hash_map.hpp | The hash map container used in userver proto structs by default. |
| oneof.hpp | Contains type to represent oneof protobuf message fields in a struct |
| type_mapping.hpp | Concepts and traits for checking struct and protobuf message compatability |
| ► src | |
| ► proto-structs | |
| exceptions.cpp | |
| ► tests | |
| any_test.cpp | |
| convert_test.cpp | |
| exceptions_test.cpp | |
| oneof_test.cpp | |
| ► samples | |
| ► 0_hello_world | |
| ► testsuite | |
| conftest.py | |
| test_basic.py | |
| main.cpp | |
| ► 1_hi | |
| ► testsuite | |
| conftest.py | |
| test_basic.py | |
| main.cpp | |
| ► 2_key_value | |
| ► testsuite | |
| conftest.py | |
| test_basic.py | |
| main.cpp | |
| ► 3_json | |
| ► testsuite | |
| conftest.py | |
| test_basic.py | |
| main.cpp | |
| ► 4_custom_dependency | |
| ► testsuite | |
| conftest.py | |
| test_basic.py | |
| main.cpp | |
| ► 5_pg_service_template | |
| ► src | |
| main.cpp | |
| ► testsuite | |
| conftest.py | |
| test_basic.py | |
| ► 6_pg_service_template_no_http_with | |
| ► src | |
| main.cpp | |
| ► testsuite | |
| conftest.py | |
| test_basic.py | |
| ► src | |
| easy.cpp | |
| ► src | |
| ► grpc-protovalidate | |
| ► client | |
| component.cpp | |
| exceptions.cpp | |
| middleware.cpp | |
| middleware.hpp | |
| ► server | |
| component.cpp | |
| middleware.cpp | |
| middleware.hpp | |
| validate.cpp | |
| ► src | |
| ► grpc-reflection | |
| proto_server_reflection.cpp | |
| proto_server_reflection.hpp | |
| reflection_service_component.cpp | |
| ► src | |
| ► s3api | |
| ► authenticators | |
| access_key.cpp | |
| utils.cpp | |
| utils_test.cpp | |
| ► clients | |
| client.cpp | |
| client.hpp | |
| ► models | |
| s3api_connection_type.cpp | |
| secret.cpp | |
| s3_connection.cpp | |
| s3_connection.hpp | |
| s3api_methods.cpp | |
| s3api_methods.hpp | |
| s3api_methods_test.cpp | |
| ► tests | |
| utils.cpp | |
| utils.hpp | |
| validator_client_test.cpp | |
| validator_service_test.cpp | |
| validator_test.cpp | |
| ► testsuite | |
| ► pytest_plugins | |
| ► pytest_userver | |
| ► grpc | |
| __init__.py | |
| _mocked_errors.py | |
| _reflection.py | |
| _servicer_mock.py | |
| ► plugins | |
| ► grpc | |
| __init__.py | |
| client.py | |
| mockserver.py | |
| ► ydb | |
| __init__.py | |
| client.py | |
| discover.py | |
| service.py | |
| ydbsupport.py | |
| __init__.py | |
| asyncio_socket.py | |
| base.py | |
| caches.py | |
| clickhouse.py | |
| config.py | |
| core.py | |
| coverage.py | |
| dumps.py | |
| dynamic_config.py | |
| kafka.py | |
| log_capture.py | |
| logging.py | |
| mongo.py | |
| mysql.py | |
| postgresql.py | |
| rabbitmq.py | |
| redis.py | |
| s3api.py | |
| service.py | |
| service_client.py | |
| service_runner.py | |
| sql_coverage.py | |
| sqlite.py | |
| testpoint.py | |
| ► utils | |
| __init__.py | |
| colorize.py | |
| net.py | |
| tskv.py | |
| __init__.py | |
| chaos.py | |
| client.py | |
| dynconf.py | |
| metrics.py | |
| s3api.py | |
| sql.py | |
| ► userver | |
| ► storages | |
| ► clickhouse | |
| ► io | |
| ► columns | |
| array_column.hpp | Array column support |
| base_column.hpp | Base class for every typed ClickHouse column. To add new columns one should derive from this class, define types aliases: |
| column_includes.hpp | |
| column_iterator.hpp | Forward-iterator for iterating over column of type ColumnType. |
| column_wrapper.hpp | |
| common_columns.hpp | |
| datetime64_column.hpp | DateTime64 columns support |
| datetime_column.hpp | DateTime column support |
| float32_column.hpp | Float32 column support |
| float64_column.hpp | Float64 column support |
| int32_column.hpp | Int32 column support |
| int64_column.hpp | Int64 column support |
| int8_column.hpp | Int8 column support |
| nullable_column.hpp | Nullable column support |
| string_column.hpp | String column support |
| uint16_column.hpp | UInt16 column support |
| uint32_column.hpp | UInt32 column support |
| uint64_column.hpp | UInt64 column support |
| uint8_column.hpp | UInt8 column support |
| uuid_column.hpp | UUID column support |
| floating_point_types.hpp | Class that can be escaped for clickhouse queries instead of [double] and [float]. [double] and [float] are escaped as FloatingWithPrecision<double, 12> and FloatingWithPrecision<float, 6> respectively. These constants were derived from the accuracity the numbers from ranges [0.0-100000.0] (doubles) and [0.0-100.0] (floats) can be represented by these type. Clickhouse also supports inf, -inf and nan, see clickhouse docs. |
| io_fwd.hpp | Customization point for Ch driver C++ <-> ClickHouse mappings |
| result_mapper.hpp | |
| type_traits.hpp | |
| typedefs.hpp | |
| cluster.hpp | Interface for executing queries on a cluster of ClickHouse servers. |
| component.hpp | ClickHouse client component. |
| execution_result.hpp | Result accessor |
| fwd.hpp | Forward declarations of some popular clickhouse related types |
| options.hpp | Options |
| parameter_store.hpp | Class for dynamic ClickHouse parameter list construction. |
| query.hpp | Holds a query, its name and logging mode; used by all the SQL databases of userver. |
| clickhouse.hpp | |
| ► userver | |
| ► alerts | |
| source.hpp | Alert source instance which is used to fire alerts via metrics for a specified amount of time. |
| ► baggage | |
| baggage.hpp | Baggage header. Contains entries (key, value, optional<properties>). |
| baggage_manager.hpp | Baggage manipulation client and component |
| fwd.hpp | Forward declarations of baggage and baggage helpers classes |
| ► cache | |
| cache_config.hpp | |
| cache_statistics.hpp | Statistics collection for components::CachingComponentBase |
| cache_update_trait.hpp | Base class for periodically updated caches. |
| caching_component_base.hpp | Base class for caching components. |
| exceptions.hpp | Exceptions thrown by components::CachingComponentBase |
| expirable_lru_cache.hpp | Class for expirable LRU cache. Use cache::LruMap for not expirable LRU Cache. |
| lru_cache_component_base.hpp | Base class for LRU-cache components. |
| lru_cache_config.hpp | |
| lru_cache_statistics.hpp | |
| nway_lru_cache.hpp | |
| update_type.hpp | Enums representing periodic update types for CachingComponentBase |
| ► chaotic | |
| ► io | |
| ► boost | |
| ► container | |
| flat_set.hpp | |
| ► clients | |
| ► dns | |
| common.hpp | Common DNS client declarations |
| component.hpp | Caching DNS resolver component. |
| exception.hpp | DNS client exceptions |
| resolver.hpp | Caching DNS resolver implementation. |
| resolver_fwd.hpp | |
| resolver_utils.hpp | |
| ► http | |
| ► plugins | |
| ► headers_propagator | |
| component.hpp | |
| ► retry_budget | |
| component.hpp | |
| ► yandex_tracing | |
| component.hpp | |
| client.hpp | HTTP client that returns a HTTP request builder from CreateRequest(). |
| component.hpp | Component that manages clients::http::Client. |
| config.hpp | |
| connect_to.hpp | CURLOPT_CONNECT_TO argument for curl's connect_to(). |
| error.hpp | |
| error_kind.hpp | Additional tag to the exception. |
| form.hpp | |
| local_stats.hpp | |
| plugin.hpp | Base class for HTTP Client plugins. |
| plugin_component.hpp | |
| request.hpp | Class for creating and performing new http requests. |
| response.hpp | Class that will be returned for successful request. |
| response_future.hpp | Allows to perform a request concurrently with other work without creating an extra coroutine for waiting. |
| streamed_response.hpp | HTTP response for streamed API. |
| ► components | |
| common_component_list.hpp | Returns the most common list of components with runtime config updates and HTTP client. |
| common_server_component_list.hpp | Returns the most common list of components to start a fully functional server. |
| component.hpp | Convenience header that provides all the types for component implementation (components::ComponentContext, components::ComponentConfig). Prefer using a lightweight userver/components/component_fwd.hpp for component declaration |
| component_base.hpp | Contains components::ComponentBase declaration and forward declarations of components::ComponentConfig and components::ComponentContext, function components::GetCurrentComponentName() |
| component_config.hpp | Represents the config of a component that is being constructed; see Component system for introduction into components. |
| component_context.hpp | Class to retrieve other components. |
| component_fwd.hpp | Forward declarations for components::ComponentContext and components::ComponentConfig; function components::GetCurrentComponentName() and components::GetFsTaskProcessor() |
| component_list.hpp | A list to keep a unique list of components to start with components::Run(), utils::DaemonMain() or components::RunOnce(). |
| dump_configurator.hpp | |
| fs_cache.hpp | Component for storing files in memory. |
| loggable_component_base.hpp | Deprecated, use <userver/components/component_base.hpp> instead |
| logging_configurator.hpp | Helper component to configure logging. |
| manager_controller_component.hpp | Component that prepares the engine internals and starts all the other components. |
| minimal_component_list.hpp | Returns a list of components to do basic logging, component initialization and configuration. |
| minimal_server_component_list.hpp | Returns a list of components to start a basic HTTP server. |
| process_starter.hpp | Component for getting the engine::subprocess::ProcessStarter. |
| raw_component_base.hpp | The base class for all components. Don't use it for application components, use ComponentBase instead. |
| run.hpp | Functions to start a service or tool with the specified config and components::ComponentList |
| single_threaded_task_processors.hpp | Component that starts multiple single threaded task processors. |
| state.hpp | |
| static_config_validator.hpp | |
| statistics_storage.hpp | Component that keeps a utils::statistics::Storage storage for metrics. |
| tcp_acceptor_base.hpp | Component for accepting incoming TCP connections. |
| ► concurrent | |
| async_event_channel.hpp | |
| async_event_source.hpp | The read-only side of an event channel. Events are delivered to listeners in a strict FIFO order, i.e. only after the event was processed a new event may appear for processing, same listener is never called concurrently. |
| background_task_storage.hpp | |
| background_task_storage_fwd.hpp | |
| conflated_event_channel.hpp | |
| lazy_value.hpp | lazy value computation with multiple users |
| mpsc_queue.hpp | Multiple producer, single consumer queue |
| mutex_set.hpp | A dynamic set of mutexes. |
| queue.hpp | Queue with single and multi producer/consumer options. |
| queue_helpers.hpp | |
| striped_counter.hpp | A contention-free sharded atomic counter, with memory consumption and read performance traded for write performance. Intended to be used for write-heavy counters, mostly in metrics. |
| variable.hpp | |
| ► congestion_control | |
| ► controllers | |
| linear.hpp | |
| linear_config.hpp | |
| v2.hpp | |
| component.hpp | Component to limit too active requests, also known as CC. |
| controller.hpp | |
| limiter.hpp | |
| sensor.hpp | |
| ► dist_lock | |
| dist_lock_settings.hpp | Distributed lock settings. |
| dist_lock_strategy.hpp | Interface for distributed lock strategies. |
| dist_locked_task.hpp | A task that tries to acquire a distributed lock and runs user callback once while the lock is held. |
| dist_locked_worker.hpp | |
| statistics.hpp | |
| ► drivers | |
| drivers.hpp | |
| subscribable_futures.hpp | An adaptor for working with certain external futures. |
| ► dump | |
| aggregates.hpp | Dumping support for aggregates |
| common.hpp | Serialization and deserialization of integral, floating point, string, std::chrono, enum and uuid types for dumps |
| common_containers.hpp | Dump support for C++ Standard Library and Boost containers, std::optional, utils::StrongTypedef, std::{unique,shared}_ptr |
| config.hpp | |
| dumper.hpp | Manages dumps of a cache-like component. |
| factory.hpp | |
| fwd.hpp | Forward declarations of dump::Reader, dump::Writer and dump::To |
| helpers.hpp | Dump utils |
| json_helpers.hpp | Convenience functions to load and dump as JSON in classes derived from components::CachingComponentBase |
| meta.hpp | Provides dump::kIsDumpable and includes userver/dump/fwd.hpp |
| meta_containers.hpp | |
| operations.hpp | |
| operations_encrypted.hpp | |
| operations_file.hpp | |
| to.hpp | A marker type used in ADL-found Read |
| unsafe.hpp | |
| ► dynamic_config | |
| ► client | |
| client.hpp | Client for the dynamic configs service. |
| component.hpp | Component that starts a clients::dynamic_config::Client client. |
| ► storage | |
| component.hpp | Component that stores the dynamic config. |
| ► updater | |
| additional_keys_token.hpp | Defines the scope where DynamicConfigClientUpdater requests additional configs. |
| component.hpp | Component that does a periodic update of runtime configs. |
| ► updates_sink | |
| component.hpp | Base class for components acting as dynamic config updates sinks. |
| find.hpp | Function for retrieving dynamic config updates sink specified in the static config |
| exception.hpp | |
| fwd.hpp | Forward declarations of dynamic_config classes |
| snapshot.hpp | The shared snapshot of dynamic configs. Cheap to copy, even cheaper to move. Thread safe, not updated with new dynamic config values in background (it's a snapshot!). |
| source.hpp | A client for easy dynamic config fetching in components. |
| storage_mock.hpp | Backing storage for dynamic_config::Source in tests and benchmarks. |
| test_helpers.hpp | Accessors for dynamic config defaults for tests and benchmarks |
| value.hpp | |
| ► engine | |
| ► io | |
| ► sys_linux | |
| inotify.hpp | Linux-specific fs notification API |
| buffered.hpp | Buffered I/O wrappers |
| common.hpp | Common definitions and base classes for stream like objects |
| exception.hpp | I/O exceptions |
| fd_control_holder.hpp | |
| fd_poller.hpp | Low-level file descriptor r/w poller |
| pipe.hpp | Unidirectional pipe representation. |
| poller.hpp | I/O event monitor. |
| sockaddr.hpp | Native socket address wrapper. |
| socket.hpp | Socket representation. |
| tls_wrapper.hpp | TLS socket wrappers |
| ► subprocess | |
| child_process.hpp | Class that allows controlling child process; usually retrieved from engine::subprocess::ProcessStarter. |
| child_process_status.hpp | status of finished subprocess |
| environment_variables.hpp | Environment variables representation. |
| process_starter.hpp | Creates a new OS subprocess and executes a command in it. |
| ► task | |
| cancel.hpp | Task cancellation helpers |
| current_task.hpp | Utility functions that query and operate on the current task |
| inherited_variable.hpp | TaskInheritedVariable is a per-coroutine variable of arbitrary type. |
| local_variable.hpp | TaskLocalVariable is a per-coroutine variable of arbitrary type. |
| shared_task.hpp | Asynchronous task that has a shared ownership of the payload. |
| shared_task_with_result.hpp | Asynchronous task with result that has a shared ownership of payload. |
| single_threaded_task_processors_pool.hpp | |
| task.hpp | Asynchronous task that has a unique ownership of the payload. |
| task_base.hpp | Base class for all the asynchronous tasks (engine::Task, engine::SharedTask, engine::SharedTaskWithResult, engine::TaskWithResult, dist_lock::DistLockedTask, ...). |
| task_processor_fwd.hpp | |
| task_with_result.hpp | |
| async.hpp | Low-level TaskWithResult creation helpers |
| condition_variable.hpp | std::condition_variable replacement for asynchronous tasks |
| condition_variable_status.hpp | std::condition_variable state extended with "cancelled" state |
| deadline.hpp | Internal representation of a deadline time point |
| exception.hpp | Coroutine engine exceptions |
| future.hpp | std::future replacement for asynchronous tasks that works in pair with engine::Promise |
| future_status.hpp | std::future state extended with "cancelled" state |
| get_all.hpp | Provides engine::GetAll |
| io.hpp | Include-all header for low-level asynchronous I/O interfaces |
| mutex.hpp | std::mutex replacement for asynchronous tasks. |
| run_in_coro.hpp | |
| run_standalone.hpp | Runs a payload in a temporary coroutine engine instance. |
| semaphore.hpp | Class that allows up to max_simultaneous_locks concurrent accesses to the critical section. It ignores task cancellation, unlike CancellableSemaphore. |
| shared_mutex.hpp | std::shared_mutex replacement for asynchronous tasks. |
| single_consumer_event.hpp | A multiple-producers, single-consumer event. |
| single_use_event.hpp | A single-producer, single-consumer event. |
| single_waiting_task_mutex.hpp | Lighter version of Mutex with not more than 1 waiting task. |
| sleep.hpp | Time-based task suspension helpers |
| task_processors_load_monitor.hpp | Component to monitor CPU usage for every TaskProcessor present in the service, and dump per-thread stats into metrics. |
| wait_all_checked.hpp | Provides engine::WaitAllChecked |
| wait_any.hpp | Provides engine::WaitAny, engine::WaitAnyFor and engine::WaitAnyUntil |
| ► error_injection | |
| hook.hpp | |
| settings.hpp | |
| settings_fwd.hpp | |
| ► fs | |
| fs_cache_client.hpp | Class client for storing files in memory Usually retrieved from components::FsCache |
| read.hpp | Functions for asynchronous file read operations |
| temp_file.hpp | A unique temporary file. The file is deleted when the TempFile object is destroyed. |
| write.hpp | Filesystem write functions |
| ► logging | |
| component.hpp | Logging component |
| level_serialization.hpp | Serialization of log levels |
| logger.hpp | Logger definitions and helpers |
| ► middlewares | |
| groups.hpp | There are groups of middlewares to build a pipeline |
| pipeline.hpp | Lists all available middlewares and builds their order of execution |
| runner.hpp | Base class for a component that runs middlewares. |
| ► moodycamel | |
| concurrentqueue_fwd.h | |
| ► net | |
| ► blocking | |
| get_addr_info.hpp | Blocking Functions for getaddrinfo |
| ► os_signals | |
| component.hpp | A component for os_signals::Processor. |
| processor.hpp | A client that allows to subscribe to OS signals SIGUSR1 and SIGUSR2. |
| processor_mock.hpp | Provides Processor for use in tests. |
| subscriber.hpp | |
| ► rcu | |
| fwd.hpp | Forward declarations for rcu::Variable and rcu::RcuMap |
| rcu.hpp | Read-Copy-Update variable. |
| rcu_map.hpp | Map-like structure allowing RCU keyset updates. |
| ► server | |
| ► auth | |
| user_auth_info.hpp | |
| user_env.hpp | |
| user_id.hpp | |
| user_provider.hpp | |
| user_scopes.hpp | |
| ► congestion_control | |
| limiter.hpp | |
| sensor.hpp | |
| ► handlers | |
| ► auth | |
| ► digest | |
| auth_checker_base.hpp | Base class for digest authentication checkers. Implements a digest-authentication logic. |
| auth_checker_settings.hpp | Struct of directives for digest authentication server settings per RFC 2617. |
| auth_checker_settings_component.hpp | Component that loads digest auth configuration settings from a static_config.yaml. |
| context.hpp | Context structures for Digest Authentication |
| directives.hpp | Various digest authentication directives |
| directives_parser.hpp | Class for parsing Authorization header directives from client request. |
| exception.hpp | Exception classes for server::handlers::auth::digest::Parser |
| nonce_cache_settings_component.hpp | Component that loads nonce cache settings from a static_config.yaml. |
| standalone_checker.hpp | Class for digest authentication checker. Implements a stand-alone digest-authentication logic. |
| types.hpp | Types for validating directive values |
| auth_checker_apikey_settings.hpp | |
| auth_checker_base.hpp | |
| auth_checker_factory.hpp | Authorization factory registration and base classes |
| auth_checker_settings.hpp | |
| auth_checker_settings_component.hpp | Component that loads auth configuration settings from a components::Secdist component if the latter was registered in components::ComponentList. |
| handler_auth_config.hpp | |
| dns_client_control.hpp | Handlers that controls the DNS client. |
| dynamic_debug_log.hpp | HTTP Handler to show/hide logs at the specific file:line |
| exceptions.hpp | Helpers for throwing exceptions |
| fallback_handlers.hpp | |
| formatted_error_data.hpp | |
| handler_base.hpp | Base class for the request handlers. |
| handler_config.hpp | |
| http_handler_base.hpp | Base class for all the Userver HTTP Handlers. |
| http_handler_flatbuf_base.hpp | Convenient base for handlers that accept requests with body in Flatbuffer format and respond with body in Flatbuffer format. |
| http_handler_json_base.hpp | Convenient base for handlers that accept requests with body in JSON format and respond with body in JSON format. |
| http_handler_static.hpp | Handler that returns HTTP 200 if file exist and returns file data with mapped content/type. |
| implicit_options.hpp | A "magical" handler that will respond to OPTIONS HTTP method for any other handler that cannot handle OPTIONS itself. |
| inspect_requests.hpp | Handler that returns information about all in-flight requests. |
| jemalloc.hpp | Handler that controls the jemalloc allocator. |
| json_error_builder.hpp | |
| legacy_json_error_builder.hpp | |
| log_level.hpp | Handler that controls logging levels of all the loggers. |
| on_log_rotate.hpp | Handler that controls logging levels of all the loggers. |
| ping.hpp | Handler that returns HTTP 200 if the service is OK and able to process requests. |
| restart.hpp | Handler that stops the service. It is expected that an external system (e.g. systemd or supervisord) restarts the service afterwards. |
| server_monitor.hpp | Handler that returns statistics data. |
| tests_control.hpp | Handler that allows to control the behavior of server from tests, and functional tests with testsuite in particular. |
| ► http | |
| form_data_arg.hpp | Argument of a multipart/form-data request. |
| http_error.hpp | Get http status code mapped to generic handler error code. |
| http_method.hpp | List of HTTP methods. |
| http_request.hpp | HTTP Request data. |
| http_request_builder.hpp | HTTP Request Builder. |
| http_response.hpp | HTTP Response data. |
| http_response_body_stream.hpp | |
| http_response_body_stream_fwd.hpp | |
| http_response_cookie.hpp | HTTP response cookie. |
| http_status.hpp | HTTP status codes. |
| ► middlewares | |
| builtin.hpp | Names of userver's built-in HTTP server middlewares |
| configuration.hpp | Utility functions/classes for middleware pipelines configuration |
| headers_propagator.hpp | |
| http_middleware_base.hpp | Base classes for implementing custom middlewares |
| ► request | |
| request_config.hpp | |
| request_context.hpp | Stores request-specific data during request processing. |
| response_base.hpp | |
| task_inherited_data.hpp | Per-request data that should be available inside handlers. |
| task_inherited_request.hpp | Functions that provide access to HttpRequest stored in TaskInheritedVariable |
| ► websocket | |
| server.hpp | Main class for Websocket connection. |
| websocket_handler.hpp | Base class for WebSocket handler. |
| component.hpp | Component that listens for incoming requests, manages incoming connections and passes the requests to the appropriate handler. |
| server.hpp | |
| ► storages | |
| ► secdist | |
| component.hpp | Component that stores security related data (keys, passwords, ...). |
| exceptions.hpp | |
| fwd.hpp | Forward declarations of components::Secdist, storages::secdist::Secdist and storages::secdist::SecdistConfig |
| helpers.hpp | |
| provider.hpp | |
| provider_component.hpp | |
| secdist.hpp | Client to retrieve credentials from the components::Secdist. |
| query.hpp | Holds a query, its name and logging mode; used by all the SQL databases of userver. |
| ► testsuite | |
| cache_control.hpp | Testsuite interface for caches and cache-like components. |
| dump_control.hpp | Dumper control interface for testsuite. |
| grpc_control.hpp | |
| http_allowed_urls_extra.hpp | |
| http_testpoint_client.hpp | |
| middlewares.hpp | |
| periodic_task_control.hpp | Periodic task control interface for testsuite. |
| postgres_control.hpp | |
| redis_control.hpp | |
| tasks.hpp | Testsuite tasks support. |
| testpoint.hpp | Send testpoint notification. Works only if testpoint support is enabled (e.g. in components::TestsControl), otherwise does nothing. |
| testpoint_control.hpp | Testpoint control interface for testsuite. |
| testsuite_support.hpp | Testsuite support component. |
| ► tracing | |
| any_value.hpp | |
| component.hpp | Component that initializes the request tracing facilities. |
| in_place_span.hpp | Avoids an extra allocation by storing tracing::Span data in-place. |
| manager.hpp | Base class for propagating trace context information in headers. |
| manager_component.hpp | TracingManager base and default components |
| scope_time.hpp | Type to measure execution time of a scope. |
| set_throttle_reason.hpp | |
| span.hpp | Measures the execution time of the current code block, links it with the parent tracing::Spans and stores that info in the log. |
| span_builder.hpp | Provides interface for editing Span, before final building. |
| span_event.hpp | Span event – time-stamped annotation of the span with user-provided text description. |
| tag_scope.hpp | RAII object that calls Span::AddTag / Span::AddTagFrozen function in constructor and reverts these actions in destructor. |
| tags.hpp | |
| tracer.hpp | |
| tracer_fwd.hpp | |
| tracing.hpp | |
| ► utils | |
| ► statistics | |
| busy.hpp | A RAII-style guard to account code block execution time in utils::statistics::BusyStorage. Aware of recursive invocations in the same thread. |
| common.hpp | |
| entry.hpp | Header with all the types required in component header to use statistics (includes utils::statistics::Entry and forward declarations) |
| fmt.hpp | Fmt formatters for various statistics types |
| fwd.hpp | Forward declarations for statistics entities |
| graphite.hpp | Statistics output in Graphite format |
| histogram.hpp | A histogram with a dynamically-allocated array of buckets. |
| histogram_aggregator.hpp | Used to aggregate multiple utils::statistics::Histogram metrics. |
| histogram_view.hpp | The non-owning reader API for "histogram" metrics. |
| json.hpp | Statistics output in JSON format |
| labels.hpp | Owning and non owning labels representations |
| metadata.hpp | |
| metric_tag.hpp | Metric description and registration in a declarative way. |
| metric_tag_impl.hpp | |
| metric_value.hpp | The value of a metric. |
| metrics_storage.hpp | |
| metrics_storage_fwd.hpp | |
| min_max_avg.hpp | Class for concurrent safe calculation of minimum, maximum and average over series of values. |
| percentile.hpp | Class allows easy calculation of percentiles. |
| percentile_format_json.hpp | |
| portability_info.hpp | Portability reports |
| pretty_format.hpp | Statistics output in human-readable format |
| prometheus.hpp | Statistics output in Prometheus format |
| rate.hpp | |
| rate_counter.hpp | Atomic counter of type Rate with relaxed memory ordering. |
| recentperiod.hpp | |
| recentperiod_detail.hpp | |
| relaxed_counter.hpp | Atomic counter of type T with relaxed memory ordering. |
| solomon.hpp | Statistics output in Solomon format |
| storage.hpp | |
| striped_rate_counter.hpp | Atomic counter of type Rate with relaxed memory ordering, increased memory consumption and decreased contention. |
| system_statistics_collector.hpp | Component for system resource usage statistics collection. |
| writer.hpp | Class for writing metrics that is provided by utils::statistics::Storage. |
| async.hpp | Utility functions to start asynchronous tasks |
| cpu_relax.hpp | Helper classes to yield in CPU intensive places |
| daemon_run.hpp | Functions to start a daemon with specified components list |
| datetime.hpp | Date, Time, and Timezone related converters |
| graphite.hpp | |
| hedged_request.hpp | Classes and functions for performing hedged requests |
| lazy_shared_ptr.hpp | A lazy wrapper around utils::SharedReadablePtr that fetches the data on first access. |
| log.hpp | Algorithms to aid logging |
| periodic_task.hpp | Task that periodically runs a user callback. Callback is started after the previous callback execution is finished every period + A - B, where: |
| retry_budget.hpp | |
| text.hpp | Text utilities |
| trx_tracker.hpp | Tracking for heavy operations while having active transactions |
| userver_info.hpp | Information about userver and its build environment |
| ► userver | |
| ► cache | |
| statistics_mock.hpp | Allows to test helper functions of CacheUpdateTrait::Update that use UpdateStatisticsScope. |
| ► dump | |
| operations_mock.hpp | |
| test_helpers.hpp | |
| ► utest | |
| dns_server_mock.hpp | |
| http_client.hpp | |
| http_server_mock.hpp | Toy HTTP server for testing; for raw TCP or TLS testing use utest::SimpleServer. |
| simple_server.hpp | Toy server for simple network testing; for testing HTTP prefer using utest::HttpServerMock. |
| test_case_macros.hpp | |
| utest.hpp | Versions of gtest macros that run tests in a coroutine environment |
| ► utils | |
| ► statistics | |
| testing.hpp | Utilities for analyzing emitted metrics in unit tests |
| ► userver | |
| ► dump | |
| protobuf.hpp | Dumping support for protobuf messages |
| ► ugrpc | |
| ► client | |
| ► middlewares | |
| ► baggage | |
| component.hpp | Component for gRPC client baggage. |
| middleware.hpp | middleware for gRPC client baggage |
| ► deadline_propagation | |
| component.hpp | Component for gRPC client deadline_propagation. Update deadline from TaskInheritedData if it exists and more strict than context deadline. |
| middleware.hpp | middleware for RPC handler logging settings |
| ► headers_propagator | |
| component.hpp | gRPC client middleware for sending headers stored by the respective HTTP and gRPC server middlewares. |
| ► log | |
| component.hpp | Component for gRPC client logging. |
| ► testsuite | |
| component.hpp | Component for gRPC client testsuite support. |
| middleware.hpp | middleware for gRPC client testsuite |
| base.hpp | Base class for client gRPC middleware. |
| fwd.hpp | Forward declarations for grpc server middlewares |
| pipeline.hpp | Component to create middlewares pipeline. |
| call_context.hpp | gRPC call context |
| call_options.hpp | Options passed to interface calls. |
| channels.hpp | Utilities for managing gRPC connections |
| client_factory.hpp | Creates gRPC clients. |
| client_factory_component.hpp | Provides a ClientFactory in the component system. |
| client_factory_settings.hpp | Settings relating to the ClientFactory. |
| client_qos.hpp | |
| client_settings.hpp | Settings relating to creation of a code-generated client. |
| common_component.hpp | Contains common machinery that's required for all ugrpc clients. |
| component_list.hpp | Two common component lists for grpc-client (default and minimal) |
| exceptions.hpp | Exceptions thrown by gRPC client streams |
| fwd.hpp | Forward declarations for ugrpc::client classes |
| generic_client.hpp | Allows to talk to gRPC services (generic and normal) using dynamic method names. |
| generic_options.hpp | |
| graceful_stream_finish.hpp | Utilities to gracefully finish streams |
| qos.hpp | Per-RPC quality-of-service config. Taken from ugrpc::client::ClientQos. Can also be passed to ugrpc client methods manually. |
| response_future.hpp | Controls a single request -> single response RPC. |
| retry_config.hpp | Retry configuration for outgoing RPCs. |
| simple_client_component.hpp | Template class for a simple gRPC client. |
| stream.hpp | Client streaming interfaces |
| stream_read_future.hpp | StreamReadFuture for waiting a single read response from stream. |
| ► server | |
| ► middlewares | |
| ► access_log | |
| component.hpp | gRPC server access log middleware component. Writes one TSKV log line per handled RPC in a static format. This log is intended to be collected, parsed and stored for audit or extended statistics purposes. |
| ► baggage | |
| component.hpp | Component for gRPC server baggage. |
| middleware.hpp | |
| ► congestion_control | |
| component.hpp | Component for gRPC server logging. |
| ► deadline_propagation | |
| component.hpp | Component for gRPC server deadline propagation. |
| middleware.hpp | |
| ► headers_propagator | |
| component.hpp | Component for gRPC server headers_propagator. |
| ► log | |
| component.hpp | Component for gRPC server logging. |
| base.hpp | Base class for server gRPC middleware. |
| fwd.hpp | Forward declarations for grpc server middlewares |
| pipeline.hpp | Component to create middlewares pipeline. |
| call_context.hpp | gRPC call context |
| component_list.hpp | Two common component lists for grpc-server (default and minimal) |
| exceptions.hpp | Errors thrown by gRPC server streams |
| generic_service_base.hpp | Allows to handle RPCs with dynamic method names. |
| metadata_utils.hpp | Utilities to work with the request metadata |
| result.hpp | Result type for service handlers (non server-streaming). |
| server.hpp | Manages the gRPC server. |
| server_component.hpp | Component that configures and manages the gRPC server. |
| service_base.hpp | The type-erased base class for all gRPC service implementations. |
| service_component_base.hpp | Base class for all the gRPC service components. |
| storage_context.hpp | StorageContext |
| stream.hpp | Server streaming interfaces |
| ► tests | |
| service.hpp | Base classes for testing and benchmarking ugrpc service implementations in a simplified gRPC environment |
| simple_client_middleware_pipeline.hpp | |
| standalone_client.hpp | Sets up a mini gRPC client that is not directly associated with any userver gRPC server. |
| byte_buffer_utils.hpp | Helper functions for working with grpc::ByteBuffer |
| datetime_utils.hpp | Utilities for google::protobuf::Timestamp, google::type::Date, and google::protobuf::Duration types |
| proto_json.hpp | Utilities for conversion Protobuf -> Json |
| protobuf_visit.hpp | Utilities for visiting the fields of protobufs |
| status_codes.hpp | Utilities for grpc::StatusCode |
| status_utils.hpp | Utilities for grpc::Status and google::rpc::Status types |
| time_utils.hpp | |
| ► userver | |
| ► ugrpc | |
| ► tests | |
| service_fixtures.hpp | Gtest fixtures for testing ugrpc service implementations. Requires linking to userver::grpc-utest |
| ► userver | |
| ► kafka | |
| consumer_component.hpp | |
| consumer_scope.hpp | |
| exceptions.hpp | |
| headers.hpp | |
| message.hpp | |
| offset_range.hpp | |
| producer.hpp | |
| producer_component.hpp | |
| rebalance_types.hpp | |
| ► userver | |
| ► kafka | |
| ► utest | |
| kafka_fixture.hpp | |
| ► userver | |
| easy.hpp | Headers of an library for easy prototyping |
| ► userver | |
| ► grpc-protovalidate | |
| ► client | |
| component.hpp | Component for gRPC client response validation. |
| exceptions.hpp | Exceptions thrown by gRPC client validator middleware |
| ► server | |
| component.hpp | Component for gRPC server request validation. |
| buf_validate.hpp | Header which wraps buf/validate/validator.h to suppress compiler warnings from it |
| validate.hpp | Coroutine-safe wrappers around protovalidate-cc |
| ► userver | |
| ► grpc-reflection | |
| reflection_service_component.hpp | |
| ► userver | |
| ► s3api | |
| ► authenticators | |
| access_key.hpp | Authenticator for using access_key and secret_key for authentication |
| interface.hpp | Base class for all authenticators - classes that sign the request with auth data. |
| utils.hpp | Helpers for writing your own authenticators |
| ► clients | |
| fwd.hpp | Forward declarations |
| s3api.hpp | Client for any S3 api service |
| ► models | |
| fwd.hpp | |
| request.hpp | Request class. Although it is rarely used in S3 client, it is required to implement authenticator |
| s3api_connection_type.hpp | S3 connection type. Currently used to distinguish between http and https. It will be removed in future versions |
| secret.hpp | Non-loggable typedef that is used for storing secrets |
| ► userver | |
| ► cache | |
| base_mongo_cache.hpp | Base class for all caches polling mongo collection |
| mongo_cache_type_traits.hpp | |
| ► formats | |
| ► bson | |
| binary.hpp | Binary representation helpers |
| bson_builder.hpp | Internal helpers for inline document build |
| document.hpp | BSON document. |
| exception.hpp | BSON-specific exceptions |
| inline.hpp | Inline value builders |
| iterator.hpp | Iterator for BSON values. |
| serialize.hpp | Textual serialization helpers |
| serialize_duration.hpp | Serializers for std::chrono::duration types |
| types.hpp | BSON-specific types |
| value.hpp | Non-mutable BSON value representation. |
| value_builder.hpp | Builder for BSON. |
| bson.hpp | Include-all header for BSON support |
| bson_fwd.hpp | Forward declarations of formats::bson types, formats::parse::To and formats::serialize::To |
| ► storages | |
| ► mongo | |
| ► utest | |
| mongo_fixture.hpp | Provides access to storages::mongo::Pool by means storages::mongo::utest::MongoLocal class. |
| mongo_local.hpp | Mongo local class. |
| bulk.hpp | Bulk collection operation model |
| bulk_ops.hpp | Bulk sub-operation models |
| collection.hpp | MongoDB collection handle, the main way to operate with MongoDB. |
| component.hpp | MongoDB client component. |
| cursor.hpp | Interface for MongoDB query cursors. |
| dist_lock_component_base.hpp | Base class for mongo-based distlock worker components. |
| dist_lock_strategy.hpp | |
| exception.hpp | MongoDB-specific exceptions |
| mongo_error.hpp | |
| multi_mongo.hpp | |
| operations.hpp | Collection operation models |
| options.hpp | Query options |
| pool.hpp | MongoDB client pool. |
| pool_config.hpp | MongoDB connection pool configuration. |
| write_result.hpp | |
| mongo.hpp | Include-all header for MongoDB client |
| ► userver | |
| ► storages | |
| ► mysql | |
| ► tests | |
| utils.hpp | Utilities for testing logic working with MySQL |
| cluster.hpp | Client interface for a cluster of MySQL servers. Usually retrieved from components::MySQL. |
| cluster_host_type.hpp | |
| command_result_set.hpp | |
| component.hpp | MySQL/MariaDB client component. |
| convert.hpp | |
| cursor_result_set.hpp | |
| dates.hpp | |
| exceptions.hpp | |
| execution_result.hpp | |
| options.hpp | |
| query.hpp | |
| row_types.hpp | Helper tags to disambiguate result extraction between row and field |
| statement_result_set.hpp | |
| transaction.hpp | |
| mysql.hpp | |
| ► userver | |
| ► otlp | |
| ► logs | |
| component.hpp | Component to configure logging via OTLP collector. |
| ► userver | |
| ► cache | |
| base_postgres_cache.hpp | Caching component for PostgreSQL. See Caching Component for PostgreSQL. |
| base_postgres_cache_fwd.hpp | Forward declaration of the components::PostgreCache |
| ► chaotic | |
| ► io | |
| ► userver | |
| ► storages | |
| ► postgres | |
| time_point_tz.hpp | |
| ► storages | |
| ► postgres | |
| ► io | |
| array_types.hpp | I/O support for arrays (std::array, std::set, std::unordered_set, std::vector) |
| bitstring.hpp | Storages::postgres::BitString I/O support |
| boost_multiprecision.hpp | Boost::multiprecision I/O support |
| buffer_io.hpp | I/O buffer helpers |
| buffer_io_base.hpp | |
| bytea.hpp | Storages::postgres::Bytea I/O support |
| chrono.hpp | Timestamp (std::chrono::*) I/O support |
| composite_types.hpp | Composite types I/O support |
| date.hpp | Utils::datetime::Date I/O support |
| decimal64.hpp | Decimal64::Decimal I/O support |
| enum_types.hpp | Enum I/O support |
| field_buffer.hpp | |
| floating_point_types.hpp | Floating point I/O support |
| geometry_types.hpp | Geometry I/O support |
| integral_types.hpp | Integral types I/O support |
| interval.hpp | Time intervals I/O support |
| io_fwd.hpp | Forward declarations of types for PostgreSQL mappings |
| ip.hpp | Utils::ip::NetworkV4 I/O support |
| json_types.hpp | JSON I/O support |
| macaddr.hpp | Utils::Macaddr and utils::Macaddr8 I/O support |
| nullable_traits.hpp | |
| numeric_data.hpp | |
| optional.hpp | Optional values I/O support |
| pg_types.hpp | Postgres-specific types I/O support |
| range_types.hpp | Ranges I/O support |
| row_types.hpp | |
| string_types.hpp | Strings I/O support |
| strong_typedef.hpp | Utils::StrongTypedef I/O support |
| supported_types.hpp | Includes parsers and formatters for all supported data types; prefer using the type specific include to avoid compilation time slowdown |
| time_of_day.hpp | Utils::datetime::TimeOfDay I/O support |
| traits.hpp | |
| transform_io.hpp | |
| type_mapping.hpp | |
| type_traits.hpp | |
| user_types.hpp | User types I/O support |
| uuid.hpp | UUID (boost::uuids::uuid) I/O support |
| cluster.hpp | Interface for executing queries on a cluster of PostgreSQL servers. |
| cluster_types.hpp | Cluster properties |
| component.hpp | PosgreSQL client component. |
| database.hpp | Object for accessing PostgreSQL database instance (sharded or not) |
| database_fwd.hpp | Forward declarations of Database, DatabasePtr |
| dist_lock_component_base.hpp | Base class for postgres-based distlock worker components. |
| dist_lock_strategy.hpp | Postgres distributed locking strategy. |
| dsn.hpp | DSN manipulation helpers |
| exceptions.hpp | Postgres errors |
| field.hpp | Result field accessors |
| message.hpp | Database messages |
| notify.hpp | Asynchronous notifications |
| null.hpp | NULL type |
| options.hpp | Options |
| parameter_store.hpp | Class for dynamic PostgreSQL parameter list construction. |
| portal.hpp | |
| postgres.hpp | |
| postgres_fwd.hpp | Forward declarations of some popular postgre related types |
| query.hpp | |
| query_queue.hpp | An utility to execute multiple queries in a single network round-trip |
| result_set.hpp | Result accessors |
| row.hpp | Result row accessors |
| sql_state.hpp | PostgreSQL error codes |
| statistics.hpp | Statistics helpers |
| transaction.hpp | Transactions |
| ► userver | |
| ► urabbitmq | |
| admin_channel.hpp | Administrative interface for the broker |
| broker_interface.hpp | A bunch of interface classes |
| channel.hpp | Publisher interface for the broker |
| client.hpp | Interface for communicating with a RabbitMQ cluster. |
| client_settings.hpp | |
| component.hpp | RabbitMQ (AMQP 0.9.1) client component. |
| consumer_base.hpp | Base class for your consumers |
| consumer_component_base.hpp | Base component for your consumers |
| consumer_settings.hpp | Consumer settings |
| typedefs.hpp | Convenient typedefs for RabbitMQ entities |
| rabbitmq.hpp | |
| rabbitmq_fwd.hpp | |
| ► userver | |
| ► storages | |
| ► redis | |
| ► utest | |
| redis_fixture.hpp | Valkey or Redis fixture. |
| redis_local.hpp | Valkey or Redis local class. |
| base.hpp | |
| bit_operation.hpp | |
| client.hpp | Valkey or Redis client. |
| client_fwd.hpp | Forward declarations of storages::redis::Client and storages::redis::SubscribeClient |
| command_control.hpp | Redis command execution options. |
| command_options.hpp | Definitions of structures representing options for different commands |
| component.hpp | Valkey and Redis client component. |
| exception.hpp | Redis-specific exceptions |
| expire_reply.hpp | Reply for the EXPIRE command |
| fwd.hpp | Forward declarations of storages::redis::Reply, storages::redis::ReplyData, storages::redis::CommandControl, storages::redis::Request, storages::redis::Client and storages::redis::SubscribeClient |
| hedged_request.hpp | Classes and functions for performing hedged requests |
| key_type.hpp | Type of the Redis value stored by a key. |
| parse_reply.hpp | Customizations for Redis response parsings |
| redis_config.hpp | Main config for the Valkey/Redis. |
| redis_state.hpp | |
| reply.hpp | |
| reply_fwd.hpp | Forward declarations of storages::redis::Reply and storages::redis::ReplyData |
| reply_status.hpp | Valkey/Redis reply status. |
| reply_types.hpp | Definitions of structures representing different Redis replies |
| request.hpp | Valkey/Redis futures for storages::redis::Client and storages::redis::Transaction |
| request_data_base.hpp | |
| request_eval.hpp | Redis future for EVAL responses. |
| request_evalsha.hpp | Redis future for EVALSHA responses. |
| request_generic.hpp | Redis future for generic command responses. Can be used to request custom modules commands or unsupported yet commands. |
| scan_tag.hpp | Enum that distinguished different SCAN requests for the storages::redis::ScanRequest. |
| subscribe_client.hpp | Client that allows subscribing to Redis channel messages. |
| subscription_token.hpp | RAII subscription guard, that is usually retrieved from storages::redis::SubscribeClient. |
| transaction.hpp | Atomic sequence of Redis commands (https://redis.io/topics/transactions), that is usually retrieved from storages::redis::Client::Multi(). |
| ttl_reply.hpp | |
| wait_connected_mode.hpp | Connection wait options for the Redis; mostly used by storages::redis::Client::WaitConnectedOnce. |
| ► userver | |
| ► storages | |
| ► sqlite | |
| ► infra | |
| ► statistics | |
| statistics.hpp | |
| statistics_counter.hpp | |
| ► strategy | |
| exclusive_read_write.hpp | |
| pool_strategy.hpp | |
| read_only.hpp | |
| read_write.hpp | |
| connection_ptr.hpp | |
| pool.hpp | |
| client.hpp | Interface for executing queries on SQLite connection. Usually retrieved from components::SQLite. |
| component.hpp | Components::SQLite |
| cursor_result_set.hpp | |
| exceptions.hpp | |
| execution_result.hpp | |
| operation_types.hpp | Operation properties for SQLite client |
| options.hpp | SQLite options |
| query.hpp | |
| result_set.hpp | A proxy for statement execution result. |
| row_types.hpp | Helper tags to disambiguate result extraction between row and field |
| savepoint.hpp | |
| sqlite_fwd.hpp | Forward declarations of some popular sqlite related types |
| transaction.hpp | |
| sqlite.hpp | |
| ► userver | |
| ► cache | |
| lru_map.hpp | |
| lru_set.hpp | |
| ► compiler | |
| demangle.hpp | Returns a human-readable representation of provided type name. |
| select.hpp | Utilities for selection of platform specific values |
| thread_local.hpp | Utilities for using thread-local variables in a coroutine-safe way |
| ► compression | |
| error.hpp | |
| zstd.hpp | |
| ► crypto | |
| algorithm.hpp | Miscellaneous cryptographic routines. |
| base64.hpp | Cryptographic hashing. |
| basic_types.hpp | Common types for crypto module |
| certificate.hpp | |
| crypto.hpp | Include-all header for crypto routines |
| exception.hpp | Exception classes for crypto module |
| hash.hpp | Cryptographic hashing. |
| openssl.hpp | Class to initialize OpenSSL with mutexes. |
| private_key.hpp | |
| public_key.hpp | |
| random.hpp | Cryptographically-secure randomness |
| signers.hpp | Digital signature generators |
| verifiers.hpp | Digital signature verifiers |
| ► decimal64 | |
| decimal64.hpp | Decimal data type for fixed-point arithmetic |
| format_options.hpp | Structure storing format options for decimal |
| ► formats | |
| ► common | |
| conversion_stack.hpp | Used in the implementation of functions that convert between different formats, e.g. formats::yaml::Value to formats::json::Value, etc. |
| items.hpp | Wrapper for handy python-like iteration over a map. |
| iterator_direction.hpp | |
| merge.hpp | Add to original new non-object elements from patch (overwriting the old ones, if any) and merge object elements recursively. |
| meta.hpp | Metaprogramming helpers for converters detection |
| path.hpp | |
| transfer_tag.hpp | This tag class is used to move a ValueBuilder object without copying. |
| type.hpp | Common enum of types. |
| utils.hpp | Formats::common::GetAtPath and formats::common::RemoveAtPath utils for Value and ValueBuilder |
| validations.hpp | Common restrictions to floating type values serialization. Asserts or throws on NaN and Inf values. |
| ► json | |
| ► gdb_autogen | |
| printers.hpp | |
| ► parser | |
| array_parser.hpp | |
| base_parser.hpp | |
| bool_parser.hpp | |
| exception.hpp | |
| int_parser.hpp | |
| map_parser.hpp | |
| number_parser.hpp | |
| parser.hpp | |
| parser_handler.hpp | |
| parser_json.hpp | |
| parser_state.hpp | |
| string_parser.hpp | |
| typed_parser.hpp | |
| validator.hpp | |
| exception.hpp | Exception classes for JSON module |
| inline.hpp | Inline value builders |
| iterator.hpp | Iterator for formats::json::Value |
| schema.hpp | JSON schema validator |
| serialize.hpp | Parsers and serializers to/from string and stream |
| serialize_boost_variant.hpp | Serializers for boost::variant types |
| serialize_container.hpp | |
| serialize_duration.hpp | Serializers for std::chrono::duration types |
| serialize_variant.hpp | Serializers for std::variant. Deprecated include, use userver/formats/serialize/variant.hpp instead of |
| string_builder.hpp | SAX like builder of JSON string. Use with extreme caution and only in performance critical part of your code. |
| string_builder_fwd.hpp | Forward declaration of formats::json::StringBuilder |
| value.hpp | Non-mutable JSON value representation. |
| value_builder.hpp | Builder for JSON. |
| ► parse | |
| boost_flat_containers.hpp | Parsers and converters for boost::container::flat_* containers |
| boost_optional.hpp | Parsers and converters for boost::optional |
| boost_uuid.hpp | Boost::uuids::uuid parser for any format |
| boost_variant.hpp | Ineffective but generic parser for boost::variant type |
| common.hpp | Parsers and converters for std::chrono::seconds, std::chrono::system_clock::time_point and integral types |
| common_containers.hpp | Parsers and converters for Standard Library containers and std::optional |
| time_of_day.hpp | Utils::datetime::TimeOfDay parser for any format |
| to.hpp | Helper for parsers |
| variant.hpp | Ineffective but generic parser for std::variant type |
| ► serialize | |
| boost_optional.hpp | Serializers for boost::optional |
| boost_uuid.hpp | Boost::uuids::uuid serializer to any format |
| common_containers.hpp | Serializers for standard containers and optional |
| time_of_day.hpp | Utils::datetime::TimeOfDay to any format |
| to.hpp | Helper for serializers |
| variant.hpp | Serializers for std::variant |
| write_to_stream.hpp | Common WriteToStream functions for SAX serializers |
| ► yaml | |
| exception.hpp | Exception classes for YAML module |
| iterator.hpp | Iterator for formats::yaml::Value |
| serialize.hpp | Parsers and serializers to/from string and stream |
| serialize_container.hpp | |
| types.hpp | Forward declarations of the internal YAML types |
| value.hpp | Non-mutable YAML value representation. |
| value_builder.hpp | Builder for YAML. |
| value_fwd.hpp | Forward declaration of the formats::yaml::Value |
| json.hpp | Include-all header for JSON support |
| json_fwd.hpp | Forward declarations of formats::json types, formats::parse::To and formats::serialize::To |
| yaml.hpp | Include-all header for YAML support |
| yaml_fwd.hpp | Forward declarations of formats::yaml types, formats::parse::To and formats::serialize::To |
| ► fs | |
| ► blocking | |
| c_file.hpp | A std::FILE* wrapper. |
| file_descriptor.hpp | A file descriptor wrapper. |
| open_mode.hpp | A set of OpenFlags. |
| read.hpp | Functions for synchronous (blocking) file read operations |
| temp_directory.hpp | A unique directory for temporary files. The directory is deleted when the TempDirectory is destroyed. |
| temp_file.hpp | A unique temporary file. The file is deleted when the TempFile object is destroyed. |
| write.hpp | Functions for synchronous (blocking) file write operations |
| ► hostinfo | |
| ► blocking | |
| get_hostname.hpp | Returns host name. |
| read_groups.hpp | Reads Conductor groups from conductor-hostinfo file. |
| cpu_limit.hpp | Information about CPU limits in container |
| ► http | |
| ► parser | |
| http_request_parse_args.hpp | Strict URL arguments parsing |
| common_headers.hpp | Common HTTP header names |
| content_type.hpp | Content-Type representation. |
| header_map.hpp | |
| http_version.hpp | HTTP version to use. |
| parse_status_code.hpp | |
| predefined_header.hpp | |
| status_code.hpp | https://en.wikipedia.org/wiki/List_of_HTTP_status_codes |
| url.hpp | URL manipulation functions |
| ► logging | |
| format.hpp | Log formats |
| fwd.hpp | Forward declarations for logging types |
| json_string.hpp | |
| level.hpp | Log levels |
| log.hpp | Logging helpers |
| log_extra.hpp | Extra tskv fields storage. |
| log_filepath.hpp | Short source path calculator |
| log_helper.hpp | |
| log_helper_extras.hpp | Logging for less popular types from std and boost |
| log_helper_fwd.hpp | |
| null_logger.hpp | Creates a logger that drops all incoming messages. |
| stacktrace_cache.hpp | |
| ► tracing | |
| opentelemetry.hpp | |
| ► utest | |
| using_namespace_userver.hpp | For samples and snippets only! Has a using namespace / USERVER_NAMESPACE; if the USERVER_NAMESPACE is not empty |
| ► utils | |
| ► datetime | |
| cpp_20_calendar.hpp | This file brings date.h into utils::datetime::date namespace, which is std::chrono::operator/ (calendar) in c++20 |
| date.hpp | Date in format YYYY-MM-DD, std::chrono::year_month_day like type. |
| from_string_saturating.hpp | Saturating converters from strings to time points |
| steady_coarse_clock.hpp | Steady clock with up to a few millisecond resolution that is slightly faster than the std::chrono::steady_clock. |
| timepoint_tz.hpp | Timepoint with timezone |
| wall_coarse_clock.hpp | System clock with up to a few millisecond resolution that is slightly faster than the std::chrono::system_clock. |
| ► encoding | |
| hex.hpp | Encoders, decoders and helpers for hexadecimal representations |
| tskv.hpp | Encoders, decoders and helpers for TSKV representations |
| tskv_parser.hpp | A streaming parser for the TSKV variant that userver emits. |
| tskv_parser_read.hpp | Read all keys-values for 1 TSKV record. |
| algo.hpp | Small useful algorithms |
| any_movable.hpp | Replacement for std::any that is not copyable. It allows to store non-copyable and even non-movable types. |
| any_storage.hpp | map-like heterogeneous data storage |
| assert.hpp | Assertion macros UASSERT, UASSERT_MSG, UINVARIANT and AbortWithStacktrace() function |
| atomic.hpp | Helper algorithms to work with atomics |
| boost_filesystem_file_status.hpp | |
| boost_uuid4.hpp | Generates UUIDv4. |
| boost_uuid7.hpp | Generates UUIDv7. |
| box.hpp | Remote storage for a single item. Implemented as a unique pointer that is never null, except when moved from. |
| bytes_per_second.hpp | Data type that represents bytes per second unit. |
| cached_hash.hpp | Holds the key and its hash for faster comparisons and hashing. |
| checked_pointer.hpp | Utility template for returning a pointer to an object that is owned by someone else; throws std::runtime_error if nullptr is stored. |
| constexpr_indices.hpp | Functions for iterating over a constexpr range of integers |
| datetime_light.hpp | Date and Time related converters |
| default_dict.hpp | Dictionary with special value for missing keys |
| distances.hpp | Distances between strings and nearest string suggestions |
| enumerate.hpp | Implementation of python-style enumerate function for range-for loops. |
| exception.hpp | Logs error_message and throws an exception ith that message. |
| expected.hpp | For holding a value or an error. |
| fast_pimpl.hpp | Implements pimpl idiom without dynamic memory allocation. |
| fast_scope_guard.hpp | a helper class to perform actions on scope exit |
| filter_bloom.hpp | Space-efficient probabilistic data structure. |
| fixed_array.hpp | A fixed-size array with the size determined at runtime. |
| flags.hpp | Types that provide flags interface to enums |
| fmt_compat.hpp | |
| from_string.hpp | Extract the number contained in the string. No space characters or other extra characters allowed. Supported types: |
| function_ref.hpp | A backport of std::function_ref from C++26 |
| get_if.hpp | |
| invariant_error.hpp | Exception that is thrown on UINVARIANT violation. |
| ip.hpp | IPv4 and IPv6 addresses and networks |
| lazy_prvalue.hpp | Can be used with various emplace functions to allow in-place constructing a non-movable value using a callable. |
| macaddr.hpp | MAC address types |
| make_intrusive_ptr.hpp | Factory function for boost::intrusive_ptr, like std::make_unique. |
| meta.hpp | Metaprogramming, template variables and concepts |
| meta_light.hpp | Lightweight concepts |
| mock_now.hpp | Mocking and getting mocked time values |
| move_only_function.hpp | A backport of std::move_only_function from C++23 |
| not_null.hpp | Restricts a pointer or smart pointer to only hold non-null values. |
| numeric_cast.hpp | |
| optional_ref.hpp | Class that behaves as a nullable reference. Main difference from the pointer - value comparison of pointed values. |
| optionals.hpp | Helper functions for std optionals |
| overloaded.hpp | Utility to define std::variant visitors in a simple way. |
| projected_set.hpp | A std::unordered_set that compares its elements (of type Value) based on their Projection. It allows to create, essentially, an equivalent of std::unordered_map where keys are stored inside values. |
| rand.hpp | Random number generators |
| regex.hpp | A drop-in replacement for std::regex without huge includes and with better performance characteristics. |
| resources.hpp | |
| result_store.hpp | |
| scope_guard.hpp | a helper class to perform actions on scope exit |
| shared_readable_ptr.hpp | std::shared_ptr<const T> wrapper that makes sure that the pointer is stored before dereferencing. Protects from dangling references. |
| sliding_interval.hpp | Sliding interval of values that provides functions to compute average, min and max values from the last window_size values of interval. |
| small_string.hpp | 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. |
| small_string_fwd.hpp | |
| small_string_serialization.hpp | |
| span.hpp | A polyfill for std::span from C++20. |
| str_icase.hpp | Case insensitive ASCII comparators and hashers |
| str_icase_containers.hpp | Contains utilities for working with containers with utils::StrCaseHash and utils::StrIcaseHash |
| strerror.hpp | MT-safe version of POSIX functions ::strerror and ::strsignal |
| string_literal.hpp | Non-empty string view to a compile time known null terminated char array that lives for the lifetime of program, as per [lex.string]; a drop-in replacement for static const std::string kVar = "value" and constexpr std::string_view kVar = "value". |
| string_to_duration.hpp | Converts strings like "10s", "5d", "1h" to durations. |
| strong_typedef.hpp | Strong typedef for a type T. |
| struct_subsets.hpp | Utilities for creating a struct with a subset of fields of the original struct, with conversions between them |
| swappingsmart.hpp | |
| text_light.hpp | Text utilities that do not use locales |
| thread_name.hpp | Functions for thread name manipulation |
| threads.hpp | Functions to work with OS threads |
| time_of_day.hpp | A simple implementation of a "time since midnight" datatype. |
| token_bucket.hpp | |
| traceful_exception.hpp | Exception that remembers the backtrace at the point of its construction. |
| trivial_map.hpp | Bidirectional map|sets over string literals or other trivial types |
| trivial_map_fwd.hpp | Forward declarations of utils::TrivialBiMap and utils::TrivialSet types |
| underlying_value.hpp | |
| uuid4.hpp | Generate a UUIDv4 string. |
| uuid7.hpp | Generate a UUIDv7 string. |
| void_t.hpp | std::void_t implementation with workarounds for compiler bugs |
| zstring_view.hpp | Non-empty string view type that guarantees null-termination and has a c_str() member function. |
| ► yaml_config | |
| fwd.hpp | Forward declarations of YamlConfig type and formats::parse::To |
| iterator.hpp | |
| map_to_array.hpp | |
| merge_schemas.hpp | Merge parent and child components schemas of static configs. |
| schema.hpp | JSON Schema-like type definition. |
| yaml_config.hpp | Datatype that represents YAML with substituted variables. |
| ► userver | |
| ► utest | |
| assert_macros.hpp | Extensions to the gtest macros for printing and testing exceptions that could work even without coroutine environment |
| current_process_open_files.hpp | returns files opened by current process |
| death_tests.hpp | Contains facilities for testing service crashes |
| default_logger_fixture.hpp | Fixture that allows to set the default logger and manages its lifetime. |
| literals.hpp | |
| log_capture_fixture.hpp | Fixture that allows to capture and extract log written into the default logger. |
| parameter_names.hpp | Test name printer for parameterized tests written in gtest. |
| ► userver | |
| ► ydb | |
| ► dist_lock | |
| component_base.hpp | Base class for YDB-based distlock worker components. |
| settings.hpp | A set of tweak-able settings for ydb::DistLockWorker. |
| worker.hpp | |
| ► io | |
| generic_optional.hpp | |
| insert_row.hpp | |
| list.hpp | |
| primitives.hpp | |
| structs.hpp | |
| supported_types.hpp | |
| traits.hpp | |
| builder.hpp | |
| component.hpp | YDB client component. |
| coordination.hpp | YDB Coordination client |
| credentials.hpp | Credentials provider component for creating custom credentials provider factory. |
| exceptions.hpp | |
| federated_topic.hpp | YDB Federated Topic client |
| fwd.hpp | |
| query.hpp | |
| response.hpp | |
| settings.hpp | |
| table.hpp | |
| topic.hpp | YDB Topic client |
| transaction.hpp | |
| types.hpp | |
| ► utest | |
| ► include | |
| ► userver | |
| ► s3api | |
| ► utest | |
| client_gmock.hpp | |
| ► src | |
| client_gmock.cpp | |