Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- accept(Message) - Method in class convex.net.ResultConsumer
- AConnection - Class in convex.net
- AConnection() - Constructor for class convex.net.AConnection
- acquire(Hash) - Method in class convex.api.Convex
-
Attempts to asynchronously acquire a complete persistent data structure for the given hash from the remote peer.
- acquire(Hash, AStore) - Method in class convex.api.Convex
-
Attempts to acquire a complete persistent data structure for the given hash from the connected peer.
- acquire(Hash, AStore) - Method in class convex.api.ConvexDirect
- acquire(Hash, AStore) - Method in class convex.api.ConvexLocal
- acquire(Hash, AStore) - Method in class convex.api.ConvexRemote
- acquireState() - Method in class convex.api.Convex
-
Gets the consensus state from the connected Peer.
- acquireState() - Method in class convex.api.ConvexLocal
- acquireState() - Method in class convex.api.ConvexRemote
- Acquiror - Class in convex.api
-
Utility class for acquiring data remotely
- Acquiror(Hash, AStore, ConvexRemote) - Constructor for class convex.api.Acquiror
- addConnection(AccountKey, Convex) - Method in class convex.peer.ConnectionManager
- address - Variable in class convex.api.Convex
-
Current Address for this Client
- alertBadMessage(Message, String) - Method in class convex.peer.ConnectionManager
-
Called to signal a bad / corrupt message from a Peer.
- alertMissing(Message, MissingDataException, AccountKey) - Method in class convex.peer.ConnectionManager
-
Called to signal missing data in a Belief / Order
- API - Class in convex.peer
-
Class providing a simple API to operate a peer protocol Server.
- API() - Constructor for class convex.peer.API
- AServer - Class in convex.net
- AServer() - Constructor for class convex.net.AServer
- AThreadedComponent - Class in convex.peer
-
Base class for a threaded execution component that runs within the context of a Peer Server
- AThreadedComponent(Server) - Constructor for class convex.peer.AThreadedComponent
B
- BELIEF_BROADCAST_DELAY - Static variable in class convex.peer.BeliefPropagator
-
Minimum delay between successive Belief broadcasts
- BELIEF_BROADCAST_POLL_TIME - Static variable in class convex.peer.BeliefPropagator
-
Polling period for Belief propagator loop
- BELIEF_FULL_BROADCAST_DELAY - Static variable in class convex.peer.BeliefPropagator
-
Time between full Belief broadcasts
- BELIEF_QUEUE_SIZE - Static variable in class convex.peer.Config
-
Size of incoming Belief queue
- BELIEF_REBROADCAST_DELAY - Static variable in class convex.peer.BeliefPropagator
- BeliefPropagator - Class in convex.peer
-
Component class to handle propagation of new Beliefs from a Peer Overall logic: 1.
- BeliefPropagator(Server) - Constructor for class convex.peer.BeliefPropagator
- broadcast(Message) - Method in class convex.peer.ConnectionManager
-
Broadcasts a Message to all connected Peers
- bufferMessage(ByteBuffer) - Method in class convex.net.MessageSender
-
Buffers a message for sending.
C
- canSendMessage() - Method in class convex.net.MessageSender
-
Checks if this sender is ready to send a message.
- ChallengeRequest - Class in convex.net
- checkCache(Hash) - Method in class convex.net.store.RemoteStore
- checkKeyStore(Map<Keyword, Object>) - Static method in class convex.peer.Config
-
Checks if the config specifies a valid keystore
- checkStore(Map<Keyword, Object>) - Static method in class convex.peer.Config
-
Checks if the config specifies a valid store
- clearSequence() - Method in class convex.api.Convex
-
Clears the sequence number cache for this client instance.
- clientTransactionCount - Variable in class convex.peer.TransactionHandler
- close() - Method in class convex.api.Convex
-
Disconnects the client from the network, releasing any connection resources.
- close() - Method in class convex.api.ConvexDirect
- close() - Method in class convex.api.ConvexLocal
- close() - Method in class convex.api.ConvexRemote
-
Disconnects the client from the network, closing the underlying connection.
- close() - Method in class convex.net.AConnection
- close() - Method in class convex.net.AServer
- close() - Method in class convex.net.MemoryByteChannel
- close() - Method in class convex.net.store.RemoteStore
- close() - Method in class convex.net.UDPServer
- close() - Method in class convex.peer.AThreadedComponent
-
Close this threaded component, including interrupting any running thread(s).
- close() - Method in class convex.peer.ConnectionManager
- close() - Method in class convex.peer.Server
- closeAllConnections() - Method in class convex.peer.ConnectionManager
-
Close all outgoing connections from this Peer
- closeConnection(AccountKey, String) - Method in class convex.peer.ConnectionManager
-
Close and remove a connection
- Config - Class in convex.peer
-
Static tools and utilities for Peer configuration
- Config() - Constructor for class convex.peer.Config
- ConfigException - Exception Class in convex.peer
-
Message thrown when a failure occurs during peer configuration
- ConfigException(String) - Constructor for exception class convex.peer.ConfigException
- ConfigException(String, Throwable) - Constructor for exception class convex.peer.ConfigException
- connect(Server) - Static method in class convex.api.Convex
-
Connect to a local Server, with no address and keypair set
- connect(Server, Address, AKeyPair) - Static method in class convex.api.Convex
-
Connect to a local Server, using given address and keypair
- connect(Object) - Static method in class convex.api.Convex
-
Attempts best possible connection
- connect(InetSocketAddress) - Static method in class convex.api.Convex
-
Creates an anonymous connection to a Peer, suitable for queries
- connect(InetSocketAddress) - Static method in class convex.api.ConvexRemote
- connect(InetSocketAddress, Address, AKeyPair) - Static method in class convex.api.Convex
-
Create a Convex client by connecting to the specified Peer using the given key pair
- connection - Variable in class convex.api.ConvexRemote
-
Current Connection to a Peer, may be null or a closed connection.
- ConnectionManager - Class in convex.peer
-
Class for managing the outbound Peer connections from a Peer Server.
- ConnectionManager(Server) - Constructor for class convex.peer.ConnectionManager
- connectNetty(InetSocketAddress) - Static method in class convex.api.ConvexRemote
- connectNIO(InetSocketAddress) - Static method in class convex.api.ConvexRemote
- connectToPeer(InetSocketAddress) - Method in class convex.api.ConvexRemote
- connectToPeer(InetSocketAddress) - Method in class convex.peer.ConnectionManager
-
Connects explicitly to a Peer at the given host address
- ContentTypes - Class in convex.api
-
MIME content types used for peer-to=peer communication
- ContentTypes() - Constructor for class convex.api.ContentTypes
- convex - Variable in class convex.net.store.RemoteStore
- Convex - Class in convex.api
-
Class providing a client API to the Convex network.
- Convex(Address, AKeyPair) - Constructor for class convex.api.Convex
- convex.api - package convex.api
- convex.net - package convex.net
- convex.net.store - package convex.net.store
- convex.peer - module convex.peer
- convex.peer - package convex.peer
- ConvexDirect - Class in convex.api
-
Convex API instance that directly interacts with a Peer instance
- ConvexDirect(Address, AKeyPair, Peer) - Constructor for class convex.api.ConvexDirect
- ConvexLocal - Class in convex.api
-
Convex Client implementation supporting a direct connection to a Peer Server in the same JVM.
- ConvexLocal(Server, Address, AKeyPair) - Constructor for class convex.api.ConvexLocal
- ConvexRemote - Class in convex.api
-
Convex client API implementation for peers accessed over a network connection using the Convex binary peer protocol
- ConvexRemote(Address, AKeyPair) - Constructor for class convex.api.ConvexRemote
- countInterests() - Method in class convex.peer.TransactionHandler
- create(int) - Static method in class convex.net.MemoryByteChannel
- create(Convex) - Method in class convex.net.store.RemoteStore
- create(AKeyPair, State) - Static method in class convex.api.ConvexDirect
- create(AccountKey) - Static method in class convex.net.ChallengeRequest
- create(AccountKey, int) - Static method in class convex.net.ChallengeRequest
- create(Hash, AStore, ConvexRemote) - Static method in class convex.api.Acquiror
- create(Server) - Static method in class convex.api.ConvexLocal
- create(Server, Address, AKeyPair) - Static method in class convex.api.ConvexLocal
- create(HashMap<Keyword, Object>) - Static method in class convex.peer.Server
-
Creates a new (unlaunched) Server with a given config.
- createAccount(AccountKey) - Method in class convex.api.Convex
-
Creates a new account with the given public key
- createAccountSync(AccountKey) - Method in class convex.api.Convex
-
Creates a new account with the given public key
- createFullUpdateMessage() - Method in class convex.peer.BeliefPropagator
- createQuickUpdateMessage() - Method in class convex.peer.BeliefPropagator
- CVMExecutor - Class in convex.peer
-
Component handling CVM execution loop with a Peer Server
- CVMExecutor(Server) - Constructor for class convex.peer.CVMExecutor
- CVX - Static variable in class convex.api.ContentTypes
-
Content type for CVX Readable format
- CVX_RAW - Static variable in class convex.api.ContentTypes
-
Content type for CVX raw encoding (multi cell supported)
D
- DEFAULT_CLIENT_TIMEOUT - Static variable in class convex.peer.Config
-
Default timeout in milliseconds for client transactions
- DEFAULT_OUTGOING_CONNECTION_COUNT - Static variable in class convex.peer.Config
-
Default number of outgoing connections for a Peer
- DEFAULT_PORT - Static variable in class convex.peer.Server
E
- ensureFlags(Map<Keyword, Object>) - Static method in class convex.peer.Config
-
Ensures standard flags are set to defaults(if not specified).
- ensureGenesisState(HashMap<Keyword, Object>) - Static method in class convex.peer.Config
-
Checks that the config specifies a source for the genesis state
- ensurePeerKey(HashMap<Keyword, Object>) - Static method in class convex.peer.Config
-
Ensures we have a hot peer :keypair set in config
- ensureStatusMap(ACell) - Static method in class convex.peer.API
-
Converts a status map or value vector to a status map
- ensureStore(Map<Keyword, Object>) - Static method in class convex.peer.Config
-
Establishes a store in the given config
- executor - Variable in class convex.peer.Server
-
Transaction handler instance.
F
- finalize() - Method in class convex.api.Convex
- fromPeerData(AKeyPair, AMap<Keyword, ACell>) - Static method in class convex.peer.Server
G
- getAccountKey() - Method in class convex.api.Convex
-
Returns the current AccountKey for the client using the API.
- getAccountKey(Address) - Method in class convex.api.Convex
-
Returns the current AccountKey for the specified address.
- getAddress() - Method in class convex.api.Convex
-
Returns the current Address for the client using the API.
- getBalance() - Method in class convex.api.Convex
-
Query the balance for the current account
- getBalance() - Method in class convex.api.ConvexLocal
- getBalance(Address) - Method in class convex.api.Convex
- getBelief() - Method in class convex.peer.Server
-
Gets the current Belief held by this Peer
- getBeliefBroadcastCount() - Method in class convex.peer.BeliefPropagator
- getBeliefPropagator() - Method in class convex.peer.Server
- getBeliefReceivedCount() - Method in class convex.peer.Server
-
Gets the number of beliefs received by this Peer
- getBroadcastCount() - Method in class convex.peer.Server
-
Gets the number of belief broadcasts made by this Peer
- getConfig() - Method in class convex.peer.Server
- getConnection(AccountKey) - Method in class convex.peer.ConnectionManager
-
Gets a connection based on the peers public key
- getConnectionCount() - Method in class convex.peer.ConnectionManager
-
Returns the number of active connections
- getConnectionManager() - Method in class convex.peer.Server
- getConnections() - Method in class convex.peer.ConnectionManager
-
Gets the current set of outbound peer connections from this server
- getControllerKey() - Method in class convex.peer.Server
-
Gets the peer controller key for the Server, if available
- getCVMExecutor() - Method in class convex.peer.Server
- getFuture() - Method in class convex.api.Acquiror
-
Gets a future for the result of a virtual task attempting to acquire data from a remote source.
- getHostAddress() - Method in class convex.api.Convex
-
Gets the remote address for this Convex client instance
- getHostAddress() - Method in class convex.api.ConvexDirect
- getHostAddress() - Method in class convex.api.ConvexLocal
- getHostAddress() - Method in class convex.api.ConvexRemote
- getHostAddress() - Method in class convex.net.AServer
- getHostAddress() - Method in class convex.peer.Server
-
Gets the host address for this Server (including port), or null if closed
- getHostname() - Method in class convex.peer.Server
-
Gets the desired host name for this Peer
- getKeyPair() - Method in class convex.api.Convex
-
Get the keypair for this Convex connection.
- getKeyPair() - Method in class convex.peer.Server
-
Returns the Keypair for this peer server SECURITY: Be careful with this!
- getLastBroadcastBelief() - Method in class convex.peer.BeliefPropagator
- getLoad() - Method in class convex.peer.AThreadedComponent
- getLocalServer() - Method in class convex.api.Convex
-
Gets the local Server instance, or null if not a local connection
- getLocalServer() - Method in class convex.api.ConvexLocal
- getLocalServer() - Method in class convex.api.ConvexRemote
- getNextID() - Method in class convex.api.Convex
- getPeer() - Method in class convex.peer.CVMExecutor
- getPeer() - Method in class convex.peer.Server
-
Gets the current Peer data structure for this
Server
. - getPeerController() - Method in class convex.peer.Server
-
Gets the Peer controller Address
- getPeerKey() - Method in class convex.net.ChallengeRequest
- getPeerKey() - Method in class convex.peer.Server
-
Gets the public key of the peer account
- getPort() - Method in class convex.net.AServer
-
Gets the port that this server instance is configured to listen on
- getPort() - Method in class convex.peer.Server
-
Gets the port that this Server is currently accepting connections on
- getQueryProcessor() - Method in class convex.peer.Server
- getReceiveAction() - Method in class convex.peer.Server
-
Gets the action to perform for an incoming client message
- getReceivedCount() - Method in class convex.net.AConnection
- getReceivedCount() - Method in class convex.net.MessageReceiver
-
Get the number of messages received in total by this Receiver
- getRemoteAddress() - Method in class convex.net.AConnection
-
Returns the remote SocketAddress associated with this connection, or null if not available
- getRootHash() - Method in class convex.net.store.RemoteStore
- getSendHash() - Method in class convex.net.ChallengeRequest
- getSequence() - Method in class convex.api.Convex
-
Gets the current sequence number for this Client, which is the sequence number of the last transaction observed for the current client's Account.
- getSequence() - Method in class convex.api.ConvexLocal
- getSequence(Address) - Method in class convex.api.Convex
-
Gets the current sequence number for an account, which is the sequence number of the last transaction observed for the Account.
- getSequence(Address) - Method in class convex.api.ConvexLocal
- getState() - Method in class convex.api.ConvexLocal
- getStatusData() - Method in class convex.peer.Server
-
Gets the status vector for the Peer 0 = latest belief hash 1 = states vector hash 2 = genesis state hash 3 = peer key 4 = consensus state hash 5 = consensus point 6 = proposal point 7 = ordering length 8 = consensus point vector
- getStatusMap() - Method in class convex.peer.Server
- getStore() - Method in class convex.peer.Server
-
Gets the Store configured for this Server.
- getThreadName() - Method in class convex.peer.AThreadedComponent
- getThreadName() - Method in class convex.peer.BeliefPropagator
- getThreadName() - Method in class convex.peer.ConnectionManager
- getThreadName() - Method in class convex.peer.CVMExecutor
- getThreadName() - Method in class convex.peer.QueryHandler
- getThreadName() - Method in class convex.peer.TransactionHandler
- getTimeout() - Method in class convex.api.Convex
- getToken() - Method in class convex.net.ChallengeRequest
- getTransactionHandler() - Method in class convex.peer.Server
H
- handleDataRequest(Message) - Method in class convex.peer.QueryHandler
-
Respond to a request for missing data, on a best-efforts basis.
- handleError(ACell, ACell, ACell) - Method in class convex.net.ResultConsumer
-
Method called when an error result is received.
- handleNormalResult(ACell, ACell) - Method in class convex.net.ResultConsumer
-
Method called when a normal (non-error) result is received.
- handleResult(ACell, Result) - Method in class convex.net.ResultConsumer
-
Handler for a fully received Result.
I
- idCounter - Variable in class convex.api.Convex
-
Counter for outgoing message IDs.
- INITIAL_RECEIVE_BUFFER_SIZE - Static variable in class convex.net.MessageReceiver
- IPUtils - Class in convex.net
- IPUtils() - Constructor for class convex.net.IPUtils
- isAutoSequence() - Method in class convex.api.Convex
-
Determines if this Client is configured to automatically generate sequence numbers
- isAwaitingResults() - Method in class convex.peer.TransactionHandler
- isClosed() - Method in class convex.net.AConnection
-
Checks if this connection is closed (i.e. the underlying channel is closed)
- isConnected() - Method in class convex.api.Convex
-
Checks if this Convex client instance has an open connection.
- isConnected() - Method in class convex.api.ConvexDirect
- isConnected() - Method in class convex.api.ConvexLocal
- isConnected() - Method in class convex.api.ConvexRemote
-
Checks if this Convex client instance has an open remote connection.
- isConnected(AccountKey) - Method in class convex.peer.ConnectionManager
-
Return true if a specified Peer is connected
- isLive() - Method in class convex.peer.Server
-
Checks is the server is Live, i.e. currently syncing successfully with network
- isOpen() - Method in class convex.net.MemoryByteChannel
- isPreCompile() - Method in class convex.api.Convex
- isRunning() - Method in class convex.peer.Server
-
Checks if the Server threads are running
- isTimedout() - Method in class convex.net.ChallengeRequest
- isTrusted() - Method in class convex.net.AConnection
J
- JSON - Static variable in class convex.api.ContentTypes
-
Content type for JSON
K
L
- lastBlockPublishedTime - Variable in class convex.peer.TransactionHandler
-
Time at which last Block was published by this Peer
- launch() - Method in class convex.net.AServer
- launch() - Method in class convex.peer.Server
-
Launch the Peer Server, including all main server threads
- launch(String, Integer) - Method in class convex.net.UDPServer
- LaunchException - Exception Class in convex.peer
-
Exception thrown when a failure occurs during peer launch
- LaunchException(String) - Constructor for exception class convex.peer.LaunchException
- LaunchException(String, Throwable) - Constructor for exception class convex.peer.LaunchException
- launchLocalPeers(List<AKeyPair>, State) - Static method in class convex.peer.API
-
Launch a local set of peers.
- launchLocalPeers(List<AKeyPair>, State, int[]) - Static method in class convex.peer.API
-
Launch a local set of peers.
- launchPeer() - Static method in class convex.peer.API
-
Launches a peer with a default configuration.
- launchPeer(Map<Keyword, Object>) - Static method in class convex.peer.API
-
Launches a Peer Server with a supplied configuration.
- listPeers(AStore) - Static method in class convex.peer.API
-
Gets the list of peers registered in the given Etch Store
- log - Static variable in class convex.api.ConvexRemote
- log - Static variable in class convex.net.MessageSender
- log - Static variable in class convex.peer.API
- lookupSequence(Address) - Method in class convex.api.Convex
-
Look up the sequence number for an account
- loop() - Method in class convex.peer.AThreadedComponent
- loop() - Method in class convex.peer.BeliefPropagator
- loop() - Method in class convex.peer.ConnectionManager
- loop() - Method in class convex.peer.CVMExecutor
- loop() - Method in class convex.peer.QueryHandler
- loop() - Method in class convex.peer.TransactionHandler
-
Loops for handling incoming client transactions
M
- main(String[]) - Static method in class convex.net.IPUtils
- main(String...) - Static method in class convex.net.UDPServer
- maintainConnections() - Method in class convex.peer.ConnectionManager
- manager - Variable in class convex.peer.Server
-
Connection manager instance.
- MAX_REBROADCAST_DELAY - Static variable in class convex.peer.Config
-
Delay before rebroadcasting Belief if not in consensus
- maybeBroadcast(boolean) - Method in class convex.peer.BeliefPropagator
- maybeGenerateBlocks() - Method in class convex.peer.TransactionHandler
-
Gets the next Blocks for publication, or null if nothing to publish Checks for pending transactions, and if found propose them as new Block(s).
- maybeMergeBeliefs(Belief...) - Method in class convex.peer.BeliefPropagator
-
Checks for mergeable remote beliefs, and if found merge and update own belief.
- maybeReportTransactions(Peer) - Method in class convex.peer.TransactionHandler
- maybeSendBytes() - Method in class convex.net.MessageSender
-
Try to send bytes on the outbound channel.
- maybeUpdateBelief(Belief) - Method in class convex.peer.BeliefPropagator
-
Handle general Belief update, taking belief registered in newBeliefs
- maybeUpdateSequence(SignedData<ATransaction>) - Method in class convex.api.Convex
-
Called after a transaction is submitted to update sequence (if possible)
- MemoryByteChannel - Class in convex.net
-
ByteChannel implementation wrapping a fixed size in-memory buffer
- mergeBeliefMessage(HashMap<AccountKey, SignedData<Order>>, Message) - Method in class convex.peer.BeliefPropagator
-
Merge a single Belief message into a map of accumulated latest Orders
- message(Message) - Method in class convex.api.Convex
-
Submits a Message to the connected peer, returning a Future for any Result
- message(Message) - Method in class convex.api.ConvexDirect
- message(Message) - Method in class convex.api.ConvexLocal
- message(Message) - Method in class convex.api.ConvexRemote
- messageRaw(Blob) - Method in class convex.api.Convex
-
Submits raw message data to the Convex network, returning a Future for any Result
- messageRaw(Blob) - Method in class convex.api.ConvexDirect
- messageRaw(Blob) - Method in class convex.api.ConvexLocal
- messageRaw(Blob) - Method in class convex.api.ConvexRemote
- MessageReceiver - Class in convex.net
-
Class responsible for buffered accumulation of data received over a single connection.
- MessageReceiver(Consumer<Message>, Predicate<Message>) - Constructor for class convex.net.MessageReceiver
- MessageSender - Class in convex.net
-
Message sender responsible for moving bytes from a ByteBuffer to a ByteChannel Must call maybeSendBytes to attempt to flush buffer to channel.
- MessageSender(ByteChannel) - Constructor for class convex.net.MessageSender
O
- of(Object...) - Static method in class convex.peer.Config
-
Build a Config map
- offerQuery(Message) - Method in class convex.peer.QueryHandler
-
Offer a transaction for handling
- offerTransaction(Message) - Method in class convex.peer.TransactionHandler
-
Offer a transaction for handling
P
- parseAddress(String, Integer) - Static method in class convex.net.IPUtils
-
Parses a socket address
- peer - Variable in class convex.api.ConvexDirect
- PEER_CONNECTION_DROP_TIME - Static variable in class convex.peer.Config
-
Number of milliseconds average time to drop low-staked Peers
- PEER_SYNC_TIMEOUT - Static variable in class convex.peer.Config
-
Timeout for syncing with an existing Peer
- PeerException - Exception Class in convex.peer
-
Base exception class for peer operations and functionality
- PeerException(String, Throwable) - Constructor for exception class convex.peer.PeerException
- peerKey - Variable in class convex.net.ChallengeRequest
- persistPeerData() - Method in class convex.peer.CVMExecutor
- persistPeerData() - Method in class convex.peer.Server
-
Writes the Peer data to the configured store.
- preCompile - Variable in class convex.api.Convex
-
Determines if transactions should be pre-compiled.
- preCompile(ACell) - Method in class convex.api.Convex
-
Pre-compiles code, compiling the given source to a CVM Op.
- prepareTransaction(ATransaction) - Method in class convex.api.Convex
-
Prepares a transaction for network submission - Sets origin account if needed - Sets sequence number (if autosequencing is enabled) - Signs transaction with current key pair
- prepareTransaction(ACell) - Method in class convex.api.Convex
-
Prepares a transaction for network submission - Pre-compiles if needed - Sets origin account to current address - Sets sequence number (if auto-sequencing is enabled) - Signs transaction with current key pair
- processBelief(Message) - Method in class convex.peer.Server
-
Process an incoming message that represents a Belief
- processChallenge(Message, Peer) - Method in class convex.peer.ConnectionManager
- processClose(Message) - Method in class convex.peer.Server
-
Called by a remote peer to close connections to the remote peer.
- processMessage(Message) - Method in class convex.peer.Server
-
Process a message received from a peer or client.
- processMessage(Message) - Method in class convex.peer.TransactionHandler
- processQuery(Message) - Method in class convex.peer.Server
- processResponse(Message) - Method in class convex.peer.Server
- processStatus(Message) - Method in class convex.peer.Server
- processTransact(Message) - Method in class convex.peer.Server
- propagator - Variable in class convex.peer.Server
-
Connection manager instance.
Q
- query(ACell) - Method in class convex.api.Convex
-
Submits a query to the Convex network, returning a Future once the query has been successfully queued.
- query(ACell, Address) - Method in class convex.api.Convex
-
Submits a query to the Convex network, returning a Future once the query has been successfully queued.
- query(ACell, Address) - Method in class convex.api.ConvexDirect
- query(ACell, Address) - Method in class convex.api.ConvexLocal
- query(ACell, Address) - Method in class convex.api.ConvexRemote
- query(String) - Method in class convex.api.Convex
-
Submits a query to the Convex network, returning a Future once the query has been successfully queued.
- QUERY_QUEUE_SIZE - Static variable in class convex.peer.Config
-
Default size for incoming client query queue Note: this limits TPS for client queries, will send failures if overloaded
- queryHandler - Variable in class convex.peer.Server
-
Query handler instance.
- QueryHandler - Class in convex.peer
- QueryHandler(Server) - Constructor for class convex.peer.QueryHandler
- querySync(ACell) - Method in class convex.api.Convex
-
Executes a query synchronously and waits for the Result
- querySync(ACell, Address) - Method in class convex.api.Convex
-
Executes a query synchronously and waits for the Result
- querySync(ACell, Address, long) - Method in class convex.api.Convex
-
Executes a query synchronously and waits for the Result
- querySync(String) - Method in class convex.api.Convex
-
Executes a query synchronously and waits for the Result
- queueBelief(Message) - Method in class convex.peer.BeliefPropagator
-
Queues a Belief Message for processing
- queueBelief(Message) - Method in class convex.peer.Server
-
Adds an event to the inbound server event queue.
- queueUpdate(Belief) - Method in class convex.peer.CVMExecutor
R
- read(ByteBuffer) - Method in class convex.net.MemoryByteChannel
- recalcState(long) - Method in class convex.peer.CVMExecutor
- receivedTransactionCount - Variable in class convex.peer.TransactionHandler
- receiveFromChannel(ReadableByteChannel) - Method in class convex.net.MessageReceiver
-
Handles receipt of bytes from a channel.
- reconnect() - Method in class convex.api.Convex
- reconnect() - Method in class convex.api.ConvexDirect
- reconnect() - Method in class convex.api.ConvexLocal
- reconnect() - Method in class convex.api.ConvexRemote
- refForHash(Hash) - Method in class convex.net.store.RemoteStore
- remoteAddress - Variable in class convex.api.ConvexRemote
- RemoteStore - Class in convex.net.store
-
A Store implementation working over a Convex binary connection
- RemoteStore(Convex) - Constructor for class convex.net.store.RemoteStore
- requestChallenge(AccountKey, AConnection, Peer) - Method in class convex.peer.ConnectionManager
-
Sends out a challenge to a connection that is not trusted.
- requestChallenge(SignedData<ACell>) - Method in class convex.api.Convex
-
Request a challenge.
- requestChallenge(SignedData<ACell>) - Method in class convex.api.ConvexDirect
- requestChallenge(SignedData<ACell>) - Method in class convex.api.ConvexLocal
- requestChallenge(SignedData<ACell>) - Method in class convex.api.ConvexRemote
- requestStatus() - Method in class convex.api.Convex
-
Submits a status request to the Convex network peer, returning a Future once the request has been successfully queued.
- requestStatus() - Method in class convex.api.ConvexDirect
- requestStatus() - Method in class convex.api.ConvexLocal
- requestStatus() - Method in class convex.api.ConvexRemote
- requestStatusSync() - Method in class convex.api.Convex
- requestStatusSync(long) - Method in class convex.api.Convex
-
Request status using a sync operation.
- resolve(String) - Method in class convex.api.Convex
-
Attempts to resolve a CNS name
- ResultConsumer - Class in convex.net
-
Consumer
abstract base class for default behaviour when awaiting results. - ResultConsumer() - Constructor for class convex.net.ResultConsumer
- returnMessageHandler - Variable in class convex.api.ConvexRemote
-
Result handler for Messages received back from a remote connection
- run() - Method in class convex.net.UDPServer
- running - Variable in class convex.net.UDPServer
S
- send(AConnection, Peer) - Method in class convex.net.ChallengeRequest
-
Sends out a single challenge to the remote peer.
- sendHash - Variable in class convex.net.ChallengeRequest
- sendMessage(Message) - Method in class convex.net.AConnection
-
Sends a message over this connection
- sequence - Variable in class convex.api.Convex
-
Sequence number for this client, or null if not yet known.
- server - Variable in class convex.peer.AThreadedComponent
- Server - Class in convex.peer
-
A self contained Peer Server that can be launched with a config.
- setAddress(Address) - Method in class convex.api.Convex
-
Sets the Address for this connection.
- setAddress(Address, AKeyPair) - Method in class convex.api.Convex
-
Sets the Address and Keypair for this connection.
- setAutoSequence(boolean) - Method in class convex.api.Convex
-
Configures auto-generation of sequence numbers
- setBeliefUpdateObserver(Consumer<Belief>) - Method in class convex.peer.BeliefPropagator
-
Sets the observer for belief updates
- setConnection(AConnection) - Method in class convex.api.ConvexRemote
-
Sets the current Connection for this Remote Client
- setHook(Consumer<Message>) - Method in class convex.net.MessageReceiver
-
Sets an optional additional message receiver hook (for debugging / observability purposes)
- setHostname(String) - Method in class convex.peer.Server
-
Sets the desired host name for this Server
- setKeyPair(AKeyPair) - Method in class convex.api.Convex
- setMessageReceiveObserver(Consumer<Message>) - Method in class convex.peer.Server
- setNextSequence(long) - Method in class convex.api.Convex
- setOrderUpdateObserver(Consumer<SignedData<Order>>) - Method in class convex.peer.BeliefPropagator
-
Sets the observer for order updates
- setPeer(Peer) - Method in class convex.peer.CVMExecutor
- setPort(Integer) - Method in class convex.net.AServer
-
Sets the port for this server.
- setPreCompile(boolean) - Method in class convex.api.Convex
-
Sets the client connection pre-compilation mode.
- setRequestObserver(Consumer<SignedData<ATransaction>>) - Method in class convex.peer.TransactionHandler
-
Sets a request observer, which will be called whenever the Peer processes a valid client transaction request
- setResponseObserver(BiConsumer<SignedData<ATransaction>, Result>) - Method in class convex.peer.TransactionHandler
-
Sets a request observer, which will be called whenever the Peer processes a valid client transaction request
- setRootData(T) - Method in class convex.net.store.RemoteStore
- setTimeout(long) - Method in class convex.api.Convex
-
Sets the default timeout for this Convex client instance.
- setTrustedKey(AccountKey) - Method in class convex.net.AConnection
-
Sets the trusted remote key for this connection.
- setUpdateHook(Consumer<Peer>) - Method in class convex.peer.CVMExecutor
- shortName() - Method in class convex.net.store.RemoteStore
- shutdown() - Method in class convex.peer.Server
-
Shut down the Server, as gracefully as possible.
- signData(T) - Method in class convex.api.Convex
-
Signs a value on behalf of this client, using the currently assigned keypair.
- SOCKET_PEER_BUFFER_SIZE - Static variable in class convex.peer.Config
-
Size of default server socket buffers for an outbound peer connection
- SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class convex.peer.Config
-
Size of default client socket receive buffer
- SOCKET_SEND_BUFFER_SIZE - Static variable in class convex.peer.Config
-
Size of default client socket send buffer
- SOCKET_SERVER_BUFFER_SIZE - Static variable in class convex.peer.Config
-
Size of default server socket receive buffer
- start() - Method in class convex.peer.AThreadedComponent
-
Start the threaded component
- start() - Method in class convex.peer.BeliefPropagator
- start() - Method in class convex.peer.ConnectionManager
- start() - Method in class convex.peer.TransactionHandler
- STATUS_COUNT - Static variable in class convex.peer.Config
-
Number of fields in a Peer STATUS message
- sTATUS_KEYS - Static variable in class convex.peer.Server
- STATUS_KEYS - Static variable in class convex.peer.API
- storeRef(Ref<T>, int, Consumer<Ref<ACell>>) - Method in class convex.net.store.RemoteStore
- storeTopRef(Ref<T>, int, Consumer<Ref<ACell>>) - Method in class convex.net.store.RemoteStore
- syncPeer(AKeyPair, Convex) - Method in class convex.peer.Server
- syncPeer(Server) - Method in class convex.peer.CVMExecutor
T
- TEXT - Static variable in class convex.api.ContentTypes
-
Content type for plain test
- thread - Variable in class convex.peer.AThreadedComponent
- timeout - Variable in class convex.api.Convex
- timeout - Variable in class convex.net.ChallengeRequest
- toInetSocketAddress(Object) - Static method in class convex.net.IPUtils
-
Converts a Object to an InetSocketAddress
- toInetSocketAddress(String) - Static method in class convex.net.IPUtils
-
Converts a String to an InetSocketAddress
- toInetSocketAddress(URI) - Static method in class convex.net.IPUtils
-
Converts a URI to an InetSocketAddress.
- toInetSocketAddress(URL) - Static method in class convex.net.IPUtils
-
Converts a URL to an InetSocketAddress.
- token - Variable in class convex.net.ChallengeRequest
- toString() - Method in class convex.api.Convex
- toString() - Method in class convex.api.ConvexDirect
- toString() - Method in class convex.api.ConvexLocal
- toString() - Method in class convex.api.ConvexRemote
- transact(ATransaction) - Method in class convex.api.Convex
-
Submits a transaction to the Convex network, returning a future once the transaction has been successfully queued.
- transact(ACell) - Method in class convex.api.Convex
-
Executes a transaction, compiling the given source code as an Invoke.
- transact(SignedData<ATransaction>) - Method in class convex.api.Convex
-
Submits a signed transaction to the Convex network, returning a Future once the transaction has been successfully queued.
- transact(SignedData<ATransaction>) - Method in class convex.api.ConvexDirect
- transact(SignedData<ATransaction>) - Method in class convex.api.ConvexLocal
- transact(SignedData<ATransaction>) - Method in class convex.api.ConvexRemote
- transact(String) - Method in class convex.api.Convex
-
Executes a transaction, compiling the given source code as an Invoke.
- TRANSACTION_QUEUE_SIZE - Static variable in class convex.peer.Config
-
Default size for incoming client transaction queue Note: this limits TPS for client transactions, will send failures if overloaded
- transactionHandler - Variable in class convex.peer.Server
-
Transaction handler instance.
- TransactionHandler - Class in convex.peer
-
Server component for handling client transactions and producing Blocks Main loop for this component handles client transaction messages, validates them and prepares them for inclusion in a Block
- TransactionHandler(Server) - Constructor for class convex.peer.TransactionHandler
- transactSync(ACell) - Method in class convex.api.Convex
-
Submits a transaction synchronously to the Convex network, returning a Result
- transactSync(ACell, long) - Method in class convex.api.Convex
-
Submits a signed transaction synchronously to the Convex network, returning a Result
- transactSync(SignedData<ATransaction>) - Method in class convex.api.Convex
-
Submits a transaction synchronously to the Convex network, returning a Result
- transactSync(SignedData<ATransaction>, long) - Method in class convex.api.Convex
-
Submits a signed transaction synchronously to the Convex network, returning a Result
- transactSync(String) - Method in class convex.api.Convex
-
Executes a transaction, compiling the given source code as an Invoke.
- transfer(Address, long) - Method in class convex.api.Convex
-
Submits a transfer transaction to the Convex network, returning a future once the transaction has been successfully queued.
- transferSync(Address, long) - Method in class convex.api.Convex
-
Submits a transfer transaction to the Convex network peer, and waits for confirmation of the result
- tryGetIP() - Static method in class convex.net.IPUtils
- tryGetWTF() - Static method in class convex.net.IPUtils
- txMessageQueue - Variable in class convex.peer.TransactionHandler
-
Queue for incoming (unverified) transaction messages
U
- UDPServer - Class in convex.net
- UDPServer() - Constructor for class convex.net.UDPServer
- updateBelief(Belief) - Method in class convex.peer.Server
-
Triggers CVM Executor Belief update
- USE_NETTY_CLIENT - Static variable in class convex.peer.Config
-
Flag to use Netty client connections
- USE_NETTY_SERVER - Static variable in class convex.peer.Config
-
Flag to use Netty server implementation
W
- waitForShutdown() - Method in class convex.peer.Server
- write(ByteBuffer) - Method in class convex.net.MemoryByteChannel
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form