Clio develop
The XRP Ledger API server.
|
Crpc::AccountChannelsHandler | The account_channels method returns information about an account's Payment Channels. This includes only channels where the specified account is the channel's source, not the destination. All information retrieved is relative to a particular version of the ledger |
Crpc::AccountCurrenciesHandler | The account_currencies command retrieves a list of currencies that an account can send or receive, based on its trust lines |
Crpc::AccountCursor | A cursor object used to traverse nodes owned by an account |
Crpc::AccountInfoHandler | The account_info command retrieves information about an account, its activity, and its XRP balance |
Crpc::AccountLinesHandler | The account_lines method returns information about an account's trust lines, which contain balances in all non-XRP currencies and assets |
Crpc::AccountNFTsHandler | The account_nfts method returns a list of NFToken objects for the specified account |
Crpc::AccountObjectsHandler | The account_objects command returns the raw ledger format for all objects owned by an account. The results can be filtered by the type. The valid types are: check, deposit_preauth, escrow, nft_offer, offer, payment_channel, signer_list, state (trust line), did and ticket |
Crpc::AccountOffersHandler | The account_offers method retrieves a list of offers made by a given account |
CAccountTransactionsData | Struct used to keep track of what to write to account_transactions/account_tx tables |
Crpc::AccountTxHandler | The account_tx method retrieves a list of transactions that involved the specified account |
Capp::CliArgs::Action | An action parsed from the command line |
Crpc::BaseServerInfoHandler< LoadBalancerType, ETLServiceType, CountersType >::AdminSection | A struct to hold the admin section of the output |
►Cweb::AdminVerificationStrategy | Interface for admin verification strategies |
Cdata::Amendment | Represents an amendment in the XRPL |
Cetl::impl::AmendmentBlockHandler | |
►Cetlng::AmendmentBlockHandlerInterface | The interface of a handler for amendment blocking |
►Cdata::AmendmentCenterInterface | The interface of an amendment center |
►Cdata::AmendmentKey | A helper for amendment name to feature conversions |
Cdata::Amendments | List of supported amendments |
Crpc::AMMInfoHandler | AMMInfoHandler returns information about AMM pools |
Cutil::prometheus::AnyBool< ImplType > | A wrapped to provide bool interface for a Prometheus metric |
►Cutil::prometheus::impl::AnyCounterBase< NumberType > | |
Cutil::async::AnyExecutionContext | A type-erased execution context |
Crpc::AnyHandler | A type-erased Handler that can contain any (NextGen) RPC handler class |
Cutil::async::AnyOperation< RetType > | A type-erased operation that can be executed via AnyExecutionContext |
Cutil::async::AnyStopToken | A type-erased stop token |
Cutil::async::AnyStrand | A type-erased execution context |
►Crpc::APIVersionParser | A baseclass for API version helper |
Cutil::config::Array | Array definition to store multiple values provided by the user from Json/Yaml |
Cutil::config::ArrayView::ArrayIterator< T > | Custom iterator class which contains config object or value underneath ArrayView |
Cutil::config::ArrayView | View for array structure for config |
Cutil::async::impl::AsioPoolContext | |
Cutil::async::impl::AsioPoolStrandContext | |
Cutil::async::impl::AssociatedExecutorExtractor | |
Cetl::impl::AsyncCallData | |
Cetlng::impl::AsyncGrpcCall | |
Cutil::Atomic< NumberType > | Atomic wrapper for integral and floating point types |
Cdata::BackendCounters | Holds statistics about the backend |
►Cdata::BackendInterface | The interface to the database used by Clio |
►Cetl::impl::BaseCursorProvider | |
►Cweb::dosguard::BaseDOSGuard | The interface of a denial of service guard |
Crpc::BaseServerInfoHandler< LoadBalancerType, ETLServiceType, CountersType > | Contains common functionality for handling the server_info command |
►Cutil::BaseTagDecorator | Represents any tag decorator |
Crpc::BaseTxHandler< ETLServiceType > | Contains common functionality for handling the tx command |
Cutil::async::BasicExecutionContext< ContextType, StopSourceType, DispatcherType, TimerContextProvider, ErrorHandlerType > | A highly configurable execution context |
Cutil::async::impl::BasicOperation< RetType > | |
►Cutil::async::impl::BasicOperation< StoppableOutcome< RetType, StopSourceType > > | |
►Cutil::async::impl::BasicOutcome< RetType > | Base for all promise side of async operations |
Cutil::async::impl::BasicStopSource | |
Cutil::async::impl::BasicStrand< ParentContextType, StopSourceType, DispatcherType, TimerContextProvider, ErrorHandlerType > | |
Crpc::validation::Between< Type > | Validate that value is between specified min and max |
Crpc::BookChange | Represents an entry in the book_changes' changes array |
Crpc::BookChanges | Encapsulates the book_changes computations and transformations |
Crpc::BookChangesHandler | BookChangesHandler returns the order book changes for a given ledger |
Crpc::BookOffersHandler | The book_offers method retrieves a list of Offers between two currencies, also known as an order book |
Cdata::BookOffersPage | Represents a page of book offer objects |
Cetlng::model::BookSuccessor | Represents a book successor |
Cetl::CacheLoader< CacheType, ExecutionContextType > | Cache loading interface |
Cetl::impl::CacheLoaderImpl< CacheType > | |
Cetl::CacheLoaderSettings | Settings for the cache loader |
Crpc::BaseServerInfoHandler< LoadBalancerType, ETLServiceType, CountersType >::CacheSection | A struct to hold the cache section of the output |
Cdata::cassandra::CassandraError | A simple container for both error message and error code |
Cmigration::cassandra::impl::CassandraMigrationSchema | The schema for the migration process. It contains the prepared statements only used for the migration process |
Crpc::AccountChannelsHandler::ChannelResponse | A struct to hold data for one channel response |
Crpc::modifiers::Clamp< Type > | Clamp value between min and max |
Capp::CliArgs | Parsed command line arguments representation |
Capp::ClioApplication | The main application class |
Cutil::config::ClioConfigDefinition | All the config data will be stored and extracted from this class |
Cutil::config::ClioConfigDescription | All the config description are stored and extracted from this class |
Crpc::ClioErrorInfo | Holds info about a particular ClioError |
►Cutil::prometheus::impl::AnyCounterBase< NumberType >::Concept | |
Cutil::Config | Convenience wrapper to query a JSON configuration file |
►Cutil::config::ConfigFileInterface | The interface for configuration files |
Cutil::ConfigReader | Simple configuration file reader |
Cutil::config::ConfigValue | Represents the config values for Json/Yaml config |
Cweb::ng::impl::ConnectionHandler | |
►Cutil::config::Constraint | An interface to enforce constraints on certain values within ClioConfigDefinition |
Cdata::cassandra::impl::Settings::ContactPoints | Represents the configuration of contact points for cassandra |
Crpc::Context | Context of an RPC call |
Cutil::CoroutineGroup | CoroutineGroup is a helper class to manage a group of coroutines. It allows to spawn multiple coroutines and wait for all of them to finish |
Cetl::CorruptionDetector< CacheType > | A helper to notify Clio operator about a corruption in the DB |
Cutil::prometheus::impl::CounterImpl< NumberType > | |
Crpc::Counters | Holds information about successful, failed, forwarded, etc. RPC handler calls |
Cetl::impl::CursorPair | |
Crpc::modifiers::CustomModifier | Customised modifier allowing user define how to modify input in provided callable |
Crpc::validation::CustomValidator | A meta-validator that allows to specify a custom validation function |
Crpc::validation::CustomValidators | A group of custom validation functions |
Cutil::async::impl::DefaultErrorHandler | |
Cdata::cassandra::impl::DefaultExecutionStrategy< HandleType, BackendCountersType > | Implements async and sync querying against the cassandra DB with support for throttling |
Crpc::impl::DefaultProcessor< HandlerType > | |
Crpc::DepositAuthorizedHandler | Handles the deposit_authorized command |
Crpc::check::Deprecated< T > | Check for a deprecated fields |
Crpc::check::Deprecated< T > | Check if a value of a field is deprecated |
Crpc::check::Deprecated<> | Check if a field is deprecated |
Capp::DisconnectHook | A function object to be called when a connection is disconnected |
►Cstd::enable_shared_from_this | |
Crpc::validation::EqualTo< Type > | Validates that the value is equal to the one passed in |
Cutil::async::impl::ErasedOperation | |
Cutil::config::Error | Displays the different errors when parsing user config |
Cweb::impl::ErrorHelper | A helper that attempts to match rippled reporting mode HTTP errors as close as possible |
Cweb::ng::impl::ErrorHelper | A helper that attempts to match rippled reporting mode HTTP errors as close as possible |
►Cetl::ETLServiceTag | A tag class to help identify ETLService in templated code |
Cetl::ETLState | This class is responsible for fetching and storing the state of the ETL information, such as the network id |
►Cstd::exception | |
Cutil::async::ExecutionError | Error channel type for async operation of any ExecutionContext |
Cutil::async::impl::SameThreadContext::Executor | |
Cutil::async::impl::SameThreadContext::Strand::Executor | |
Capp::CliArgs::Action::Exit | Exit action |
Cdata::cassandra::impl::ExponentialBackoffRetryPolicy | A retry policy that employs exponential backoff |
Cetl::impl::ExtractionDataPipe< RawDataType > | A collection of thread safe async queues used by Extractor and Transformer to communicate |
Cetl::impl::Extractor< DataPipeType, LedgerFetcherType > | Extractor thread that is fetching GRPC data and enqueue it on the DataPipeType |
►Cetlng::ExtractorInterface | An interface for the Extractor |
Crpc::FeatureHandler::Output::Feature | Represents an amendment/feature |
Crpc::FeatureHandler | Contains common functionality for handling the server_info command |
Crpc::FieldSpec | Represents a Specification for one field of an RPC command |
CFormattedTransactionsData | Account transactions, NFT transactions and NFT data bundled togeher |
Crpc::impl::ForwardingProxy< LoadBalancerType, CountersType, HandlerProviderType > | |
Crpc::impl::ForwardingProxy< LoadBalancerType, CountersType, rpc::HandlerProvider > | |
Cetl::impl::ForwardingSource | |
Cmigration::cassandra::impl::FullTableScanner< TableAdapter > | The full table scanner. It will split the full table scan into multiple ranges and read the data in given executor |
Cmigration::cassandra::impl::FullTableScannerAdapterBase< TableDesc > | The base class for the full table scanner adapter. It is responsible for reading the rows from the full table scanner and call the callback when a row is read. With this base class, each table adapter can focus on the actual row data converting |
►Cmigration::cassandra::impl::FullTableScannerAdapterBase< TableObjectsDesc > | |
►Cmigration::cassandra::impl::FullTableScannerAdapterBase< TableTransactionsDesc > | |
Cmigration::cassandra::impl::FullTableScanner< TableAdapter >::FullTableScannerSettings | The full table scanner settings |
Crpc::GatewayBalancesHandler | Handles the gateway_balances command |
Crpc::GetAggregatePriceHandler | The get_aggregate_price method |
Cetl::impl::GrpcSource | |
Cetlng::impl::GrpcSource | |
Cdata::cassandra::Handle | Represents a handle to the cassandra database cluster |
►Crpc::HandlerProvider | Interface for the provider of RPC handlers |
Capp::HealthCheckHandler | A function object that handles the health check endpoint |
Crpc::validation::Hex256ItemType | Validates that the elements of the array is of type Hex256 uint |
Cutil::prometheus::impl::HistogramImpl< NumberType > | |
Cutil::requests::HttpHeader | HTTP header |
Crpc::meta::IfType< Type > | A meta-processor that specifies a list of requirements to run against when the type matches the template parameter |
Crpc::BaseServerInfoHandler< LoadBalancerType, ETLServiceType, CountersType >::InfoSection | A struct to hold the info section of the output |
►Cetlng::InitialLoadObserverInterface | The interface for observing the initial ledger load |
Crpc::AccountChannelsHandler::Input | A struct to hold the input data for the command |
Crpc::AccountCurrenciesHandler::Input | A struct to hold the input data for the command |
Crpc::AccountInfoHandler::Input | A struct to hold the input data for the command |
Crpc::AccountLinesHandler::Input | A struct to hold the input data for the command |
Crpc::AccountNFTsHandler::Input | A struct to hold the input data for the command |
Crpc::AccountObjectsHandler::Input | A struct to hold the input data for the command |
Crpc::AccountOffersHandler::Input | A struct to hold the input data for the command |
Crpc::AccountTxHandler::Input | A struct to hold the input data for the command |
Crpc::AMMInfoHandler::Input | A struct to hold the input data for the command |
Crpc::BaseServerInfoHandler< LoadBalancerType, ETLServiceType, CountersType >::Input | A struct to hold the input data for the command |
Crpc::BaseTxHandler< ETLServiceType >::Input | A struct to hold the input data for the command |
Crpc::BookChangesHandler::Input | A struct to hold the input data for the command |
Crpc::BookOffersHandler::Input | A struct to hold the input data for the command |
Crpc::DepositAuthorizedHandler::Input | A struct to hold the input data for the command |
Crpc::FeatureHandler::Input | A struct to hold the input data for the command |
Crpc::GatewayBalancesHandler::Input | A struct to hold the input data for the command |
Crpc::GetAggregatePriceHandler::Input | A struct to hold the input data for the command |
Crpc::LedgerDataHandler::Input | A struct to hold the input data for the command |
Crpc::LedgerEntryHandler::Input | A struct to hold the input data for the command |
Crpc::LedgerHandler::Input | A struct to hold the input data for the command |
Crpc::LedgerIndexHandler::Input | A struct to hold the input data for the command |
Crpc::MPTHoldersHandler::Input | A struct to hold the input data for the command |
Crpc::NFTHistoryHandler::Input | A struct to hold the input data for the command |
Crpc::NFTInfoHandler::Input | A struct to hold the input data for the command |
Crpc::NFTOffersHandlerBase::Input | A struct to hold the input data for the command |
Crpc::NFTsByIssuerHandler::Input | A struct to hold the input data for the command |
Crpc::NoRippleCheckHandler::Input | A struct to hold the input data for the command |
Crpc::SubscribeHandler::Input | A struct to hold the input data for the command |
Crpc::TransactionEntryHandler::Input | A struct to hold the input data for the command |
Crpc::UnsubscribeHandler::Input | A struct to hold the input data for the command |
Cweb::dosguard::IntervalSweepHandler | Sweep handler clearing context every sweep interval from config |
Cdata::cassandra::impl::ResultExtractor< Types >::Iterator | |
Crpc::JsonBool | A wrapper around bool that allows to convert from any JSON value |
Cutil::config::ClioConfigDescription::KV | Struct to represent a key-value pair |
Cutil::prometheus::Label | Class representing a Prometheus label |
Cutil::prometheus::Labels | Class representing a collection of Prometheus labels |
Cdata::LedgerCache | Cache for an entire ledger |
Cetlng::model::LedgerData | Represents an entire ledger diff worth of transactions and objects |
Crpc::LedgerDataHandler | The ledger_data method retrieves contents of the specified ledger. You can iterate through several calls to retrieve the entire contents of a single ledger version |
Crpc::LedgerEntryHandler | The ledger_entry method returns a single ledger object from the XRP Ledger in its raw format |
Cetl::impl::LedgerFetcher< LoadBalancerType > | GRPC Ledger data fetcher |
Cetl::LedgerFetcherInterface | An interface for LedgerFetcher |
Crpc::LedgerHandler | Retrieve information about the public ledger |
Crpc::LedgerIndexHandler | The ledger_index method fetches the lastest closed ledger before the given date |
Cetl::impl::LedgerLoader< LoadBalancerType, LedgerFetcherType > | Loads ledger data into the DB |
Cdata::LedgerObject | Represents an object in the ledger |
Cdata::LedgerPage | Represents a page of LedgerObjects |
Cetl::impl::LedgerPublisher< CacheType > | Publishes ledgers in a synchronized fashion |
Cetlng::LedgerPublisherInterface | The interface of a scheduler for the extraction proccess |
Cdata::LedgerRange | Stores a range of sequences as a min and max pair |
Crpc::LedgerRangeHandler | The ledger_range command returns the index number of the earliest and latest ledgers that the server has |
Cutil::impl::LedgerTypeAttribute | |
Cutil::LedgerTypes | A helper class that provides lists of different ledger type catagory |
Cdata::cassandra::Limit | A strong type wrapper for int32_t |
Crpc::AccountLinesHandler::LineResponse | A struct to hold data for one line response |
Cetlng::LoadBalancerInterface | An interface for LoadBalancer |
►Cetl::LoadBalancerTag | A tag class to help identify LoadBalancer in templated code |
►Cetlng::LoaderInterface | An interface for a ETL Loader |
Cutil::Lock< ProtectedDataType, LockType, MutexType > | A lock on a mutex that provides access to the protected data |
Cutil::Logger | A simple thread-safe logger for the channel specified in the constructor |
►Cstd::logic_error | |
Cutil::LogService | A global logging service |
►Cdata::cassandra::impl::ManagedObject< Managed > | |
►Cdata::cassandra::impl::ManagedObject< CassBatch > | |
►Cdata::cassandra::impl::ManagedObject< CassCluster > | |
►Cdata::cassandra::impl::ManagedObject< CassCollection > | |
►Cdata::cassandra::impl::ManagedObject< CassFuture > | |
►Cdata::cassandra::impl::ManagedObject< CassIterator > | |
Cdata::cassandra::impl::ManagedObject< CassPrepared const > | |
Cdata::cassandra::impl::ManagedObject< CassResult const > | |
►Cdata::cassandra::impl::ManagedObject< CassSession > | |
►Cdata::cassandra::impl::ManagedObject< CassSsl > | |
►Cdata::cassandra::impl::ManagedObject< CassStatement > | |
►Cdata::cassandra::impl::ManagedObject< CassTuple > | |
Crpc::AccountTxHandler::Marker | A struct to hold the marker data |
Crpc::NFTHistoryHandler::Marker | A struct to hold the marker data |
Crpc::validation::Max< Type > | Validate that value is not greater than max |
►Cutil::prometheus::MetricBase | Base class for a Prometheus metric containing a name and labels |
►Cutil::prometheus::MetricBuilderInterface | Interface to create a metric |
Cutil::prometheus::MetricsFamily | Class representing a collection of Prometheus metric with the same name and type |
Capp::MetricsHandler | A function object that handles the metrics endpoint |
Capp::CliArgs::Action::Migrate | Migration action |
Capp::MigrateSubCmd | The command to run for migration framework |
Capp::MigrateSubCmd::Migration | Run a migration |
►Cmigration::MigrationInspectorInterface | The interface for the migration inspector.The Clio server application will use this interface to inspect the migration status |
Capp::MigratorApplication | The migration application class |
Cmigration::impl::MigratorsRegister< Backend, MigratorType > | The register of migrators. It will dispatch the migration to the corresponding migrator. It also hold the shared pointer of backend, which is used by the migrators |
Cmigration::MigratorStatus | The status of a migrator, it provides the helper functions to convert the status to string and vice versa |
Crpc::validation::Min< Type > | Validate that value is equal or greater than the specified min |
►Cutil::MoveTracker | A base-class that can be used to check whether the current instance was moved from |
CMPTHolderData | Represents an MPT and holder pair |
Cdata::MPTHoldersAndCursor | Represents an array of MPTokens |
Crpc::MPTHoldersHandler | The mpt_holders command asks the Clio server for all holders of a particular MPTokenIssuance |
Cutil::Mutex< ProtectedDataType, MutexType > | A container for data that is protected by a mutex. Inspired by Mutex in Rust |
Cutil::Mutex< bool > | |
Cutil::Mutex< ConnectionsMap > | |
Cutil::Mutex< OneTimeCallable > | |
Cutil::Mutex< OptionalFuture > | |
Cutil::Mutex< SignalsMap > | |
Cutil::Mutex< State > | |
Cutil::Mutex< std::chrono::steady_clock::time_point > | |
Cutil::Mutex< ValidatedLedgersData > | |
►Cetl::NetworkValidatedLedgersInterface | An interface for NetworkValidatedLedgers |
Cdata::NFT | Represents a NFToken |
Crpc::NFTHistoryHandler | The nft_history command asks the Clio server for past transaction metadata for the NFT being queried |
Crpc::NFTInfoHandler | The nft_info command asks the Clio server for information about the NFT being queried |
►Crpc::NFTOffersHandlerBase | Contains common functionality for handling the nft_offers command |
Cdata::NFTsAndCursor | Represents a bundle of NFTs with a cursor to the next page |
Crpc::NFTsByIssuerHandler | Handler for the nfts_by_issuer command |
CNFTsData | Represents an NFT state at a particular ledger |
CNFTTransactionsData | Represents a link from a tx to an NFT that was targeted/modified/created by it |
Cutil::async::impl::NoErrorHandler | |
Crpc::NoRippleCheckHandler | Handles the noripple_check command |
Crpc::validation::NotSupported< T > | A validator that forbids a field to be present |
Crpc::validation::NotSupported< T > | A specialized NotSupported validator that forbids a field to be present when the value equals the given value |
Crpc::validation::NotSupported<> | A specialized NotSupported validator that forbids a field to be present |
Cutil::impl::NullTagGenerator | A null tag generator - does nothing |
Cutil::config::NullType | A type that represents a null value |
Cetlng::model::Object | Represents a single object on the ledger |
Cutil::config::ObjectView | Provides a view into a subset of configuration data defined by a prefix |
Crpc::AccountOffersHandler::Offer | A struct to hold data for one offer response |
Capp::OnConnectCheck | A function object that checks if the connection is allowed to proceed |
Crpc::validation::OneOf< Type > | Validates that the value is one of the values passed in |
Crpc::GetAggregatePriceHandler::Oracle | A struct to hold the input oracle data |
Crpc::SubscribeHandler::OrderBook | A struct to hold the data for one order book |
Crpc::UnsubscribeHandler::OrderBook | A struct to hold one order book |
Cutil::prometheus::OStream | A stream that can optionally compress its data |
Crpc::AccountChannelsHandler::Output | A struct to hold the output data of the command |
Crpc::AccountCurrenciesHandler::Output | A struct to hold the output data of the command |
Crpc::AccountInfoHandler::Output | A struct to hold the output data of the command |
Crpc::AccountLinesHandler::Output | A struct to hold the output data of the command |
Crpc::AccountNFTsHandler::Output | A struct to hold the output data of the command |
Crpc::AccountObjectsHandler::Output | A struct to hold the output data of the command |
Crpc::AccountOffersHandler::Output | A struct to hold the output data of the command |
Crpc::AccountTxHandler::Output | A struct to hold the output data of the command |
Crpc::AMMInfoHandler::Output | A struct to hold the output data of the command |
Crpc::BaseServerInfoHandler< LoadBalancerType, ETLServiceType, CountersType >::Output | A struct to hold the output data of the command |
Crpc::BaseTxHandler< ETLServiceType >::Output | A struct to hold the output data of the command |
Crpc::BookChangesHandler::Output | A struct to hold the output data of the command |
Crpc::BookOffersHandler::Output | A struct to hold the output data of the command |
Crpc::DepositAuthorizedHandler::Output | A struct to hold the output data of the command |
Crpc::FeatureHandler::Output | A struct to hold the output data of the command |
Crpc::GatewayBalancesHandler::Output | A struct to hold the output data of the command |
Crpc::GetAggregatePriceHandler::Output | A struct to hold the output data of the command |
Crpc::LedgerDataHandler::Output | A struct to hold the output data of the command |
Crpc::LedgerEntryHandler::Output | A struct to hold the output data of the command |
Crpc::LedgerHandler::Output | A struct to hold the output data of the command |
Crpc::LedgerIndexHandler::Output | A struct to hold the output data of the command |
Crpc::LedgerRangeHandler::Output | A struct to hold the output data of the command |
Crpc::MPTHoldersHandler::Output | A struct to hold the output data of the command |
Crpc::NFTHistoryHandler::Output | A struct to hold the output data of the command |
Crpc::NFTInfoHandler::Output | A struct to hold the output data of the command |
Crpc::NFTOffersHandlerBase::Output | A struct to hold the output data of the command |
Crpc::NFTsByIssuerHandler::Output | A struct to hold the output data of the command |
Crpc::NoRippleCheckHandler::Output | A struct to hold the output data of the command |
Crpc::RandomHandler::Output | A struct to hold the output data of the command |
Crpc::SubscribeHandler::Output | A struct to hold the output data of the command |
Crpc::TransactionEntryHandler::Output | A struct to hold the output data of the command |
Crpc::VersionHandler::Output | A struct to hold the output data of the command |
Crpc::PingHandler | The ping command returns an acknowledgement, so that clients can test the connection status and latency |
Cutil::requests::impl::PlainStreamData< StreamType > | |
Cutil::async::impl::PostDispatchStrategy | |
►Cutil::prometheus::PrometheusInterface | Interface for prometheus (https://prometheus.io/) |
CPrometheusService | Singleton class to access the PrometheusInterface |
Cfeed::impl::ProposedTransactionFeed | Feed that publishes the Proposed Transactions |
Cutil::Random | Random number generator |
Crpc::RandomHandler | The random command provides a random number to be used as a source of entropy for random number generation by clients |
►Cetlng::RegistryInterface | The interface for a registry that can dispatch transactions and objects to extensions |
Cutil::Repeat | A class to repeat some action at a regular interval |
Cweb::ng::Request | Represents an HTTP or WebSocket request |
Cutil::requests::RequestBuilder | Builder for HTTP requests |
Cutil::requests::RequestError | Error type for HTTP requests |
Capp::RequestHandler< RpcHandlerType > | A function object that handles the websocket endpoint |
Crpc::validation::Required | A validator that simply requires a field to be present |
Cweb::Resolver | Simple hostnames to IP addresses resolver |
Cweb::ng::Response | Represents an HTTP or Websocket response |
Cutil::ResponseExpirationCache | Cache of requests' responses with TTL support and configurable cachable commands |
Crpc::Result | Result type used to return responses or error statuses to the Webserver subsystem |
Cdata::cassandra::impl::ResultExtractor< Types > | |
Cutil::Retry | A retry mechanism |
►Cutil::RetryStrategy | Interface for retry strategies |
Crpc::ReturnType | The final return type out of RPC engine |
Crpc::RPCEngine< LoadBalancerType, CountersType > | The RPC engine that ties all RPC-related functionality together |
Cweb::ng::RPCServerHandler< RPCEngineType, ETLType > | The server handler for RPC requests called by web server |
Cweb::RPCServerHandler< RPCEngineType, ETLType > | The server handler for RPC requests called by web server |
Crpc::RpcSpec | Represents a Specification of an entire RPC command |
Capp::CliArgs::Action::Run | Run action |
Cutil::async::impl::SameThreadContext | |
►Cetlng::SchedulerInterface | The interface of a scheduler for the extraction proccess |
Cdata::cassandra::Schema< SettingsProviderType > | Manages the DB schema and provides access to prepared statements |
Crpc::meta::Section | A meta-processor that acts as a spec for a sub-object/section |
Cdata::cassandra::impl::Settings::SecureConnectionBundle | Represents the configuration of a secure connection bundle |
Cutil::async::impl::SelfContextProvider | |
Cdata::cassandra::impl::ResultExtractor< Types >::Sentinel | |
►Cweb::ng::ServerTag | A tag class for server to help identify Server in templated code |
Cdata::cassandra::impl::Settings | Bundles all cassandra settings in one place |
Cetlng::impl::TaskManager::Settings | |
Cdata::cassandra::SettingsProvider | Provides settings for BasicCassandraBackend |
Cutil::SignalsHandler | Class handling signals |
►Cfeed::impl::SingleFeedBase | Base class for single feed |
►Cetl::SourceBase | Provides an implementation of a ETL source |
Cutil::SourceLocation | A class representing the source location of the current code |
Cutil::async::impl::SpawnDispatchStrategy | |
Cetlng::model::Spec< Types > | A specification for the Registry |
Cutil::requests::impl::SslStreamData< StreamType > | |
Cutil::async::impl::BasicScheduledOperation< CtxType, OpType >::State | |
Cdata::cassandra::Schema< SettingsProviderType >::Statements | Prepared statements holder |
Crpc::GetAggregatePriceHandler::Stats | A struct to hold the statistics |
Capp::MigrateSubCmd::Status | Check the status of the migrations |
Crpc::Status | A status returned from any RPC handler |
Cutil::async::impl::SteadyTimer< ExecutorType > | |
Cutil::StopHelper | Helper class to stop a class asynchronously |
Capp::Stopper | Application stopper class. On stop it will create a new thread to run all the shutdown tasks |
Cutil::async::impl::StopState | |
Cutil::async::impl::SameThreadContext::Strand | |
Cutil::StrandedPriorityQueue< T, Compare > | A wrapper for std::priority_queue that serialises operations using a strand |
Cweb::ng::impl::ConnectionHandler::StringHash | |
Crpc::SubscribeHandler | Contains functionality for handling the subscribe command. The subscribe method requests periodic notifications from the server when certain events happen |
►Cfeed::SubscriptionManagerInterface | Interface of subscription manager. A subscription manager is responsible for managing the subscriptions and publishing the feeds |
Cetl::impl::SubscriptionSource | This class is used to subscribe to a source of ledger data and forward it to the subscription manager |
Cutil::async::impl::SyncDispatchStrategy | |
Cutil::async::impl::SystemContextProvider | |
Cutil::async::SystemExecutionContext | A execution context that runs tasks on a system thread pool of 1 thread |
Cetl::SystemState | Represents the state of the ETL subsystem |
Cmigration::cassandra::impl::TableObjectsDesc | The description of the objects table. It has to be a TableSpec |
Cmigration::cassandra::impl::TableTransactionsDesc | The description of the transactions table. It has to be a TableSpec |
Cutil::TagDecoratorFactory | A factory for TagDecorator instantiation |
►Cutil::Taggable | A base class that allows attaching a tag decorator to a subclass |
Cetlng::model::Task | Represents a task for the extractors |
Cetlng::impl::TaskManager | |
Cdata::cassandra::Text | A strong type wrapper for string |
Cetl::ThreadSafeQueue< T > | Generic thread-safe queue with a max capacity |
Cetl::ThreadSafeQueue< etl::impl::CursorPair > | |
Cetl::ThreadSafeQueue< migration::cassandra::impl::TokenRange > | |
Crpc::validation::TimeFormatValidator | Validate that value can be converted to time according to the given format |
Cutil::async::impl::SameThreadContext::Strand::Timer | |
Cutil::async::impl::SameThreadContext::Timer | |
Cutil::async::impl::BasicStopSource::Token | |
Cutil::async::impl::YieldContextStopSource::Token | |
Cutil::impl::Tokenizer< KeyType, Separator > | Simple string tokenizer. Used by Config |
Cmigration::cassandra::impl::TokenRange | The token range used to split the full table scan into multiple ranges |
Crpc::modifiers::ToLower | Convert input string to lower case |
Crpc::modifiers::ToNumber | Convert input string to integer |
Cfeed::impl::TrackableSignal< Session, Args > | A thread-safe class to manage a signal and its tracking connections |
Cfeed::impl::TrackableSignal< web::SubscriptionContextInterface, AllVersionTransactionsType const & > | |
Cfeed::impl::TrackableSignal< web::SubscriptionContextInterface, std::shared_ptr< std::string > > | |
Cfeed::impl::TrackableSignal< web::SubscriptionContextInterface, std::shared_ptr< std::string > const & > | |
Cfeed::impl::TrackableSignalMap< Key, Session, Args > | Class to manage a map of key and its associative signal |
Cfeed::impl::TrackableSignalMap< ripple::AccountID, web::SubscriptionContextInterface, AllVersionTransactionsType const & > | |
Cfeed::impl::TrackableSignalMap< ripple::AccountID, web::SubscriptionContextInterface, std::shared_ptr< std::string > > | |
Cfeed::impl::TrackableSignalMap< ripple::Book, web::SubscriptionContextInterface, AllVersionTransactionsType const & > | |
Cetlng::model::Transaction | Represents a single transaction on the ledger |
Cdata::TransactionAndMetadata | Represents a transaction and its metadata bundled together |
Crpc::TransactionEntryHandler | The transaction_entry method retrieves information on a single transaction from a specific ledger version |
Cfeed::impl::TransactionFeed | |
Cdata::TransactionsAndCursor | Represests a bundle of transactions with metadata and a cursor to the next page |
Cdata::TransactionsCursor | Represents a cursor into the transactions table |
Cetl::impl::Transformer< DataPipeType, LedgerLoaderType, LedgerPublisherType, AmendmentBlockHandlerType > | Transformer thread that prepares new ledger out of raw data from GRPC |
►CTs... | |
Crpc::validation::Type< Types > | Validates that the type of the value is one of the given types |
Cutil::impl::UIntTagGenerator | This strategy uses an atomic_uint64_t to remain lock free |
Crpc::UnsubscribeHandler | Handles the unsubscribe command which is used to disconnect a subscriber from a feed. The unsubscribe command tells the server to stop sending messages for a particular subscription or set of subscriptions |
Cutil::impl::UUIDTagGenerator | This strategy uses boost::uuids::uuid with a static random generator and a mutex |
Crpc::meta::ValidateArrayAt | A meta-processor that specifies a list of specs to run against the object at the given index in the array |
Crpc::BaseServerInfoHandler< LoadBalancerType, ETLServiceType, CountersType >::ValidatedLedgerSection | A struct to hold the validated ledger section of the output |
Cutil::config::ValueView | Provides view into ConfigValues that represents values in Clio Config |
Capp::CliArgs::Action::VerifyConfig | Verify Config action |
Crpc::VersionHandler | The version command returns the min,max and current api Version we are using |
Crpc::VoidOutput | An empty type used as Output for handlers than don't actually produce output |
Crpc::check::Warning | Warning that checks can return |
Crpc::WarningInfo | Holds information about a clio warning |
Cweb::dosguard::Whitelist | A whitelist to remove rate limits of certain IP addresses |
►Cweb::dosguard::WhitelistHandlerInterface | Interface for a whitelist handler |
Crpc::meta::WithCustomError< RequirementOrModifierType > | A meta-processor that wraps a validator and produces a custom error in case the wrapped validator fails |
Crpc::WorkQueue | An asynchronous, thread-safe queue for RPC requests |
►Cutil::requests::WsConnection | Interface for WebSocket connections. It is used to hide SSL and plain connections behind the same interface |
Cutil::requests::WsConnectionBuilder | Builder for WebSocket connections |
Cutil::async::impl::YieldContextStopSource |