| Ccbdc::atomizer::aggregate_tx_notification | Transaction notification message with a full set of input attestations |
| Ccbdc::atomizer::aggregate_tx_notify_request | Batch of aggregate transaction notifications |
| Ccbdc::locking_shard::rpc::apply_response | Empty type for the apply response |
| Ccbdc::watchtower::async_client | Client to asynchronously request information from the watchtower |
| ►Ccbdc::sentinel::async_interface | Interface for an asynchronous sentinel |
| Ccbdc::sentinel::rpc::client | TCP RPC client for sentinels |
| Ccbdc::sentinel_2pc::controller | Manages a sentinel server for the two-phase commit architecture |
| Ccbdc::sentinel::rpc::async_server | Asynchronous RPC server for a sentinel |
| Ccbdc::atomizer::atomizer | Atomizer implementation |
| Ccbdc::watchtower::best_block_height_request | Request the watchtower's known best block height |
| Ccbdc::watchtower::best_block_height_response | Contains the watchtower's known best block height |
| Ccbdc::atomizer::block | Batch of compact transactions settled by the atomizer |
| Ccbdc::watchtower::block_cache | Stores a set of blocks in memory and maintains an index of the UHS IDs contained therein |
| Ccbdc::watchtower::blocking_client | Client to synchronously request information from the watchtower |
| Ccbdc::blocking_queue_internal< T, Q > | Thread-safe producer-consumer FIFO queue supporting multiple concurrent producers and consumers |
| Ccbdc::blocking_queue_internal< cbdc::atomizer::tx_notify_request > | |
| Ccbdc::blocking_queue_internal< cbdc::network::message_t > | |
| Ccbdc::blocking_queue_internal< request_type > | |
| Ccbdc::blocking_queue_internal< size_t > | |
| Ccbdc::blocking_queue_internal< size_t, std::greater<> > | |
| Ccbdc::blocking_queue_internal< std::function< void()> > | |
| Ccbdc::blocking_queue_internal< std::shared_ptr< cbdc::buffer > > | |
| Ccbdc::blocking_queue_internal< std::shared_ptr< cbdc::watchtower::response > > | |
| Ccbdc::buffer | Buffer to store and retrieve byte data |
| Ccbdc::cache_set< K, H > | Thread-safe set with a maximum size |
| Ccbdc::cache_set< hash_t, cbdc::hashing::null > | |
| Ccbdc::archiver::client | Retrieves blocks from a remote archiver via the network |
| ►Ccbdc::client | External client for sending new transactions to the system |
| Ccbdc::atomizer_client | Client for interacting with the atomizer architecture |
| Ccbdc::twophase_client | Client for interacting with the 2PC architecture |
| Ccbdc::parsec::agent::rpc::client | RPC client for an agent |
| ►Ccbdc::rpc::client< Request, Response > | Generic RPC client |
| Ccbdc::rpc::tcp_client< Request, Response > | Implements an RPC client over TCP sockets |
| ►Ccbdc::rpc::client< request, response > | |
| Ccbdc::rpc::tcp_client< request, response > | |
| Ccbdc::parsec::agent::runner::code_key | |
| Ccbdc::parsec::runtime_locking_shard::rpc::commit_request | Commit request message |
| Ccbdc::transaction::compact_tx | A condensed, hash-only transaction representation |
| Ccbdc::transaction::compact_tx_hasher | |
| ►Cleveldb::Comparator | |
| Ccbdc::raft::index_comparator | LevelDB comparator for ordering NuRaft log indices |
| Ccbdc::parsec::config | Configuration parameters for a phase two system |
| Ccbdc::network::connection_manager | Manages a group of peer s |
| Ccbdc::hashing::const_sip_hash< T > | SipHash function to generate STL data structure hash keys for system IDs |
| Ccbdc::hashing::const_sip_hash< buffer > | |
| Ccbdc::hashing::const_sip_hash< cbdc::buffer > | |
| Ccbdc::archiver::controller | Wrapper for the archiver executable implementation |
| Ccbdc::atomizer::controller | Wrapper for the atomizer raft executable implementation |
| Ccbdc::locking_shard::controller | Manages a replicated locking shard using Raft |
| Ccbdc::parsec::runtime_locking_shard::controller | Manages a replicated runtime locking shard using Raft |
| Ccbdc::parsec::ticket_machine::controller | Manages a replicated ticket machine using Raft |
| Ccbdc::shard::controller | Wrapper for the shard executable implementation |
| Ccbdc::watchtower::controller | Wrapper for the watchtower executable implementation |
| Ccbdc::coordinator::controller::coordinator_state | Current state of distributed transactions managed by a coordinator |
| Ccbdc::coordinator::state_machine::coordinator_state | Used to store dtxs, which phase they are in and relevant data require for recovery |
| Ccbdc::rpc::curl_initializer | Class for performing libcurl global initialization |
| Ccbdc::locking_shard::rpc::discard_params | Empty type for discard command parameters |
| Ccbdc::locking_shard::rpc::discard_response | Empty type for the discard response |
| Ccbdc::coordinator::distributed_tx | Class to manage a single distributed transaction (dtx) batch between shards |
| Ccbdc::watchtower::error_cache | Stores a set of internal transaction errors in memory, indexed by Tx ID and UHS ID |
| ►Ccbdc::rpc::event_handler | Event handler interface for tracking events on non-blocking file descriptors |
| Ccbdc::rpc::epoll_event_handler | Event handler implementation using Linux epoll |
| Ccbdc::rpc::kqueue_event_handler | Event handler implementation using BSD kqueue |
| Ccbdc::parsec::agent::runner::evm_access_tuple | Type for tracking storage key accesses between accounts |
| Ccbdc::parsec::agent::runner::evm_account | EVM account type |
| Ccbdc::parsec::agent::runner::evm_dryrun_tx | Dry-run EVM transaction type |
| Ccbdc::parsec::agent::runner::evm_log | EVM log output type |
| Ccbdc::parsec::agent::runner::evm_log_index | Index data for evm logs |
| Ccbdc::parsec::agent::runner::evm_log_query | Describes the parameters of a query on EVM logs - used to transfer these parameters from the getLogs API method to the runner |
| Ccbdc::parsec::agent::runner::evm_pretend_block | EVM pretend block is a pairing of the blocknumber (equal to the ticket number) and the transactions (currently always a single one) "inside
the block" (executed by that ticket) |
| Ccbdc::parsec::agent::runner::evm_sig | EVM signature type |
| Ccbdc::parsec::agent::runner::evm_tx | EVM transaction type |
| Ccbdc::parsec::agent::runner::evm_tx_receipt | EVM transaction receipt type |
| Ccbdc::parsec::agent::rpc::exec_request | Agent contract execution RPC request message |
| Ccbdc::sentinel::execute_response | Sentinel response message |
| Ccbdc::parsec::agent::runner::factory< T > | Runner factory for agents to intiantiate new runners of a particular type while only worrying about the runner interface |
| Ccbdc::parsec::runtime_locking_shard::rpc::finish_request | Finish request message |
| ►Ccbdc::transaction::full_tx | A complete transaction |
| Ccbdc::sentinel::execute_request | Sentinel request message |
| Ccbdc::sentinel::validate_request | Request type for transaction validation and attestation |
| Ccbdc::atomizer::get_block_request | Retrieve cached block request |
| Ccbdc::atomizer::get_block_response | Atomizer state machine response from get block request |
| Ccbdc::parsec::runtime_locking_shard::rpc::get_tickets_request | Get tickets request message |
| Ccbdc::rpc::header | RPC request and response header |
| ►Cevmc::Host | |
| Ccbdc::parsec::agent::runner::evm_host | Implementation of the evmc::Host interface using PARSEC as the backend database |
| Ccbdc::transaction::input | An input for a new transaction |
| Ccbdc::transaction::validation::input_error | An error that may occur when sentinels validate inputs |
| ►Ccbdc::coordinator::interface | Interface for a coordinator |
| Ccbdc::coordinator::controller | Replicated coordinator node |
| Ccbdc::coordinator::rpc::client | RPC client for a coordinator |
| ►Ccbdc::locking_shard::interface | Interface for a locking shard |
| Ccbdc::locking_shard::locking_shard | In-memory implementation of interface and status_interface |
| Ccbdc::locking_shard::rpc::client | RPC client for the mutable interface to a locking shard raft cluster |
| ►Ccbdc::parsec::agent::interface | Interface for an agent |
| Ccbdc::parsec::agent::impl | Implementation of an agent |
| ►Ccbdc::parsec::agent::runner::interface | Interface for a contract runner |
| Ccbdc::parsec::agent::runner::evm_runner | Executes EVM transactions, implementing the runner interface |
| Ccbdc::parsec::agent::runner::lua_runner | Lua function executor |
| ►Ccbdc::parsec::broker::interface | Interface for a broker |
| Ccbdc::parsec::broker::impl | Implementation of a broker |
| ►Ccbdc::parsec::directory::interface | Interface for a directory. Maps keys to shard IDs |
| Ccbdc::parsec::directory::impl | Implementation of a directory which map keys to shard IDs. Thread-safe |
| ►Ccbdc::parsec::runtime_locking_shard::interface | Interface for a runtime locking shard |
| Ccbdc::parsec::runtime_locking_shard::impl | Implementation of a runtime locking shard |
| Ccbdc::parsec::runtime_locking_shard::rpc::client | RPC client for a runtime locking shard cluster |
| ►Ccbdc::parsec::ticket_machine::interface | Ticket machine interface |
| Ccbdc::parsec::ticket_machine::impl | Thread-safe ticket machine implementation |
| Ccbdc::parsec::ticket_machine::rpc::client | RPC client for a remote ticket machine |
| ►Ccbdc::sentinel::interface | Interface for a sentinel |
| Ccbdc::sentinel::controller | Sentinel implementation |
| Ccbdc::sentinel::rpc::client | TCP RPC client for sentinels |
| Ccbdc::rpc::json_rpc_http_client | Asynchronous HTTP JSON-RPC client implemented using libcurl |
| Ccbdc::rpc::json_rpc_http_server | Asynchrounous HTTP JSON-RPC server implemented using libmicrohttpd and libjsoncpp |
| Ccbdc::logging::log | Generalized logging class |
| ►Cnuraft::log_store | |
| Ccbdc::raft::log_store | NuRaft log_store implementation using LevelDB |
| ►Cnuraft::logger | |
| Ccbdc::raft::console_logger | Nuraft::logger implementation using logging::log |
| Ccbdc::atomizer::make_block_request | Placeholder struct for a make block state machine request |
| Ccbdc::atomizer::make_block_response | Response from atomizer state machine to a make block request |
| Ccbdc::network::message_t | Received message type |
| ►Ccbdc::raft::node | A node in a raft cluster |
| Ccbdc::atomizer::atomizer_raft | Manager for an atomizer raft node |
| Ccbdc::hashing::null | Uses the raw value of a provided hash as an STL data structure hash key |
| Ccbdc::config::options | Project-wide configuration options |
| ►Cstd::ostream | |
| Ccbdc::logging::null_stream | No-op stream destination for log output |
| Ccbdc::transaction::out_point | The unique identifier of a specific output from a transaction |
| Ccbdc::transaction::output | An output of a transaction |
| Ccbdc::transaction::validation::output_error | An error that may occur when sentinels validate transaction outputs |
| Ccbdc::config::parser | Reads configuration parameters line-by-line from a file |
| Ccbdc::network::peer | Maintains a TCP socket |
| Ccbdc::parsec::runtime_locking_shard::rpc::prepare_request | Prepare request message |
| Ccbdc::atomizer::prune_request | Prune blocks request for RPC and state machine |
| Ccbdc::random_source | Generates pseudo-random numbers from a given entropy source |
| Ccbdc::parsec::runtime_locking_shard::rpc::replicated_get_tickets_request | Message for retrieving unfinished tickets from the replicated state machine |
| Ccbdc::parsec::runtime_locking_shard::rpc::replicated_prepare_request | Message for replicating a prepare request |
| ►Ccbdc::parsec::runtime_locking_shard::replicated_shard_interface | Interface for replicating internal state for prepared and committed tickets managed by a locking shard |
| Ccbdc::parsec::runtime_locking_shard::replicated_shard | Implementation of the replicated shard interface |
| Ccbdc::parsec::runtime_locking_shard::replicated_shard_client | Client for asynchronously interacting with a raft replicated shard on the leader node of the cluster |
| Ccbdc::locking_shard::rpc::request | Request to a shard |
| Ccbdc::rpc::request< T > | RPC request message |
| Ccbdc::watchtower::request | RPC request message to the watchtower external endpoint |
| Ccbdc::rpc::response< T > | RPC response message |
| Ccbdc::watchtower::response | RPC response message from the watchtower external endpoint |
| Ccbdc::rlp_value | This class contains a value that can be serialized into, or was deserialized from, a Recursive Length Prefix (RLP) encoded representation |
| Ccbdc::parsec::runtime_locking_shard::rpc::rollback_request | Rollback request message |
| ►Ccbdc::serializer | Interface for serializing objects into and out of raw bytes representations |
| Ccbdc::buffer_serializer | Serializer implementation for buffer |
| Ccbdc::nuraft_serializer | Implements serializer for nuraft::buffer |
| Ccbdc::size_serializer | Utility class for determining the size of a buffer needed to serialize a sequence of objects |
| ►Ccbdc::stream_serializer | Implementation of serializer for std::ios |
| Ccbdc::istream_serializer | Implementation of serializer for reading from a std::istream |
| Ccbdc::ostream_serializer | Implementation of serializer for writing to a std::ostream |
| ►CServer | |
| Ccbdc::rpc::tcp_server< Server > | Implements an RPC server over a TCP socket |
| Ccbdc::coordinator::rpc::server | RPC server for a coordinator |
| Ccbdc::parsec::runtime_locking_shard::rpc::server | RPC server for a runtime locking shard |
| Ccbdc::rpc::server< Request, Response, InBuffer, OutBuffer > | Generic RPC server |
| Ccbdc::sentinel::rpc::server | RPC server for a sentinel |
| ►Ccbdc::rpc::server< Request, Response, buffer, buffer > | |
| ►Ccbdc::rpc::async_server< Request, Response, InBuffer, OutBuffer > | Generic asynchronous RPC server |
| Ccbdc::raft::rpc::server | Generic RPC server for raft nodes for which the replicated state machine handles the request processing logic |
| Ccbdc::rpc::blocking_server< Request, Response, InBuffer, OutBuffer > | Generic synchronous RPC server |
| ►Ccbdc::rpc::server< rpc::request, rpc::response, nuraft::buffer &, nuraft::ptr< nuraft::buffer > > | |
| ►Ccbdc::rpc::blocking_server< rpc::request, rpc::response, nuraft::buffer &, nuraft::ptr< nuraft::buffer > > | |
| Ccbdc::locking_shard::state_machine | Raft state machine for handling locking shard RPC requests |
| Ccbdc::parsec::ticket_machine::state_machine | NuRaft state machine implementation for a replicated ticket machine |
| ►Ccbdc::parsec::agent::rpc::server_interface | Server interface for an agent |
| Ccbdc::parsec::agent::rpc::http_server | RPC server for a agent |
| Ccbdc::parsec::agent::rpc::server | RPC server for an agent running a Lua exector |
| Ccbdc::shard::shard | Database shard representing a fraction of the UTXO set |
| Ccbdc::parsec::runtime_locking_shard::shard_error | |
| Ccbdc::sentinel::shard_info | Sentinel-specific representation of shard network information |
| Ccbdc::coordinator::controller::sm_command | A full command for the state machine to process |
| Ccbdc::coordinator::controller::sm_command_header | Metadata of a command for the state machine |
| Ccbdc::atomizer::state_machine::snapshot | Represents a snapshot of the state machine with associated metadata |
| ►Ccbdc::network::socket | Generic superclass for network sockets |
| Ccbdc::network::tcp_listener | Listens for incoming TCP connections on a given endpoint |
| Ccbdc::network::tcp_socket | Wrapper for a TCP socket |
| Ccbdc::network::socket_selector | Waits on a group of blocking sockets to be ready for read operations |
| ►Cnuraft::state_machine | |
| Ccbdc::atomizer::state_machine | Raft state machine for managing a replicated atomizer |
| Ccbdc::coordinator::state_machine | Raft state machine for managing a replicated coordinator |
| Ccbdc::locking_shard::state_machine | Raft state machine for handling locking shard RPC requests |
| Ccbdc::parsec::runtime_locking_shard::state_machine | NuRaft state machine implementation for a runtime locking shard |
| Ccbdc::parsec::ticket_machine::state_machine | NuRaft state machine implementation for a replicated ticket machine |
| ►Cnuraft::state_mgr | |
| Ccbdc::raft::state_manager | Implementation of nuraft::state_mgr using a file |
| ►Ccbdc::locking_shard::status_interface | Interface for querying the read-only state of a locking shard |
| Ccbdc::locking_shard::locking_shard | In-memory implementation of interface and status_interface |
| Ccbdc::locking_shard::rpc::status_client | Client for interacting with the read-only port on 2PC shards |
| Ccbdc::watchtower::status_request_check_success | Indicates a successful check request, sent with a StatusUpdateResponse |
| Ccbdc::locking_shard::rpc::status_server | Server for handling TX and UHS ID status requests |
| Ccbdc::watchtower::status_update_request | Network request to interact with the Watchtower's status update service |
| Ccbdc::watchtower::status_update_state | Represents the internal state of an ongoing status update request |
| Ccbdc::parsec::agent::runner::storage_key | Type for account storage keys |
| Ccbdc::thread_pool | |
| Ccbdc::parsec::runtime_locking_shard::replicated_shard_interface::ticket_type | Ticket date stored in the replicated state machine |
| Ccbdc::parsec::runtime_locking_shard::rpc::try_lock_request | Try lock request message |
| ►CTs... | |
| Ccbdc::overloaded< Ts > | Variant handler template |
| Ccbdc::locking_shard::tx | Transaction type processed by locking shards |
| Ccbdc::watchtower::tx_error | Wrapper for transaction errors |
| Ccbdc::watchtower::tx_error_incomplete | Indicates that the atomizer did not receive enough attestations for a particular transaction from shards before it had to clean up the transaction and free up space for others |
| Ccbdc::watchtower::tx_error_inputs_dne | Indicates a shard that tried to process a given transaction could not locate one or more of the transaction's inputs it expected to possess |
| Ccbdc::watchtower::tx_error_inputs_spent | Indicates that the given transaction contains one or more inputs that have already been spent in other transactions sent to the atomizer |
| Ccbdc::watchtower::tx_error_stxo_range | Indicates that a shard did not attest to this transaction recently enough for the atomizer to check it against the STXO cache |
| Ccbdc::watchtower::tx_error_sync | Indicates a shard that tried to process a given transaction was out of sync with the atomizer, and the transaction should be retried |
| Ccbdc::atomizer::tx_notify_request | Transaction notification message |
| Ccbdc::locking_shard::rpc::tx_status_request | RPC message for clients to use to request the status of a TX ID |
| Ccbdc::locking_shard::rpc::uhs_status_request | RPC message for clients to use to request the status of a UHS ID |
| Ccbdc::transaction::wallet | Cryptographic wallet for digital currency assets and secrets |
| Ccbdc::watchtower::watchtower | Service to answer client requests for processing status updates on submitted transactions |
| Ccbdc::transaction::validation::witness_error | An error that may occur when sentinels validate witness commitments |
| Ccbdc::parsec::runtime_locking_shard::wounded_details | Details about wounded error code |
| ►Cleveldb::WriteOptions | |
| Ccbdc::archiver::leveldbWriteOptions | Wrapper for leveldb::WriteOptions to provide a constructor to set base class member "sync" |