▼ en | |
► cpp | |
def_groups.hpp | |
▼ testsuite | |
► pytest_plugins | |
► pytest_userver | |
► plugins | |
► grpc | |
__init__.py | |
client.py | |
mockserver.py | |
► ydb | |
__init__.py | |
client.py | |
discover.py | |
service.py | |
ydbsupport.py | |
__init__.py | |
base.py | |
caches.py | |
clickhouse.py | |
config.py | |
core.py | |
dumps.py | |
dynamic_config.py | |
log_capture.py | |
logging.py | |
mongo.py | |
mysql.py | |
postgresql.py | |
rabbitmq.py | |
redis.py | |
service.py | |
service_client.py | |
service_runner.py | |
testpoint.py | |
► utils | |
__init__.py | |
colorize.py | |
net.py | |
tskv.py | |
__init__.py | |
chaos.py | |
client.py | |
metrics.py | |
sql.py | |
▼ userver | |
► storages | |
► clickhouse | |
► impl | |
block_wrapper_fwd.hpp | |
insertion_request.hpp | |
is_decl_complete.hpp | |
iterators_helper.hpp | |
pool.hpp | |
► 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 | |
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 |
► impl | |
escape.hpp | |
validate.hpp | |
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 |
query.hpp | Holds a query and its name. In case query is expected to be executed with parameters, query text should conform to fmt format. |
clickhouse.hpp | |
▼ userver | |
► alerts | |
component.hpp | |
handler.hpp | |
storage.hpp | |
► baggage | |
baggage.hpp | Baggage header. Contains entries (key, value, optional<properties>). |
baggage_manager.hpp | Baggage manipulation client and component |
baggage_settings.hpp | |
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 |
► clients | |
► dns | |
common.hpp | Common DNS client declarations |
component.hpp | Caching DNS resolver component. |
config.hpp | Caching DNS resolver static configuration. |
exception.hpp | DNS client exceptions |
resolver.hpp | Caching DNS resolver implementation. |
resolver_fwd.hpp | |
resolver_utils.hpp | |
► http | |
► plugins | |
► 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 | |
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. |
request_tracing_editor.hpp | Auxiliary entity that allows editing request to a client from plugins. |
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 | |
► impl | |
component_base.hpp | |
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_config.hpp | |
component_context.hpp | Class to retrieve other components. |
component_fwd.hpp | Forward declarations for components::ComponentContext and components::ComponentConfig; function components::GetCurrentComponentName() |
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. |
headers_propagator_component.hpp | HeadersPropagatorComponent and default components |
loggable_component_base.hpp | Contains components::LoggableComponentBase declaration and forward declarations of components::ComponentConfig and components::ComponentContext, function components::GetCurrentComponentName() |
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. |
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 | |
► impl | |
asymmetric_fence.hpp | |
intrusive_hooks.hpp | |
intrusive_stack.hpp | |
semaphore_capacity_control.hpp | |
striped_read_indicator.hpp | |
tagged_ptr.hpp | |
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 | |
mpsc_queue.hpp | Multiple producer, single consumer queue |
mutex_set.hpp | A dynamic set of mutexes. |
queue.hpp | |
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. |
config.hpp | Congestion Control config structures |
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 | |
► impl | |
connection_pool_base.hpp | Base connection pool implementation to be derived in different drivers. Takes care of synchronization, pool limits (min/max, simultaneously connecting etc.) and provides hooks for metrics. |
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. |
► impl | |
snapshot.hpp | |
to_json.hpp | |
► 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 | |
► impl | |
condition_variable_any.hpp | |
context_accessor.hpp | |
detached_tasks_sync_block.hpp | |
future_state.hpp | |
task_context_factory.hpp | |
task_context_holder.hpp | |
task_local_storage.hpp | |
wait_list_fwd.hpp | |
► io | |
► sys_linux | |
inotify.hpp | |
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. |
sockaddr.hpp | Native socket address wrapper. |
socket.hpp | Socket representation. |
tls_wrapper.hpp | TLS socket wrappers |
► subprocess | |
child_process.hpp | |
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 |
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 | 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 | |
sleep.hpp | Time-based coroutine 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 | @copybref fs::FsCacheClient |
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 |
► 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 | |
auth_checker_settings_component.hpp | server::handlers::auth::digest::AuthCheckerSettingsComponent |
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 | server::handlers::auth::digest::NonceCacheSettingsComponent |
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 | |
► impl | |
deadline_propagation_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. |
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_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 | |
configuration.hpp | Utility functions/classes for middleware pipelines configuration |
http_middleware_base.hpp | Base classes for implementing custom middlewares |
► request | |
request_base.hpp | |
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 | |
websocket_handler.hpp | |
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. |
► 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 | |
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. |
tag_scope.hpp | |
tags.hpp | |
tracer.hpp | |
tracer_fwd.hpp | |
tracing.hpp | |
► utils | |
► impl | |
cached_time.hpp | |
userver_experiments.hpp | |
wait_token_storage.hpp | |
wrapped_call.hpp | std::packaged_task replacement with noncopyable types support |
wrapped_call_base.hpp | |
► statistics | |
► impl | |
histogram_bucket.hpp | |
busy.hpp | |
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_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. |
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 |
graphite.hpp | |
hedged_request.hpp | Classes and functions for performing hedged requests |
internal_tag_fwd.hpp | |
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 |
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 | |
current_process_open_files.hpp | @copyprief std::vector<std::string> CurrentProcessOpenFiles() |
default_logger_fixture.hpp | Fixture that allows to set the default logger and manages its lifetime. |
dns_server_mock.hpp | |
http_client.hpp | |
http_server_mock.hpp | |
log_capture_fixture.hpp | Fixture that allows to capture and extract log. |
parameter_names.hpp | Test name printer for parameterized tests written in gtest. |
simple_server.hpp | |
test_case_macros.hpp | |
utest.hpp | Versions of gtest macros that run tests in a coroutine environment |
► utils | |
► statistics | |
testing.hpp | |
▼ userver | |
► ugrpc | |
► client | |
► impl | |
async_method_invocation.hpp | |
async_methods.hpp | |
call_params.hpp | |
channel_cache.hpp | |
client_data.hpp | |
client_qos.hpp | |
codegen_declarations.hpp | |
codegen_definitions.hpp | |
► middlewares | |
► baggage | |
component.hpp | |
► deadline_propagation | |
component.hpp | ugrpc::client::middlewares::deadline_propagation::Component |
► log | |
component.hpp | |
base.hpp | |
fwd.hpp | Forward declarations for grpc server middlewares |
channels.hpp | Utilities for managing gRPC connections |
client_factory.hpp | Creates 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. |
client_factory_component.hpp | Provides a ClientFactory in the component system. |
exceptions.hpp | Exceptions thrown by gRPC client streams |
qos.hpp | |
queue_holder.hpp | Manages a gRPC completion queue, usable only in clients. |
rpc.hpp | Classes representing an outgoing RPC |
simple_client_component.hpp | Template class for a simple gRPC client. |
► impl | |
async_method_invocation.hpp | |
completion_queues.hpp | |
deadline_timepoint.hpp | |
internal_tag_fwd.hpp | Contains the tag-class to mark a function as internal only |
queue_runner.hpp | |
span.hpp | |
static_metadata.hpp | |
statistics.hpp | |
statistics_scope.hpp | |
statistics_storage.hpp | |
► server | |
► impl | |
async_method_invocation.hpp | |
async_methods.hpp | |
async_service.hpp | |
call_params.hpp | |
call_traits.hpp | |
codegen_declarations.hpp | |
codegen_definitions.hpp | |
error_code.hpp | |
queue_holder.hpp | |
service_worker.hpp | |
service_worker_impl.hpp | |
► middlewares | |
► baggage | |
component.hpp | ugrpc::server::middlewares::baggage::Component |
► congestion_control | |
component.hpp | ugrpc::server::middlewares::congestion_control::Component |
► deadline_propagation | |
component.hpp | ugrpc::server::middlewares::deadline_propagation::Component |
► log | |
component.hpp | |
base.hpp | |
fwd.hpp | Forward declarations for grpc server middlewares |
exceptions.hpp | Errors thrown by gRPC server streams |
rpc.hpp | Classes representing an incoming RPC |
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 |
proto_json.hpp | Utilities for conversion Protobuf -> Json |
status_codes.hpp | Utilities for grpc::StatusCode |
▼ userver | |
► kafka | |
► components | |
consumer_component.hpp | |
producer_component.hpp | |
consumer_scope.hpp | |
message.hpp | |
producer.hpp | |
▼ 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 | |
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 | |
► impl | |
► io | |
binder_declarations.hpp | |
common_binders.hpp | |
decimal_binder.hpp | |
extractor.hpp | |
insert_binder.hpp | |
params_binder.hpp | |
params_binder_base.hpp | |
result_binder.hpp | |
bind_helper.hpp | |
binder_fwd.hpp | |
tracing_tags.hpp | |
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 | |
► 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 |
► storages | |
► postgres | |
► detail | |
connection_ptr.hpp | |
const_data_iterator.hpp | |
db_data_type_name.hpp | |
is_decl_complete.hpp | |
is_in_namespace.hpp | |
iterator_direction.hpp | |
non_transaction.hpp | |
query_parameters.hpp | |
string_hash.hpp | |
time_types.hpp | |
typed_rows.hpp | |
► 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 | |
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 | |
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 |
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 |
sql_state.hpp | PostgreSQL error codes |
statistics.hpp | Statistics helpers |
transaction.hpp | Transactions |
typed_result_set.hpp | Typed PostgreSQL results |
▼ 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 | |
► impl | |
► reply | |
expire_reply.hpp | |
ttl_reply.hpp | |
base.hpp | |
command_options.hpp | |
keyshard.hpp | |
redis_state.hpp | |
reply.hpp | |
request.hpp | |
secdist_redis.hpp | |
thread_pools.hpp | |
transaction_subrequest_data.hpp | |
types.hpp | |
wait_connected_mode.hpp | |
client.hpp | Redis client. |
client_fwd.hpp | |
command_control.hpp | Redis command execution options. |
command_options.hpp | |
component.hpp | Redis client component. |
exception.hpp | Redis-specific exceptions |
hedged_request.hpp | Classes and functions for performing hedged requests |
key_type.hpp | |
parse_reply.hpp | |
redis_config.hpp | |
reply.hpp | |
reply_fwd.hpp | |
reply_status.hpp | |
reply_types.hpp | |
request.hpp | |
request_data_base.hpp | |
request_eval.hpp | |
request_evalsha.hpp | |
scan_tag.hpp | |
subscribe_client.hpp | Client that allows subscribing to Redis channel messages. |
subscription_token.hpp | |
transaction.hpp | |
▼ userver | |
► cache | |
► impl | |
lru.hpp | |
slru.hpp | |
lru_map.hpp | |
lru_set.hpp | |
► compiler | |
► impl | |
constexpr.hpp | |
lifetime.hpp | |
lsan.hpp | |
tls.hpp | |
tsan.hpp | Defines USERVER_IMPL_HAS_TSAN to 1 and includes <sanitizer/tsan_interface.h> if Thread Sanitizer is enabled; otherwise defines USERVER_IMPL_HAS_TSAN to 0 |
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 |
► 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. |
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 | |
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 |
► json | |
► impl | |
mutable_value_wrapper.hpp | |
types.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 |
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 |
validate.hpp | Json schema validator |
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 | |
predefined_header.hpp | |
url.hpp | URL manipulation functions |
► logging | |
► impl | |
logger_base.hpp | |
tag_writer.hpp | |
format.hpp | Log formats |
fwd.hpp | Forward declarations for logging types |
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 | |
► impl | |
assert_macros.hpp | |
assert_macros.hpp | Extensions to the gtest macros for printing and testing exceptions that could work even without coroutine environment |
death_tests.hpp | Contains facilities for testing service crashes |
literals.hpp | |
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 |
► impl | |
disable_core_dumps.hpp | |
internal_tag_fwd.hpp | |
intrusive_link_mode.hpp | |
projecting_view.hpp | |
source_location.hpp | |
static_registration.hpp | |
transparent_hash.hpp | |
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 |
atomic.hpp | Helper algorithms to work with atomics |
boost_uuid4.hpp | Generates UUIDv4. |
boost_uuid7.hpp | |
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.hpp | Date and Time related converters |
default_dict.hpp | Dictionary with special value for missing keys |
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 | |
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 |
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 | Small alias for boost::regex / std::regex without huge includes. |
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 | |
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 |
string_to_duration.hpp | Converts strings like "10s", "5d", "1h" to durations. |
strong_typedef.hpp | Strong typedef for a type T. |
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 |
► yaml_config | |
► impl | |
validate_static_config.hpp | |
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 | |
► 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 | |
► impl | |
cast.hpp | |
stats_scope.hpp | |
string.hpp | |
string_view.hpp | |
► io | |
insert_row.hpp | |
list.hpp | |
primitives.hpp | |
structs.hpp | |
supported_types.hpp | |
traits.hpp | |
builder.hpp | |
component.hpp | YDB client component. |
coordination.hpp | |
credentials.hpp | |
exceptions.hpp | |
fwd.hpp | |
query.hpp | |
response.hpp | |
settings.hpp | |
table.hpp | |
topic.hpp | |
transaction.hpp | |
types.hpp | |