|
Clio
develop
The XRP Ledger API server.
|
| Napp | |
| CCliArgs | Parsed command line arguments representation |
| CAction | An action parsed from the command line |
| CRun | Run action |
| CExit | Exit action |
| CMigrate | Migration action |
| CVerifyConfig | Verify Config action |
| CClioApplication | The main application class |
| CStopper | Application stopper class. On stop it will create a new thread to run all the shutdown tasks |
| COnConnectCheck | A function object that checks if the connection is allowed to proceed |
| CIpChangeHook | A function object that is called when the IP of a connection changes (usually if proxy detected). This is used to update the DOS guard |
| CDisconnectHook | A function object to be called when a connection is disconnected |
| CMetricsHandler | A function object that handles the metrics endpoint |
| CHealthCheckHandler | A function object that handles the health check endpoint |
| CCacheStateHandler | A function object that handles the cache state check endpoint |
| CRequestHandler | A function object that handles the websocket endpoint |
| CMigrateSubCmd | The command to run for migration framework |
| CStatus | Check the status of the migrations |
| CMigration | Run a migration |
| CMigratorApplication | The migration application class |
| Ncluster | |
| CClioNode | Represents a node in the cluster |
| CClusterCommunicationService | Service to post and read messages to/from the cluster. It uses a backend to communicate with the cluster |
| CClusterCommunicationServiceInterface | Interface for the cluster communication service |
| Ndata | This namespace implements the data access layer and related components |
| Nimpl | |
| CWritingAmendmentKey | |
| Ncassandra | This namespace implements a wrapper for the Cassandra C++ driver |
| Nimpl | |
| CAsyncExecutor | A query executor with a changeable retry policy |
| CBatch | |
| CSettings | Bundles all cassandra settings in one place |
| CContactPoints | Represents the configuration of contact points for cassandra |
| CSecureConnectionBundle | Represents the configuration of a secure connection bundle |
| CCluster | |
| CCollection | |
| CDefaultExecutionStrategy | Implements async and sync querying against the cassandra DB with support for throttling |
| CFuture | |
| CFutureWithCallback | |
| CManagedObject | |
| CResult | |
| CResultIterator | |
| CResultExtractor | |
| CSentinel | |
| CIterator | |
| CExponentialBackoffRetryPolicy | A retry policy that employs exponential backoff |
| CSession | |
| CSslContext | |
| CStatement | |
| CPreparedStatement | Represents a prepared statement on the DB side |
| CTuple | |
| CTupleIterator | |
| CCassandraBackendFamily | Implements BackendInterface for Cassandra/ScyllaDB/Keyspace |
| CCassandraSchema | Manages the DB schema and provides access to prepared statements |
| CCassandraStatements | Construct a new Cassandra Schema object |
| CCassandraError | A simple container for both error message and error code |
| CHandle | Represents a handle to the cassandra database cluster |
| CKeyspaceSchema | Manages the DB schema and provides access to prepared statements |
| CKeyspaceStatements | Construct a new Keyspace Schema object |
| CSchema | Manages the DB schema and provides access to prepared statements |
| CStatements | Prepared statements holder |
| CSettingsProvider | Provides settings for BasicCassandraBackend |
| CLimit | A strong type wrapper for int32_t |
| CText | A strong type wrapper for string |
| CBasicCassandraBackend | Implements CassandraBackendFamily for Cassandra/ScyllaDB |
| CBasicKeyspaceBackend | Implements CassandraBackendFamily for Keyspace |
| CAmendments | List of supported amendments |
| CAmendmentCenter | Knowledge center for amendments within XRPL |
| CAmendmentCenterInterface | The interface of an amendment center |
| CBackendCounters | Holds statistics about the backend |
| CDatabaseTimeout | Represents a database timeout error |
| CBackendInterface | The interface to the database used by Clio |
| CLedgerCache | Cache for an entire ledger |
| CLedgerCacheInterface | Cache for an entire ledger |
| CFetchLedgerCache | A simple cache holding one ripple::LedgerHeader to reduce DB lookups |
| CCacheEntry | Struct to store ledger header cache entry and the sequence it belongs to |
| CLedgerObject | Represents an object in the ledger |
| CLedgerPage | Represents a page of LedgerObjects |
| CBookOffersPage | Represents a page of book offer objects |
| CTransactionAndMetadata | Represents a transaction and its metadata bundled together |
| CTransactionsCursor | Represents a cursor into the transactions table |
| CTransactionsAndCursor | Represests a bundle of transactions with metadata and a cursor to the next page |
| CNFT | Represents a NFToken |
| CNFTsAndCursor | Represents a bundle of NFTs with a cursor to the next page |
| CMPTHoldersAndCursor | Represents an array of MPTokens |
| CLedgerRange | Stores a range of sequences as a min and max pair |
| CAmendment | Represents an amendment in the XRPL |
| CAmendmentKey | A helper for amendment name to feature conversions |
| Netl | |
| Nimpl | |
| CAmendmentBlockHandler | |
| CAsyncGrpcCall | |
| CCursorPair | |
| CBaseCursorProvider | |
| CCacheLoaderImpl | |
| CCacheUpdater | |
| CCursorFromAccountProvider | |
| CCursorFromDiffProvider | |
| CCursorFromFixDiffNumProvider | |
| CCacheExt | |
| CCoreExt | |
| CMPTExt | |
| CNFTExt | |
| CSuccessorExt | |
| CExtractor | |
| CForwardingSource | |
| CGrpcSource | |
| CLedgerFetcher | GRPC Ledger data fetcher |
| CLedgerPublisher | Publishes ledgers in a synchronized fashion |
| CLoader | |
| CMonitor | |
| CMonitorProvider | |
| CRegistry | |
| CForwardScheduler | |
| CBackfillScheduler | |
| CSchedulerChain | |
| CSourceImpl | Provides an implementation of a ETL source |
| CSubscriptionSource | This class is used to subscribe to a source of ledger data and forward it to the subscription manager |
| CTaskManager | |
| CTaskManagerProvider | Implementation of the TaskManagerProvider interface |
| CReverseOrderComparator | |
| CTaskQueue | A wrapper for std::priority_queue that serialises operations using a mutex |
| CSettings | |
| Nmodel | |
| CSpec | A specification for the Registry |
| CTransaction | Represents a single transaction on the ledger |
| CObject | Represents a single object on the ledger |
| CBookSuccessor | Represents a book successor |
| CLedgerData | Represents an entire ledger diff worth of transactions and objects |
| CTask | Represents a task for the extractors |
| CAmendmentBlockHandlerInterface | The interface of a handler for amendment blocking |
| CCacheLoader | Cache loading interface |
| CCacheLoaderInterface | An interface for the Cache Loader |
| CCacheLoaderSettings | Settings for the cache loader |
| CCacheUpdaterInterface | An interface for the Cache Updater |
| CCorruptionDetector | A helper to notify Clio operator about a corruption in the DB |
| CThreadSafeQueue | Generic thread-safe queue with a max capacity |
| CETLService | This class is responsible for continuously extracting data from a p2p node, and writing that data to the databases |
| CETLServiceInterface | This is a base class for any ETL service implementations |
| CETLState | This class is responsible for fetching and storing the state of the ETL information, such as the network id |
| CExtractorInterface | An interface for the Extractor |
| CInitialLoadObserverInterface | The interface for observing the initial ledger load |
| CLedgerFetcherInterface | An interface for LedgerFetcher |
| CLedgerPublisherInterface | The interface of a scheduler for the extraction process |
| CLoadBalancerTag | A tag class to help identify LoadBalancer in templated code |
| CLoadBalancer | This class is used to manage connections to transaction processing processes |
| CLoadBalancerInterface | An interface for LoadBalancer |
| CLoaderInterface | An interface for a ETL Loader |
| CMonitorInterface | An interface for the monitor service An implementation of this service is responsible for periodically checking various datasources to detect newly ingested ledgers |
| CMonitorProviderInterface | An interface for providing Monitor instances |
| CNetworkValidatedLedgers | This datastructure is used to keep track of the sequence of the most recent ledger validated by the network |
| CNetworkValidatedLedgersInterface | An interface for NetworkValidatedLedgers |
| CRegistryInterface | The interface for a registry that can dispatch transactions and objects to extensions |
| CSchedulerInterface | The interface of a scheduler for the extraction process |
| CSourceBase | Provides an implementation of a ETL source |
| CSystemState | Represents the state of the ETL subsystem |
| CTaskManagerInterface | An interface for the Task Manager |
| CTaskManagerProviderInterface | An interface for providing the Task Manager |
| Nfeed | This namespace implements everything related to subscriptions |
| Nimpl | |
| CBookChangesFeed | Feed that publishes book changes. This feed will be published every ledger, even if there are no changes. Example : {'type': 'bookChanges', 'ledger_index': 2647936, 'ledger_hash': '0A5010342D8AAFABDCA58A68F6F588E1C6E58C21B63ED6CA8DB2478F58F3ECD5', 'ledger_time': 756395682, 'changes': []} |
| CForwardFeed | Feed that publishes the json object as it is |
| CLedgerFeed | Feed that publishes the ledger info. Example : {'type': 'ledgerClosed', 'ledger_index': 2647935, 'ledger_hash': '5D022718CD782A82EE10D2147FD90B5F42F26A7E937C870B4FE3CF1086C916AE', 'ledger_time': 756395681, 'fee_base': 10, 'reserve_base': 10000000, 'reserve_inc': 2000000, 'validated_ledgers': '2619127-2647935', 'txn_count': 0, 'network_id': 1} |
| CProposedTransactionFeed | Feed that publishes the Proposed Transactions |
| CSingleFeedBase | Base class for single feed |
| CTrackableSignal | A thread-safe class to manage a signal and its tracking connections |
| CTrackableSignalMap | Class to manage a map of key and its associative signal |
| CTransactionFeed | |
| CSubscriptionManager | A subscription manager is responsible for managing the subscriptions and publishing the feeds |
| CSubscriptionManagerInterface | Interface of subscription manager. A subscription manager is responsible for managing the subscriptions and publishing the feeds |
| Nmigration | |
| Ncassandra | |
| Nimpl | |
| CCassandraMigrationSchema | The schema for the migration process. It contains the prepared statements only used for the migration process |
| CTokenRange | The token range used to split the full table scan into multiple ranges |
| CFullTableScanner | The full table scanner. It will split the full table scan into multiple ranges and read the data in given executor |
| CFullTableScannerSettings | The full table scanner settings |
| CFullTableScannerAdapterBase | 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 |
| CTableObjectsDesc | The description of the objects table. It has to be a TableSpec |
| CObjectsAdapter | The adapter for the objects table. This class is responsible for reading the objects from the FullTableScanner and converting the blobs to the STObject |
| CTableTransactionsDesc | The description of the transactions table. It has to be a TableSpec |
| CTransactionsAdapter | The adapter for the transactions table. This class is responsible for reading the transactions from the FullTableScanner and converting the blobs to the STTx and TxMeta |
| CCassandraMigrationBackend | The backend for the migration. It is a subclass of the CassandraBackend and provides the migration specific functionalities |
| Nimpl | |
| CMigrationInspectorBase | The migration inspector implementation for Cassandra. It will report the migration status for Cassandra database |
| CMigrationManagerBase | The migration manager implementation for Cassandra. It will run the migration for the Cassandra database |
| CMigratorsRegister | 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 |
| CMigrationInspectorInterface | The interface for the migration inspector.The Clio server application will use this interface to inspect the migration status |
| CMigrationManagerInterface | The interface for the migration manager. The migration application layer will use this interface to run the migrations. Unlike the MigrationInspectorInterface which only provides the status of migration, this interface contains the actual migration running method |
| CMigratorStatus | The status of a migrator, it provides the helper functions to convert the status to string and vice versa |
| Nrpc | This namespace contains all the RPC logic and handlers |
| Ncheck | |
| CWarning | Warning that checks can return |
| CDeprecated | Check for a deprecated fields |
| CDeprecated<> | Check if a field is deprecated |
| CDeprecated< T > | Check if a value of a field is deprecated |
| Nimpl | |
| CProductionAPIVersionParser | |
| CForwardingProxy | |
| CProductionHandlerProvider | |
| CDefaultProcessor | |
| Nmeta | |
| CSection | A meta-processor that acts as a spec for a sub-object/section |
| CValidateArrayAt | A meta-processor that specifies a list of specs to run against the object at the given index in the array |
| CIfType | A meta-processor that specifies a list of requirements to run against when the type matches the template parameter |
| CWithCustomError | A meta-processor that wraps a validator and produces a custom error in case the wrapped validator fails |
| Nmodifiers | |
| CClamp | Clamp value between min and max |
| CToLower | Convert input string to lower case |
| CToNumber | Convert input string to integer |
| CCustomModifier | Customised modifier allowing user define how to modify input in provided callable |
| Nvalidation | |
| CRequired | A validator that simply requires a field to be present |
| CNotSupported | A validator that forbids a field to be present |
| CNotSupported< T > | A specialized NotSupported validator that forbids a field to be present when the value equals the given value |
| CNotSupported<> | A specialized NotSupported validator that forbids a field to be present |
| CType | Validates that the type of the value is one of the given types |
| CBetween | Validate that value is between specified min and max |
| CMin | Validate that value is equal or greater than the specified min |
| CMax | Validate that value is not greater than max |
| CTimeFormatValidator | Validate that value can be converted to time according to the given format |
| CEqualTo | Validates that the value is equal to the one passed in |
| COneOf | Validates that the value is one of the values passed in |
| CCustomValidator | A meta-validator that allows to specify a custom validation function |
| CCustomValidators | A group of custom validation functions |
| CHex256ItemType | Validates that the elements of the array is of type Hex256 uint |
| CBookChange | Represents an entry in the book_changes' changes array |
| CBookChanges | Encapsulates the book_changes computations and transformations |
| CAnyHandler | A type-erased Handler that can contain any (NextGen) RPC handler class |
| CAPIVersionParser | A baseclass for API version helper |
| CHandlerProvider | Interface for the provider of RPC handlers |
| CJsonBool | A wrapper around bool that allows to convert from any JSON value |
| CFieldSpec | Represents a Specification for one field of an RPC command |
| CRpcSpec | Represents a Specification of an entire RPC command |
| CReturnType | The final return type out of RPC engine |
| CVoidOutput | An empty type used as Output for handlers than don't actually produce output |
| CContext | Context of an RPC call |
| CResult | Result type used to return responses or error statuses to the Webserver subsystem |
| CAccountCursor | A cursor object used to traverse nodes owned by an account |
| CCounters | Holds information about successful, failed, forwarded, etc. RPC handler calls |
| CClioErrorInfo | Holds info about a particular ClioError |
| CStatus | A status returned from any RPC handler |
| CWarningInfo | Holds information about a clio warning |
| CInvalidParamsError | Invalid parameters error |
| CAccountNotFoundError | Account not found error |
| CAccountChannelsHandler | 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 |
| CChannelResponse | A struct to hold data for one channel response |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountCurrenciesHandler | The account_currencies command retrieves a list of currencies that an account can send or receive, based on its trust lines |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountInfoHandler | The account_info command retrieves information about an account, its activity, and its XRP balance |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountLinesHandler | The account_lines method returns information about an account's trust lines, which contain balances in all non-XRP currencies and assets |
| CLineResponse | A struct to hold data for one line response |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountMPTokenIssuancesHandler | The account_mptoken_issuances method returns information about all MPTokenIssuance objects the account has created |
| CMPTokenIssuanceResponse | A struct to hold data for one MPTokenIssuance response |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountMPTokensHandler | The account_mptokens method returns information about the MPTokens the account currently holds |
| CMPTokenResponse | A struct to hold data for one MPToken response |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountNFTsHandler | The account_nfts method returns a list of NFToken objects for the specified account |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountObjectsHandler | 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 |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountOffersHandler | The account_offers method retrieves a list of offers made by a given account |
| COffer | A struct to hold data for one offer response |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAccountTxHandler | The account_tx method retrieves a list of transactions that involved the specified account |
| CMarker | A struct to hold the marker data |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CAMMInfoHandler | AMMInfoHandler returns information about AMM pools |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CBookChangesHandler | BookChangesHandler returns the order book changes for a given ledger |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CBookOffersHandler | The book_offers method retrieves a list of Offers between two currencies, also known as an order book |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CDepositAuthorizedHandler | Handles the deposit_authorized command |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CFeatureHandler | Contains common functionality for handling the server_info command |
| CInput | A struct to hold the input data for the command |
| COutput | A struct to hold the output data of the command |
| CFeature | Represents an amendment/feature |
| CGatewayBalancesHandler | Handles the gateway_balances command |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CGetAggregatePriceHandler | The get_aggregate_price method |
| CStats | A struct to hold the statistics |
| COutput | A struct to hold the output data of the command |
| COracle | A struct to hold the input oracle data |
| CInput | A struct to hold the input data for the command |
| CLedgerHandler | Retrieve information about the public ledger |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CLedgerDataHandler | 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 |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CLedgerEntryHandler | The ledger_entry method returns a single ledger object from the XRP Ledger in its raw format |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CLedgerIndexHandler | The ledger_index method fetches the latest closed ledger before the given date |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CLedgerRangeHandler | The ledger_range command returns the index number of the earliest and latest ledgers that the server has |
| COutput | A struct to hold the output data of the command |
| CMPTHoldersHandler | The mpt_holders command asks the Clio server for all holders of a particular MPTokenIssuance |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CNFTBuyOffersHandler | The nft_buy_offers method returns a list of buy offers for a given NFToken object |
| CNFTHistoryHandler | The nft_history command asks the Clio server for past transaction metadata for the NFT being queried |
| CMarker | A struct to hold the marker data |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CNFTInfoHandler | The nft_info command asks the Clio server for information about the NFT being queried |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CNFTOffersHandlerBase | Contains common functionality for handling the nft_offers command |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CNFTsByIssuerHandler | Handler for the nfts_by_issuer command |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CNFTSellOffersHandler | The nft_sell_offers method returns a list of sell offers for a given NFToken object |
| CNoRippleCheckHandler | Handles the noripple_check command |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CPingHandler | The ping command returns an acknowledgement, so that clients can test the connection status and latency |
| CRandomHandler | The random command provides a random number to be used as a source of entropy for random number generation by clients |
| COutput | A struct to hold the output data of the command |
| CBaseServerInfoHandler | Contains common functionality for handling the server_info command |
| CInput | A struct to hold the input data for the command |
| CAdminSection | A struct to hold the admin section of the output |
| CValidatedLedgerSection | A struct to hold the validated ledger section of the output |
| CCacheSection | A struct to hold the cache section of the output |
| CInfoSection | A struct to hold the info section of the output |
| COutput | A struct to hold the output data of the command |
| CSubscribeHandler | Contains functionality for handling the subscribe command. The subscribe method requests periodic notifications from the server when certain events happen |
| COutput | A struct to hold the output data of the command |
| COrderBook | A struct to hold the data for one order book |
| CInput | A struct to hold the input data for the command |
| CTransactionEntryHandler | The transaction_entry method retrieves information on a single transaction from a specific ledger version |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CTxHandler | The tx method retrieves information on a single transaction, by its identifying hash |
| COutput | A struct to hold the output data of the command |
| CInput | A struct to hold the input data for the command |
| CUnsubscribeHandler | 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 |
| COrderBook | A struct to hold one order book |
| CInput | A struct to hold the input data for the command |
| CVaultInfoHandler | The vault_info command retrieves information about a vault, currency, shares etc |
| CInput | A struct to hold the input data for the command |
| COutput | A struct to hold the output data for the command |
| CVersionHandler | The version command returns the min,max and current api Version we are using |
| COutput | A struct to hold the output data of the command |
| CRPCCenter | Registry of RPC commands supported by Clio |
| CRPCEngine | The RPC engine that ties all RPC-related functionality together |
| CReportable | An interface for any class providing a report as json object |
| CWorkQueue | An asynchronous, thread-safe queue for RPC requests |
| CDontStartProcessingTag | |
| CLabel | Class representing a Prometheus label |
| CLabels | Class representing a collection of Prometheus labels |
| Nutil | This namespace contains various utilities |
| Nimpl | |
| COnAssert | |
| CLedgerTypeAttribute | |
| CPropagatingCompletionHandler | A completion handler that restores boost::asio::spawn's behaviour from Boost 1.83 |
| CNullTagGenerator | A null tag generator - does nothing |
| CUIntTagGenerator | This strategy uses an atomic_uint64_t to remain lock free |
| CUUIDTagGenerator | This strategy uses boost::uuids::uuid with a static random generator and a mutex |
| Nasync | This namespace implements an async framework built on top of execution contexts |
| Nimpl | |
| CAsioPoolStrandContext | |
| CAsioPoolContext | |
| CStopState | |
| CYieldContextStopSource | |
| CToken | |
| CBasicStopSource | |
| CToken | |
| CSpawnDispatchStrategy | |
| CPostDispatchStrategy | |
| CSyncDispatchStrategy | |
| CBasicStrand | |
| CSteadyTimer | |
| CAssociatedExecutorExtractor | |
| CSelfContextProvider | |
| CSameThreadContext | |
| CExecutor | |
| CTimer | |
| CStrand | |
| CExecutor | |
| CTimer | |
| CSystemContextProvider | |
| CErasedOperation | |
| CDefaultErrorHandler | |
| CNoErrorHandler | |
| CBasicOperation | |
| CBasicScheduledOperation | |
| CState | |
| CBasicOutcome | Base for all promise side of async operations |
| CAnyExecutionContext | A type-erased execution context |
| CAnyOperation | A type-erased operation that can be executed via AnyExecutionContext |
| CAnyStopToken | A type-erased stop token |
| CAnyStrand | A type-erased execution context |
| CBasicExecutionContext | A highly configurable execution context |
| CSystemExecutionContext | A execution context that runs tasks on a system thread pool of 1 thread |
| CExecutionError | Error channel type for async operation of any ExecutionContext |
| CStoppableOperation | The future side of async operations that can be stopped |
| CRepeatingOperation | The future side of async operations that automatically repeat until aborted |
| COutcome | Unstoppable outcome |
| CStoppableOutcome | Stoppable outcome |
| Nconfig | |
| CArray | Array definition to store multiple values provided by the user from Json/Yaml |
| CArrayView | View for array structure for config |
| CArrayIterator | Custom iterator class which contains config object or value underneath ArrayView |
| CConstraint | An interface to enforce constraints on certain values within ClioConfigDefinition |
| CPortConstraint | A constraint to ensure the port number is within a valid range |
| CValidIPConstraint | A constraint to ensure the IP address is valid |
| COneOf | A constraint class to ensure the provided value is one of the specified values in an array |
| CNumberValueConstraint | A constraint class to ensure an integer value is between two numbers (inclusive) |
| CPositiveDouble | A constraint to ensure a double number is positive |
| CRpcNameConstraint | A constraint to ensure the value is a valid RPC command name |
| CClioConfigDefinition | All the config data will be stored and extracted from this class |
| CClioConfigDescription | All the config description are stored and extracted from this class |
| CKV | Struct to represent a key-value pair |
| CConfigFileInterface | The interface for configuration files |
| CConfigFileJson | Json representation of config |
| CConfigValue | Represents the config values for Json/Yaml config |
| CError | Displays the different errors when parsing user config |
| CObjectView | Provides a view into a subset of configuration data defined by a prefix |
| CValueView | Provides view into ConfigValues that represents values in Clio Config |
| Nprometheus | |
| Nimpl | |
| CAnyCounterBase | |
| CConcept | |
| CModel | |
| CCounterImpl | |
| CHistogramImpl | |
| CAnyBool | A wrapped to provide bool interface for a Prometheus metric |
| CAnyCounter | A prometheus counter metric implementation. It can only be increased or be reset to zero |
| CAnyGauge | A prometheus gauge metric implementation. It can be increased, decreased or set to a value |
| CAnyHistogram | A Prometheus histogram metric with a generic value type |
| CLabel | Class representing a Prometheus label |
| CLabels | Class representing a collection of Prometheus labels |
| CMetricBase | Base class for a Prometheus metric containing a name and labels |
| CMetricBuilderInterface | Interface to create a metric |
| CMetricBuilder | Implementation for building a metric |
| CMetricsFamily | Class representing a collection of Prometheus metric with the same name and type |
| COStream | A stream that can optionally compress its data |
| CPrometheusInterface | Interface for prometheus (https://prometheus.io/) |
| CPrometheusImpl | Implementation of PrometheusInterface |
| Nrequests | |
| Nimpl | |
| CPlainStreamData | |
| CSslStreamData | |
| CWsConnectionImpl | |
| CRequestBuilder | Builder for HTTP requests |
| CRequestError | Error type for HTTP requests |
| CHttpHeader | HTTP header |
| CWsConnection | Interface for WebSocket connections. It is used to hide SSL and plain connections behind the same interface |
| CWsConnectionBuilder | Builder for WebSocket connections |
| CAtomic | Atomic wrapper for integral and floating point types |
| CBlockingCache | A thread-safe cache that blocks getting operations until the cache is updated |
| CCoroutine | Manages a coroutine execution context, allowing for cooperative multitasking and cancellation |
| CCoroutineGroup | 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 |
| CLedgerTypes | A helper class that provides lists of different ledger type category |
| CLogger | A simple thread-safe logger for the channel specified in the constructor |
| CLogServiceState | Base state management class for the logging service |
| CLogService | A global logging service |
| CMoveTracker | A base-class that can be used to check whether the current instance was moved from |
| CMutex | A container for data that is protected by a mutex. Inspired by Mutex in Rust |
| CLock | A lock on a mutex that provides access to the protected data |
| COverloadSet | Overload set for lambdas |
| CRandomGeneratorInterface | Random number generator interface |
| CMTRandomGenerator | Mersenne Twister random number generator |
| CRepeat | A class to repeat some action at a regular interval |
| CResponseExpirationCache | Cache of requests' responses with TTL support and configurable cacheable commands |
| CRetryStrategy | Interface for retry strategies |
| CRetry | A retry mechanism |
| CExponentialBackoffStrategy | A retry strategy that retries while exponentially increasing the delay between attempts |
| CScopeGuard | Run a function when the scope is exited |
| CSignalsHandler | Class handling signals |
| CSourceLocation | A class representing the source location of the current code |
| CStopHelper | Helper class to stop a class asynchronously |
| CStringHash | A string hash functor that provides transparent hash operations for various string types |
| CBaseTagDecorator | Represents any tag decorator |
| CTagDecorator | A decorator that decorates a string (log line) with a unique tag |
| CTagDecorator< impl::NullTagGenerator > | Specialization for a nop/null decorator |
| CTagDecoratorFactory | A factory for TagDecorator instantiation |
| CTaggable | A base class that allows attaching a tag decorator to a subclass |
| Nweb | This namespace implements the web server and related components |
| Ndosguard | |
| CDOSGuard | A simple denial of service guard used for rate limiting |
| CBaseDOSGuard | The interface of a denial of service guard |
| CDOSGuardInterface | The interface of a denial of service guard |
| CIntervalSweepHandler | Sweep handler clearing context every sweep interval from config |
| CWeights | Implementation of WeightsInterface that manages command weights for DosGuard |
| CEntry | Structure representing weight configuration for a command |
| CWeightsInterface | Interface for determining request weights in DOS protection |
| CWhitelist | A whitelist to remove rate limits of certain IP addresses |
| CWhitelistHandler | A simple handler to add/check elements in a whitelist |
| CWhitelistHandlerInterface | Interface for a whitelist handler |
| Nimpl | |
| CErrorHelper | A helper that attempts to match rippled reporting mode HTTP errors as close as possible |
| CHttpBase | This is the implementation class for http sessions |
| CWsBase | Web socket implementation. This class is the base class of the web socket session, it will handle the read and write operations |
| Nng | |
| Nimpl | |
| CConnectionHandler | |
| CErrorHelper | A helper that attempts to match rippled reporting mode HTTP errors as close as possible |
| CUpgradableConnection | |
| CHttpConnection | |
| CSendingQueue | |
| CWsConnectionBase | |
| CWsConnection | |
| CConnectionMetadata | An interface for a connection metadata class |
| CConnection | A class representing a connection to a client |
| CRequest | Represents an HTTP or WebSocket request |
| CResponse | Represents an HTTP or Websocket response |
| CRPCServerHandler | The server handler for RPC requests called by web server |
| CServerTag | A tag class for server to help identify Server in templated code |
| CServer | Web server class |
| CHooks | A struct that holds all the hooks for the server |
| CSubscriptionContext | Implementation of SubscriptionContextInterface |
| CAdminVerificationStrategy | Interface for admin verification strategies |
| CIPAdminVerificationStrategy | Admin verification strategy that checks the ip address of the client |
| CPasswordAdminVerificationStrategy | Admin verification strategy that checks the password from the request header |
| CContext | Context that is used by the Webserver to pass around information about an incoming request |
| CHttpSession | Represents a HTTP connection established by a client |
| CConnectionBase | Base class for all connections |
| CPlainWsSession | Represents a non-secure websocket session |
| CWsUpgrader | The websocket upgrader class, upgrade from an HTTP session to a non-secure websocket session |
| CProxyIpResolver | Resolves the client's IP address, considering proxy servers |
| CResolver | Simple hostnames to IP addresses resolver |
| CRPCServerHandler | The server handler for RPC requests called by web server |
| CDetector | The Detector class to detect if the connection is a ssl or not |
| CServer | The WebServer class. It creates server socket and start listening on it |
| CSslHttpSession | Represents a HTTPS connection established by a client |
| CSslWsSession | Represents a secure websocket session |
| CSslWsUpgrader | The HTTPS upgrader class, upgrade from an HTTPS session to a secure websocket session |
| CSubscriptionContext | A context of a WsBase connection for subscriptions |
| CSubscriptionContextInterface | An interface to provide connection functionality for subscriptions |
| CAccountTransactionsData | Struct used to keep track of what to write to account_transactions/account_tx tables |
| CLabels | Class representing a collection of Prometheus labels |
| CMPTHolderData | Represents an MPT and holder pair |
| 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 |
| CPrometheusService | Singleton class to access the PrometheusInterface |