- abbreviate($receiver, maxWidth) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- abort(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- abort() - Method in class net.corda.node.services.messaging.NodeLoginModule
-
- AbstractAttachment - Class in net.corda.core.contracts
-
- AbstractAttachment(dataLoader) - Constructor for class net.corda.core.contracts.AbstractAttachment
-
- AbstractAttachment.Companion - Class in net.corda.core.contracts
-
- AbstractCashFlow<T> - Class in net.corda.flows
-
Initiates a flow that produces an Issue/Move or Exit Cash transaction.
- AbstractCashFlow(progressTracker) - Constructor for class net.corda.flows.AbstractCashFlow
-
Initiates a flow that produces an Issue/Move or Exit Cash transaction.
- AbstractCashFlow.Companion - Class in net.corda.flows
-
- AbstractCashFlow.Result - Class in net.corda.flows
-
Combined signed transaction and identity lookup map, which is the resulting data from regular cash flows.
Specialised flows for unit tests differ from this.
- AbstractConserveAmount<S extends FungibleAsset<T>,C extends CommandData,T> - Class in net.corda.contracts.clause
-
Standardised clause for checking input/output balances of fungible assets. Requires that a
Move command is provided, and errors if absent. Must be the last clause under a grouping clause;
errors on no-match, ends on match.
- AbstractConserveAmount() - Constructor for class net.corda.contracts.clause.AbstractConserveAmount
-
Standardised clause for checking input/output balances of fungible assets. Requires that a
Move command is provided, and errors if absent. Must be the last clause under a grouping clause;
errors on no-match, ends on match.
- AbstractIssue<S extends ContractState,C extends CommandData,T> - Class in net.corda.contracts.clause
-
Standard issue clause for contracts that issue fungible assets.
- AbstractIssue(sum, sumOrZero) - Constructor for class net.corda.contracts.clause.AbstractIssue
-
Standard issue clause for contracts that issue fungible assets.
- AbstractJDBCHashMap<K,V,T extends JDBCHashedTable> - Class in net.corda.node.utilities
-
A base class for a JDBC table backed hash map that iterates in insertion order by using
an ever increasing sequence number on entries. Iterators supports remove() but entries are not really mutable and
do not support setValue() method from
MutableMap.MutableEntry.
- AbstractJDBCHashMap(table, loadOnInit, maxBuckets) - Constructor for class net.corda.node.utilities.AbstractJDBCHashMap
-
A base class for a JDBC table backed hash map that iterates in insertion order by using
an ever increasing sequence number on entries. Iterators supports remove() but entries are not really mutable and
do not support setValue() method from
MutableMap.MutableEntry.
- AbstractJDBCHashMap.Companion - Class in net.corda.node.utilities
-
- AbstractJDBCHashSet<K,T extends JDBCHashedTable> - Class in net.corda.node.utilities
-
Base class for JDBC backed hash set that delegates to a JDBC backed hash map where the values are all
Unit and not actually persisted. Iteration order is order of insertion. Iterators can remove().
- AbstractJDBCHashSet(table, loadOnInit, maxBuckets) - Constructor for class net.corda.node.utilities.AbstractJDBCHashSet
-
Base class for JDBC backed hash set that delegates to a JDBC backed hash map where the values are all
Unit and not actually persisted. Iteration order is order of insertion. Iterators can remove().
- AbstractNetworkMapService - Class in net.corda.node.services.network
-
Abstracted out core functionality as the basis for a persistent implementation, as well as existing in-memory implementation.
- AbstractNetworkMapService(services, minimumPlatformVersion) - Constructor for class net.corda.node.services.network.AbstractNetworkMapService
-
Abstracted out core functionality as the basis for a persistent implementation, as well as existing in-memory implementation.
- AbstractNetworkMapService.Companion - Class in net.corda.node.services.network
-
- AbstractNode - Class in net.corda.node.internal
-
A base node implementation that can be customised either for production (with real implementations that do real
I/O), or a mock implementation suitable for unit test environments.
- AbstractNode(configuration, advertisedServices, platformClock, busyNodeLatch) - Constructor for class net.corda.node.internal.AbstractNode
-
A base node implementation that can be customised either for production (with real implementations that do real
I/O), or a mock implementation suitable for unit test environments.
- AbstractNode.DatabaseConfigurationException - Exception in net.corda.node.internal
-
- AbstractNodeService - Class in net.corda.node.services.api
-
Abstract superclass for services that a node can host, which provides helper functions.
- AbstractNodeService(services) - Constructor for class net.corda.node.services.api.AbstractNodeService
-
Abstract superclass for services that a node can host, which provides helper functions.
- AbstractParty - Class in net.corda.core.identity
-
- AbstractParty(owningKey) - Constructor for class net.corda.core.identity.AbstractParty
-
- AbstractStateReplacementFlow - Class in net.corda.core.flows
-
Abstract flow to be used for replacing one state with another, for example when changing the notary of a state.
Notably this requires a one to one replacement of states, states cannot be split, merged or issued as part of these
flows.
- AbstractStateReplacementFlow() - Constructor for class net.corda.core.flows.AbstractStateReplacementFlow
-
Abstract flow to be used for replacing one state with another, for example when changing the notary of a state.
Notably this requires a one to one replacement of states, states cannot be split, merged or issued as part of these
flows.
- AbstractStateReplacementFlow.Acceptor<T> - Class in net.corda.core.flows
-
- AbstractStateReplacementFlow.Instigator<S extends ContractState,T extends ContractState,M> - Class in net.corda.core.flows
-
- AbstractStateReplacementFlow.Proposal<M> - Class in net.corda.core.flows
-
- AbstractStateReplacementFlow.UpgradeTx - Class in net.corda.core.flows
-
The assembled transaction for upgrading a contract.
- acceptableLiveFiberCountOnStop() - Method in class net.corda.node.internal.AbstractNode
-
- Acceptor(otherSide, progressTracker) - Constructor for class net.corda.core.flows.AbstractStateReplacementFlow.Acceptor
-
- Acceptor(otherParty, progressTracker) - Constructor for class net.corda.flows.TwoPartyDealFlow.Acceptor
-
One side of the flow for inserting a pre-agreed deal.
- Acceptor.Companion - Class in net.corda.core.flows
-
- accepts(type) - Method in interface net.corda.node.services.api.AcceptsFileUpload
-
Check if this service accepts this type of upload. For example if you are uploading interest rates this could
be "my-service-interest-rates". Type here does not refer to file extentions or MIME types.
- accepts($this, type) - Static method in class net.corda.node.services.api.AcceptsFileUpload.DefaultImpls
-
Check if this service accepts this type of upload. For example if you are uploading interest rates this could
be "my-service-interest-rates". Type here does not refer to file extentions or MIME types.
- accepts(type) - Method in interface net.corda.node.services.api.FileUploader
-
Check if this service accepts this type of upload. For example if you are uploading interest rates this could
be "my-service-interest-rates". Type here does not refer to file extentions or MIME types.
- AcceptsFileUpload - Interface in net.corda.node.services.api
-
A service that implements AcceptsFileUpload can have new binary data provided to it via an HTTP upload.
- AcceptsFileUpload.DefaultImpls - Class in net.corda.node.services.api
-
A service that implements AcceptsFileUpload can have new binary data provided to it via an HTTP upload.
- AccrualAdjustment - Enum in net.corda.contracts
-
Simple enum for returning accurals adjusted or unadjusted.
We don't actually do anything with this yet though, so it's ignored for now.
- AccrualAdjustment() - Constructor for enum net.corda.contracts.AccrualAdjustment
-
Simple enum for returning accurals adjusted or unadjusted.
We don't actually do anything with this yet though, so it's ignored for now.
- add(element) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- add(index, element) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- add(entry) - Method in class net.corda.core.serialization.GlobalTransientClassWhiteList
-
- add(entry) - Method in class net.corda.core.serialization.LoggingWhitelist
-
- add(entry) - Method in interface net.corda.core.serialization.MutableClassWhitelist
-
- add(p) - Method in class net.corda.core.utilities.NonEmptySet
-
- add(logic, flowInitiator) - Method in class net.corda.node.services.statemachine.StateMachineManager
-
Kicks off a brand new state machine of the given class.
The state machine will be persisted when it suspends, with automated restart if the StateMachineManager is
restarted with checkpointed state machines in the storage service.
- Add(logic) - Constructor for class net.corda.node.services.statemachine.Change.Add
-
- add(element) - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- addAll(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- addAll(index, elements) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- addAll(elements) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- addAll(p) - Method in class net.corda.core.utilities.NonEmptySet
-
- addAttachment(attachmentId) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addCheckpoint(checkpoint) - Method in interface net.corda.node.services.api.CheckpointStorage
-
Add a new checkpoint to the store.
- addCheckpoint(checkpoint) - Method in class net.corda.node.services.persistence.DBCheckpointStorage
-
Add a new checkpoint to the store.
- addCommand(arg) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addCommand(data, keys) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addCommand(data, keys) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addDepPair(type, dependant, dependee) - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
- Added(stateMachineInfo) - Constructor for class net.corda.core.messaging.StateMachineUpdate.Added
-
- Added(node) - Constructor for class net.corda.core.node.services.MapChange.Added
-
- addElementToInsert(insert, entry, finalizables) - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
Implementation should marshall the element to the insert statement.
- addElementToInsert(insert, entry, finalizables) - Method in class net.corda.node.utilities.JDBCHashSet
-
Implementation should marshall the element to the insert statement.
- addInputState(stateAndRef) - Method in class net.corda.core.contracts.NotaryChange.Builder
-
- addInputState(stateAndRef) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addKey(key, weight) - Method in class net.corda.core.crypto.composite.CompositeKey.Builder
-
Adds a child
class CompositeKey
node. Specifying a weight for the child is optional and will default to 1.
- addKeys(keys) - Method in class net.corda.core.crypto.composite.CompositeKey.Builder
-
- addKeys(keys) - Method in class net.corda.core.crypto.composite.CompositeKey.Builder
-
- addKeyToInsert(insert, entry, finalizables) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
Implementation should marshall the key to the insert statement.
- addKeyToInsert(insert, entry, finalizables) - Method in class net.corda.node.utilities.JDBCHashMap
-
Implementation should marshall the key to the insert statement.
- addListener(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- addListener(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- addListener(listener) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- addListener(listener) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- addMapping(stateMachineRunId, transactionId) - Method in interface net.corda.node.services.api.StateMachineRecordedTransactionMappingStorage
-
- addMapping(stateMachineRunId, transactionId) - Method in class net.corda.node.services.persistence.DBTransactionMappingStorage
-
- addMapping(stateMachineRunId, transactionId) - Method in class net.corda.node.services.persistence.InMemoryStateMachineRecordedTransactionMappingStorage
-
- addMapService(network, networkMapAddress, subscribe, ifChangedSinceVer) - Method in interface net.corda.node.services.api.NetworkMapCacheInternal
-
Add a network map service; fetches a copy of the latest map from the service and subscribes to any further
updates.
- addMapService(network, networkMapAddress, subscribe, ifChangedSinceVer) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
Add a network map service; fetches a copy of the latest map from the service and subscribes to any further
updates.
- addMessageHandler(topic, sessionID, callback) - Method in interface net.corda.node.services.messaging.MessagingService
-
The provided function will be invoked for each received message whose topic matches the given string. The callback
will run on threads provided by the messaging service, and the callback is expected to be thread safe as a result.
- addMessageHandler(topicSession, callback) - Method in interface net.corda.node.services.messaging.MessagingService
-
The provided function will be invoked for each received message whose topic and session matches. The callback
will run on the main server thread provided when the messaging service is constructed, and a database
transaction is set up for you automatically.
- addMessageHandler(topic, sessionID, callback) - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
The provided function will be invoked for each received message whose topic matches the given string. The callback
will run on threads provided by the messaging service, and the callback is expected to be thread safe as a result.
- addMessageHandler(topicSession, callback) - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
The provided function will be invoked for each received message whose topic and session matches. The callback
will run on the main server thread provided when the messaging service is constructed, and a database
transaction is set up for you automatically.
- addNode(node) - Method in interface net.corda.node.services.api.NetworkMapCacheInternal
-
Adds a node to the local cache (generally only used for adding ourselves).
- addNode(node) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
Adds a node to the local cache (generally only used for adding ourselves).
- addNoteToTransaction(txnId, noteText) - Method in interface net.corda.core.node.services.VaultService
-
Add a note to an existing
LedgerTransaction given by its unique
class SecureHash
id
Multiple notes may be attached to the same
LedgerTransaction.
These are additively and immutably persisted within the node local vault database in a single textual field
using a semi-colon separator
- addNoteToTransaction(txnId, noteText) - Method in class net.corda.node.services.vault.NodeVaultService
-
Add a note to an existing
LedgerTransaction given by its unique
class SecureHash
id
Multiple notes may be attached to the same
LedgerTransaction.
These are additively and immutably persisted within the node local vault database in a single textual field
using a semi-colon separator
- addNullabilityAnnotation(mv) - Method in class net.corda.core.serialization.carpenter.Field
-
- AddOrRemove - Enum in net.corda.node.utilities
-
Enum for when adding/removing something, for example adding or removing an entry in a directory.
- AddOrRemove() - Constructor for enum net.corda.node.utilities.AddOrRemove
-
Enum for when adding/removing something, for example adding or removing an entry in a directory.
- addOrReplaceCertificate($receiver, alias, cert) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Helper extension method to add, or overwrite any public certificate data in store.
- addOrReplaceKey($receiver, alias, key, password, chain) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Helper extension method to add, or overwrite any key data in store.
- addOrReplaceKey($receiver, alias, key, password, chain) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Helper extension method to add, or overwrite any key data in store.
- addOutputState(state) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addOutputState(state, notary, encumbrance) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addOutputState(state, notary) - Method in class net.corda.core.transactions.TransactionBuilder
-
- addOutputState(state) - Method in class net.corda.core.transactions.TransactionBuilder
-
A default notary must be specified during builder construction to use this method
- AddressUtils - Class in net.corda.node.utilities
-
- addSignature($this, signedTransaction, publicKey) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- addSignature($this, signedTransaction) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- addSignature(signedTransaction, publicKey) - Method in interface net.corda.core.node.ServiceHub
-
- addSignature(signedTransaction) - Method in interface net.corda.core.node.ServiceHub
-
Helper method to ap-pend an additional signature for an existing (partially)
class SignedTransaction
using the default identity signing key of the node.
- addSignature($this, signedTransaction, publicKey) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
- addSignature($this, signedTransaction) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
Helper method to ap-pend an additional signature for an existing (partially)
class SignedTransaction
using the default identity signing key of the node.
- addSignature($this, signedTransaction, publicKey) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- addSignature($this, signedTransaction) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- addSignatureUnchecked(sig) - Method in class net.corda.core.transactions.TransactionBuilder
-
Deprecated.
- addSuppressed(suppressed) - Method in exception net.corda.core.CordaException
-
- addSuppressed(suppressed) - Method in exception net.corda.core.CordaRuntimeException
-
- addSuppressed(suppressed) - Method in interface net.corda.core.CordaThrowable
-
- addToMap(ccy, amount) - Method in class net.corda.client.mock.EventGenerator
-
- addToWhitelist($receiver, type) - Static method in class net.corda.core.serialization.CordaClassResolverKt
-
- addToWhitelist(type) - Method in class net.corda.core.serialization.KryoSerializationCustomization
-
- addToWhitelist(type) - Method in interface net.corda.core.serialization.SerializationCustomization
-
- addTransaction(transaction) - Method in interface net.corda.node.services.api.WritableTransactionStorage
-
Add a new transaction to the store. If the store already has a transaction with the same id it will be
overwritten.
- addTransaction(transaction) - Method in class net.corda.node.services.persistence.DBTransactionStorage
-
Add a new transaction to the store. If the store already has a transaction with the same id it will be
overwritten.
- addValueToInsert(insert, entry, finalizables) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
Implementation should marshall the value to the insert statement.
- addValueToInsert(insert, entry, finalizables) - Method in class net.corda.node.utilities.JDBCHashMap
-
Implementation should marshall the value to the insert statement.
- addVaultTransactionNote(txnId, txnNote) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- addVaultTransactionNote(txnId, txnNote) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
- AffinityExecutor - Interface in net.corda.node.utilities
-
An extended executor interface that supports thread affinity assertions and short circuiting. This can be useful
for ensuring code runs on the right thread, and also for unit testing.
- AffinityExecutor.DefaultImpls - Class in net.corda.node.utilities
-
An extended executor interface that supports thread affinity assertions and short circuiting. This can be useful
for ensuring code runs on the right thread, and also for unit testing.
- AffinityExecutor.Gate - Class in net.corda.node.utilities
-
An executor useful for unit tests: allows the current thread to block until a command arrives from another
thread, which is then executed. Inbound closures/commands stack up until they are cleared by looping.
- AffinityExecutor.ServiceAffinityExecutor - Class in net.corda.node.utilities
-
An executor backed by thread pool (which may often have a single thread) which makes it easy to schedule
tasks in the future and verify code is running on the executor.
- AggregatedList<A,E,K> - Class in net.corda.client.jfx.utils
-
Given an ObservableList
and a grouping key K, class AggregatedList
groups the elements by the key into a fresh
ObservableList for each group and exposes the groups as an observable list of As by calling assemble on each.
- AggregatedList(list, toKey, assemble) - Constructor for class net.corda.client.jfx.utils.AggregatedList
-
Given an ObservableList
and a grouping key K, class AggregatedList
groups the elements by the key into a fresh
ObservableList for each group and exposes the groups as an observable list of As by calling assemble on each.
- AggregateFunction(type) - Constructor for class net.corda.core.node.services.vault.ColumnPredicate.AggregateFunction
-
- AggregateFunctionExpression(column, predicate, groupByColumns, orderBy) - Constructor for class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- AggregateFunctionType - Enum in net.corda.core.node.services.vault
-
- AggregateFunctionType() - Constructor for enum net.corda.core.node.services.vault.AggregateFunctionType
-
- AllButBlacklisted - Class in net.corda.core.serialization
-
This is a
interface ClassWhitelist
implementation where everything is whitelisted except for blacklisted classes and interfaces.
In practice, as flows are arbitrary code in which it is convenient to do many things,
we can often end up pulling in a lot of objects that do not make sense to put in a checkpoint.
Thus, by blacklisting classes/interfaces we don't expect to be serialised, we can better handle/monitor the aforementioned behaviour.
Inheritance works for blacklisted items, but one can specifically exclude classes from blacklisting as well.
- AllComposition<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Deprecated.
- AllComposition(firstClause, remainingClauses) - Constructor for class net.corda.core.contracts.clauses.AllComposition
-
Deprecated.
Compose a number of clauses, such that all of the clauses must run for verification to pass.
- AllOf<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Compose a number of clauses, such that all of the clauses must run for verification to pass.
- AllOf(firstClause, remainingClauses) - Constructor for class net.corda.core.contracts.clauses.AllOf
-
Compose a number of clauses, such that all of the clauses must run for verification to pass.
- AllPossibleRecipients - Interface in net.corda.core.messaging
-
A special base class for the set of all possible recipients, without having to identify who they all are.
- AllWhitelist - Class in net.corda.core.serialization
-
- alreadyLocked(body) - Method in class net.corda.core.internal.ThreadBox
-
- Amount<T> - Class in net.corda.core.contracts
-
Amount represents a positive quantity of some token (currency, asset, etc.), measured in quantity of the smallest
representable units. The nominal quantity represented by each individual token is equal to the displayTokenSize.
The scale property of the displayTokenSize should correctly reflect the displayed decimal places and is used
when rounding conversions from indicative/displayed amounts in
BigDecimal to Amount occur via the Amount.fromDecimal method.
- Amount(quantity, displayTokenSize, token) - Constructor for class net.corda.core.contracts.Amount
-
Amount represents a positive quantity of some token (currency, asset, etc.), measured in quantity of the smallest
representable units. The nominal quantity represented by each individual token is equal to the displayTokenSize.
The scale property of the displayTokenSize should correctly reflect the displayed decimal places and is used
when rounding conversions from indicative/displayed amounts in
BigDecimal to Amount occur via the Amount.fromDecimal method.
- Amount(tokenQuantity, token) - Constructor for class net.corda.core.contracts.Amount
-
Automatic conversion constructor from number of tokens to an Amount using getDisplayTokenSize to determine
the displayTokenSize.
- AMOUNT(amount, token) - Static method in class net.corda.core.contracts.ContractsDSL
-
- AMOUNT(amount, token) - Static method in class net.corda.core.contracts.ContractsDSL
-
- Amount.Companion - Class in net.corda.core.contracts
-
- AmountBindings - Class in net.corda.client.jfx.utils
-
Utility bindings for the
class Amount
type, similar in spirit to Bindings
- AmountKt - Class in net.corda.core.contracts
-
- AmountTransfer<T,P> - Class in net.corda.core.contracts
-
This class represents a possibly negative transfer of tokens from one vault state to another, possibly at a future date.
- AmountTransfer(quantityDelta, token, source, destination) - Constructor for class net.corda.core.contracts.AmountTransfer
-
This class represents a possibly negative transfer of tokens from one vault state to another, possibly at a future date.
- AmountTransfer.Companion - Class in net.corda.core.contracts
-
- AMQPCharPropertySerializer(name, readMethod) - Constructor for class net.corda.core.serialization.amqp.PropertySerializer.AMQPCharPropertySerializer
-
A property serializer for the AMQP char type, needed as a specialisation as the underlying
value of the character is stored in numeric UTF-16 form and on deserialisation requires explicit
casting back to a char otherwise it's treated as an Integer and a TypeMismatch occurs
- AMQPPrimitivePropertySerializer(name, readMethod, resolvedType) - Constructor for class net.corda.core.serialization.amqp.PropertySerializer.AMQPPrimitivePropertySerializer
-
A property serializer for most AMQP primitive type (Int, String, etc).
- AMQPPrimitiveSerializer - Class in net.corda.core.serialization.amqp
-
Serializer / deserializer for native AMQP types (Int, Float, String etc).
- AMQPPrimitiveSerializer(clazz) - Constructor for class net.corda.core.serialization.amqp.AMQPPrimitiveSerializer
-
Serializer / deserializer for native AMQP types (Int, Float, String etc).
- AMQPSchemaExtensionsKt - Class in net.corda.core.serialization.carpenter
-
- AMQPSerializer<T> - Interface in net.corda.core.serialization.amqp
-
Implemented to serialize and deserialize different types of objects to/from AMQP.
- and(criteria) - Method in class net.corda.core.node.services.vault.QueryCriteria
-
- andForget($receiver, log) - Static method in class net.corda.core.Utils
-
- anonymousFromKey(owningKey) - Method in interface net.corda.core.node.services.IdentityService
-
Get the certificate and path for a previously registered anonymous identity. These are used to prove an anonmyous
identity is owned by a well known identity.
- anonymousFromKey(owningKey) - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
Get the certificate and path for a previously registered anonymous identity. These are used to prove an anonmyous
identity is owned by a well known identity.
- AnonymousParty - Class in net.corda.core.identity
-
The
class AnonymousParty
class contains enough information to uniquely identify a
class Party
while excluding private
information such as name. It is intended to represent a party on the distributed ledger.
- AnonymousParty(owningKey) - Constructor for class net.corda.core.identity.AnonymousParty
-
The
class AnonymousParty
class contains enough information to uniquely identify a
class Party
while excluding private
information such as name. It is intended to represent a party on the distributed ledger.
- AnonymousPartyAndPath - Class in net.corda.core.identity
-
A pair of an anonymous party and the certificate path to prove it is owned by a well known identity. This class
does not validate the certificate path matches the party, and should not be trusted without being verified, for example
using
IdentityService.verifyAnonymousIdentity.
- AnonymousPartyAndPath(party, certPath) - Constructor for class net.corda.core.identity.AnonymousPartyAndPath
-
A pair of an anonymous party and the certificate path to prove it is owned by a well known identity. This class
does not validate the certificate path matches the party, and should not be trusted without being verified, for example
using
IdentityService.verifyAnonymousIdentity.
- AnonymousPartyAndPath(party, certPath) - Constructor for class net.corda.core.identity.AnonymousPartyAndPath
-
- ANSIProgressRenderer - Class in net.corda.node.utilities
-
Knows how to render a
class ProgressTracker
to the terminal using coloured, emoji-fied output. Useful when writing small
command line tools, demos, tests etc. Just set the progressTracker field and it will go ahead and start drawing
if the terminal supports it. Otherwise it just prints out the name of the step whenever it changes.
- AnyComposition<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Deprecated.
- AnyComposition(rawClauses) - Constructor for class net.corda.core.contracts.clauses.AnyComposition
-
Deprecated.
Compose a number of clauses, such that any number of the clauses can run.
- AnyOf<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Compose a number of clauses, such that one or more of the clauses can run.
- AnyOf(rawClauses) - Constructor for class net.corda.core.contracts.clauses.AnyOf
-
Compose a number of clauses, such that one or more of the clauses can run.
- AppContext - Class in net.corda.core.flows
-
This is just some way to track what attachments need to be in the class loader, but may later include some app
properties loaded from the attachments. And perhaps the authenticated user for an API call?
- AppContext(attachments) - Constructor for class net.corda.core.flows.AppContext
-
This is just some way to track what attachments need to be in the class loader, but may later include some app
properties loaded from the attachments. And perhaps the authenticated user for an API call?
- appendToCommonName($receiver, commonName) - Static method in class net.corda.core.crypto.X509UtilitiesKt
-
Rebuild the distinguished name, adding a postfix to the common name. If no common name is present.
- appExecuteBatch(command, mcs) - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- appExecuteUnordered(command, msgCtx) - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- apply(balances, newRef) - Method in class net.corda.core.contracts.AmountTransfer
-
Applies this AmountTransfer to a list of
class SourceAndAmount
objects representing balances.
The list can be heterogeneous in terms of token types and parties, so long as there is sufficient balance
of the correct token type held with the party paying for the transfer.
- applyRollConvention(testDate, dateRollConvention) - Method in class net.corda.contracts.BusinessCalendar
-
- ArgsParser - Class in net.corda.node
-
- ArgsParser() - Constructor for class net.corda.node.ArgsParser
-
- ArraySerializer - Class in net.corda.core.serialization.amqp
-
Serialization / deserialization of arrays.
- ArraySerializer(type, factory) - Constructor for class net.corda.core.serialization.amqp.ArraySerializer
-
Serialization / deserialization of arrays.
- ArraySerializer.Companion - Class in net.corda.core.serialization.amqp
-
- ArtemisMessagingServer - Class in net.corda.node.services.messaging
-
This class configures and manages an Apache Artemis message queue broker.
- ArtemisMessagingServer(config, p2pPort, rpcPort, networkMapCache, userService) - Constructor for class net.corda.node.services.messaging.ArtemisMessagingServer
-
This class configures and manages an Apache Artemis message queue broker.
- ArtemisMessagingServer.Companion - Class in net.corda.node.services.messaging
-
- assembleBareTx(stateRef, upgradedContractClass) - Method in class net.corda.core.flows.ContractUpgradeFlow.Companion
-
- assembleSharedTX(handshake) - Method in class net.corda.flows.TwoPartyDealFlow.Acceptor
-
- assembleSharedTX(handshake) - Method in class net.corda.flows.TwoPartyDealFlow.Secondary
-
- assembleTx() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Instigator
-
Build the upgrade transaction.
- assembleTx() - Method in class net.corda.core.flows.ContractUpgradeFlow
-
Build the upgrade transaction.
- assembleTx() - Method in class net.corda.core.flows.NotaryChangeFlow
-
Build the upgrade transaction.
- assertOwnership(party, anonymousParty) - Method in interface net.corda.core.node.services.IdentityService
-
Asserts that an anonymous party maps to the given full party, by looking up the certificate chain associated with
the anonymous party and resolving it back to the given full party.
- assertOwnership(party, anonymousParty) - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
Asserts that an anonymous party maps to the given full party, by looking up the certificate chain associated with
the anonymous party and resolving it back to the given full party.
- AssetMismatchException(expectedTypeName, typeName) - Constructor for exception net.corda.flows.TwoPartyTradeFlow.AssetMismatchException
-
- associateBy($receiver, toKey, assemble) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
data class Person(val height: Long)
val people: ObservableList = (..)
val nameToHeight: ObservableMap = people.associateBy(Person::name) { name, person -> person.height }
- associateBy($receiver, toKey) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val people: ObservableList = (..)
val nameToPerson: ObservableMap = people.associateBy(Person::name)
- associateByAggregation($receiver, toKey, assemble) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val people: ObservableList = (..)
val heightToNames: ObservableMap = people.associateByAggregation(Person::height) { name, person -> person.name }
- associateByAggregation($receiver, toKey) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val people: ObservableList = (..)
val heightToPeople: ObservableMap = people.associateByAggregation(Person::height)
- AssociatedList<K,A,B> - Class in net.corda.client.jfx.utils
-
class AssociatedList
creates an ObservableMap from an ObservableList by associating each list element with a unique key.
It is
not allowed to have several elements map to the same value!
- AssociatedList(sourceList, toKey, assemble) - Constructor for class net.corda.client.jfx.utils.AssociatedList
-
class AssociatedList
creates an ObservableMap from an ObservableList by associating each list element with a unique key.
It is
not allowed to have several elements map to the same value!
- at($receiver, dueBefore) - Static method in class net.corda.contracts.asset.ObligationKt
-
- Attachment - Interface in net.corda.core.contracts
-
An attachment is a ZIP (or an optionally signed JAR) that contains one or more files. Attachments are meant to
contain public static data which can be referenced from transactions and utilised from contracts. Good examples
of how attachments are meant to be used include:
- Attachment.DefaultImpls - Class in net.corda.core.contracts
-
An attachment is a ZIP (or an optionally signed JAR) that contains one or more files. Attachments are meant to
contain public static data which can be referenced from transactions and utilised from contracts. Good examples
of how attachments are meant to be used include:
- attachmentDataLoader($receiver, id) - Method in class net.corda.core.contracts.AbstractAttachment.Companion
-
- attachmentExists(id) - Method in interface net.corda.core.messaging.CordaRPCOps
-
Checks whether an attachment with the given hash is stored on the node.
- attachmentExists(id) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Checks whether an attachment with the given hash is stored on the node.
- AttachmentResolutionException - Exception in net.corda.core.contracts
-
- AttachmentResolutionException(hash) - Constructor for exception net.corda.core.contracts.AttachmentResolutionException
-
- attachments() - Method in class net.corda.core.transactions.TransactionBuilder
-
- attachments - Variable in class net.corda.node.internal.AbstractNode
-
- AttachmentsClassLoader - Class in net.corda.core.serialization
-
A custom ClassLoader that knows how to load classes from a set of attachments. The attachments themselves only
need to provide JAR streams, and so could be fetched from a database, local disk, etc. Constructing an
AttachmentsClassLoader is somewhat expensive, as every attachment is scanned to ensure that there are no overlapping
file paths.
- AttachmentsClassLoader(attachments, parent) - Constructor for class net.corda.core.serialization.AttachmentsClassLoader
-
A custom ClassLoader that knows how to load classes from a set of attachments. The attachments themselves only
need to provide JAR streams, and so could be fetched from a database, local disk, etc. Constructing an
AttachmentsClassLoader is somewhat expensive, as every attachment is scanned to ensure that there are no overlapping
file paths.
- AttachmentsClassLoader.OverlappingAttachments - Exception in net.corda.core.serialization
-
- AttachmentStorage - Interface in net.corda.core.node.services
-
An attachment store records potentially large binary objects, identified by their hash.
- AuditEvent - Class in net.corda.node.services.api
-
Minimum event specific data for any audit event to be logged. It is expected that the underlying audit service
will enrich this to include details of the node, so that in clustered configurations the source node can be identified.
- AuditService - Interface in net.corda.node.services.api
-
Minimal interface for recording audit information within the system. The AuditService is assumed to be available only
to trusted internal components via ServiceHubInternal.
- AuthenticatedObject<T> - Class in net.corda.core.contracts
-
Wraps an object that was signed by a public key, which may be a well known/recognised institutional key.
- AuthenticatedObject(signers, signingParties, value) - Constructor for class net.corda.core.contracts.AuthenticatedObject
-
Wraps an object that was signed by a public key, which may be a well known/recognised institutional key.
- authoriseContractUpgrade(state, upgradedContractClass) - Method in interface net.corda.core.messaging.CordaRPCOps
-
Authorise a contract state upgrade.
This will store the upgrade authorisation in the vault, and will be queried by
ContractUpgradeFlow.Acceptor during contract upgrade process.
Invoking this method indicate the node is willing to upgrade the state using the upgradedContractClass.
This method will NOT initiate the upgrade process. To start the upgrade process, see
ContractUpgradeFlow.Instigator.
- authoriseContractUpgrade(stateAndRef, upgradedContractClass) - Method in interface net.corda.core.node.services.VaultService
-
Authorise a contract state upgrade.
This will store the upgrade authorisation in the vault, and will be queried by
ContractUpgradeFlow.Acceptor during contract upgrade process.
Invoking this method indicate the node is willing to upgrade the
state using the upgradedContractClass.
This method will NOT initiate the upgrade process. To start the upgrade process, see
ContractUpgradeFlow.Instigator.
- authoriseContractUpgrade(state, upgradedContractClass) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Authorise a contract state upgrade.
This will store the upgrade authorisation in the vault, and will be queried by
ContractUpgradeFlow.Acceptor during contract upgrade process.
Invoking this method indicate the node is willing to upgrade the state using the upgradedContractClass.
This method will NOT initiate the upgrade process. To start the upgrade process, see
ContractUpgradeFlow.Instigator.
- authoriseContractUpgrade(stateAndRef, upgradedContractClass) - Method in class net.corda.node.services.vault.NodeVaultService
-
Authorise a contract state upgrade.
This will store the upgrade authorisation in the vault, and will be queried by
ContractUpgradeFlow.Acceptor during contract upgrade process.
Invoking this method indicate the node is willing to upgrade the
state using the upgradedContractClass.
This method will NOT initiate the upgrade process. To start the upgrade process, see
ContractUpgradeFlow.Instigator.
- AutoOffer(notary, dealBeingOffered) - Constructor for class net.corda.flows.TwoPartyDealFlow.AutoOffer
-
- avg($receiver, groupByColumns, orderBy) - Method in class net.corda.core.node.services.vault.Builder
-
- avg($receiver, groupByColumns, orderBy) - Static method in class net.corda.core.node.services.vault.Builder
-
- avg($receiver, groupByColumns) - Static method in class net.corda.core.node.services.vault.Builder
-
- avg($receiver) - Static method in class net.corda.core.node.services.vault.Builder
-
- awaitWithDeadline($receiver, deadline, future) - Static method in class net.corda.node.utilities.ClockUtilsKt
-
Wait until the given
Future is complete or the deadline is reached, with support for
class MutableClock
implementations
used in demos or testing. This will substitute a Fiber compatible Future so the current
co.paralleluniverse.strands.Strand is not blocked.
- calculateDaysBetween(startDate, endDate, dcbYear, dcbDay) - Static method in class net.corda.contracts.FinanceTypesKt
-
- calculateServices() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- call() - Method in class net.corda.core.contracts.TransactionGraphSearch
-
- call() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Acceptor
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Instigator
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.BroadcastTransactionFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.CollectSignaturesFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.FetchDataFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.FinalityFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.FlowLogic
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.NotaryFlow.Client
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.NotaryFlow.Service
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.ResolveTransactionsFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.SignTransactionFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.core.flows.TransactionKeyFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.CashExitFlow
-
- call() - Method in class net.corda.flows.CashIssueFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.CashPaymentFlow
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.IssuerFlow.IssuanceRequester
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.IssuerFlow.Issuer
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.TwoPartyDealFlow.Primary
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.TwoPartyDealFlow.Secondary
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.TwoPartyTradeFlow.Buyer
-
This is where you fill out your business logic.
- call() - Method in class net.corda.flows.TwoPartyTradeFlow.Seller
-
This is where you fill out your business logic.
- call() - Method in class net.corda.jackson.StringToMethodCallParser.ParsedMethodCall
-
- call() - Method in class net.corda.node.services.FetchDataHandler
-
This is where you fill out your business logic.
- call() - Method in class net.corda.node.services.NotifyTransactionHandler
-
This is where you fill out your business logic.
- call() - Method in class net.corda.node.services.TransactionKeyHandler
-
This is where you fill out your business logic.
- cancelRedelivery(retryId) - Method in interface net.corda.node.services.messaging.MessagingService
-
Cancels the scheduled message redelivery for the specified retryId
- cancelRedelivery(retryId) - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
Cancels the scheduled message redelivery for the specified retryId
- canDeserializeVersion(byteSequence, target) - Method in class net.corda.client.rpc.serialization.KryoClientSerializationScheme
-
- canDeserializeVersion(byteSequence, target) - Method in class net.corda.node.serialization.KryoServerSerializationScheme
-
- CarpenterClassLoader - Class in net.corda.core.serialization.carpenter
-
- CarpenterClassLoader() - Constructor for class net.corda.core.serialization.carpenter.CarpenterClassLoader
-
- carpenterSchema($receiver, loaders) - Static method in class net.corda.core.serialization.carpenter.AMQPSchemaExtensionsKt
-
- carpenterSchema($receiver, classLoaders, carpenterSchemas, force) - Static method in class net.corda.core.serialization.carpenter.AMQPSchemaExtensionsKt
-
based upon this AMQP schema either
a) add the corresponding carpenter schema to the carpenterSchemas param
b) add the class to the dependency tree in carpenterSchemas if it cannot be instantiated
at this time
- CarpenterSchemaConstructor - Static variable in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
- CarpenterSchemaFactory - Class in net.corda.core.serialization.carpenter
-
- CarpenterSchemas - Class in net.corda.core.serialization.carpenter
-
Generated from an AMQP schema this class represents the classes unknown to the deserialiser and that thusly
require carpenting up in bytecode form. This is a multi step process as carpenting one object may be depedent
upon the creation of others, this information is tracked in the dependency tree represented by
dependencies and dependsOn. Creatable classes are stored in carpenterSchemas.
- CarpenterSchemas(carpenterSchemas, dependencies, dependsOn) - Constructor for class net.corda.core.serialization.carpenter.CarpenterSchemas
-
Generated from an AMQP schema this class represents the classes unknown to the deserialiser and that thusly
require carpenting up in bytecode form. This is a multi step process as carpenting one object may be depedent
upon the creation of others, this information is tracked in the dependency tree represented by
dependencies and dependsOn. Creatable classes are stored in carpenterSchemas.
- CarpenterSchemas.CarpenterSchemaConstructor - Class in net.corda.core.serialization.carpenter
-
- Cash - Class in net.corda.contracts.asset
-
A cash transaction may split and merge money represented by a set of (issuer, depositRef) pairs, across multiple
input and output states. Imagine a Bitcoin transaction but in which all UTXOs had a colour
(a blend of issuer+depositRef) and you couldn't merge outputs of two colours together, but you COULD put them in
the same transaction.
- Cash() - Constructor for class net.corda.contracts.asset.Cash
-
A cash transaction may split and merge money represented by a set of (issuer, depositRef) pairs, across multiple
input and output states. Imagine a Bitcoin transaction but in which all UTXOs had a colour
(a blend of issuer+depositRef) and you couldn't merge outputs of two colours together, but you COULD put them in
the same transaction.
- Cash.Clauses - Interface in net.corda.contracts.asset
-
- Cash.Commands - Interface in net.corda.contracts.asset
-
- Cash.State - Class in net.corda.contracts.asset
-
A state representing a cash claim against some party.
- CashBalanceAsMetricsObserver - Class in net.corda.node.services.vault
-
This class observes the vault and reflect current cash balances as exposed metrics in the monitoring service.
- CashBalanceAsMetricsObserver(serviceHubInternal, database) - Constructor for class net.corda.node.services.vault.CashBalanceAsMetricsObserver
-
This class observes the vault and reflect current cash balances as exposed metrics in the monitoring service.
- CashException - Exception in net.corda.flows
-
- CashException(message, cause) - Constructor for exception net.corda.flows.CashException
-
- CashExitFlow - Class in net.corda.flows
-
Initiates a flow that produces an cash exit transaction.
- CashExitFlow(amount, issueRef, progressTracker) - Constructor for class net.corda.flows.CashExitFlow
-
Initiates a flow that produces an cash exit transaction.
- CashExitFlow(amount, issueRef) - Constructor for class net.corda.flows.CashExitFlow
-
- CashExitFlow.Companion - Class in net.corda.flows
-
- CashFlowCommand - Class in net.corda.flows
-
A command to initiate the cash flow with.
- CashFlowCommand.ExitCash - Class in net.corda.flows
-
Exit cash from the ledger.
- CashFlowCommand.IssueCash - Class in net.corda.flows
-
A command to initiate the Cash flow with.
- CashFlowCommand.PayCash - Class in net.corda.flows
-
Pay cash to someone else.
- CashIssueFlow - Class in net.corda.flows
-
Initiates a flow that produces cash issuance transaction.
- CashIssueFlow(amount, issueRef, recipient, notary, anonymous, progressTracker) - Constructor for class net.corda.flows.CashIssueFlow
-
Initiates a flow that produces cash issuance transaction.
- CashIssueFlow(amount, issueRef, recipient, notary) - Constructor for class net.corda.flows.CashIssueFlow
-
- CashIssueFlow(amount, issueRef, recipient, notary, anonymous) - Constructor for class net.corda.flows.CashIssueFlow
-
- CashKt - Class in net.corda.contracts.asset
-
- CashPaymentFlow - Class in net.corda.flows
-
Initiates a flow that sends cash to a recipient.
- CashPaymentFlow(amount, recipient, anonymous, progressTracker, issuerConstraint) - Constructor for class net.corda.flows.CashPaymentFlow
-
Initiates a flow that sends cash to a recipient.
- CashPaymentFlow(amount, recipient) - Constructor for class net.corda.flows.CashPaymentFlow
-
A straightforward constructor that constructs spends using cash states of any issuer.
- CashPaymentFlow(amount, recipient, anonymous) - Constructor for class net.corda.flows.CashPaymentFlow
-
A straightforward constructor that constructs spends using cash states of any issuer.
- CashSchema - Class in net.corda.schemas
-
An object used to fully qualify the
class CashSchema
family name (i.e. independent of version).
- CashSchemaV1 - Class in net.corda.schemas
-
First version of a cash contract ORM schema that maps all fields of the
Cash contract state as it stood
at the time of writing.
- CashSchemaV1.PersistentCashState - Class in net.corda.schemas
-
- castIfPossible($receiver, obj) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- catch($receiver, block) - Static method in class net.corda.core.Utils
-
Executes the given block and sets the future to either the result, or any exception that was thrown.
- CERT_CHAIN_CHECKS_OPTION_NAME - Static variable in class net.corda.node.services.messaging.NodeLoginModule
-
- CertChainPolicyConfig - Class in net.corda.node.services.config
-
- CertChainPolicyConfig(role, policy, trustedAliases) - Constructor for class net.corda.node.services.config.CertChainPolicyConfig
-
- CertChainPolicyType - Enum in net.corda.node.services.config
-
- CertChainPolicyType() - Constructor for enum net.corda.node.services.config.CertChainPolicyType
-
- certificate($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
-
Table column helpers for use with Exposed, as per
varchar etc.
- CertificateAndKeyPair - Class in net.corda.core.crypto
-
- CertificateAndKeyPair(certificate, keyPair) - Constructor for class net.corda.core.crypto.CertificateAndKeyPair
-
- certificateAndKeyPair(alias) - Method in class net.corda.node.utilities.KeyStoreWrapper
-
- CertificateChainCheckPolicy - Class in net.corda.node.services.messaging
-
- CertificateChainCheckPolicy.Any - Class in net.corda.node.services.messaging
-
- CertificateChainCheckPolicy.Check - Interface in net.corda.node.services.messaging
-
- CertificateChainCheckPolicy.LeafMustMatch - Class in net.corda.node.services.messaging
-
- CertificateChainCheckPolicy.MustContainOneOf - Class in net.corda.node.services.messaging
-
- CertificateChainCheckPolicy.RootMustMatch - Class in net.corda.node.services.messaging
-
- certificateFromKey(owningKey) - Method in interface net.corda.core.node.services.IdentityService
-
Get the certificate and path for a well known identity's owning key.
- certificateFromKey(owningKey) - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
Get the certificate and path for a well known identity's owning key.
- certificateFromParty(party) - Method in interface net.corda.core.node.services.IdentityService
-
Get the certificate and path for a well known identity.
- certificateFromParty(party) - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
Get the certificate and path for a well known identity.
- certificatePath($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
-
- CertificateRequestException - Exception in net.corda.node.utilities.registration
-
- CertificateRequestException(message) - Constructor for exception net.corda.node.utilities.registration.CertificateRequestException
-
- CertificateStream - Class in net.corda.core.crypto
-
- CertificateStream(input) - Constructor for class net.corda.core.crypto.CertificateStream
-
- CertificateType - Enum in net.corda.core.crypto
-
- CertificateType(keyUsage, purposes, isCA) - Constructor for enum net.corda.core.crypto.CertificateType
-
- CertPathColumnType - Class in net.corda.node.utilities
-
ColumnType for marshalling to/from database on behalf of
CertPath.
- CertPathSerializer - Class in net.corda.core.serialization
-
For serialising an
CertPath in an X.500 standard format.
- Change.Add - Class in net.corda.node.services.statemachine
-
- Change.Position - Class in net.corda.core.utilities
-
- Change.Removed - Class in net.corda.node.services.statemachine
-
- Change.Rendering - Class in net.corda.core.utilities
-
- Change.Structural - Class in net.corda.core.utilities
-
- char($receiver) - Static method in class net.corda.client.mock.GeneratorKt
-
- CharArraySerializer - Class in net.corda.core.serialization.amqp
-
- CharArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.CharArraySerializer
-
- check(tag) - Method in class net.corda.node.services.messaging.TopicStringValidator
-
- checkAndAddSignature(sig) - Method in class net.corda.core.transactions.TransactionBuilder
-
Deprecated.
- checkCertificateChain(theirChain) - Method in interface net.corda.node.services.messaging.CertificateChainCheckPolicy.Check
-
- checkFlowPermission(permissionName, extraAuditData) - Method in class net.corda.core.flows.FlowLogic
-
Flows can call this method to ensure that the active FlowInitiator is authorised for a particular action.
This provides fine grained control over application level permissions, when RPC control over starting the flow is insufficient,
or the permission is runtime dependent upon the choices made inside long lived flow code.
For example some users may have restricted limits on how much cash they can transfer, or whether they can change certain fields.
An audit event is always recorded whenever this method is used.
If the permission is not granted for the FlowInitiator a FlowException is thrown.
- checkFlowPermission(permissionName, extraAuditData) - Method in interface net.corda.core.internal.FlowStateMachine
-
- checkFlowPermission(permissionName, extraAuditData) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- checkInvariants() - Method in class net.corda.core.transactions.BaseTransaction
-
- checkNotLocked() - Method in class net.corda.core.internal.ThreadBox
-
- checkOnThread() - Method in interface net.corda.node.utilities.AffinityExecutor
-
Throws an IllegalStateException if the current thread is not one of the threads this executor is backed by.
- checkOnThread($this) - Static method in class net.corda.node.utilities.AffinityExecutor.DefaultImpls
-
Throws an IllegalStateException if the current thread is not one of the threads this executor is backed by.
- checkPayloadIs($receiver, type) - Static method in class net.corda.node.services.statemachine.SessionMessageKt
-
- Checkpoint - Class in net.corda.node.services.api
-
- Checkpoint(serializedFiber) - Constructor for class net.corda.node.services.api.Checkpoint
-
- checkpointStorage - Variable in class net.corda.node.internal.AbstractNode
-
- CheckpointStorage - Interface in net.corda.node.services.api
-
Thread-safe storage of fiber checkpoints.
- checkProposal(stx) - Method in class net.corda.flows.TwoPartyDealFlow.Instigator
-
- checkProposal(stx) - Method in class net.corda.flows.TwoPartyDealFlow.Primary
-
- checkSignature(sig) - Method in class net.corda.core.transactions.TransactionBuilder
-
Deprecated.
- checkSignature(sig) - Method in class net.corda.core.transactions.WireTransaction
-
Checks that the given signature matches one of the commands and that it is a correct signature over the tx.
- checkSignaturesAreValid() - Method in class net.corda.core.transactions.SignedTransaction
-
Mathematically validates the signatures that are present on this transaction. This does not imply that
the signatures are by the right keys, or that there are sufficient signatures, just that they aren't
corrupt. If you use this function directly you'll need to do the other checks yourself. Probably you
want verifySignaturesExcept instead.
- checkTransaction(stx) - Method in class net.corda.core.flows.SignTransactionFlow
-
The
SignTransactionFlow.checkTransaction
method allows the caller of this flow to provide some additional checks over the proposed
transaction received from the counter-party. For example:
- checkValidity() - Method in class net.corda.core.crypto.composite.CompositeKey
-
This method will detect graph cycles in the full composite key structure to protect against infinite loops when
traversing the graph and key duplicates in the each layer. It also checks if the threshold and weight constraint
requirements are met, while it tests for aggregated-weight integer overflow.
In practice, this method should be always invoked on the root
class CompositeKey
, as it inherently
validates the child nodes (all the way till the leaves).
TODO: Always call this method when deserialising
class CompositeKey
s.
- checkWithFun(checkingFun) - Method in class net.corda.core.transactions.FilteredLeaves
-
Function that checks the whole filtered structure.
Force type checking on a structure that we obtained, so we don't sign more than expected.
Example: Oracle is implemented to check only for commands, if it gets an attachment and doesn't expect it - it can sign
over a transaction with the attachment that wasn't verified. Of course it depends on how you implement it, but else -> false
should solve a problem with possible later extensions to WireTransaction.
- CHF - Static variable in class net.corda.core.contracts.ContractsDSL
-
- childProgressTracker() - Method in class net.corda.core.flows.Companion.NOTARISING
-
- childProgressTracker() - Method in class net.corda.core.utilities.ProgressTracker.Step
-
- childProgressTracker() - Method in class net.corda.flows.Buyer.COLLECTING_SIGNATURES
-
- childProgressTracker() - Method in class net.corda.flows.Companion.VERIFYING_AND_SIGNING
-
- choice(generators) - Method in class net.corda.client.mock.Generator.Companion
-
- Choice - Class in net.corda.core.serialization.amqp
-
- Choice(name, value) - Constructor for class net.corda.core.serialization.amqp.Choice
-
- Choice.Companion - Class in net.corda.core.serialization.amqp
-
- ChosenList<E> - Class in net.corda.client.jfx.utils
-
class ChosenList
manages an ObservableList that may be changed by the wrapping ObservableValue. Whenever the underlying
ObservableValue changes the exposed list changes to the new value. Changes to the list are simply propagated.
- ChosenList(chosenListObservable) - Constructor for class net.corda.client.jfx.utils.ChosenList
-
class ChosenList
manages an ObservableList that may be changed by the wrapping ObservableValue. Whenever the underlying
ObservableValue changes the exposed list changes to the new value. Changes to the list are simply propagated.
- CityDatabase - Class in net.corda.core.node
-
A simple lookup table of city names to their coordinates. Lookups are case insensitive.
- ClassCarpenter - Class in net.corda.core.serialization.carpenter
-
A class carpenter generates JVM bytecodes for a class given a schema and then loads it into a sub-classloader.
The generated classes have getters, a toString method and implement a simple property access interface. The
resulting class can then be accessed via reflection APIs, or cast to one of the requested interfaces.
- ClassCarpenter() - Constructor for class net.corda.core.serialization.carpenter.ClassCarpenter
-
A class carpenter generates JVM bytecodes for a class given a schema and then loads it into a sub-classloader.
The generated classes have getters, a toString method and implement a simple property access interface. The
resulting class can then be accessed via reflection APIs, or cast to one of the requested interfaces.
- ClassCarpenter.Companion - Class in net.corda.core.serialization.carpenter
-
- ClassSchema - Class in net.corda.core.serialization.carpenter
-
- ClassSchema(name, fields, superclass, interfaces) - Constructor for class net.corda.core.serialization.carpenter.ClassSchema
-
- ClassSerializer - Class in net.corda.core.serialization
-
- ClassWhitelist - Interface in net.corda.core.serialization
-
- Clause<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
A clause of a contract, containing a chunk of verification logic. That logic may be delegated to other clauses, or
provided directly by this clause.
- Clause() - Constructor for class net.corda.core.contracts.clauses.Clause
-
A clause of a contract, containing a chunk of verification logic. That logic may be delegated to other clauses, or
provided directly by this clause.
- Clause.Companion - Class in net.corda.core.contracts.clauses
-
- ClauseKt - Class in net.corda.core.contracts.clauses
-
- Clauses.ConserveAmount - Class in net.corda.contracts.asset
-
- Clauses.ConserveAmount - Class in net.corda.contracts.asset
-
Standard clause for conserving the amount from input to output.
- Clauses.ConserveAmount<P> - Class in net.corda.contracts.asset
-
Generic move/exit clause for fungible assets
- Clauses.Group - Class in net.corda.contracts.asset
-
- Clauses.Group - Class in net.corda.contracts.asset
-
Grouping clause to extract input and output states into matched groups and then run a set of clauses over
each group.
- Clauses.Group<P> - Class in net.corda.contracts.asset
-
Parent clause for clauses that operate on grouped states (those which are fungible).
- Clauses.Group - Class in net.corda.contracts
-
- Clauses.Issue - Class in net.corda.contracts.asset
-
- Clauses.Issue - Class in net.corda.contracts.asset
-
Standard issue clause, specialised to match the commodity issue command.
- Clauses.Issue<P> - Class in net.corda.contracts.asset
-
Generic issuance clause
- Clauses.Issue - Class in net.corda.contracts
-
- Clauses.Move - Class in net.corda.contracts
-
- Clauses.Net<C extends CommandData,P> - Class in net.corda.contracts.asset
-
Clause for supporting netting of obligations.
- Clauses.Redeem - Class in net.corda.contracts
-
- Clauses.SetLifecycle<P> - Class in net.corda.contracts.asset
-
Obligation-specific clause for changing the lifecycle of one or more states.
- Clauses.Settle<P> - Class in net.corda.contracts.asset
-
Obligation-specific clause for settling an outstanding obligation by witnessing
change of ownership of other states to fulfil
- Clauses.VerifyLifecycle<S extends ContractState,C extends CommandData,T,P> - Class in net.corda.contracts.asset
-
Obligation-specific clause for verifying that all states are in
normal lifecycle. In a group clause set, this must be run after
any lifecycle change clause, which is the only clause that involve
non-standard lifecycle states on input/output.
- ClauseVerifier - Class in net.corda.core.contracts.clauses
-
- ClauseVerifier() - Constructor for class net.corda.core.contracts.LinearState.ClauseVerifier
-
Standard clause to verify the LinearState safety properties.
- clear() - Method in class net.corda.client.jfx.utils.MapValuesList
-
- clear() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- clear() - Method in class net.corda.core.utilities.NonEmptySet
-
- clear() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- clear() - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- clearWarnings() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- Client(stx, progressTracker) - Constructor for class net.corda.core.flows.NotaryFlow.Client
-
A flow to be used by a party for obtaining signature(s) from a
class NotaryService
ascertaining the transaction
time-window is correct and none of its inputs have been used in another completed transaction.
- Client(stx) - Constructor for class net.corda.core.flows.NotaryFlow.Client
-
- Client(config, clientId) - Constructor for class net.corda.node.services.transactions.BFTSMaRt.Client
-
- Client.Companion - Class in net.corda.core.flows
-
- Client.Companion - Class in net.corda.node.services.transactions
-
- ClockUtilsKt - Class in net.corda.node.utilities
-
- close() - Method in class net.corda.client.rpc.CordaRPCConnection
-
- close() - Method in class net.corda.client.rpc.internal.RPCClientProxyHandler
-
Closes the RPC proxy. Reaps all observables, shuts down the reaper, closes all sessions and executors.
- close() - Method in class net.corda.core.internal.LazyPool
-
Closes the pool. Note that all borrowed instances must have been released before calling this function, otherwise
the returned iterable will be inaccurate.
- close() - Method in class net.corda.core.internal.LazyStickyPool
-
- close() - Method in interface net.corda.core.messaging.FlowHandle
-
Use this function for flows whose returnValue is not going to be used, so as to free up server resources.
- close() - Method in class net.corda.core.messaging.FlowHandleImpl
-
Use this function for flows whose returnValue is not going to be used, so as to free up server resources.
- close() - Method in interface net.corda.core.messaging.FlowProgressHandle
-
Use this function for flows whose returnValue and progress are not going to be used or tracked, so as to free up
server resources.
Note that it won't really close if one subscribes on progress Observable, but then forgets to unsubscribe.
- close() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
Use this function for flows whose returnValue and progress are not going to be used or tracked, so as to free up
server resources.
Note that it won't really close if one subscribes on progress Observable, but then forgets to unsubscribe.
- close() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- close() - Method in class net.corda.node.services.messaging.RPCServer
-
- close() - Method in class net.corda.node.services.persistence.NodeAttachmentService.HashCheckingStream
-
- close() - Method in class net.corda.node.services.transactions.PathManager
-
- close() - Method in class net.corda.node.utilities.CordaPersistence
-
- close() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- close() - Method in class net.corda.node.utilities.ExposedTransaction
-
- closeAll() - Method in class net.corda.node.shell.InteractiveShell.InputStreamDeserializer
-
- closeConnection(conn) - Method in class net.corda.node.services.database.HibernateConfiguration.NodeDatabaseConnectionProvider
-
- ClusterResponse.Error - Class in net.corda.node.services.transactions
-
- ClusterResponse.Signatures - Class in net.corda.node.services.transactions
-
- CmdLineOptions - Class in net.corda.node
-
- CmdLineOptions(baseDirectory, configFile, help, loggingLevel, logToConsole, isRegistration, isVersion, noLocalShell, sshdServer) - Constructor for class net.corda.node.CmdLineOptions
-
- CollectionExpression(operator, rightLiteral) - Constructor for class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
-
- CollectionOperator - Enum in net.corda.core.node.services.vault
-
- CollectionOperator() - Constructor for enum net.corda.core.node.services.vault.CollectionOperator
-
- CollectionSerializer - Class in net.corda.core.serialization.amqp
-
Serialization / deserialization of predefined set of supported
Collection types covering mostly
Lists and
Sets.
- CollectionSerializer(declaredType, factory) - Constructor for class net.corda.core.serialization.amqp.CollectionSerializer
-
Serialization / deserialization of predefined set of supported
Collection types covering mostly
Lists and
Sets.
- CollectionSerializer.Companion - Class in net.corda.core.serialization.amqp
-
- CollectSignaturesFlow - Class in net.corda.core.flows
-
- CollectSignaturesFlow(partiallySignedTx, progressTracker) - Constructor for class net.corda.core.flows.CollectSignaturesFlow
-
- CollectSignaturesFlow.Companion - Class in net.corda.core.flows
-
- Column<O,C> - Class in net.corda.core.node.services.vault
-
- Column(name, declaringClass) - Constructor for class net.corda.core.node.services.vault.Column
-
- Column(field) - Constructor for class net.corda.core.node.services.vault.Column
-
- Column(property) - Constructor for class net.corda.core.node.services.vault.Column
-
- ColumnPredicate<C> - Class in net.corda.core.node.services.vault
-
- ColumnPredicate.AggregateFunction<C> - Class in net.corda.core.node.services.vault
-
- ColumnPredicate.Between<C extends Comparable<? super C>> - Class in net.corda.core.node.services.vault
-
- ColumnPredicate.BinaryComparison<C extends Comparable<? super C>> - Class in net.corda.core.node.services.vault
-
- ColumnPredicate.CollectionExpression<C> - Class in net.corda.core.node.services.vault
-
- ColumnPredicate.EqualityComparison<C> - Class in net.corda.core.node.services.vault
-
- ColumnPredicate.Likeness - Class in net.corda.core.node.services.vault
-
- ColumnPredicate.NullExpression<C> - Class in net.corda.core.node.services.vault
-
- ColumnPredicateExpression(column, predicate) - Constructor for class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
-
- combine(other1, function) - Method in class net.corda.client.mock.Generator
-
- combine(other1, other2, function) - Method in class net.corda.client.mock.Generator
-
- combine(other1, other2, other3, function) - Method in class net.corda.client.mock.Generator
-
- combine(other1, other2, other3, other4, function) - Method in class net.corda.client.mock.Generator
-
- combine(other, function) - Method in class net.corda.core.utilities.Try
-
- Command<T extends CommandData> - Class in net.corda.core.contracts
-
Command data/content plus pubkey pair: the signature is stored at the end of the serialized bytes
- Command(value, signers) - Constructor for class net.corda.core.contracts.Command
-
Command data/content plus pubkey pair: the signature is stored at the end of the serialized bytes
- Command(data, key) - Constructor for class net.corda.core.contracts.Command
-
- CommandData - Interface in net.corda.core.contracts
-
Marker interface for classes that represent commands
- commands() - Method in class net.corda.core.transactions.TransactionBuilder
-
- Commands.Exit - Class in net.corda.contracts.asset
-
A command stating that money has been withdrawn from the shared ledger and is now accounted for
in some other way.
- Commands.Exit - Class in net.corda.contracts.asset
-
A command stating that money has been withdrawn from the shared ledger and is now accounted for
in some other way.
- Commands.Exit<P> - Class in net.corda.contracts.asset
-
A command stating that the debt is being released by the beneficiary. Normally would indicate
either settlement outside of the ledger, or that the obligor is unable to pay.
- Commands.Exit<T> - Interface in net.corda.core.contracts
-
A command stating that money has been withdrawn from the shared ledger and is now accounted for
in some other way.
- Commands.Get<K,V> - Class in net.corda.node.services.transactions
-
- Commands.Issue - Class in net.corda.contracts.asset
-
Allows new cash states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- Commands.Issue - Class in net.corda.contracts.asset
-
Allows new commodity states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- Commands.Issue - Class in net.corda.contracts.asset
-
Allows new obligation states to be issued into existence: the nonce ("number used once") ensures the
transaction has a unique ID even when there are no inputs.
- Commands.Issue - Class in net.corda.contracts
-
- Commands.Issue - Class in net.corda.contracts
-
- Commands.Issue - Interface in net.corda.core.contracts
-
Allows new asset states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- Commands.Move - Class in net.corda.contracts.asset
-
A command stating that money has been moved, optionally to fulfil another contract.
- Commands.Move - Class in net.corda.contracts.asset
-
A command stating that money has been moved, optionally to fulfil another contract.
- Commands.Move - Class in net.corda.contracts.asset
-
A command stating that a debt has been moved, optionally to fulfil another contract.
- Commands.Move - Class in net.corda.contracts
-
- Commands.Move - Class in net.corda.contracts
-
- Commands.Move - Interface in net.corda.core.contracts
-
- Commands.Net - Class in net.corda.contracts.asset
-
Net two or more obligation states together in a close-out netting style. Limited to bilateral netting
as only the beneficiary (not the obligor) needs to sign.
- Commands.PutAll<K,V> - Class in net.corda.node.services.transactions
-
- Commands.Redeem - Class in net.corda.contracts
-
- Commands.Redeem - Class in net.corda.contracts
-
- Commands.SetLifecycle - Class in net.corda.contracts.asset
-
A command stating that the beneficiary is moving the contract into the defaulted state as it has not been settled
by the due date, or resetting a defaulted contract back to the issued state.
- Commands.Settle<P> - Class in net.corda.contracts.asset
-
A command stating that the obligor is settling some or all of the amount owed by transferring a suitable
state object to the beneficiary. If this reduces the balance to zero, the state object is destroyed.
- Commands.Size - Class in net.corda.node.services.transactions
-
- commandsOfType(clazz) - Method in class net.corda.core.transactions.LedgerTransaction
-
- CommercialPaper - Class in net.corda.contracts
-
- CommercialPaper() - Constructor for class net.corda.contracts.CommercialPaper
-
- CommercialPaper.Clauses - Interface in net.corda.contracts
-
- CommercialPaper.Commands - Interface in net.corda.contracts
-
- CommercialPaper.State - Class in net.corda.contracts
-
- CommercialPaper.Terms - Class in net.corda.contracts
-
- CommercialPaperKt - Class in net.corda.contracts
-
- CommercialPaperLegacy - Class in net.corda.contracts
-
- CommercialPaperLegacy() - Constructor for class net.corda.contracts.CommercialPaperLegacy
-
- CommercialPaperLegacy.Commands - Interface in net.corda.contracts
-
- CommercialPaperLegacy.State - Class in net.corda.contracts
-
- CommercialPaperLegacyKt - Class in net.corda.contracts
-
- CommercialPaperSchema - Class in net.corda.schemas
-
- CommercialPaperSchemaV1 - Class in net.corda.schemas
-
First version of a commercial paper contract ORM schema that maps all fields of the
CommercialPaper contract state
as it stood at the time of writing.
- CommercialPaperSchemaV1.PersistentCommercialPaperState - Class in net.corda.schemas
-
- commit(states, txId, callerIdentity) - Method in interface net.corda.core.node.services.UniquenessProvider
-
Commits all input states of the given transaction
- commit() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- commit() - Method in class net.corda.node.services.messaging.NodeLoginModule
-
- commit(states, txId, callerIdentity) - Method in class net.corda.node.services.transactions.PersistentUniquenessProvider
-
Commits all input states of the given transaction
- commit(states, txId, callerIdentity) - Method in class net.corda.node.services.transactions.RaftUniquenessProvider
-
Commits all input states of the given transaction
- commit() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- commit() - Method in class net.corda.node.utilities.ExposedTransaction
-
- commitInputStates(inputs, txId, caller) - Method in class net.corda.core.node.services.TrustedAuthorityNotaryService
-
A NotaryException is thrown if any of the states have been consumed by a different transaction. Note that
this method does not throw an exception when input states are present multiple times within the transaction.
- commitInputStates(states, txId, callerIdentity) - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- CommitRequest(tx, callerIdentity) - Constructor for class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
-
- commitTransaction(tx, otherSide) - Method in class net.corda.node.services.transactions.BFTNonValidatingNotaryService
-
- commitTransaction(transaction, otherSide) - Method in class net.corda.node.services.transactions.BFTSMaRt.Client
-
Sends a transaction commit request to the BFT cluster. The proxy will deliver the request to every
replica, and block until a sufficient number of replies are received.
- Commodity - Class in net.corda.contracts
-
Class representing a commodity, as an equivalent to the
Currency class. This exists purely to enable the
CommodityContract contract, and is likely to change in future.
- Commodity(commodityCode, displayName, defaultFractionDigits) - Constructor for class net.corda.contracts.Commodity
-
Class representing a commodity, as an equivalent to the
Currency class. This exists purely to enable the
CommodityContract contract, and is likely to change in future.
- Commodity.Companion - Class in net.corda.contracts
-
- CommodityContract - Class in net.corda.contracts.asset
-
A commodity contract represents an amount of some commodity, tracked on a distributed ledger. The design of this
contract is intentionally similar to the
class Cash
contract, and the same commands (issue, move, exit) apply, the
differences are in representation of the underlying commodity. Issuer in this context means the party who has the
commodity, or is otherwise responsible for delivering the commodity on demand, and the deposit reference is use for
internal accounting by the issuer (it might be, for example, a warehouse and/or location within a warehouse).
- CommodityContract() - Constructor for class net.corda.contracts.asset.CommodityContract
-
A commodity contract represents an amount of some commodity, tracked on a distributed ledger. The design of this
contract is intentionally similar to the
class Cash
contract, and the same commands (issue, move, exit) apply, the
differences are in representation of the underlying commodity. Issuer in this context means the party who has the
commodity, or is otherwise responsible for delivering the commodity on demand, and the deposit reference is use for
internal accounting by the issuer (it might be, for example, a warehouse and/or location within a warehouse).
- CommodityContract.Clauses - Interface in net.corda.contracts.asset
-
The clauses for this contract are essentially:
- CommodityContract.Commands - Interface in net.corda.contracts.asset
-
- CommodityContract.State - Class in net.corda.contracts.asset
-
A state representing a commodity claim against some party
- CommodityContractKt - Class in net.corda.contracts.asset
-
- CommonQueryCriteria() - Constructor for class net.corda.core.node.services.vault.QueryCriteria.CommonQueryCriteria
-
- CommonSchema - Class in net.corda.core.schemas
-
JPA representation of the common schema entities
- CommonSchemaV1 - Class in net.corda.core.schemas
-
First version of the Vault ORM schema
- CommonSchemaV1.FungibleState - Class in net.corda.core.schemas
-
- CommonSchemaV1.LinearState - Class in net.corda.core.schemas
-
- CommonSchemaV1.Party - Class in net.corda.core.schemas
-
Party entity (to be replaced by referencing final Identity Schema)
- CommonStateAttribute(attributeParent, attributeChild) - Constructor for enum net.corda.core.node.services.vault.Sort.CommonStateAttribute
-
- compaction() - Method in class net.corda.node.services.transactions.Commands.PutAll
-
- Companion - Static variable in class net.corda.client.jfx.model.ContractStateModel
-
- Companion - Static variable in class net.corda.client.jfx.model.PartiallyResolvedTransaction
-
- Companion - Static variable in class net.corda.client.jfx.model.ProgressTrackingEvent
-
- Companion - Static variable in class net.corda.client.jfx.utils.MapValuesList
-
- Companion - Static variable in class net.corda.client.mock.Generator
-
- Companion - Static variable in class net.corda.client.rpc.CordaRPCClient
-
- Companion - Static variable in class net.corda.client.rpc.CordaRPCClientConfiguration
-
- Companion - Static variable in class net.corda.client.rpc.internal.RPCClient
-
- Companion - Static variable in class net.corda.client.rpc.internal.RPCClientConfiguration
-
- Companion - Static variable in class net.corda.client.rpc.internal.RPCClientProxyHandler
-
- Companion - Static variable in class net.corda.contracts.asset.OnLedgerAsset
-
- Companion - Static variable in class net.corda.contracts.BusinessCalendar
-
- Companion - Static variable in class net.corda.contracts.clause.AbstractConserveAmount
-
- Companion - Static variable in class net.corda.contracts.Commodity
-
- Companion - Static variable in class net.corda.core.contracts.AbstractAttachment
-
- Companion - Static variable in class net.corda.core.contracts.Amount
-
- Companion - Static variable in class net.corda.core.contracts.AmountTransfer
-
- Companion - Static variable in class net.corda.core.contracts.clauses.Clause
-
- Companion - Static variable in class net.corda.core.contracts.clauses.FirstOf
-
- Companion - Static variable in class net.corda.core.contracts.TimeWindow
-
- Companion - Static variable in class net.corda.core.contracts.UniqueIdentifier
-
- Companion - Static variable in class net.corda.core.crypto.composite.CompositeKey
-
- Companion - Static variable in class net.corda.core.crypto.composite.CompositeSignature
-
- Companion - Static variable in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
-
- Companion - Static variable in class net.corda.core.crypto.MerkleTree
-
- Companion - Static variable in class net.corda.core.crypto.PartialMerkleTree
-
- Companion - Static variable in class net.corda.core.crypto.provider.CordaSecurityProvider
-
- Companion - Static variable in class net.corda.core.crypto.SecureHash
-
- Companion - Static variable in class net.corda.core.flows.AbstractStateReplacementFlow.Acceptor
-
- Companion - Static variable in class net.corda.core.flows.AbstractStateReplacementFlow.Instigator
-
- Companion - Static variable in class net.corda.core.flows.CollectSignaturesFlow
-
- Companion - Static variable in class net.corda.core.flows.ContractUpgradeFlow
-
- Companion - Static variable in class net.corda.core.flows.FinalityFlow
-
- Companion - Static variable in class net.corda.core.flows.NotaryFlow.Client
-
- Companion - Static variable in class net.corda.core.flows.ResolveTransactionsFlow
-
- Companion - Static variable in class net.corda.core.flows.SignTransactionFlow
-
- Companion - Static variable in class net.corda.core.flows.StateMachineRunId
-
- Companion - Static variable in class net.corda.core.flows.TransactionKeyFlow
-
- Companion - Static variable in class net.corda.core.internal.InputStreamAndHash
-
- Companion - Static variable in class net.corda.core.node.services.ServiceInfo
-
- Companion - Static variable in class net.corda.core.node.services.ServiceType
-
- Companion - Static variable in class net.corda.core.node.services.Vault
-
- Companion - Static variable in class net.corda.core.serialization.amqp.ArraySerializer
-
- Companion - Static variable in class net.corda.core.serialization.amqp.Choice
-
- Companion - Static variable in class net.corda.core.serialization.amqp.CollectionSerializer
-
- Companion - Static variable in class net.corda.core.serialization.amqp.CompositeType
-
- Companion - Static variable in class net.corda.core.serialization.amqp.Descriptor
-
- Companion - Static variable in class net.corda.core.serialization.amqp.DeserializedParameterizedType
-
- Companion - Static variable in class net.corda.core.serialization.amqp.Envelope
-
- Companion - Static variable in class net.corda.core.serialization.amqp.Field
-
- Companion - Static variable in class net.corda.core.serialization.amqp.MapSerializer
-
- Companion - Static variable in class net.corda.core.serialization.amqp.PrimArraySerializer
-
- Companion - Static variable in class net.corda.core.serialization.amqp.PropertySerializer
-
- Companion - Static variable in class net.corda.core.serialization.amqp.RestrictedType
-
- Companion - Static variable in class net.corda.core.serialization.amqp.Schema
-
- Companion - Static variable in class net.corda.core.serialization.amqp.SerializerFactory
-
- Companion - Static variable in class net.corda.core.serialization.amqp.TypeNotation
-
- Companion - Static variable in class net.corda.core.serialization.carpenter.ClassCarpenter
-
- Companion - Static variable in class net.corda.core.serialization.carpenter.Field
-
- Companion - Static variable in class net.corda.core.serialization.GlobalTransientClassWhiteList
-
- Companion - Static variable in class net.corda.core.serialization.LoggingWhitelist
-
- Companion - Static variable in class net.corda.core.serialization.SingletonSerializationToken
-
- Companion - Static variable in class net.corda.core.transactions.FilteredTransaction
-
- Companion - Static variable in class net.corda.core.utilities.ByteSequence
-
- Companion - Static variable in class net.corda.core.utilities.NetworkHostAndPort
-
- Companion - Static variable in class net.corda.core.utilities.NonEmptySet
-
- Companion - Static variable in class net.corda.core.utilities.OpaqueBytes
-
- Companion - Static variable in class net.corda.core.utilities.Try
-
- Companion - Static variable in class net.corda.flows.AbstractCashFlow
-
- Companion - Static variable in class net.corda.flows.CashExitFlow
-
- Companion - Static variable in class net.corda.flows.IssuerFlow.Issuer
-
- Companion - Static variable in class net.corda.flows.TwoPartyDealFlow.Primary
-
- Companion - Static variable in class net.corda.flows.TwoPartyDealFlow.Secondary
-
- Companion - Static variable in class net.corda.flows.TwoPartyTradeFlow.Seller
-
- Companion - Static variable in class net.corda.jackson.StringToMethodCallParser
-
- Companion - Static variable in class net.corda.node.internal.CordaRPCOpsImpl
-
- Companion - Static variable in class net.corda.node.internal.Node
-
- Companion - Static variable in class net.corda.node.internal.NodeStartup
-
- Companion - Static variable in interface net.corda.node.services.api.RegulatorService
-
- Companion - Static variable in interface net.corda.node.services.api.ServiceHubInternal
-
- Companion - Static variable in class net.corda.node.services.database.HibernateConfiguration
-
- Companion - Static variable in class net.corda.node.services.database.RequeryConfiguration
-
- Companion - Static variable in class net.corda.node.services.events.NodeSchedulerService
-
- Companion - Static variable in class net.corda.node.services.identity.InMemoryIdentityService
-
- Companion - Static variable in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- Companion - Static variable in class net.corda.node.services.messaging.NodeLoginModule
-
- Companion - Static variable in class net.corda.node.services.messaging.NodeMessagingClient
-
- Companion - Static variable in class net.corda.node.services.messaging.ObservableContext
-
- Companion - Static variable in class net.corda.node.services.messaging.RPCServer
-
- Companion - Static variable in class net.corda.node.services.messaging.RPCServerConfiguration
-
- Companion - Static variable in class net.corda.node.services.network.AbstractNetworkMapService
-
- Companion - Static variable in class net.corda.node.services.network.InMemoryNetworkMapCache
-
- Companion - Static variable in interface net.corda.node.services.network.NetworkMapService
-
- Companion - Static variable in class net.corda.node.services.persistence.NodeAttachmentService
-
- Companion - Static variable in class net.corda.node.services.schema.HibernateObserver
-
- Companion - Static variable in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- Companion - Static variable in class net.corda.node.services.statemachine.StateMachineManager
-
- Companion - Static variable in class net.corda.node.services.TransactionKeyHandler
-
- Companion - Static variable in class net.corda.node.services.transactions.BFTNonValidatingNotaryService
-
- Companion - Static variable in class net.corda.node.services.transactions.BFTSMaRt.Client
-
- Companion - Static variable in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- Companion - Static variable in class net.corda.node.services.transactions.BFTSMaRtConfig
-
- Companion - Static variable in class net.corda.node.services.transactions.DistributedImmutableMap
-
- Companion - Static variable in class net.corda.node.services.transactions.OutOfProcessTransactionVerifierService
-
- Companion - Static variable in class net.corda.node.services.transactions.PersistentUniquenessProvider
-
- Companion - Static variable in class net.corda.node.services.transactions.RaftNonValidatingNotaryService
-
- Companion - Static variable in class net.corda.node.services.transactions.RaftUniquenessProvider
-
- Companion - Static variable in class net.corda.node.services.transactions.RaftValidatingNotaryService
-
- Companion - Static variable in class net.corda.node.services.transactions.SimpleNotaryService
-
- Companion - Static variable in class net.corda.node.services.transactions.ValidatingNotaryService
-
- Companion - Static variable in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- Companion - Static variable in class net.corda.node.services.vault.HibernateVaultQueryImpl
-
- Companion - Static variable in class net.corda.node.services.vault.NodeVaultService
-
- Companion - Static variable in class net.corda.node.services.vault.VaultSoftLockManager
-
- Companion - Static variable in class net.corda.node.utilities.AbstractJDBCHashMap
-
- Companion - Static variable in class net.corda.node.utilities.AffinityExecutor.ServiceAffinityExecutor
-
- Companion - Static variable in class net.corda.node.utilities.CordaPersistence
-
- Companion - Static variable in class net.corda.node.utilities.DatabaseTransactionManager
-
- Companion - Static variable in class net.corda.node.utilities.ExposedTransactionManager
-
- Companion - Static variable in class net.corda.node.utilities.registration.HTTPNetworkRegistrationService
-
- Companion - Static variable in class net.corda.node.utilities.registration.NetworkRegistrationHelper
-
- Companion.APPROVING - Class in net.corda.core.flows
-
- Companion.AWAITING_KEY - Class in net.corda.core.flows
-
- Companion.AWAITING_PROPOSAL - Class in net.corda.flows
-
- Companion.AWAITING_REQUEST - Class in net.corda.flows
-
- Companion.BROADCASTING - Class in net.corda.core.flows
-
- Companion.COLLECTING - Class in net.corda.core.flows
-
- Companion.COLLECTING_SIGNATURES - Class in net.corda.flows
-
- Companion.COPYING_TO_COUNTERPARTY - Class in net.corda.flows
-
- Companion.COPYING_TO_REGULATOR - Class in net.corda.flows
-
- Companion.FINALISING_TX - Class in net.corda.flows
-
- Companion.GENERATING_ID - Class in net.corda.flows
-
- Companion.GENERATING_TX - Class in net.corda.flows
-
- Companion.ISSUING - Class in net.corda.flows
-
- Companion.NOTARISING - Class in net.corda.core.flows
-
- Companion.NOTARY - Class in net.corda.core.flows
-
- Companion.RECEIVING - Class in net.corda.core.flows
-
- Companion.RECEIVING - Class in net.corda.flows
-
- Companion.RECORDING - Class in net.corda.flows
-
- Companion.REQUESTING - Class in net.corda.core.flows
-
- Companion.SENDING_CONFIRM - Class in net.corda.flows
-
- Companion.SENDING_KEY - Class in net.corda.node.services
-
- Companion.SENDING_PROPOSAL - Class in net.corda.flows
-
- Companion.SIGNING - Class in net.corda.core.flows
-
- Companion.SIGNING - Class in net.corda.core.flows
-
- Companion.SIGNING - Class in net.corda.flows
-
- Companion.SIGNING_TX - Class in net.corda.flows
-
- Companion.TRANSFERRING - Class in net.corda.flows
-
- Companion.VALIDATING - Class in net.corda.core.flows
-
- Companion.VERIFYING - Class in net.corda.core.flows
-
- Companion.VERIFYING - Class in net.corda.core.flows
-
- Companion.VERIFYING - Class in net.corda.core.flows
-
- Companion.VERIFYING - Class in net.corda.flows
-
- Companion.VERIFYING_AND_SIGNING - Class in net.corda.flows
-
- compare(operator, value) - Method in class net.corda.core.node.services.vault.Builder
-
- comparePredicate($receiver, operator, value) - Method in class net.corda.core.node.services.vault.Builder
-
- comparePredicate($receiver, operator, value) - Method in class net.corda.core.node.services.vault.Builder
-
- compareTo(other) - Method in class net.corda.core.contracts.Amount
-
- compareTo(other) - Method in class net.corda.core.contracts.UniqueIdentifier
-
- compareTo(other) - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
-
- compareTo(other) - Method in class net.corda.core.crypto.testing.DummyPublicKey
-
Deprecated.
- compareTo(other) - Method in class net.corda.core.crypto.testing.NullPublicKey
-
- compareTo(other) - Method in class net.corda.core.utilities.ByteSequence
-
Compare byte arrays byte by byte. Arrays that are shorter are deemed less than longer arrays if all the bytes
of the shorter array equal those in the same position of the longer array.
- component1() - Method in class net.corda.client.jfx.model.Diff
-
- component1() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
-
- component1() - Method in class net.corda.client.jfx.model.InputResolution.Resolved
-
- component1() - Method in class net.corda.client.jfx.model.InputResolution.Unresolved
-
- component1() - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
-
- component1() - Method in class net.corda.client.rpc.CordaRPCClientConfiguration
-
- component1() - Method in class net.corda.client.rpc.internal.ObservableContext
-
- component1() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The minimum protocol version required from the server
- component1() - Method in class net.corda.contracts.asset.Commands.Exit
-
- component1() - Method in class net.corda.contracts.asset.Commands.Issue
-
- component1() - Method in class net.corda.contracts.asset.Commands.Move
-
Contract code the moved state
- component1() - Method in class net.corda.contracts.asset.Cash.State
-
- component1() - Method in class net.corda.contracts.asset.Commands.Exit
-
- component1() - Method in class net.corda.contracts.asset.Commands.Issue
-
- component1() - Method in class net.corda.contracts.asset.Commands.Move
-
Contract code the moved state
- component1() - Method in class net.corda.contracts.asset.CommodityContract.State
-
- component1() - Method in class net.corda.contracts.asset.Commands.Exit
-
- component1() - Method in class net.corda.contracts.asset.Commands.Issue
-
- component1() - Method in class net.corda.contracts.asset.Commands.Move
-
Contract code the moved state
- component1() - Method in class net.corda.contracts.asset.Commands.Net
-
The type of netting to apply,
- component1() - Method in class net.corda.contracts.asset.Commands.SetLifecycle
-
- component1() - Method in class net.corda.contracts.asset.Commands.Settle
-
- component1() - Method in class net.corda.contracts.asset.Obligation.State
-
- component1() - Method in class net.corda.contracts.asset.Obligation.Terms
-
The hash of the asset contract we
- component1() - Method in class net.corda.contracts.clause.BilateralNetState
-
- component1() - Method in class net.corda.contracts.clause.MultilateralNetState
-
- component1() - Method in class net.corda.contracts.Commands.Issue
-
- component1() - Method in class net.corda.contracts.Commands.Move
-
Contract code the moved state
- component1() - Method in class net.corda.contracts.CommercialPaper.State
-
- component1() - Method in class net.corda.contracts.CommercialPaper.Terms
-
- component1() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
- component1() - Method in class net.corda.contracts.Commodity
-
- component1() - Method in class net.corda.contracts.Expression
-
- component1() - Method in class net.corda.contracts.Fix
-
- component1() - Method in class net.corda.contracts.FixOf
-
- component1() - Method in class net.corda.contracts.Tenor
-
- component1() - Method in class net.corda.core.contracts.Amount
-
- component1() - Method in class net.corda.core.contracts.AuthenticatedObject
-
- component1() - Method in class net.corda.core.contracts.Command
-
- component1() - Method in class net.corda.core.contracts.Issued
-
- component1() - Method in class net.corda.core.contracts.PartyAndReference
-
- component1() - Method in class net.corda.core.contracts.ScheduledActivity
-
- component1() - Method in class net.corda.core.contracts.ScheduledStateRef
-
- component1() - Method in class net.corda.core.contracts.SourceAndAmount
-
- component1() - Method in class net.corda.core.contracts.StateAndRef
-
- component1() - Method in class net.corda.core.contracts.StateRef
-
- component1() - Method in class net.corda.core.contracts.TransactionState
-
The custom contract state
- component1() - Method in class net.corda.core.contracts.UniqueIdentifier
-
- component1() - Method in class net.corda.core.contracts.UpgradeCommand
-
- component1() - Method in class net.corda.core.crypto.CertificateAndKeyPair
-
- component1() - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
-
- component1() - Method in class net.corda.core.crypto.composite.CompositeSignature.State
-
- component1() - Method in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
-
- component1($receiver) - Static method in class net.corda.core.crypto.CryptoUtils
-
- component1() - Method in class net.corda.core.crypto.MerkleTree.Leaf
-
- component1() - Method in class net.corda.core.crypto.MerkleTree.Node
-
- component1() - Method in class net.corda.core.crypto.PartialTree.IncludedLeaf
-
- component1() - Method in class net.corda.core.crypto.PartialTree.Leaf
-
- component1() - Method in class net.corda.core.crypto.PartialTree.Node
-
- component1() - Method in class net.corda.core.crypto.SignatureScheme
-
- component1() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
-
- component1() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
-
- component1() - Method in class net.corda.core.flows.AppContext
-
- component1() - Method in class net.corda.core.flows.BroadcastTransactionFlow.NotifyTxRequest
-
- component1() - Method in class net.corda.core.flows.FetchDataFlow.Request
-
- component1() - Method in class net.corda.core.flows.FetchDataFlow.Result
-
- component1() - Method in class net.corda.core.flows.FinalityFlow.Participant
-
- component1() - Method in class net.corda.core.flows.FlowInitiator.Peer
-
- component1() - Method in class net.corda.core.flows.FlowInitiator.RPC
-
- component1() - Method in class net.corda.core.flows.FlowInitiator.Scheduled
-
- component1() - Method in class net.corda.core.flows.NotaryError.Conflict
-
- component1() - Method in class net.corda.core.flows.NotaryError.TransactionInvalid
-
- component1() - Method in class net.corda.core.flows.StateMachineRunId
-
- component1() - Method in class net.corda.core.flows.TransactionParts
-
- component1() - Method in class net.corda.core.identity.AnonymousPartyAndPath
-
- component1() - Method in class net.corda.core.identity.PartyAndCertificate
-
- component1() - Method in class net.corda.core.internal.InputStreamAndHash
-
- component1() - Method in class net.corda.core.messaging.DataFeed
-
- component1() - Method in class net.corda.core.messaging.FlowHandleImpl
-
The started state machine
- component1() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
The started state machine
- component1() - Method in class net.corda.core.messaging.StateMachineInfo
-
- component1() - Method in class net.corda.core.messaging.StateMachineTransactionMapping
-
- component1() - Method in class net.corda.core.messaging.StateMachineUpdate.Added
-
- component1() - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
-
- component1() - Method in class net.corda.core.node.NodeInfo
-
- component1() - Method in class net.corda.core.node.ServiceEntry
-
- component1() - Method in class net.corda.core.node.services.MapChange.Added
-
- component1() - Method in class net.corda.core.node.services.MapChange.Modified
-
- component1() - Method in class net.corda.core.node.services.MapChange.Removed
-
- component1() - Method in class net.corda.core.node.services.PartyInfo.Node
-
- component1() - Method in class net.corda.core.node.services.PartyInfo.Service
-
- component1() - Method in class net.corda.core.node.services.ServiceInfo
-
- component1() - Method in class net.corda.core.node.services.UniquenessProvider.Conflict
-
- component1() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
- component1() - Method in class net.corda.core.node.services.vault.ColumnPredicate.AggregateFunction
-
- component1() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
-
- component1() - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
-
- component1() - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
-
- component1() - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
-
- component1() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
-
- component1() - Method in class net.corda.core.node.services.vault.ColumnPredicate.NullExpression
-
- component1() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- component1() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
-
- component1() - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
-
- component1() - Method in class net.corda.core.node.services.vault.CriteriaExpression.Not
-
- component1() - Method in class net.corda.core.node.services.Vault.Page
-
- component1() - Method in class net.corda.core.node.services.vault.PageSpecification
-
- component1() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- component1() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- component1() - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
-
- component1() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
- component1() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- component1() - Method in class net.corda.core.node.services.vault.Sort
-
- component1() - Method in class net.corda.core.node.services.vault.Sort.SortColumn
-
- component1() - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
-
- component1() - Method in class net.corda.core.node.services.vault.SortAttribute.Standard
-
- component1() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component1() - Method in class net.corda.core.node.services.Vault.Update
-
- component1() - Method in class net.corda.core.node.WorldCoordinate
-
- component1() - Method in class net.corda.core.node.WorldMapLocation
-
- component1() - Method in class net.corda.core.schemas.PersistentStateRef
-
- component1() - Method in class net.corda.core.serialization.amqp.Choice
-
- component1() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- component1() - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
-
- component1() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- component1() - Method in class net.corda.core.serialization.amqp.Descriptor
-
- component1() - Method in class net.corda.core.serialization.amqp.Envelope
-
- component1() - Method in class net.corda.core.serialization.amqp.Field
-
- component1() - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
-
- component1() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- component1() - Method in class net.corda.core.serialization.amqp.Schema
-
- component1() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
The list of carpentable classes
- component1() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
- component1() - Method in class net.corda.core.transactions.SignedTransaction
-
- component1() - Method in class net.corda.core.utilities.NetworkHostAndPort
-
- component1() - Method in class net.corda.core.utilities.Change.Position
-
- component1() - Method in class net.corda.core.utilities.Change.Rendering
-
- component1() - Method in class net.corda.core.utilities.Change.Structural
-
- component1() - Method in class net.corda.core.utilities.Try.Failure
-
- component1() - Method in class net.corda.core.utilities.Try.Success
-
- component1() - Method in class net.corda.flows.AbstractCashFlow.Result
-
- component1() - Method in class net.corda.flows.CashFlowCommand.ExitCash
-
- component1() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- component1() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- component1() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- component1() - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
-
- component1() - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
-
- component1() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- component1() - Method in class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
-
- component1() - Method in class net.corda.node.CmdLineOptions
-
- component1() - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
-
- component1() - Method in class net.corda.node.internal.InitiatedFlowFactory.Core
-
- component1() - Method in class net.corda.node.internal.NetworkMapInfo
-
- component1() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The UTC time point at which the audit event happened.
- component1() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The UTC time point at which the audit event happened.
- component1() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The UTC time point at which the audit event happened.
- component1() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The UTC time point at which the audit event happened.
- component1() - Method in class net.corda.node.services.api.FlowStartEvent
-
The UTC time point at which the audit event happened.
- component1() - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
-
- component1() - Method in class net.corda.node.services.api.SystemAuditEvent
-
The UTC time point at which the audit event happened.
- component1() - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- component1() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component1() - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
-
- component1() - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
-
- component1() - Method in class net.corda.node.services.messaging.RpcContext
-
- component1() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The number of threads to use for handling RPC requests
- component1() - Method in class net.corda.node.services.messaging.TopicSession
-
- component1() - Method in class net.corda.node.services.network.LastAcknowledgeInfo
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityResponse
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationResponse
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeResponse
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.Update
-
- component1() - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
-
- component1() - Method in class net.corda.node.services.network.NodeRegistration
-
- component1() - Method in class net.corda.node.services.network.NodeRegistrationInfo
-
- component1() - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
-
- component1() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
-
- component1() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
-
- component1() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiating
-
- component1() - Method in class net.corda.node.services.statemachine.NormalSessionEnd
-
- component1() - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
-
- component1() - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- component1() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- component1() - Method in class net.corda.node.services.statemachine.SendOnly
-
- component1() - Method in class net.corda.node.services.statemachine.SessionConfirm
-
- component1() - Method in class net.corda.node.services.statemachine.SessionData
-
- component1() - Method in class net.corda.node.services.statemachine.SessionInit
-
- component1() - Method in class net.corda.node.services.statemachine.SessionReject
-
- component1() - Method in class net.corda.node.services.statemachine.Change.Add
-
- component1() - Method in class net.corda.node.services.statemachine.Change.Removed
-
- component1() - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
-
- component1() - Method in class net.corda.node.services.transactions.ClusterResponse.Error
-
- component1() - Method in class net.corda.node.services.transactions.ClusterResponse.Signatures
-
- component1() - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
-
- component1() - Method in class net.corda.node.services.transactions.ReplicaResponse.Error
-
- component1() - Method in class net.corda.node.services.transactions.ReplicaResponse.Signature
-
- component1() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Boundary
-
- component1() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- component1() - Method in class net.corda.node.utilities.PartyColumns
-
- component1() - Method in class net.corda.node.utilities.StateRefColumns
-
- component1() - Method in class net.corda.node.utilities.TxnNoteColumns
-
- component1() - Method in class net.corda.node.VersionInfo
-
Platform version of the node which is an integer value which increments on any release where any of the public
- component10() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
- component10() - Method in class net.corda.core.crypto.SignatureScheme
-
- component10() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component11() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
Maximum file size
- component11() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component12() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component13() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component14() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component15() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component16() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component17() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component18() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component19() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component2() - Method in class net.corda.client.jfx.model.Diff
-
- component2() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
-
- component2() - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
-
- component2() - Method in class net.corda.client.rpc.internal.ObservableContext
-
- component2() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
If set to true the client will track RPC call sites.
- component2() - Method in class net.corda.contracts.asset.Cash.State
-
There must be a MoveCommand signed by this key to claim the amount.
- component2() - Method in class net.corda.contracts.asset.CommodityContract.State
-
There must be a MoveCommand signed by this key to claim the amount
- component2() - Method in class net.corda.contracts.asset.Obligation.State
-
Where the debt originates from
- component2() - Method in class net.corda.contracts.asset.Obligation.Terms
-
The parties whose assets we are willing to accept in payment for this debt.
- component2() - Method in class net.corda.contracts.clause.BilateralNetState
-
- component2() - Method in class net.corda.contracts.CommercialPaper.State
-
There must be a MoveCommand signed by this key to claim the amount
- component2() - Method in class net.corda.contracts.CommercialPaper.Terms
-
- component2() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
There must be a MoveCommand signed by this key to claim the amount
- component2() - Method in class net.corda.contracts.Commodity
-
- component2() - Method in class net.corda.contracts.Fix
-
- component2() - Method in class net.corda.contracts.FixOf
-
- component2() - Method in class net.corda.core.contracts.Amount
-
- component2() - Method in class net.corda.core.contracts.AuthenticatedObject
-
If any public keys were recognised,
- component2() - Method in class net.corda.core.contracts.Command
-
- component2() - Method in class net.corda.core.contracts.Issued
-
- component2() - Method in class net.corda.core.contracts.PartyAndReference
-
- component2() - Method in class net.corda.core.contracts.ScheduledActivity
-
- component2() - Method in class net.corda.core.contracts.ScheduledStateRef
-
- component2() - Method in class net.corda.core.contracts.SourceAndAmount
-
- component2() - Method in class net.corda.core.contracts.StateAndRef
-
- component2() - Method in class net.corda.core.contracts.StateRef
-
- component2() - Method in class net.corda.core.contracts.TransactionState
-
Identity of the notary that ensures the state is not used as an input to a transaction more than once
- component2() - Method in class net.corda.core.contracts.UniqueIdentifier
-
- component2() - Method in class net.corda.core.crypto.CertificateAndKeyPair
-
- component2() - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
-
- component2() - Method in class net.corda.core.crypto.composite.CompositeSignature.State
-
- component2($receiver) - Static method in class net.corda.core.crypto.CryptoUtils
-
- component2() - Method in class net.corda.core.crypto.MerkleTree.Node
-
- component2() - Method in class net.corda.core.crypto.PartialTree.Node
-
- component2() - Method in class net.corda.core.crypto.SignatureScheme
-
- component2() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
-
- component2() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
-
- component2() - Method in class net.corda.core.flows.FetchDataFlow.Result
-
- component2() - Method in class net.corda.core.flows.FinalityFlow.Participant
-
- component2() - Method in class net.corda.core.flows.NotaryError.Conflict
-
- component2() - Method in class net.corda.core.flows.TransactionParts
-
- component2() - Method in class net.corda.core.identity.AnonymousPartyAndPath
-
- component2() - Method in class net.corda.core.identity.PartyAndCertificate
-
- component2() - Method in class net.corda.core.internal.InputStreamAndHash
-
- component2() - Method in class net.corda.core.messaging.DataFeed
-
- component2() - Method in class net.corda.core.messaging.FlowHandleImpl
-
A
- component2() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
A
- component2() - Method in class net.corda.core.messaging.StateMachineInfo
-
- component2() - Method in class net.corda.core.messaging.StateMachineTransactionMapping
-
- component2() - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
-
- component2() - Method in class net.corda.core.node.NodeInfo
-
- component2() - Method in class net.corda.core.node.ServiceEntry
-
- component2() - Method in class net.corda.core.node.services.MapChange.Modified
-
- component2() - Method in class net.corda.core.node.services.ServiceInfo
-
- component2() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
- component2() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
-
- component2() - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
-
- component2() - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
-
- component2() - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
-
- component2() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
-
- component2() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- component2() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
-
- component2() - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
-
- component2() - Method in class net.corda.core.node.services.Vault.Page
-
- component2() - Method in class net.corda.core.node.services.vault.PageSpecification
-
- component2() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- component2() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- component2() - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
-
- component2() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
- component2() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- component2() - Method in class net.corda.core.node.services.vault.Sort.SortColumn
-
- component2() - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
-
- component2() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component2() - Method in class net.corda.core.node.services.Vault.Update
-
- component2() - Method in class net.corda.core.node.WorldCoordinate
-
- component2() - Method in class net.corda.core.node.WorldMapLocation
-
- component2() - Method in class net.corda.core.schemas.PersistentStateRef
-
- component2() - Method in class net.corda.core.serialization.amqp.Choice
-
- component2() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- component2() - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
-
- component2() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- component2() - Method in class net.corda.core.serialization.amqp.Descriptor
-
- component2() - Method in class net.corda.core.serialization.amqp.Envelope
-
- component2() - Method in class net.corda.core.serialization.amqp.Field
-
- component2() - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
-
- component2() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- component2() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
Maps a class to a list of classes that depend on it being built first
- component2() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
- component2() - Method in class net.corda.core.transactions.SignedTransaction
-
- component2() - Method in class net.corda.core.utilities.NetworkHostAndPort
-
- component2() - Method in class net.corda.core.utilities.Change.Position
-
- component2() - Method in class net.corda.core.utilities.Change.Rendering
-
- component2() - Method in class net.corda.core.utilities.Change.Structural
-
- component2() - Method in class net.corda.flows.AbstractCashFlow.Result
-
- component2() - Method in class net.corda.flows.CashFlowCommand.ExitCash
-
- component2() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- component2() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- component2() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- component2() - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
-
- component2() - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
-
- component2() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- component2() - Method in class net.corda.node.CmdLineOptions
-
- component2() - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
-
- component2() - Method in class net.corda.node.internal.NetworkMapInfo
-
- component2() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The responsible individual,
- component2() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The responsible individual,
- component2() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The responsible individual,
- component2() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The responsible individual,
- component2() - Method in class net.corda.node.services.api.FlowStartEvent
-
The responsible individual,
- component2() - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
-
- component2() - Method in class net.corda.node.services.api.SystemAuditEvent
-
The responsible individual,
- component2() - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- component2() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component2() - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
-
- component2() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The number of consumers to handle incoming messages
- component2() - Method in class net.corda.node.services.messaging.TopicSession
-
- component2() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- component2() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
-
- component2() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
-
- component2() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
-
- component2() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- component2() - Method in class net.corda.node.services.network.NetworkMapService.Update
-
- component2() - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
-
- component2() - Method in class net.corda.node.services.network.NodeRegistration
-
- component2() - Method in class net.corda.node.services.network.NodeRegistrationInfo
-
- component2() - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
-
- component2() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
-
- component2() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
-
- component2() - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
-
- component2() - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- component2() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- component2() - Method in class net.corda.node.services.statemachine.SendOnly
-
- component2() - Method in class net.corda.node.services.statemachine.SessionConfirm
-
- component2() - Method in class net.corda.node.services.statemachine.SessionData
-
- component2() - Method in class net.corda.node.services.statemachine.SessionInit
-
- component2() - Method in class net.corda.node.services.statemachine.SessionReject
-
- component2() - Method in class net.corda.node.services.statemachine.Change.Removed
-
- component2() - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
-
- component2() - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
-
- component2() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- component2() - Method in class net.corda.node.utilities.PartyColumns
-
- component2() - Method in class net.corda.node.utilities.StateRefColumns
-
- component2() - Method in class net.corda.node.utilities.TxnNoteColumns
-
- component2() - Method in class net.corda.node.VersionInfo
-
Release version string of the node.
- component20() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component21() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component22() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component23() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component24() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component3() - Method in class net.corda.client.rpc.internal.ObservableContext
-
- component3() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The interval of unused observable reaping.
- component3() - Method in class net.corda.contracts.asset.Obligation.State
-
- component3() - Method in class net.corda.contracts.asset.Obligation.Terms
-
When the contract must be settled by.
- component3() - Method in class net.corda.contracts.CommercialPaper.State
-
- component3() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
- component3() - Method in class net.corda.contracts.Commodity
-
- component3() - Method in class net.corda.contracts.FixOf
-
- component3() - Method in class net.corda.core.contracts.Amount
-
- component3() - Method in class net.corda.core.contracts.AuthenticatedObject
-
- component3() - Method in class net.corda.core.contracts.SourceAndAmount
-
- component3() - Method in class net.corda.core.contracts.TransactionState
-
All contract states may be encumbered by up to one other state.
- component3() - Method in class net.corda.core.crypto.MerkleTree.Node
-
- component3() - Method in class net.corda.core.crypto.SignatureScheme
-
- component3() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
-
- component3() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
-
- component3() - Method in class net.corda.core.flows.TransactionParts
-
- component3() - Method in class net.corda.core.identity.PartyAndCertificate
-
- component3() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
The stream of progress tracker events.
- component3() - Method in class net.corda.core.messaging.StateMachineInfo
-
- component3() - Method in class net.corda.core.node.NodeInfo
-
- component3() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
- component3() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- component3() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
-
- component3() - Method in class net.corda.core.node.services.Vault.Page
-
- component3() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- component3() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- component3() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- component3() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component3() - Method in class net.corda.core.node.services.Vault.Update
-
- component3() - Method in class net.corda.core.node.WorldMapLocation
-
- component3() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- component3() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- component3() - Method in class net.corda.core.serialization.amqp.Field
-
- component3() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- component3() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
Maps a class to a list of classes it depends on being built before it
- component3() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
- component3() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- component3() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- component3() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- component3() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- component3() - Method in class net.corda.node.CmdLineOptions
-
- component3() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
A human readable description of audit event including any permission check results.
- component3() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
A human readable description of audit event including any permission check results.
- component3() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
A human readable description of audit event including any permission check results.
- component3() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
A human readable description of audit event including any permission check results.
- component3() - Method in class net.corda.node.services.api.FlowStartEvent
-
A human readable description of audit event including any permission check results.
- component3() - Method in class net.corda.node.services.api.SystemAuditEvent
-
A human readable description of audit event including any permission check results.
- component3() - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- component3() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component3() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The maximum number of producers to create to handle outgoing messages
- component3() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- component3() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
-
- component3() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
-
- component3() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- component3() - Method in class net.corda.node.services.network.NetworkMapService.Update
-
- component3() - Method in class net.corda.node.services.network.NodeRegistration
-
- component3() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
-
- component3() - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- component3() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- component3() - Method in class net.corda.node.services.statemachine.SessionInit
-
- component3() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- component3() - Method in class net.corda.node.VersionInfo
-
The exact version control commit ID of the node build.
- component4() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The number of threads to use for observations
- component4() - Method in class net.corda.contracts.asset.Obligation.State
-
- component4() - Method in class net.corda.contracts.asset.Obligation.Terms
-
- component4() - Method in class net.corda.contracts.CommercialPaper.State
-
- component4() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
- component4() - Method in class net.corda.core.crypto.SignatureScheme
-
- component4() - Method in class net.corda.core.messaging.StateMachineInfo
-
- component4() - Method in class net.corda.core.node.NodeInfo
-
- component4() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- component4() - Method in class net.corda.core.node.services.Vault.Page
-
- component4() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- component4() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- component4() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- component4() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component4() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- component4() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- component4() - Method in class net.corda.core.serialization.amqp.Field
-
- component4() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- component4() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- component4() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- component4() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- component4() - Method in class net.corda.node.CmdLineOptions
-
- component4() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- component4() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- component4() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- component4() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The concrete type of FlowLogic being referenced.
- component4() - Method in class net.corda.node.services.api.FlowStartEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- component4() - Method in class net.corda.node.services.api.SystemAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- component4() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component4() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The interval of subscription reaping
- component4() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- component4() - Method in class net.corda.node.services.network.NodeRegistration
-
- component4() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- component4() - Method in class net.corda.node.services.statemachine.SessionInit
-
- component4() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- component4() - Method in class net.corda.node.VersionInfo
-
The node vendor
- component5() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The maximum number of producers to create to handle outgoing messages
- component5() - Method in class net.corda.contracts.asset.Obligation.State
-
The public key of the entity the contract pays to
- component5() - Method in class net.corda.core.crypto.SignatureScheme
-
- component5() - Method in class net.corda.core.node.NodeInfo
-
- component5() - Method in class net.corda.core.node.services.Vault.Page
-
- component5() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- component5() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- component5() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component5() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- component5() - Method in class net.corda.core.serialization.amqp.Field
-
- component5() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- component5() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- component5() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- component5() - Method in class net.corda.node.CmdLineOptions
-
- component5() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The concrete type of FlowLogic being referenced.
- component5() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The concrete type of FlowLogic being referenced.
- component5() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The concrete type of FlowLogic being referenced.
- component5() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- component5() - Method in class net.corda.node.services.api.FlowStartEvent
-
The concrete type of FlowLogic being referenced.
- component5() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component6() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
Determines the concurrency level of the Observable Cache.
- component6() - Method in class net.corda.core.crypto.SignatureScheme
-
- component6() - Method in class net.corda.core.node.NodeInfo
-
- component6() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- component6() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- component6() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component6() - Method in class net.corda.core.serialization.amqp.Field
-
- component6() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- component6() - Method in class net.corda.node.CmdLineOptions
-
- component6() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- component6() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- component6() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- component6() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
- component6() - Method in class net.corda.node.services.api.FlowStartEvent
-
The stable identifier of the flow as stored with Checkpoints.
- component6() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component7() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The retry interval of artemis connections in milliseconds
- component7() - Method in class net.corda.core.crypto.SignatureScheme
-
- component7() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component7() - Method in class net.corda.core.serialization.amqp.Field
-
- component7() - Method in class net.corda.node.CmdLineOptions
-
- component7() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
- component7() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
- component7() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
- component7() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component8() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The retry interval multiplier for exponential backoff
- component8() - Method in class net.corda.core.crypto.SignatureScheme
-
- component8() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component8() - Method in class net.corda.node.CmdLineOptions
-
- component8() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
- component8() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- component9() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
Maximum retry interval
- component9() - Method in class net.corda.core.crypto.SignatureScheme
-
- component9() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- component9() - Method in class net.corda.node.CmdLineOptions
-
- component9() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- CompositeClause<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Abstract supertype for clauses which compose other clauses together in some logical manner.
- CompositeClause() - Constructor for class net.corda.core.contracts.clauses.CompositeClause
-
Abstract supertype for clauses which compose other clauses together in some logical manner.
- CompositeKey - Class in net.corda.core.crypto.composite
-
A tree data structure that enables the representation of composite public keys.
Notice that with that implementation CompositeKey extends PublicKey. Leaves are represented by single public keys.
- CompositeKey.Builder - Class in net.corda.core.crypto.composite
-
- CompositeKey.Companion - Class in net.corda.core.crypto.composite
-
- CompositeKey.NodeAndWeight - Class in net.corda.core.crypto.composite
-
Holds node - weight pairs for a CompositeKey. Ordered first by weight, then by node's hashCode.
Each node should be assigned with a positive weight to avoid certain types of weight underflow attacks.
- CompositeKeyKt - Class in net.corda.core.crypto.composite
-
- CompositeKeySerializer - Class in net.corda.core.serialization
-
- CompositeSignature - Class in net.corda.core.crypto.composite
-
- CompositeSignature() - Constructor for class net.corda.core.crypto.composite.CompositeSignature
-
- CompositeSignature.Companion - Class in net.corda.core.crypto.composite
-
- CompositeSignature.State - Class in net.corda.core.crypto.composite
-
- CompositeSignaturesWithKeys - Class in net.corda.core.crypto.composite
-
Custom class for holding signature data. This exists for later extension work to provide a standardised cross-platform
serialization format (i.e. not Kryo).
- CompositeSignaturesWithKeys(sigs) - Constructor for class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
-
Custom class for holding signature data. This exists for later extension work to provide a standardised cross-platform
serialization format (i.e. not Kryo).
- CompositeSignaturesWithKeys.Companion - Class in net.corda.core.crypto.composite
-
- CompositeType - Class in net.corda.core.serialization.amqp
-
- CompositeType(name, label, provides, descriptor, fields) - Constructor for class net.corda.core.serialization.amqp.CompositeType
-
- CompositeType.Companion - Class in net.corda.core.serialization.amqp
-
- concatenate($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val groups: ObservableList = (..)
val allPeople: ObservableList = groups.concatenate()
- ConcatenatedList<A> - Class in net.corda.client.jfx.utils
-
class ConcatenatedList
takes a list of lists and concatenates them. Any change to the underlying lists or the outer list
is propagated as expected.
- ConcatenatedList(sourceList) - Constructor for class net.corda.client.jfx.utils.ConcatenatedList
-
class ConcatenatedList
takes a list of lists and concatenates them. Any change to the underlying lists or the outer list
is propagated as expected.
- ConcurrencyUtilsKt - Class in net.corda.core.concurrent
-
- ConfigHelper - Class in net.corda.node.services.config
-
- configOf(pairs) - Static method in class net.corda.node.services.config.ConfigUtilitiesKt
-
- ConfigurationException - Exception in net.corda.node.internal
-
- ConfigurationException(message) - Constructor for exception net.corda.node.internal.ConfigurationException
-
- configureDatabase(props) - Static method in class net.corda.node.utilities.CordaPersistenceKt
-
- configureDevKeyAndTrustStores($receiver, myLegalName) - Static method in class net.corda.node.services.config.ConfigUtilitiesKt
-
- configureWithDevSSLCertificate($receiver) - Static method in class net.corda.node.services.config.ConfigUtilitiesKt
-
Strictly for dev only automatically construct a server certificate/private key signed from
the CA certs in Node resources. Then provision KeyStores into certificates folder under node path.
- ConfigUtilitiesKt - Class in net.corda.node.services.config
-
- Conflict(txId, conflict) - Constructor for class net.corda.core.flows.NotaryError.Conflict
-
- Conflict(stateHistory) - Constructor for class net.corda.core.node.services.UniquenessProvider.Conflict
-
Specifies the consuming transaction for every conflicting state
- connect(dataSource) - Method in class net.corda.node.utilities.CordaPersistence.Companion
-
- ConserveAmount() - Constructor for class net.corda.contracts.asset.Clauses.ConserveAmount
-
- ConserveAmount() - Constructor for class net.corda.contracts.asset.Clauses.ConserveAmount
-
Standard clause for conserving the amount from input to output.
- ConserveAmount() - Constructor for class net.corda.contracts.asset.Clauses.ConserveAmount
-
Generic move/exit clause for fungible assets
- construct(properties) - Method in class net.corda.core.serialization.amqp.ObjectSerializer
-
- ConstructorForDeserialization - Interface in net.corda.core.serialization.amqp
-
Annotation indicating a constructor to be used to reconstruct instances of a class during deserialization.
- ConsumingTx(id, inputIndex, requestingParty) - Constructor for class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
Specifies the transaction id, the position of the consumed state in the inputs, and
the caller identity requesting the commit.
- contains(element) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- contains(instant) - Method in class net.corda.core.contracts.TimeWindow
-
Returns true iff the given instant is within the time interval of this
class TimeWindow
.
- contains(element) - Method in class net.corda.core.utilities.NonEmptySet
-
- contains(element) - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- containsAlias(alias) - Method in class net.corda.node.utilities.KeyStoreWrapper
-
- containsAll(elements) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- containsAll(elements) - Method in class net.corda.core.utilities.NonEmptySet
-
- containsAny($receiver, otherKeys) - Static method in class net.corda.core.crypto.CryptoUtils
-
Checks whether any of the given keys matches a leaf on the CompositeKey tree or a single PublicKey
- containsKey(key) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- containsKey(key) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- containsType($receiver, type) - Static method in class net.corda.core.node.services.ServiceInfoKt
-
- containsType(clazz, status) - Method in class net.corda.core.node.services.Vault.Update
-
Checks whether the update contains a state of the specified type and state status
- containsValue(value) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- containsValue(value) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- ContentSignerBuilder - Class in net.corda.core.crypto
-
Provide extra OID look up for signature algorithm not supported by bouncy castle.
This builder will use bouncy castle's JcaContentSignerBuilder as fallback for unknown algorithm.
- Contract - Interface in net.corda.core.contracts
-
Implemented by a program that implements business logic on the shared ledger. All participants run this code for
every
class LedgerTransaction
they see on the network, for every input and output state. All
contracts must accept the transaction for it to be accepted: failure of any aborts the entire thing. The time is taken
from a trusted time-window attached to the transaction itself i.e. it is NOT necessarily the current time.
- ContractRejection(txId, contract, cause) - Constructor for exception net.corda.core.contracts.TransactionVerificationException.ContractRejection
-
- ContractsDSL - Class in net.corda.core.contracts
-
- ContractState - Interface in net.corda.core.contracts
-
A contract state (or just "state") contains opaque data used by a contract program. It can be thought of as a disk
file that the program can use to persist data across transactions. States are immutable: once created they are never
updated, instead, any changes must generate a new successor state. States can be updated (consumed) only once: the
notary is responsible for ensuring there is no "double spending" by only signing a transaction if the input states
are all free.
- ContractStateModel - Class in net.corda.client.jfx.model
-
This model exposes the list of owned contract states.
- ContractStateModel() - Constructor for class net.corda.client.jfx.model.ContractStateModel
-
This model exposes the list of owned contract states.
- ContractStateModel.Companion - Class in net.corda.client.jfx.model
-
- ContractUpgradeFlow<OldState extends ContractState,NewState extends ContractState> - Class in net.corda.core.flows
-
A flow to be used for upgrading state objects of an old contract to a new contract.
- ContractUpgradeFlow(originalState, newContractClass) - Constructor for class net.corda.core.flows.ContractUpgradeFlow
-
A flow to be used for upgrading state objects of an old contract to a new contract.
- ContractUpgradeFlow.Companion - Class in net.corda.core.flows
-
- ContractUpgradeHandler - Class in net.corda.node.services
-
- ContractUpgradeHandler(otherSide) - Constructor for class net.corda.node.services.ContractUpgradeHandler
-
- convert(wire) - Method in class net.corda.core.flows.FetchAttachmentsFlow
-
- convert(wire) - Method in class net.corda.core.flows.FetchDataFlow
-
- convertToMapped(type, value) - Method in class net.corda.core.schemas.requery.converters.BlobConverter
-
- convertToMapped(type, value) - Method in class net.corda.core.schemas.requery.converters.InstantConverter
-
- convertToMapped(type, value) - Method in class net.corda.core.schemas.requery.converters.SecureHashConverter
-
- convertToMapped(type, value) - Method in class net.corda.core.schemas.requery.converters.StateRefConverter
-
- convertToPersisted(value) - Method in class net.corda.core.schemas.requery.converters.BlobConverter
-
- convertToPersisted(value) - Method in class net.corda.core.schemas.requery.converters.InstantConverter
-
- convertToPersisted(value) - Method in class net.corda.core.schemas.requery.converters.SecureHashConverter
-
- convertToPersisted(value) - Method in class net.corda.core.schemas.requery.converters.StateRefConverter
-
- copy(added, removed) - Method in class net.corda.client.jfx.model.Diff
-
- copy(transaction, inputs) - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
-
- copy(stateAndRef) - Method in class net.corda.client.jfx.model.InputResolution.Resolved
-
- copy(stateRef) - Method in class net.corda.client.jfx.model.InputResolution.Unresolved
-
- copy(stateMachineId, message) - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
-
- copy(connectionMaxRetryInterval) - Method in class net.corda.client.rpc.CordaRPCClientConfiguration
-
- copy(callSiteMap, observableMap, hardReferenceStore) - Method in class net.corda.client.rpc.internal.ObservableContext
-
Holds a context available during Kryo deserialisation of messages that are expected to contain Observables.
- copy(minimumServerProtocolVersion, trackRpcCallSites, reapInterval, observationExecutorPoolSize, producerPoolBound, cacheConcurrencyLevel, connectionRetryInterval, connectionRetryIntervalMultiplier, connectionMaxRetryInterval, maxReconnectAttempts, maxFileSize) - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
This configuration may be used to tweak the internals of the RPC client.
- copy(amount) - Method in class net.corda.contracts.asset.Commands.Exit
-
A command stating that money has been withdrawn from the shared ledger and is now accounted for
in some other way.
- copy(nonce) - Method in class net.corda.contracts.asset.Commands.Issue
-
Allows new cash states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- copy(contractHash) - Method in class net.corda.contracts.asset.Commands.Move
-
A command stating that money has been moved, optionally to fulfil another contract.
- copy(amount, owner) - Method in class net.corda.contracts.asset.Cash.State
-
A state representing a cash claim against some party.
- copy(amount) - Method in class net.corda.contracts.asset.Commands.Exit
-
A command stating that money has been withdrawn from the shared ledger and is now accounted for
in some other way.
- copy(nonce) - Method in class net.corda.contracts.asset.Commands.Issue
-
Allows new commodity states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- copy(contractHash) - Method in class net.corda.contracts.asset.Commands.Move
-
A command stating that money has been moved, optionally to fulfil another contract.
- copy(amount, owner) - Method in class net.corda.contracts.asset.CommodityContract.State
-
A state representing a commodity claim against some party
- copy(amount) - Method in class net.corda.contracts.asset.Commands.Exit
-
A command stating that the debt is being released by the beneficiary. Normally would indicate
either settlement outside of the ledger, or that the obligor is unable to pay.
- copy(nonce) - Method in class net.corda.contracts.asset.Commands.Issue
-
Allows new obligation states to be issued into existence: the nonce ("number used once") ensures the
transaction has a unique ID even when there are no inputs.
- copy(contractHash) - Method in class net.corda.contracts.asset.Commands.Move
-
A command stating that a debt has been moved, optionally to fulfil another contract.
- copy(type) - Method in class net.corda.contracts.asset.Commands.Net
-
Net two or more obligation states together in a close-out netting style. Limited to bilateral netting
as only the beneficiary (not the obligor) needs to sign.
- copy(lifecycle) - Method in class net.corda.contracts.asset.Commands.SetLifecycle
-
A command stating that the beneficiary is moving the contract into the defaulted state as it has not been settled
by the due date, or resetting a defaulted contract back to the issued state.
- copy(amount) - Method in class net.corda.contracts.asset.Commands.Settle
-
A command stating that the obligor is settling some or all of the amount owed by transferring a suitable
state object to the beneficiary. If this reduces the balance to zero, the state object is destroyed.
- copy(lifecycle, obligor, template, quantity, beneficiary) - Method in class net.corda.contracts.asset.Obligation.State
-
A state representing the obligation of one party (obligor) to deliver a specified number of
units of an underlying asset (described as token.acceptableIssuedProducts) to the beneficiary
no later than the specified time.
- copy(acceptableContracts, acceptableIssuedProducts, dueBefore, timeTolerance) - Method in class net.corda.contracts.asset.Obligation.Terms
-
Subset of state, containing the elements specified when issuing a new settlement contract.
- copy(partyKeys, template) - Method in class net.corda.contracts.clause.BilateralNetState
-
Subset of state, containing the elements which must match for two obligation transactions to be nettable.
If two obligation state objects produce equal bilateral net states, they are considered safe to net directly.
Bilateral states are used in close-out netting.
- copy(template) - Method in class net.corda.contracts.clause.MultilateralNetState
-
Subset of state, containing the elements which must match for two or more obligation transactions to be candidates
for netting (this does not include the checks to enforce that everyone's amounts received are the same at the end,
which is handled under the verify() function).
In comparison to
class BilateralNetState
, this doesn't include the parties' keys, as ensuring balances match on
input and output is handled elsewhere.
Used in cases where all parties (or their proxies) are signing, such as central clearing.
- copy(nonce) - Method in class net.corda.contracts.Commands.Issue
-
- copy(contractHash) - Method in class net.corda.contracts.Commands.Move
-
- copy(issuance, owner, faceValue, maturityDate) - Method in class net.corda.contracts.CommercialPaper.State
-
- copy(asset, maturityDate) - Method in class net.corda.contracts.CommercialPaper.Terms
-
- copy(issuance, owner, faceValue, maturityDate) - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
- copy(commodityCode, displayName, defaultFractionDigits) - Method in class net.corda.contracts.Commodity
-
Class representing a commodity, as an equivalent to the
Currency class. This exists purely to enable the
CommodityContract contract, and is likely to change in future.
- copy(expr) - Method in class net.corda.contracts.Expression
-
Represents a textual expression of e.g. a formula
- copy(of, value) - Method in class net.corda.contracts.Fix
-
A
class Fix
represents a named interest rate, on a given day, for a given duration. It can be embedded in a tx.
- copy(name, forDay, ofTenor) - Method in class net.corda.contracts.FixOf
-
A
class FixOf
identifies the question side of a fix: what day, tenor and type of fix ("LIBOR", "EURIBOR" etc)
- copy(name) - Method in class net.corda.contracts.Tenor
-
Placeholder class for the Tenor datatype - which is a standardised duration of time until maturity
- copy(quantity, displayTokenSize, token) - Method in class net.corda.core.contracts.Amount
-
Amount represents a positive quantity of some token (currency, asset, etc.), measured in quantity of the smallest
representable units. The nominal quantity represented by each individual token is equal to the displayTokenSize.
The scale property of the displayTokenSize should correctly reflect the displayed decimal places and is used
when rounding conversions from indicative/displayed amounts in
BigDecimal to Amount occur via the Amount.fromDecimal method.
- copy(quantityDelta, token, source, destination) - Method in class net.corda.core.contracts.AmountTransfer
-
- copy(signers, signingParties, value) - Method in class net.corda.core.contracts.AuthenticatedObject
-
Wraps an object that was signed by a public key, which may be a well known/recognised institutional key.
- copy(value, signers) - Method in class net.corda.core.contracts.Command
-
Command data/content plus pubkey pair: the signature is stored at the end of the serialized bytes
- copy(issuer, product) - Method in class net.corda.core.contracts.Issued
-
Definition for an issued product, which can be cash, a cash-like thing, assets, or generally anything else that's
quantifiable with integer quantities.
- copy(party, reference) - Method in class net.corda.core.contracts.PartyAndReference
-
Reference to something being stored or issued by a party e.g. in a vault or (more likely) on their normal
ledger. The reference is intended to be encrypted so it's meaningless to anyone other than the party.
- copy(logicRef, scheduledAt) - Method in class net.corda.core.contracts.ScheduledActivity
-
This class represents the lifecycle activity that a contract state of type
interface LinearState
would like to perform at a
given point in time. e.g. run a fixing flow.
- copy(ref, scheduledAt) - Method in class net.corda.core.contracts.ScheduledStateRef
-
Represents a contract state (unconsumed output) of type
interface LinearState
and a point in time that a lifecycle event is
expected to take place for that contract state.
- copy(source, amount, ref) - Method in class net.corda.core.contracts.SourceAndAmount
-
Simple data class to associate the origin, owner, or holder of a particular Amount object.
- copy(state, ref) - Method in class net.corda.core.contracts.StateAndRef
-
A StateAndRef is simply a (state, ref) pair. For instance, a vault (which holds available assets) contains these.
- copy(txhash, index) - Method in class net.corda.core.contracts.StateRef
-
A stateref is a pointer (reference) to a state, this is an equivalent of an "outpoint" in Bitcoin. It records which
transaction defined the state and where in that transaction it was.
- copy(data, notary, encumbrance) - Method in class net.corda.core.contracts.TransactionState
-
A wrapper for
interface ContractState
containing additional platform-level state information.
This is the definitive state that is stored on the ledger and used in transaction outputs.
- copy(externalId, id) - Method in class net.corda.core.contracts.UniqueIdentifier
-
This class provides a truly unique identifier of a trade, state, or other business object, bound to any existing
external ID. Equality and comparison are based on the unique ID only; if two states somehow have the same UUID but
different external IDs, it would indicate a problem with handling of IDs.
- copy(upgradedContractClass) - Method in class net.corda.core.contracts.UpgradeCommand
-
Indicates that this transaction replaces the inputs contract state to another contract state
- copy(certificate, keyPair) - Method in class net.corda.core.crypto.CertificateAndKeyPair
-
- copy(node, weight) - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
-
Holds node - weight pairs for a CompositeKey. Ordered first by weight, then by node's hashCode.
Each node should be assigned with a positive weight to avoid certain types of weight underflow attacks.
- copy(buffer, verifyKey) - Method in class net.corda.core.crypto.composite.CompositeSignature.State
-
- copy(sigs) - Method in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
-
Custom class for holding signature data. This exists for later extension work to provide a standardised cross-platform
serialization format (i.e. not Kryo).
- copy(hash) - Method in class net.corda.core.crypto.MerkleTree.Leaf
-
- copy(hash, left, right) - Method in class net.corda.core.crypto.MerkleTree.Node
-
- copy(hash) - Method in class net.corda.core.crypto.PartialTree.IncludedLeaf
-
- copy(hash) - Method in class net.corda.core.crypto.PartialTree.Leaf
-
- copy(left, right) - Method in class net.corda.core.crypto.PartialTree.Node
-
- copy(schemeNumberID, schemeCodeName, signatureOID, alternativeOIDs, providerName, algorithmName, signatureName, algSpec, keySize, desc) - Method in class net.corda.core.crypto.SignatureScheme
-
This class is used to define a digital signature scheme.
- copy(stateRef, modification, stx) - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
-
- copy(stx, participants, myKey) - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
-
The assembled transaction for upgrading a contract.
- copy(attachments) - Method in class net.corda.core.flows.AppContext
-
This is just some way to track what attachments need to be in the class loader, but may later include some app
properties loaded from the attachments. And perhaps the authenticated user for an API call?
- copy(tx) - Method in class net.corda.core.flows.BroadcastTransactionFlow.NotifyTxRequest
-
- copy(hashes) - Method in class net.corda.core.flows.FetchDataFlow.Request
-
- copy(fromDisk, downloaded) - Method in class net.corda.core.flows.FetchDataFlow.Result
-
- copy(participant, wellKnown) - Method in class net.corda.core.flows.FinalityFlow.Participant
-
- copy(party) - Method in class net.corda.core.flows.FlowInitiator.Peer
-
Started when we get new session initiation request.
- copy(username) - Method in class net.corda.core.flows.FlowInitiator.RPC
-
Started using net.corda.core.messaging.CordaRPCOps.startFlowDynamic.
- copy(scheduledState) - Method in class net.corda.core.flows.FlowInitiator.Scheduled
-
Started as scheduled activity.
- copy(txId, conflict) - Method in class net.corda.core.flows.NotaryError.Conflict
-
- copy(cause) - Method in class net.corda.core.flows.NotaryError.TransactionInvalid
-
- copy(uuid) - Method in class net.corda.core.flows.StateMachineRunId
-
A unique identifier for a single state machine run, valid across node restarts. Note that a single run always
has at least one flow, but that flow may also invoke sub-flows: they all share the same run id.
- copy(id, inputs, timestamp) - Method in class net.corda.core.flows.TransactionParts
-
The minimum amount of information needed to notarise a transaction. Note that this does not include
any sensitive transaction details.
- copy(party, certPath) - Method in class net.corda.core.identity.AnonymousPartyAndPath
-
A pair of an anonymous party and the certificate path to prove it is owned by a well known identity. This class
does not validate the certificate path matches the party, and should not be trusted without being verified, for example
using
IdentityService.verifyAnonymousIdentity.
- copy(party, certificate, certPath) - Method in class net.corda.core.identity.PartyAndCertificate
-
A full party plus the X.509 certificate and path linking the party back to a trust root. Equality of
class PartyAndCertificate
instances is based on the party only, as certificate and path are data associated with the party,
not part of the identifier themselves.
- copy(inputStream, sha256) - Method in class net.corda.core.internal.InputStreamAndHash
-
- copy(snapshot, updates) - Method in class net.corda.core.messaging.DataFeed
-
The Data feed contains a snapshot of the requested data and an Observable of future updates.
- copy(id, returnValue) - Method in class net.corda.core.messaging.FlowHandleImpl
-
- copy(id, returnValue, progress) - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
- copy(id, flowLogicClassName, initiator, progressTrackerStepAndUpdates) - Method in class net.corda.core.messaging.StateMachineInfo
-
- copy(stateMachineRunId, transactionId) - Method in class net.corda.core.messaging.StateMachineTransactionMapping
-
- copy(stateMachineInfo) - Method in class net.corda.core.messaging.StateMachineUpdate.Added
-
- copy(id, result) - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
-
- copy(addresses, legalIdentityAndCert, legalIdentitiesAndCerts, platformVersion, advertisedServices, worldMapLocation) - Method in class net.corda.core.node.NodeInfo
-
Info about a network node that acts on behalf of some form of contract party.
- copy(info, identity) - Method in class net.corda.core.node.ServiceEntry
-
Information for an advertised service including the service specific identity information.
The identity can be used in flows and is distinct from the Node's legalIdentity
- copy(node) - Method in class net.corda.core.node.services.MapChange.Added
-
- copy(node, previousNode) - Method in class net.corda.core.node.services.MapChange.Modified
-
- copy(node) - Method in class net.corda.core.node.services.MapChange.Removed
-
- copy(node) - Method in class net.corda.core.node.services.PartyInfo.Node
-
- copy(service) - Method in class net.corda.core.node.services.PartyInfo.Service
-
- copy(type, name) - Method in class net.corda.core.node.services.ServiceInfo
-
A container for additional information for an advertised service.
- copy(stateHistory) - Method in class net.corda.core.node.services.UniquenessProvider.Conflict
-
Specifies the consuming transaction for every conflicting state
- copy(id, inputIndex, requestingParty) - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
Specifies the transaction id, the position of the consumed state in the inputs, and
the caller identity requesting the commit.
- copy(type) - Method in class net.corda.core.node.services.vault.ColumnPredicate.AggregateFunction
-
- copy(rightFromLiteral, rightToLiteral) - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
-
- copy(operator, rightLiteral) - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
-
- copy(operator, rightLiteral) - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
-
- copy(operator, rightLiteral) - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
-
- copy(operator, rightLiteral) - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
-
- copy(operator) - Method in class net.corda.core.node.services.vault.ColumnPredicate.NullExpression
-
- copy(column, predicate, groupByColumns, orderBy) - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- copy(left, right, operator) - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
-
- copy(column, predicate) - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
-
- copy(expression) - Method in class net.corda.core.node.services.vault.CriteriaExpression.Not
-
- copy(states, statesMetadata, totalStatesAvailable, stateTypes, otherResults) - Method in class net.corda.core.node.services.Vault.Page
-
Returned in queries VaultService.queryBy and VaultService.trackBy.
A Page contains:
- copy(pageNumber, pageSize) - Method in class net.corda.core.node.services.vault.PageSpecification
-
class PageSpecification
allows specification of a page number (starting from DEFAULT_PAGE_NUM) and page size
(defaulting to DEFAULT_PAGE_SIZE with a maximum page size of MAX_PAGE_SIZE)
Note: we default the page number to DEFAULT_PAGE_SIZE to enable queries without requiring a page specification
but enabling detection of large results sets that fall out of the DEFAULT_PAGE_SIZE requirement.
MAX_PAGE_SIZE should be used with extreme caution as results may exceed your JVM memory footprint.
- copy(participants, owner, quantity, issuerPartyName, issuerRef, status) - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- copy(participants, linearId, dealRef, status) - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- copy(type, predicate) - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
-
- copy(expression, status) - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
VaultCustomQueryCriteria: provides query by custom attributes defined in a contracts
QueryableState implementation.
(see Persistence documentation for more information)
- copy(status, contractStateTypes, stateRefs, notaryName, includeSoftlockedStates, timeCondition) - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- copy(columns) - Method in class net.corda.core.node.services.vault.Sort
-
Sort allows specification of a set of entity attribute names and their associated directionality
and null handling, to be applied upon processing a query specification.
- copy(sortAttribute, direction) - Method in class net.corda.core.node.services.vault.Sort.SortColumn
-
- copy(entityStateClass, entityStateColumnName) - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
-
entityStateClass should reference a persistent state entity
entityStateColumnName should reference an entity attribute name as defined by the associated mapped schema
(for example,
CashSchemaV1.PersistentCashStatecurrency.name)
- copy(attribute) - Method in class net.corda.core.node.services.vault.SortAttribute.Standard
-
sortAttribute refers to common table attributes defined in the node schemas:
VaultState, VaultLinearStates, VaultFungibleStates
- copy(ref, contractStateClassName, recordedTime, consumedTime, status, notaryName, notaryKey, lockId, lockUpdateTime) - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- copy(consumed, produced, flowId) - Method in class net.corda.core.node.services.Vault.Update
-
Represents an update observed by the vault that will be notified to observers. Include the
class StateRef
s of
transaction outputs that were consumed (inputs) and the
interface ContractState
s produced (outputs) to/by the transaction
or transactions observed and the vault.
- copy(latitude, longitude) - Method in class net.corda.core.node.WorldCoordinate
-
A latitude/longitude pair.
- copy(coordinate, description, countryCode) - Method in class net.corda.core.node.WorldMapLocation
-
A labelled
class WorldCoordinate
, where the label is human meaningful. For example, the name of the nearest city.
Labels should not refer to non-landmarks, for example, they should not contain the names of organisations.
The countryCode field is a two letter ISO country code.
- copy(txId, index) - Method in class net.corda.core.schemas.PersistentStateRef
-
- copy(name, value) - Method in class net.corda.core.serialization.amqp.Choice
-
- copy(name, label, provides, descriptor, fields) - Method in class net.corda.core.serialization.amqp.CompositeType
-
- copy(epochSeconds, nanos) - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
-
- copy(declaringClass, methodName, fileName, lineNumber) - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- copy(name, code) - Method in class net.corda.core.serialization.amqp.Descriptor
-
- copy(obj, schema) - Method in class net.corda.core.serialization.amqp.Envelope
-
This class wraps all serialized data, so that the schema can be carried along with it. We will provide various internal utilities
to decompose and recompose with/without schema etc so that e.g. we can store objects with a (relationally) normalised out schema to
avoid excessive duplication.
- copy(name, type, requires, p, label, mandatory, multiple) - Method in class net.corda.core.serialization.amqp.Field
-
- copy(obj, envelope) - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
-
- copy(name, label, provides, source, descriptor, choices) - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- copy(types) - Method in class net.corda.core.serialization.amqp.Schema
-
This and the classes below are OO representations of the AMQP XML schema described in the specification. Their
Schema.toString
representations generate the associated XML form.
- copy(carpenterSchemas, dependencies, dependsOn) - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
Generated from an AMQP schema this class represents the classes unknown to the deserialiser and that thusly
require carpenting up in bytecode form. This is a multi step process as carpenting one object may be depedent
upon the creation of others, this information is tracked in the dependency tree represented by
dependencies and dependsOn. Creatable classes are stored in carpenterSchemas.
- copy(name, field) - Method in class net.corda.core.serialization.carpenter.Field
-
- copy(name, field) - Method in class net.corda.core.serialization.carpenter.NonNullableField
-
- copy(name, field) - Method in class net.corda.core.serialization.carpenter.NullableField
-
- copy(inputs, outputs, groupingKey) - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
A set of related inputs and outputs that are connected by some common attributes. An InOutGroup is calculated
using groupStates and is useful for handling cases where a transaction may contain similar but unrelated
state evolutions, for example, a transaction that moves cash in two different currencies. The numbers must add
up on both sides of the transaction, but the values must be summed independently per currency. Grouping can
be used to simplify this logic.
- copy(txBits, sigs) - Method in class net.corda.core.transactions.SignedTransaction
-
SignedTransaction wraps a serialized WireTransaction. It contains one or more signatures, each one for
a public key (including composite keys) that is mentioned inside a transaction command. SignedTransaction is the top level transaction type
and the type most frequently passed around the network and stored. The identity of a transaction is the hash of Merkle root
of a WireTransaction, therefore if you are storing data keyed by WT hash be aware that multiple different STs may
map to the same key (and they could be different in important ways, like validity!). The signatures on a
SignedTransaction might be invalid or missing: the type does not imply validity.
A transaction ID should be the hash of the
class WireTransaction
Merkle tree root. Thus adding or removing a signature does not change it.
- copy() - Method in class net.corda.core.transactions.TransactionBuilder
-
Creates a copy of the builder.
- copy() - Method in class net.corda.core.utilities.ByteSequence
-
Copy this sequence, complete with new backing array. This can be helpful to break references to potentially
large backing arrays from small sub-sequences.
- copy(host, port) - Method in class net.corda.core.utilities.NetworkHostAndPort
-
Tuple of host and port. Use parseNetworkHostAndPort on untrusted data.
- copy(tracker, newStep) - Method in class net.corda.core.utilities.Change.Position
-
- copy(tracker, ofStep) - Method in class net.corda.core.utilities.Change.Rendering
-
- copy(tracker, parent) - Method in class net.corda.core.utilities.Change.Structural
-
- copy(exception) - Method in class net.corda.core.utilities.Try.Failure
-
- copy(value) - Method in class net.corda.core.utilities.Try.Success
-
- copy(stx, recipient) - Method in class net.corda.flows.AbstractCashFlow.Result
-
Combined signed transaction and identity lookup map, which is the resulting data from regular cash flows.
Specialised flows for unit tests differ from this.
- copy(amount, issueRef) - Method in class net.corda.flows.CashFlowCommand.ExitCash
-
Exit cash from the ledger.
- copy(amount, issueRef, recipient, notary, anonymous) - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
A command to initiate the Cash flow with.
- copy(amount, recipient, issuerConstraint, anonymous) - Method in class net.corda.flows.CashFlowCommand.PayCash
-
Pay cash to someone else.
- copy(amount, issueToParty, issuerPartyRef, notaryParty, anonymous) - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- copy(notary, dealBeingOffered) - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
-
- copy(payload, publicKey) - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
-
- copy(assetForSale, price, sellerOwner) - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- copy(holidayDates) - Method in class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
-
- copy(baseDirectory, configFile, help, loggingLevel, logToConsole, isRegistration, isVersion, noLocalShell, sshdServer) - Method in class net.corda.node.CmdLineOptions
-
- copy(version, factory) - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
-
- copy(factory) - Method in class net.corda.node.internal.InitiatedFlowFactory.Core
-
- copy(address, legalName) - Method in class net.corda.node.internal.NetworkMapInfo
-
- copy(timestamp, principal, description, contextData, flowType, flowId, auditEventType) - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
Sealed data class to record custom application specified flow event.
- copy(timestamp, principal, description, contextData, flowType, flowId, error) - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
Sealed data class to record any FlowExceptions, or other unexpected terminations of a Flow.
- copy(timestamp, principal, description, contextData, flowType, flowId, permissionRequested, permissionGranted) - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
Sealed data class to record checks on per flow permissions and the verdict of these checks
If the permission is denied i.e. permissionGranted is false, then it is expected that the flow will be terminated immediately
after recording the FlowPermissionAuditEvent. This may cause an extra FlowErrorAuditEvent to be recorded too.
- copy(timestamp, principal, description, flowType, flowId, flowProgress) - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
Sealed data class to record ProgressTracker Step object whenever a change is signalled.
The API for ProgressTracker has been extended so that the Step can contain some extra context data,
which is copied into the contextData Map.
- copy(timestamp, principal, description, contextData, flowType, flowId) - Method in class net.corda.node.services.api.FlowStartEvent
-
Sealed data class to record the initiation of a new flow.
The flow parameters should be captured to the context data.
- copy(databaseSchema, tablePrefix) - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
-
Represents any options configured on the node for a schema.
- copy(timestamp, principal, description, contextData) - Method in class net.corda.node.services.api.SystemAuditEvent
-
Sealed data class to mark system related events as a distinct category.
- copy(role, policy, trustedAliases) - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- copy(basedir, myLegalName, emailAddress, keyStorePassword, trustStorePassword, dataSourceProperties, certificateSigningService, networkMapService, minimumPlatformVersion, rpcUsers, verifierType, messageRedeliveryDelaySeconds, useHTTPS, p2pAddress, rpcAddress, messagingServerAddress, extraAdvertisedServiceIds, bftReplicaId, notaryNodeAddress, notaryClusterAddresses, certificateChainCheckPolicies, devMode, useTestClock, detectPublicIp) - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- copy(trustedAliases) - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
-
- copy(topicSession, callback) - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
-
A registration to handle messages of different types
- copy(currentUser) - Method in class net.corda.node.services.messaging.RpcContext
-
- copy(rpcThreadPoolSize, consumerPoolSize, producerPoolBound, reapInterval) - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
- copy(topic, sessionID) - Method in class net.corda.node.services.messaging.TopicSession
-
- copy(mapVersion) - Method in class net.corda.node.services.network.LastAcknowledgeInfo
-
- copy(subscribe, ifChangedSinceVersion, replyTo, sessionID) - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- copy(nodes, version) - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
-
- copy(identity, replyTo, sessionID) - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
-
- copy(node) - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityResponse
-
- copy(wireReg, replyTo, sessionID) - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
-
- copy(error) - Method in class net.corda.node.services.network.NetworkMapService.RegistrationResponse
-
If error is null then the registration was successful. If not null then it wasn't and it explains why
- copy(subscribe, replyTo, sessionID) - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- copy(confirmed) - Method in class net.corda.node.services.network.NetworkMapService.SubscribeResponse
-
- copy(wireReg, mapVersion, replyTo) - Method in class net.corda.node.services.network.NetworkMapService.Update
-
- copy(mapVersion, replyTo) - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
-
- copy(node, serial, type, expires) - Method in class net.corda.node.services.network.NodeRegistration
-
A node registration state in the network map.
- copy(reg, mapVersion) - Method in class net.corda.node.services.network.NodeRegistrationInfo
-
- copy(recipientSessionId, errorResponse) - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
-
- copy(flowLogicClassName, appContext, args) - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
-
The internal concrete implementation of the FlowLogicRef marker interface.
- copy(peerParty, peerSessionId) - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
-
- copy(otherParty) - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiating
-
otherParty may be a specific peer or a service party
- copy(recipientSessionId) - Method in class net.corda.node.services.statemachine.NormalSessionEnd
-
- copy(sender, message) - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
-
- copy(session, receiveType, userReceiveType) - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- copy(session, message, receiveType, userReceiveType) - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- copy(session, message) - Method in class net.corda.node.services.statemachine.SendOnly
-
- copy(initiatorSessionId, initiatedSessionId) - Method in class net.corda.node.services.statemachine.SessionConfirm
-
- copy(recipientSessionId, payload) - Method in class net.corda.node.services.statemachine.SessionData
-
- copy(initiatorSessionId, initiatingFlowClass, flowVerison, firstPayload) - Method in class net.corda.node.services.statemachine.SessionInit
-
- copy(initiatorSessionId, errorMessage) - Method in class net.corda.node.services.statemachine.SessionReject
-
- copy(logic) - Method in class net.corda.node.services.statemachine.Change.Add
-
- copy(logic, result) - Method in class net.corda.node.services.statemachine.Change.Removed
-
- copy(hash, fiber) - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
-
- copy(error) - Method in class net.corda.node.services.transactions.ClusterResponse.Error
-
- copy(txSignatures) - Method in class net.corda.node.services.transactions.ClusterResponse.Signatures
-
- copy(tx, callerIdentity) - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
-
- copy(error) - Method in class net.corda.node.services.transactions.ReplicaResponse.Error
-
- copy(txSignature) - Method in class net.corda.node.services.transactions.ReplicaResponse.Signature
-
- copy(txId) - Method in class net.corda.node.utilities.DatabaseTransactionManager.Boundary
-
- copy(name, owningKey, certificate, certPath) - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- copy(name, owningKey) - Method in class net.corda.node.utilities.PartyColumns
-
- copy(txId, index) - Method in class net.corda.node.utilities.StateRefColumns
-
- copy(txId, note) - Method in class net.corda.node.utilities.TxnNoteColumns
-
- copy(platformVersion, releaseVersion, revision, vendor) - Method in class net.corda.node.VersionInfo
-
Encapsulates various pieces of version information of the node.
- copyOf(elements) - Method in class net.corda.core.utilities.NonEmptySet.Companion
-
Returns a non-empty set containing each of elements, minus duplicates, in the order each appears first in
the source collection.
- copyOf(elements) - Static method in class net.corda.core.utilities.NonEmptySet
-
Returns a non-empty set containing each of elements, minus duplicates, in the order each appears first in
the source collection.
- copyTo($receiver, target, options) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- copyToDirectory($receiver, targetDir, options) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- Corda - Class in net.corda.node
-
- CordaClassResolver - Class in net.corda.core.serialization
-
- CordaClassResolver(whitelist, amqpEnabled) - Constructor for class net.corda.core.serialization.CordaClassResolver
-
- CordaClassResolverKt - Class in net.corda.core.serialization
-
- CordaConnection(connection) - Constructor for class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- CordaDataSourceConnectionProvider(dataSource) - Constructor for class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaDataSourceConnectionProvider
-
- CordaException - Exception in net.corda.core
-
- CordaException(message, cause) - Constructor for exception net.corda.core.CordaException
-
- CordaKryo - Class in net.corda.core.serialization
-
We need to disable whitelist checking during calls from our Kryo code to register a serializer, since it checks
for existing registrations and then will enter our CordaClassResolver.getRegistration method.
- CordaKryo(classResolver) - Constructor for class net.corda.core.serialization.CordaKryo
-
We need to disable whitelist checking during calls from our Kryo code to register a serializer, since it checks
for existing registrations and then will enter our CordaClassResolver.getRegistration method.
- CordaObjectIdentifier - Class in net.corda.core.crypto.provider
-
- CordaPersistence - Class in net.corda.node.utilities
-
- CordaPersistence(dataSource) - Constructor for class net.corda.node.utilities.CordaPersistence
-
- CordaPersistence.Companion - Class in net.corda.node.utilities
-
- CordaPersistenceKt - Class in net.corda.node.utilities
-
- CordaPluginRegistry - Class in net.corda.core.node
-
Implement this interface on a class advertised in a META-INF/services/net.corda.core.node.CordaPluginRegistry file
to extend a Corda node with additional application services.
- CordaPluginRegistry() - Constructor for class net.corda.core.node.CordaPluginRegistry
-
Implement this interface on a class advertised in a META-INF/services/net.corda.core.node.CordaPluginRegistry file
to extend a Corda node with additional application services.
- CorDapp(version, factory) - Constructor for class net.corda.node.internal.InitiatedFlowFactory.CorDapp
-
- CordaRPCClient - Class in net.corda.client.rpc
-
- CordaRPCClient(hostAndPort, sslConfiguration, configuration, initialiseSerialization) - Constructor for class net.corda.client.rpc.CordaRPCClient
-
- CordaRPCClient.Companion - Class in net.corda.client.rpc
-
- CordaRPCClientConfiguration - Class in net.corda.client.rpc
-
- CordaRPCClientConfiguration(connectionMaxRetryInterval) - Constructor for class net.corda.client.rpc.CordaRPCClientConfiguration
-
- CordaRPCClientConfiguration.Companion - Class in net.corda.client.rpc
-
- CordaRPCConnection - Class in net.corda.client.rpc
-
- CordaRPCOps - Interface in net.corda.core.messaging
-
RPC operations that the node exposes to clients using the Java client library. These can be called from
client apps and are implemented by the node in the
class CordaRPCOpsImpl
class.
- CordaRPCOps.DefaultImpls - Class in net.corda.core.messaging
-
RPC operations that the node exposes to clients using the Java client library. These can be called from
client apps and are implemented by the node in the
class CordaRPCOpsImpl
class.
- CordaRPCOpsImpl - Class in net.corda.node.internal
-
Server side implementations of RPCs available to MQ based client tools. Execution takes place on the server
thread (i.e. serially). Arguments are serialised and deserialised automatically.
- CordaRPCOpsImpl(services, smm, database) - Constructor for class net.corda.node.internal.CordaRPCOpsImpl
-
Server side implementations of RPCs available to MQ based client tools. Execution takes place on the server
thread (i.e. serially). Arguments are serialised and deserialised automatically.
- CordaRPCOpsImpl.Companion - Class in net.corda.node.internal
-
- CordaRPCOpsKt - Class in net.corda.core.messaging
-
- CordaRuntimeException - Exception in net.corda.core
-
- CordaRuntimeException(message, cause) - Constructor for exception net.corda.core.CordaRuntimeException
-
- CordaSecurityProvider - Class in net.corda.core.crypto.provider
-
- CordaSecurityProvider() - Constructor for class net.corda.core.crypto.provider.CordaSecurityProvider
-
- CordaSecurityProvider.Companion - Class in net.corda.core.crypto.provider
-
- CordaSerializable - Interface in net.corda.core.serialization
-
This annotation is a marker to indicate that a class is permitted and intended to be serialized as part of Node messaging.
- cordaService(type) - Method in interface net.corda.core.node.ServiceHub
-
Return the singleton instance of the given Corda service type. This is a class that is annotated with
interface CordaService
and will have automatically been registered by the node.
- CordaService - Interface in net.corda.core.node.services
-
Annotate any class that needs to be a long-lived service within the node, such as an oracle, with this annotation.
Such a class needs to have a constructor with a single parameter of type
interface PluginServiceHub
. This
construtor will be invoked during node start to initialise the service. The service hub provided can be used to get
information about the node that may be necessary for the service. Corda services are created as singletons within
the node and are available to flows via net.corda.core.node.ServiceHub.cordaService.
- CordaThrowable - Interface in net.corda.core
-
- Core(factory) - Constructor for class net.corda.node.internal.InitiatedFlowFactory.Core
-
- count($receiver) - Method in class net.corda.core.node.services.vault.Builder
-
- count($receiver) - Static method in class net.corda.core.node.services.vault.Builder
-
- create(sourceMap, assemble) - Method in class net.corda.client.jfx.utils.MapValuesList.Companion
-
- create(xs, ys) - Method in class net.corda.contracts.math.CubicSplineInterpolator.Factory
-
- create(xs, ys) - Method in interface net.corda.contracts.math.InterpolatorFactory
-
- create(xs, ys) - Method in class net.corda.contracts.math.LinearInterpolator.Factory
-
- create(flowClass, args) - Method in interface net.corda.core.flows.FlowLogicRefFactory
-
- create(flowClass, args) - Method in class net.corda.node.services.statemachine.FlowLogicRefFactoryImpl
-
- createArrayOf(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createBlob() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createCertificate(certificateType, issuer, subject, subjectPublicKey, validityWindow, nameConstraints) - Method in class net.corda.core.crypto.Crypto
-
Build a partial X.509 certificate ready for signing.
- createCertificate(certificateType, issuer, issuerSigner, subject, subjectPublicKey, validityWindow, nameConstraints) - Method in class net.corda.core.crypto.Crypto
-
Build and sign an X.509 certificate with the given signer.
- createCertificate(certificateType, issuer, issuerKeyPair, subject, subjectPublicKey, validityWindow, nameConstraints) - Method in class net.corda.core.crypto.Crypto
-
Build and sign an X.509 certificate with CA cert private key.
- createCertificate(certificateType, issuerCertificate, issuerKeyPair, subject, subjectPublicKey, validityWindow, nameConstraints) - Static method in class net.corda.core.crypto.X509Utilities
-
Create a X509 v3 cert.
- createCertificateSigningRequest(subject, keyPair, signatureScheme) - Method in class net.corda.core.crypto.Crypto
-
Create certificate signing request using provided information.
- createCertificateSigningRequest(subject, keyPair, signatureScheme) - Method in class net.corda.core.crypto.X509Utilities
-
- createCheck(keyStore, trustStore) - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.Any
-
- createCheck(keyStore, trustStore) - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy
-
- createCheck(keyStore, trustStore) - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.LeafMustMatch
-
- createCheck(keyStore, trustStore) - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
-
- createCheck(keyStore, trustStore) - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.RootMustMatch
-
- createClob() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createConnector(configuration, handler, listener, closeExecutor, threadPool, scheduledThreadPool, protocolManager) - Method in class net.corda.node.services.messaging.VerifyingNettyConnectorFactory
-
- createContext(serializationContext, observableContext) - Method in class net.corda.client.rpc.internal.RpcClientObservableSerializer
-
- createContext(observableContext) - Method in class net.corda.node.services.messaging.RpcServerObservableSerializer
-
- createDefaultMapper(rpc, factory, fuzzyIdentityMatch) - Static method in class net.corda.jackson.JacksonSupport
-
Creates a Jackson ObjectMapper that uses RPC to deserialise parties from string names.
- createDefaultMapper(rpc, factory) - Static method in class net.corda.jackson.JacksonSupport
-
Creates a Jackson ObjectMapper that uses RPC to deserialise parties from string names.
- createDefaultMapper(rpc) - Static method in class net.corda.jackson.JacksonSupport
-
Creates a Jackson ObjectMapper that uses RPC to deserialise parties from string names.
- createDirectories($receiver, attrs) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- createDirectory($receiver, attrs) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- createFlow(platformVersion, otherParty, sessionInit) - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
-
- createFlow(platformVersion, otherParty, sessionInit) - Method in class net.corda.node.internal.InitiatedFlowFactory.Core
-
- createFlow(platformVersion, otherParty, sessionInit) - Method in interface net.corda.node.internal.InitiatedFlowFactory
-
- createForRPC(flowClass, args) - Method in class net.corda.node.services.statemachine.FlowLogicRefFactoryImpl
-
- createGenericSchedule(startDate, period, calendar, dateRollConvention, noOfAdditionalPeriods, endDate, periodOffset) - Method in class net.corda.contracts.BusinessCalendar.Companion
-
Calculates an event schedule that moves events around to ensure they fall on working days.
- createInMemoryMapper(identityService, factory, fuzzyIdentityMatch) - Static method in class net.corda.jackson.JacksonSupport
-
Creates a Jackson ObjectMapper that uses an
interface IdentityService
directly inside the node to deserialise parties from string names.
- createInMemoryMapper(identityService, factory) - Static method in class net.corda.jackson.JacksonSupport
-
Creates a Jackson ObjectMapper that uses an
interface IdentityService
directly inside the node to deserialise parties from string names.
- createInMemoryMapper(identityService) - Static method in class net.corda.jackson.JacksonSupport
-
Creates a Jackson ObjectMapper that uses an
interface IdentityService
directly inside the node to deserialise parties from string names.
- createInMemoryTestZip(numOfExpectedBytes, content) - Method in class net.corda.core.internal.InputStreamAndHash.Companion
-
Get a valid InputStream from an in-memory zip as required for some tests. The zip consists of a single file
called "z" that contains the given content byte repeated the given number of times.
Note that a slightly bigger than numOfExpectedBytes size is expected.
- createKeystoreForCordaNode(sslKeyStorePath, clientCAKeystorePath, storePassword, keyPassword, caKeyStore, caKeyPassword, legalName, signatureScheme) - Static method in class net.corda.node.services.config.ConfigUtilitiesKt
-
An all in wrapper to manufacture a server certificate and keys all stored in a KeyStore suitable for running TLS on the local machine.
- createMapChange($receiver, key, removedValue, addedValue) - Static method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBaseKt
-
- createMessage($receiver, topic, sessionID, data) - Static method in class net.corda.node.services.messaging.MessagingKt
-
Returns an initialised
interface Message
with the current time, etc, already filled in.
- createMessage(topicSession, data, uuid) - Method in interface net.corda.node.services.messaging.MessagingService
-
Returns an initialised
interface Message
with the current time, etc, already filled in.
- createMessage(topicSession, data, uuid) - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
Returns an initialised
interface Message
with the current time, etc, already filled in.
- createNClob() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createNode(conf, versionInfo, services) - Method in class net.corda.node.internal.NodeStartup
-
- createNonRpcMapper(factory) - Static method in class net.corda.jackson.JacksonSupport
-
For testing or situations where deserialising parties is not required
- createNonRpcMapper() - Static method in class net.corda.jackson.JacksonSupport
-
For testing or situations where deserialising parties is not required
- createRandom() - Method in class net.corda.core.flows.StateMachineRunId.Companion
-
- createSelfSignedCACertificate(subject, keyPair, validityWindow) - Static method in class net.corda.core.crypto.X509Utilities
-
- createServiceFlow(otherParty, platformVersion) - Method in class net.corda.core.node.services.NotaryService
-
Produces a notary service flow which has the corresponding sends and receives as
NotaryFlow.Client.
The first parameter is the client
class Party
making the request and the second is the platform version
of the client's node. Use this version parameter to provide backwards compatibility if the notary flow protocol
changes.
- createServiceFlow(otherParty, platformVersion) - Method in class net.corda.node.services.transactions.BFTNonValidatingNotaryService
-
Produces a notary service flow which has the corresponding sends and receives as
NotaryFlow.Client.
The first parameter is the client
class Party
making the request and the second is the platform version
of the client's node. Use this version parameter to provide backwards compatibility if the notary flow protocol
changes.
- createServiceFlow(otherParty, platformVersion) - Method in class net.corda.node.services.transactions.RaftNonValidatingNotaryService
-
Produces a notary service flow which has the corresponding sends and receives as
class NotaryFlow.Client
.
The first parameter is the client
class Party
making the request and the second is the platform version
of the client's node. Use this version parameter to provide backwards compatibility if the notary flow protocol
changes.
- createServiceFlow(otherParty, platformVersion) - Method in class net.corda.node.services.transactions.RaftValidatingNotaryService
-
Produces a notary service flow which has the corresponding sends and receives as
class NotaryFlow.Client
.
The first parameter is the client
class Party
making the request and the second is the platform version
of the client's node. Use this version parameter to provide backwards compatibility if the notary flow protocol
changes.
- createServiceFlow(otherParty, platformVersion) - Method in class net.corda.node.services.transactions.SimpleNotaryService
-
Produces a notary service flow which has the corresponding sends and receives as
class NotaryFlow.Client
.
The first parameter is the client
class Party
making the request and the second is the platform version
of the client's node. Use this version parameter to provide backwards compatibility if the notary flow protocol
changes.
- createServiceFlow(otherParty, platformVersion) - Method in class net.corda.node.services.transactions.ValidatingNotaryService
-
Produces a notary service flow which has the corresponding sends and receives as
class NotaryFlow.Client
.
The first parameter is the client
class Party
making the request and the second is the platform version
of the client's node. Use this version parameter to provide backwards compatibility if the notary flow protocol
changes.
- createSignature($this, signedTransaction, publicKey) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- createSignature($this, signedTransaction) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- createSignature(signedTransaction, publicKey) - Method in interface net.corda.core.node.ServiceHub
-
- createSignature(signedTransaction) - Method in interface net.corda.core.node.ServiceHub
-
Helper method to create an additional signature for an existing (partially) SignedTransaction
using the default identity signing key of the node.
- createSignature($this, signedTransaction, publicKey) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
- createSignature($this, signedTransaction) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
Helper method to create an additional signature for an existing (partially) SignedTransaction
using the default identity signing key of the node.
- createSignature($this, signedTransaction, publicKey) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- createSignature($this, signedTransaction) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- createSQLXML() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createStatement() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createStatement(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createStatement(p0, p1, p2) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createStreamFromStateMachineInfo(stateMachine) - Method in class net.corda.client.jfx.model.ProgressTrackingEvent.Companion
-
- createStruct(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- createTransaction() - Method in class net.corda.node.utilities.CordaPersistence
-
- CriteriaExpression<O,T> - Class in net.corda.core.node.services.vault
-
- CriteriaExpression.AggregateFunctionExpression<O,C> - Class in net.corda.core.node.services.vault
-
- CriteriaExpression.BinaryLogical<O> - Class in net.corda.core.node.services.vault
-
- CriteriaExpression.ColumnPredicateExpression<O,C> - Class in net.corda.core.node.services.vault
-
- CriteriaExpression.Not<O> - Class in net.corda.core.node.services.vault
-
- Crypto - Class in net.corda.core.crypto
-
This object controls and provides the available and supported signature schemes for Corda.
Any implemented
class SignatureScheme
should be strictly defined here.
However, only the schemes returned by {@link #listSupportedSignatureSchemes()} are supported.
Note that Corda currently supports the following signature schemes by their code names:
- CryptoUtils - Class in net.corda.core.crypto
-
- CubicSplineInterpolator - Class in net.corda.contracts.math
-
- CubicSplineInterpolator(xs, ys) - Constructor for class net.corda.contracts.math.CubicSplineInterpolator
-
- CubicSplineInterpolator.Factory - Class in net.corda.contracts.math
-
- currency(code) - Static method in class net.corda.core.contracts.ContractsDSL
-
Defines a simple domain specific language for the specification of financial contracts. Currently covers:
- CurrencySerializer - Class in net.corda.core.serialization.amqp.custom
-
A custom serializer for the
Currency class, utilizing the currency code string representation.
- current() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- currentNodeTime() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Returns the node's current time.
- currentNodeTime() - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Returns the node's current time.
- currentOrNew(isolation) - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- currentOrNull() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- currentOrNull() - Method in class net.corda.node.utilities.ExposedTransactionManager
-
- currentStateMachine() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl.Companion
-
- Custom(entityStateClass, entityStateColumnName) - Constructor for class net.corda.core.node.services.vault.SortAttribute.Custom
-
entityStateClass should reference a persistent state entity
entityStateColumnName should reference an entity attribute name as defined by the associated mapped schema
(for example,
CashSchemaV1.PersistentCashStatecurrency.name)
- customize(kryo) - Method in class net.corda.core.serialization.DefaultKryoCustomizer
-
- customizeSerialization(custom) - Method in class net.corda.core.node.CordaPluginRegistry
-
Optionally whitelist types for use in object serialization, as we lock down the types that can be serialized.
- CustomSerializer<T> - Class in net.corda.core.serialization.amqp
-
Base class for serializers of core platform types that do not conform to the usual serialization rules and thus
cannot be automatically serialized.
- CustomSerializer() - Constructor for class net.corda.core.serialization.amqp.CustomSerializer
-
Base class for serializers of core platform types that do not conform to the usual serialization rules and thus
cannot be automatically serialized.
- CustomSerializer.Implements<T> - Class in net.corda.core.serialization.amqp
-
Additional base features for a custom serializer for all implementations of a particular interface or super class.
- CustomSerializer.Is<T> - Class in net.corda.core.serialization.amqp
-
Additional base features for a custom serializer for a particular class, that excludes subclasses.
- CustomSerializer.Proxy<T,P> - Class in net.corda.core.serialization.amqp
-
- CustomSerializer.SubClass<T> - Class in net.corda.core.serialization.amqp
-
This custom serializer represents a sort of symbolic link from a subclass to a super class, where the super
class custom serializer is responsible for the "on the wire" format but we want to create a reference to the
subclass in the schema, so that we can distinguish between subclasses.
- CustomSerializer.ToString<T> - Class in net.corda.core.serialization.amqp
-
A custom serializer where the on-wire representation is a string. For example, a
Currency might be represented
as a 3 character currency code, and converted to and from that string. By default, it is assumed that the
toString method will generate the string representation and that there is a constructor that takes such a
string as an argument to reconstruct.
- Factory - Static variable in class net.corda.contracts.math.CubicSplineInterpolator
-
- Factory - Static variable in class net.corda.contracts.math.LinearInterpolator
-
- fail(error) - Method in class net.corda.client.mock.Generator.Companion
-
- FailedParse(e) - Constructor for exception net.corda.jackson.UnparseableCallException.FailedParse
-
- Failure(exception) - Constructor for class net.corda.core.utilities.Try.Failure
-
- FetchAttachmentsFlow - Class in net.corda.core.flows
-
Given a set of hashes either loads from from local storage or requests them from the other peer. Downloaded
attachments are saved to local storage automatically.
- FetchAttachmentsFlow(requests, otherSide) - Constructor for class net.corda.core.flows.FetchAttachmentsFlow
-
Given a set of hashes either loads from from local storage or requests them from the other peer. Downloaded
attachments are saved to local storage automatically.
- FetchAttachmentsHandler - Class in net.corda.node.services
-
- FetchAttachmentsHandler(otherParty) - Constructor for class net.corda.node.services.FetchAttachmentsHandler
-
- FetchDataFlow<T extends NamedByHash,W> - Class in net.corda.core.flows
-
An abstract flow for fetching typed data from a remote peer.
- FetchDataFlow(requests, otherSide, wrapperType) - Constructor for class net.corda.core.flows.FetchDataFlow
-
An abstract flow for fetching typed data from a remote peer.
- FetchDataFlow.DownloadedVsRequestedDataMismatch - Exception in net.corda.core.flows
-
- FetchDataFlow.DownloadedVsRequestedSizeMismatch - Exception in net.corda.core.flows
-
- FetchDataFlow.HashNotFound - Exception in net.corda.core.flows
-
- FetchDataFlow.Request - Class in net.corda.core.flows
-
- FetchDataFlow.Result<T extends NamedByHash> - Class in net.corda.core.flows
-
- FetchDataHandler<T> - Class in net.corda.node.services
-
- FetchDataHandler(otherParty) - Constructor for class net.corda.node.services.FetchDataHandler
-
- fetchFrom($this, fetcher) - Static method in class net.corda.node.utilities.AffinityExecutor.DefaultImpls
-
Runs the given function on the executor, blocking until the result is available. Be careful not to deadlock this
way! Make sure the executor can't possibly be waiting for the calling thread.
- fetchFrom(fetcher) - Method in interface net.corda.node.utilities.AffinityExecutor
-
Runs the given function on the executor, blocking until the result is available. Be careful not to deadlock this
way! Make sure the executor can't possibly be waiting for the calling thread.
- FetchMapRequest(subscribe, ifChangedSinceVersion, replyTo, sessionID) - Constructor for class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- FetchMapResponse(nodes, version) - Constructor for class net.corda.node.services.network.NetworkMapService.FetchMapResponse
-
- FetchTransactionsFlow - Class in net.corda.core.flows
-
Given a set of tx hashes (IDs), either loads them from local disk or asks the remote peer to provide them.
- FetchTransactionsFlow(requests, otherSide) - Constructor for class net.corda.core.flows.FetchTransactionsFlow
-
Given a set of tx hashes (IDs), either loads them from local disk or asks the remote peer to provide them.
- FetchTransactionsHandler - Class in net.corda.node.services
-
This class sets up network message handlers for requests from peers for data keyed by hash. It is a piece of simple
glue that sits between the network layer and the database layer.
- FetchTransactionsHandler(otherParty) - Constructor for class net.corda.node.services.FetchTransactionsHandler
-
This class sets up network message handlers for requests from peers for data keyed by hash. It is a piece of simple
glue that sits between the network layer and the database layer.
- FiberScheduler() - Constructor for class net.corda.node.services.statemachine.StateMachineManager.FiberScheduler
-
- Field - Class in net.corda.core.serialization.amqp
-
- Field(name, type, requires, p, label, mandatory, multiple) - Constructor for class net.corda.core.serialization.amqp.Field
-
- Field - Class in net.corda.core.serialization.carpenter
-
- Field(field) - Constructor for class net.corda.core.serialization.carpenter.Field
-
- Field.Companion - Class in net.corda.core.serialization.amqp
-
- Field.Companion - Class in net.corda.core.serialization.carpenter
-
- FieldFactory - Class in net.corda.core.serialization.carpenter
-
- fieldsIncludingSuperclasses() - Method in class net.corda.core.serialization.carpenter.Schema
-
- FileUploader - Interface in net.corda.node.services.api
-
An interface that denotes a service that can accept file uploads.
- filter($receiver, predicate) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
enum class FilterCriterion { HEIGHT, NAME }
val filterCriterion: ObservableValue = (..)
val people: ObservableList = (..)
fun filterFunction(filterCriterion: FilterCriterion): (Person) -> Boolean { .. }
- filterCommands(clazz, predicate) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify filtering
class Command
items according to a Predicate.
- FilteredLeaves - Class in net.corda.core.transactions
-
- FilteredLeaves(inputs, attachments, outputs, commands, notary, mustSign, type, timeWindow) - Constructor for class net.corda.core.transactions.FilteredLeaves
-
- FilteredTransaction - Class in net.corda.core.transactions
-
Class representing merkleized filtered transaction.
- FilteredTransaction.Companion - Class in net.corda.core.transactions
-
- filterInputs(clazz, predicate) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify filtering inputs according to a Predicate.
- filterInRefs(clazz, predicate) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify filtering inputs according to a Predicate.
- filterMyKeys(candidateKeys) - Method in interface net.corda.core.node.services.KeyManagementService
-
Filter some keys down to the set that this node owns (has private keys for).
- filterMyKeys(candidateKeys) - Method in class net.corda.node.services.keys.E2ETestKeyManagementService
-
Filter some keys down to the set that this node owns (has private keys for).
- filterMyKeys(candidateKeys) - Method in class net.corda.node.services.keys.PersistentKeyManagementService
-
Filter some keys down to the set that this node owns (has private keys for).
- filterNotNull($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
data class Dog(val owner: Person?)
val dogs: ObservableList = (..)
val owners: ObservableList = dogs.map(Dog::owner).filterNotNull()
- FilterOn<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Filter the states that are passed through to the wrapped clause, to restrict them to a specific type.
- FilterOn(clause, filterStates) - Constructor for class net.corda.core.contracts.clauses.FilterOn
-
Filter the states that are passed through to the wrapped clause, to restrict them to a specific type.
- filterOutputs(clazz, predicate) - Method in class net.corda.core.transactions.BaseTransaction
-
Helper to simplify filtering outputs according to a Predicate.
- filterOutRefs(clazz, predicate) - Method in class net.corda.core.transactions.BaseTransaction
-
Helper to simplify filtering output
class StateAndRef
items according to a Predicate.
- filterWithFun(filtering) - Method in class net.corda.core.transactions.WireTransaction
-
Construction of partial transaction from WireTransaction based on filtering.
- finaliseTx(participants, tx, message) - Method in class net.corda.flows.AbstractCashFlow
-
- FinalityFlow - Class in net.corda.core.flows
-
Verifies the given transactions, then sends them to the named notary. If the notary agrees that the transactions
are acceptable then they are from that point onwards committed to the ledger, and will be written through to the
vault. Additionally they will be distributed to the parties reflected in the participants list of the states.
- FinalityFlow(transactions, extraRecipients, progressTracker) - Constructor for class net.corda.core.flows.FinalityFlow
-
Verifies the given transactions, then sends them to the named notary. If the notary agrees that the transactions
are acceptable then they are from that point onwards committed to the ledger, and will be written through to the
vault. Additionally they will be distributed to the parties reflected in the participants list of the states.
- FinalityFlow(transaction, extraParticipants) - Constructor for class net.corda.core.flows.FinalityFlow
-
- FinalityFlow(transaction) - Constructor for class net.corda.core.flows.FinalityFlow
-
- FinalityFlow(transaction, progressTracker) - Constructor for class net.corda.core.flows.FinalityFlow
-
- FinalityFlow.Companion - Class in net.corda.core.flows
-
- FinalityFlow.Participant - Class in net.corda.core.flows
-
- FinanceTypesKt - Class in net.corda.contracts
-
- findClass(name) - Method in class net.corda.core.serialization.AttachmentsClassLoader
-
- findCommand(clazz, predicate) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify finding a single
class Command
items according to a Predicate.
- findInput(clazz, predicate) - Method in class net.corda.core.transactions.LedgerTransaction
-
- findInRef(clazz, predicate) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify finding a single input matching a Predicate.
- findMyLocation() - Method in class net.corda.node.internal.AbstractNode
-
- findOutput(clazz, predicate) - Method in class net.corda.core.transactions.BaseTransaction
-
Helper to simplify finding a single output matching a Predicate.
- findOutRef(clazz, predicate) - Method in class net.corda.core.transactions.BaseTransaction
-
- findResource(name) - Method in class net.corda.core.serialization.AttachmentsClassLoader
-
- findSignatureScheme(algorithm) - Method in class net.corda.core.crypto.Crypto
-
- findSignatureScheme(schemeCodeName) - Method in class net.corda.core.crypto.Crypto
-
Factory pattern to retrieve the corresponding
class SignatureScheme
based on the type of the
String input.
This function is usually called by key generators and verify signature functions.
In case the input is not a key in the supportedSignatureSchemes map, null will be returned.
- findSignatureScheme(key) - Method in class net.corda.core.crypto.Crypto
-
Retrieve the corresponding
class SignatureScheme
based on the type of the input
Key.
This function is usually called when requiring to verify signatures and the signing schemes must be defined.
For the supported signature schemes see
class Crypto
.
- findSignatureScheme(key) - Method in class net.corda.core.crypto.Crypto
-
Retrieve the corresponding
class SignatureScheme
based on the type of the input
Key.
This function is usually called when requiring to verify signatures and the signing schemes must be defined.
For the supported signature schemes see
class Crypto
.
- findStateMachines(flowClass) - Method in class net.corda.node.services.statemachine.StateMachineManager
-
Returns a list of all state machines executing the given flow logic at the top level (subflows do not count)
- fireChange(change) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- first($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
- FirstComposition<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Deprecated.
- FirstComposition(firstClause, remainingClauses) - Constructor for class net.corda.core.contracts.clauses.FirstComposition
-
Deprecated.
Compose a number of clauses, such that the first match is run, and it errors if none is run.
- firstOf(futures, handler) - Static method in class net.corda.core.concurrent.ConcurrencyUtilsKt
-
As soon as a given future becomes done, the handler is invoked with that future as its argument.
The result of the handler is copied into the result future, and the handler isn't invoked again.
If a given future errors after the result future is done, the error is automatically logged.
- FirstOf<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
Compose a number of clauses, such that the first match is run, and it errors if none is run.
- FirstOf(firstClause, remainingClauses) - Constructor for class net.corda.core.contracts.clauses.FirstOf
-
Compose a number of clauses, such that the first match is run, and it errors if none is run.
- FirstOf.Companion - Class in net.corda.core.contracts.clauses
-
- firstOrDefault($receiver, p, predicate) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
Return first element of the observable list as observable value.
Return provided default value if the list is empty.
- firstOrNullObservable($receiver, predicate) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
Return first element of the observable list as observable value.
Return ObservableValue(null) if the list is empty.
- Fix - Class in net.corda.contracts
-
A
class Fix
represents a named interest rate, on a given day, for a given duration. It can be embedded in a tx.
- Fix(of, value) - Constructor for class net.corda.contracts.Fix
-
A
class Fix
represents a named interest rate, on a given day, for a given duration. It can be embedded in a tx.
- FixableDealState - Interface in net.corda.contracts
-
Interface adding fixing specific methods.
- FixOf - Class in net.corda.contracts
-
A
class FixOf
identifies the question side of a fix: what day, tenor and type of fix ("LIBOR", "EURIBOR" etc)
- FixOf(name, forDay, ofTenor) - Constructor for class net.corda.contracts.FixOf
-
A
class FixOf
identifies the question side of a fix: what day, tenor and type of fix ("LIBOR", "EURIBOR" etc)
- flatMap(function) - Method in class net.corda.client.mock.Generator
-
- flatMap(function) - Method in class net.corda.core.utilities.Try
-
- flatMap($receiver, mapper) - Static method in class net.corda.core.Utils
-
- flatten($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
data class Person(val height: ObservableValue)
val people: ObservableList = (..)
val heights: ObservableList = people.map(Person::height).flatten()
- FlattenedList<A> - Class in net.corda.client.jfx.utils
-
class FlattenedList
flattens the passed in list of ObservableValues so that changes in individual updates to the values
are reflected in the exposed list as expected.
- FlattenedList(sourceList) - Constructor for class net.corda.client.jfx.utils.FlattenedList
-
class FlattenedList
flattens the passed in list of ObservableValues so that changes in individual updates to the values
are reflected in the exposed list as expected.
- FlattenedList.WrappedObservableValue<A> - Class in net.corda.client.jfx.utils
-
We maintain an ObservableValue->index map. This is needed because we need the ObservableValue's index in order to
propagate a change and if the listener closure captures the index at the time of the call to
ObservableValue.addListener it will become incorrect if the indices shift around later.
- FlowAppAuditEvent - Class in net.corda.node.services.api
-
Sealed data class to record custom application specified flow event.
- FlowAppAuditEvent(timestamp, principal, description, contextData, flowType, flowId, auditEventType) - Constructor for class net.corda.node.services.api.FlowAppAuditEvent
-
Sealed data class to record custom application specified flow event.
- FlowAuditInfo - Interface in net.corda.node.services.api
-
Interface to mandate flow identification properties
- FlowErrorAuditEvent - Class in net.corda.node.services.api
-
Sealed data class to record any FlowExceptions, or other unexpected terminations of a Flow.
- FlowErrorAuditEvent(timestamp, principal, description, contextData, flowType, flowId, error) - Constructor for class net.corda.node.services.api.FlowErrorAuditEvent
-
Sealed data class to record any FlowExceptions, or other unexpected terminations of a Flow.
- FlowException - Exception in net.corda.core.flows
-
Exception which can be thrown by a
class FlowLogic
at any point in its logic to unexpectedly bring it to a permanent end.
The exception will propagate to all counterparty flows and will be thrown on their end the next time they wait on a
FlowLogic.receive or FlowLogic.sendAndReceive. Any flow which no longer needs to do a receive, or has already ended,
will not receive the exception (if this is required then have them wait for a confirmation message).
- FlowException(message, cause) - Constructor for exception net.corda.core.flows.FlowException
-
Exception which can be thrown by a
class FlowLogic
at any point in its logic to unexpectedly bring it to a permanent end.
The exception will propagate to all counterparty flows and will be thrown on their end the next time they wait on a
FlowLogic.receive or FlowLogic.sendAndReceive. Any flow which no longer needs to do a receive, or has already ended,
will not receive the exception (if this is required then have them wait for a confirmation message).
- FlowException(message) - Constructor for exception net.corda.core.flows.FlowException
-
- FlowException(cause) - Constructor for exception net.corda.core.flows.FlowException
-
- FlowException() - Constructor for exception net.corda.core.flows.FlowException
-
- FlowHandle<A> - Interface in net.corda.core.messaging
-
interface FlowHandle
is a serialisable handle for the started flow, parameterised by the type of the flow's return value.
- FlowHandleImpl<A> - Class in net.corda.core.messaging
-
- FlowHandleImpl(id, returnValue) - Constructor for class net.corda.core.messaging.FlowHandleImpl
-
- FlowHandleKt - Class in net.corda.core.messaging
-
- FlowInitiator - Class in net.corda.core.flows
-
- FlowInitiator.Peer - Class in net.corda.core.flows
-
Started when we get new session initiation request.
- FlowInitiator.RPC - Class in net.corda.core.flows
-
Started using net.corda.core.messaging.CordaRPCOps.startFlowDynamic.
- FlowInitiator.Scheduled - Class in net.corda.core.flows
-
Started as scheduled activity.
- FlowInitiator.Shell - Class in net.corda.core.flows
-
- FlowIORequest - Interface in net.corda.node.services.statemachine
-
- FlowLogic<T> - Class in net.corda.core.flows
-
A sub-class of
class FlowLogic
implements a flow using direct, straight line blocking code. Thus you
can write complex flow logic in an ordinary fashion, without having to think about callbacks, restarting after
a node crash, how many instances of your flow there are running and so on.
- FlowLogic() - Constructor for class net.corda.core.flows.FlowLogic
-
A sub-class of
class FlowLogic
implements a flow using direct, straight line blocking code. Thus you
can write complex flow logic in an ordinary fashion, without having to think about callbacks, restarting after
a node crash, how many instances of your flow there are running and so on.
- FlowLogicRef - Interface in net.corda.core.flows
-
A handle interface representing a
class FlowLogic
instance which would be possible to safely pass out of the contract sandbox.
Use FlowLogicRefFactory to construct a concrete security checked instance.
- FlowLogicRefFactory - Interface in net.corda.core.flows
-
The public factory interface for creating validated FlowLogicRef instances as part of the scheduling framework.
Typically this would be used from within the nextScheduledActivity method of a QueryableState to specify
the flow to run at the scheduled time.
- FlowLogicRefFactoryImpl - Class in net.corda.node.services.statemachine
-
- FlowLogicRefImpl - Class in net.corda.node.services.statemachine
-
The internal concrete implementation of the FlowLogicRef marker interface.
- FlowPermissionAuditEvent - Class in net.corda.node.services.api
-
Sealed data class to record checks on per flow permissions and the verdict of these checks
If the permission is denied i.e. permissionGranted is false, then it is expected that the flow will be terminated immediately
after recording the FlowPermissionAuditEvent. This may cause an extra FlowErrorAuditEvent to be recorded too.
- FlowPermissionAuditEvent(timestamp, principal, description, contextData, flowType, flowId, permissionRequested, permissionGranted) - Constructor for class net.corda.node.services.api.FlowPermissionAuditEvent
-
Sealed data class to record checks on per flow permissions and the verdict of these checks
If the permission is denied i.e. permissionGranted is false, then it is expected that the flow will be terminated immediately
after recording the FlowPermissionAuditEvent. This may cause an extra FlowErrorAuditEvent to be recorded too.
- FlowPermissionException - Exception in net.corda.node.services.statemachine
-
- FlowPermissionException(message) - Constructor for exception net.corda.node.services.statemachine.FlowPermissionException
-
- FlowProgressAuditEvent - Class in net.corda.node.services.api
-
Sealed data class to record ProgressTracker Step object whenever a change is signalled.
The API for ProgressTracker has been extended so that the Step can contain some extra context data,
which is copied into the contextData Map.
- FlowProgressAuditEvent(timestamp, principal, description, flowType, flowId, flowProgress) - Constructor for class net.corda.node.services.api.FlowProgressAuditEvent
-
Sealed data class to record ProgressTracker Step object whenever a change is signalled.
The API for ProgressTracker has been extended so that the Step can contain some extra context data,
which is copied into the contextData Map.
- FlowProgressHandle<A> - Interface in net.corda.core.messaging
-
- FlowProgressHandleImpl<A> - Class in net.corda.core.messaging
-
- FlowProgressHandleImpl(id, returnValue, progress) - Constructor for class net.corda.core.messaging.FlowProgressHandleImpl
-
- FlowSession - Class in net.corda.node.services.statemachine
-
- FlowSession(flow, ourSessionId, initiatingParty, state, retryable) - Constructor for class net.corda.node.services.statemachine.FlowSession
-
- FlowSessionState - Class in net.corda.node.services.statemachine
-
- FlowSessionState.Initiated - Class in net.corda.node.services.statemachine
-
- FlowSessionState.Initiating - Class in net.corda.node.services.statemachine
-
otherParty may be a specific peer or a service party
- FlowStartEvent - Class in net.corda.node.services.api
-
Sealed data class to record the initiation of a new flow.
The flow parameters should be captured to the context data.
- FlowStartEvent(timestamp, principal, description, contextData, flowType, flowId) - Constructor for class net.corda.node.services.api.FlowStartEvent
-
Sealed data class to record the initiation of a new flow.
The flow parameters should be captured to the context data.
- FlowStateMachine<R> - Interface in net.corda.core.internal
-
This is an internal interface that is implemented by code in the node module. You should look at
class FlowLogic
.
- FlowStateMachineImpl<R> - Class in net.corda.node.services.statemachine
-
- FlowStateMachineImpl(id, logic, scheduler, flowInitiator) - Constructor for class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- FlowStateMachineImpl.Companion - Class in net.corda.node.services.statemachine
-
- FlowStateMachineImplKt - Class in net.corda.node.services.statemachine
-
- FlowWatchPrintingSubscriber - Class in net.corda.node.shell
-
- FlowWatchPrintingSubscriber(toStream) - Constructor for class net.corda.node.shell.FlowWatchPrintingSubscriber
-
- flush() - Method in interface net.corda.node.utilities.AffinityExecutor
-
Run the executor until there are no tasks pending and none executing.
- flush() - Method in class net.corda.node.utilities.AffinityExecutor.Gate
-
Run the executor until there are no tasks pending and none executing.
- flush() - Method in class net.corda.node.utilities.AffinityExecutor.ServiceAffinityExecutor
-
Run the executor until there are no tasks pending and none executing.
- fold($receiver, accumulator, folderFun) - Static method in class net.corda.client.jfx.utils.ObservableFoldKt
-
fold takes an rx.Observable stream and applies fold function on it, and collects all elements using the accumulator.
- foldObservable($receiver, initial, folderFunction) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val people: ObservableList = (..)
val concatenatedNames = people.foldObservable("", { names, person -> names + person.name })
val concatenatedNames2 = people.map(Person::name).fold("", String::plus)
- foldToObservableValue($receiver, initial, folderFun) - Static method in class net.corda.client.jfx.utils.ObservableFoldKt
-
foldToObservableValue takes an rx.Observable stream and creates an ObservableValue out of it.
- forEach(action) - Method in class net.corda.core.utilities.NonEmptySet
-
- forEach(block) - Method in interface net.corda.node.services.api.CheckpointStorage
-
Allows the caller to process safely in a thread safe fashion the set of all checkpoints.
The checkpoints are only valid during the lifetime of a single call to the block, to allow memory management.
Return false from the block to terminate further iteration.
- forEach(block) - Method in class net.corda.node.services.persistence.DBCheckpointStorage
-
Allows the caller to process safely in a thread safe fashion the set of all checkpoints.
The checkpoints are only valid during the lifetime of a single call to the block, to allow memory management.
Return false from the block to terminate further iteration.
- frequency(generators) - Method in class net.corda.client.mock.Generator.Companion
-
- frequency($receiver, generators) - Static method in class net.corda.client.mock.GeneratorKt
-
- Frequency - Enum in net.corda.contracts
-
Frequency at which an event occurs - the enumerator also casts to an integer specifying the number of times per year
that would divide into (eg annually = 1, semiannual = 2, monthly = 12 etc).
- Frequency(annualCompoundCount, offset) - Constructor for enum net.corda.contracts.Frequency
-
Frequency at which an event occurs - the enumerator also casts to an integer specifying the number of times per year
that would divide into (eg annually = 1, semiannual = 2, monthly = 12 etc).
- freshCertificate(identityService, subjectPublicKey, issuer, issuerSigner, revocationEnabled) - Static method in class net.corda.node.services.keys.KMSUtilsKt
-
Generates a new random
KeyPair, adds it to the internal key storage, then generates a corresponding
X509Certificate and adds it to the identity service.
- freshKey() - Method in interface net.corda.core.node.services.KeyManagementService
-
Generates a new random
KeyPair and adds it to the internal key storage. Returns the public part of the pair.
- freshKey() - Method in class net.corda.node.services.keys.E2ETestKeyManagementService
-
Generates a new random
KeyPair and adds it to the internal key storage. Returns the public part of the pair.
- freshKey() - Method in class net.corda.node.services.keys.PersistentKeyManagementService
-
Generates a new random
KeyPair and adds it to the internal key storage. Returns the public part of the pair.
- freshKeyAndCert(identity, revocationEnabled) - Method in interface net.corda.core.node.services.KeyManagementService
-
Generates a new random
KeyPair, adds it to the internal key storage, then generates a corresponding
X509Certificate and adds it to the identity service.
- freshKeyAndCert(identity, revocationEnabled) - Method in class net.corda.node.services.keys.E2ETestKeyManagementService
-
Generates a new random
KeyPair, adds it to the internal key storage, then generates a corresponding
X509Certificate and adds it to the identity service.
- freshKeyAndCert(identity, revocationEnabled) - Method in class net.corda.node.services.keys.PersistentKeyManagementService
-
Generates a new random
KeyPair, adds it to the internal key storage, then generates a corresponding
X509Certificate and adds it to the identity service.
- fromDecimal(displayQuantity, token, rounding) - Method in class net.corda.core.contracts.Amount.Companion
-
Build an Amount from a decimal representation. For example, with an input of "12.34 GBP",
returns an amount with a quantity of "1234" tokens. The displayTokenSize as determined via
getDisplayTokenSize is used to determine the conversion scaling.
e.g. Bonds might be in nominal amounts of 100, currencies in 0.01 penny units.
- fromDecimal(displayQuantity, token) - Method in class net.corda.core.contracts.Amount.Companion
-
Build an Amount from a decimal representation. For example, with an input of "12.34 GBP",
returns an amount with a quantity of "1234" tokens. The displayTokenSize as determined via
getDisplayTokenSize is used to determine the conversion scaling.
e.g. Bonds might be in nominal amounts of 100, currencies in 0.01 penny units.
- fromDecimal(displayQuantity, token, rounding) - Static method in class net.corda.core.contracts.Amount
-
Build an Amount from a decimal representation. For example, with an input of "12.34 GBP",
returns an amount with a quantity of "1234" tokens. The displayTokenSize as determined via
getDisplayTokenSize is used to determine the conversion scaling.
e.g. Bonds might be in nominal amounts of 100, currencies in 0.01 penny units.
- fromDecimal(displayQuantity, token) - Static method in class net.corda.core.contracts.Amount
-
Build an Amount from a decimal representation. For example, with an input of "12.34 GBP",
returns an amount with a quantity of "1234" tokens. The displayTokenSize as determined via
getDisplayTokenSize is used to determine the conversion scaling.
e.g. Bonds might be in nominal amounts of 100, currencies in 0.01 penny units.
- fromDecimal(displayQuantityDelta, token, source, destination, rounding) - Method in class net.corda.core.contracts.AmountTransfer.Companion
-
Construct an AmountTransfer object from an indicative/displayable BigDecimal source, applying rounding as specified.
The token size is determined from the token type and is the same as for
class Amount
of the same token.
- fromDecimal(displayQuantityDelta, token, source, destination) - Method in class net.corda.core.contracts.AmountTransfer.Companion
-
Construct an AmountTransfer object from an indicative/displayable BigDecimal source, applying rounding as specified.
The token size is determined from the token type and is the same as for
class Amount
of the same token.
- fromDecimal(displayQuantityDelta, token, source, destination, rounding) - Static method in class net.corda.core.contracts.AmountTransfer
-
Construct an AmountTransfer object from an indicative/displayable BigDecimal source, applying rounding as specified.
The token size is determined from the token type and is the same as for
class Amount
of the same token.
- fromDecimal(displayQuantityDelta, token, source, destination) - Static method in class net.corda.core.contracts.AmountTransfer
-
Construct an AmountTransfer object from an indicative/displayable BigDecimal source, applying rounding as specified.
The token size is determined from the token type and is the same as for
class Amount
of the same token.
- fromOnly(fromTime) - Method in class net.corda.core.contracts.TimeWindow.Companion
-
Creates a
class TimeWindow
with null untilTime, i.e. the time interval
[fromTime, ∞)
. midpoint will return null.
- fromOnly(fromTime) - Static method in class net.corda.core.contracts.TimeWindow
-
Creates a
class TimeWindow
with null untilTime, i.e. the time interval
[fromTime, ∞)
. midpoint will return null.
- fromProxy(proxy) - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer
-
- fromProxy(proxy) - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer
-
- fromProxy(proxy) - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer
-
- fromProxy(proxy) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
- fromProxy(proxy) - Method in class net.corda.core.serialization.amqp.CustomSerializer.ToString
-
- fromSignedTransaction(transaction, transactions) - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction.Companion
-
- fromStartAndDuration(fromTime, duration) - Method in class net.corda.core.contracts.TimeWindow.Companion
-
Creates a
class TimeWindow
with the time interval
[fromTime, fromTime + duration)
. midpoint will return
fromTime + duration / 2
- fromStartAndDuration(fromTime, duration) - Static method in class net.corda.core.contracts.TimeWindow
-
Creates a
class TimeWindow
with the time interval
[fromTime, fromTime + duration)
. midpoint will return
fromTime + duration / 2
- fromString(name) - Method in class net.corda.core.contracts.UniqueIdentifier.Companion
-
Helper function for unit tests where the UUID needs to be manually initialised for consistency.
- fromToken(context) - Method in interface net.corda.core.serialization.SerializationToken
-
- fromToken(context) - Method in class net.corda.core.serialization.SingletonSerializationToken
-
- FullNodeConfiguration - Class in net.corda.node.services.config
-
- FullNodeConfiguration(basedir, myLegalName, emailAddress, keyStorePassword, trustStorePassword, dataSourceProperties, certificateSigningService, networkMapService, minimumPlatformVersion, rpcUsers, verifierType, messageRedeliveryDelaySeconds, useHTTPS, p2pAddress, rpcAddress, messagingServerAddress, extraAdvertisedServiceIds, bftReplicaId, notaryNodeAddress, notaryClusterAddresses, certificateChainCheckPolicies, devMode, useTestClock, detectPublicIp) - Constructor for class net.corda.node.services.config.FullNodeConfiguration
-
- functionPredicate($receiver, predicate, groupByColumns, orderBy) - Method in class net.corda.core.node.services.vault.Builder
-
- functionPredicate($receiver, predicate, groupByColumns, orderBy) - Method in class net.corda.core.node.services.vault.Builder
-
- FungibleAsset<T> - Interface in net.corda.core.contracts
-
Interface for contract states representing assets which are fungible, countable and issued by a
specific party. States contain assets which are equivalent (such as cash of the same currency),
so records of their existence can be merged or split as needed where the issuer is the same. For
instance, dollars issued by the Fed are fungible and countable (in cents), barrels of West Texas
crude are fungible and countable (oil from two small containers can be poured into one large
container), shares of the same class in a specific company are fungible and countable, and so on.
- FungibleAsset.Commands - Interface in net.corda.core.contracts
-
- FungibleAssetKt - Class in net.corda.core.contracts
-
- FungibleAssetQueryCriteria(participants, owner, quantity, issuerPartyName, issuerRef, status) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- FungibleAssetQueryCriteria(participants, owner, quantity, issuerPartyName, issuerRef) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- FungibleAssetQueryCriteria(participants, owner, quantity, issuerPartyName) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- FungibleAssetQueryCriteria(participants, owner, quantity) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- FungibleAssetQueryCriteria(participants, owner) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- FungibleAssetQueryCriteria(participants) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- FungibleAssetQueryCriteria() - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- FungibleState(participants, ownerKey, quantity, issuerParty, issuerRef) - Constructor for class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- FungibleState(_participants, _ownerKey, _quantity, _issuerParty, _issuerRef) - Constructor for class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- FungibleStateAttribute(attributeName) - Constructor for enum net.corda.core.node.services.vault.Sort.FungibleStateAttribute
-
- future(block) - Static method in class net.corda.core.Utils
-
- Gate(alwaysQueue) - Constructor for class net.corda.node.utilities.AffinityExecutor.Gate
-
An executor useful for unit tests: allows the current thread to block until a command arrives from another
thread, which is then executed. Inbound closures/commands stack up until they are cleared by looping.
- Gate() - Constructor for class net.corda.node.utilities.AffinityExecutor.Gate
-
An executor useful for unit tests: allows the current thread to block until a command arrives from another
thread, which is then executed. Inbound closures/commands stack up until they are cleared by looping.
- GBP - Static variable in class net.corda.core.contracts.ContractsDSL
-
- General.Builder - Class in net.corda.core.contracts
-
- generateAgreement(notary) - Method in interface net.corda.contracts.DealState
-
Generate a partial transaction representing an agreement (command) to this deal, allowing a general
deal/agreement flow to generate the necessary transaction for potential implementations.
- generateAmount(min, max, tokenGenerator) - Static method in class net.corda.client.mock.GeneratorsKt
-
- generateCashIssue(tx, obligor, amount, dueBefore, beneficiary, notary) - Method in class net.corda.contracts.asset.Obligation
-
Puts together an issuance transaction for the specified currency obligation amount that starts out being owned by
the given pubkey.
- generateCloseOutNetting(tx, signer, states) - Method in class net.corda.contracts.asset.Obligation
-
Generate a transaction performing close-out netting of two or more states.
- generateCurrency() - Static method in class net.corda.client.mock.GeneratorsKt
-
- generateCurrencyAmount(min, max) - Static method in class net.corda.client.mock.GeneratorsKt
-
- generateExit(tx, amountIssued, assetStates) - Method in class net.corda.contracts.asset.Obligation
-
Generate an transaction exiting an obligation from the ledger.
- generateExit(tx, amountIssued, assetStates, deriveState, generateMoveCommand, generateExitCommand) - Method in class net.corda.contracts.asset.OnLedgerAsset.Companion
-
Generate an transaction exiting fungible assets from the ledger.
- generateExit(tx, amountIssued, assetStates) - Method in class net.corda.contracts.asset.OnLedgerAsset
-
Generate an transaction exiting assets from the ledger.
- generateExit(tx, amountIssued, assetStates, deriveState, generateMoveCommand, generateExitCommand) - Static method in class net.corda.contracts.asset.OnLedgerAsset
-
Generate an transaction exiting fungible assets from the ledger.
- generateExit(tx, amountIssued, assetStates, deriveState, generateMoveCommand, generateExitCommand) - Method in class net.corda.contracts.clause.AbstractConserveAmount
-
Deprecated.
- generateExitCommand(amount) - Method in class net.corda.contracts.asset.Cash
-
- generateExitCommand(amount) - Method in class net.corda.contracts.asset.CommodityContract
-
- generateExitCommand(amount) - Method in class net.corda.contracts.asset.OnLedgerAsset
-
- generateField(cw) - Method in class net.corda.core.serialization.carpenter.Field
-
- generateFix(ptx, oldState, fix) - Method in interface net.corda.contracts.FixableDealState
-
Generate a fixing command for this deal and fix.
- generateIssue(tx, tokenDef, pennies, owner, notary) - Method in class net.corda.contracts.asset.Cash
-
Puts together an issuance transaction from the given template, that starts out being owned by the given pubkey.
- generateIssue(tx, amount, owner, notary) - Method in class net.corda.contracts.asset.Cash
-
Puts together an issuance transaction for the specified amount that starts out being owned by the given pubkey.
- generateIssue(tx, tokenDef, pennies, owner, notary) - Method in class net.corda.contracts.asset.CommodityContract
-
Puts together an issuance transaction from the given template, that starts out being owned by the given pubkey.
- generateIssue(tx, amount, owner, notary) - Method in class net.corda.contracts.asset.CommodityContract
-
Puts together an issuance transaction for the specified amount that starts out being owned by the given pubkey.
- generateIssue(tx, obligor, issuanceDef, pennies, beneficiary, notary) - Method in class net.corda.contracts.asset.Obligation
-
Puts together an issuance transaction for the specified amount that starts out being owned by the given pubkey.
- generateIssue(tx, transactionState, issueCommand) - Method in class net.corda.contracts.asset.OnLedgerAsset.Companion
-
Puts together an issuance transaction for the specified state. Normally contracts will provide convenient
wrappers around this function, which build the state for you, and those should be used in preference.
- generateIssue(tx, transactionState, issueCommand) - Static method in class net.corda.contracts.asset.OnLedgerAsset
-
Puts together an issuance transaction for the specified state. Normally contracts will provide convenient
wrappers around this function, which build the state for you, and those should be used in preference.
- generateIssue(issuance, faceValue, maturityDate, notary) - Method in class net.corda.contracts.CommercialPaper
-
Returns a transaction that issues commercial paper, owned by the issuing parties key. Does not update
an existing transaction because you aren't able to issue multiple pieces of CP in a single transaction
at the moment: this restriction is not fundamental and may be lifted later.
- generateIssue(issuance, faceValue, maturityDate, notary) - Method in class net.corda.contracts.CommercialPaperLegacy
-
- generateIssueCommand() - Method in class net.corda.contracts.asset.Cash
-
- generateIssueCommand() - Method in class net.corda.contracts.asset.CommodityContract
-
- generateIssueCommand() - Method in class net.corda.contracts.asset.OnLedgerAsset
-
- generateIssueRef(size) - Static method in class net.corda.client.mock.GeneratorsKt
-
- generateKeyPair(schemeCodeName) - Method in class net.corda.core.crypto.Crypto
-
Utility to simplify the act of generating keys.
Normally, we don't expect other errors here, assuming that key generation parameters for every supported signature scheme have been unit-tested.
- generateKeyPair(signatureScheme) - Method in class net.corda.core.crypto.Crypto
-
Generate a
KeyPair for the selected
class SignatureScheme
.
Note that RSA is the sole algorithm initialized specifically by its supported keySize.
- generateKeyPair() - Method in class net.corda.core.crypto.Crypto
-
Generate a
KeyPair for the selected
class SignatureScheme
.
Note that RSA is the sole algorithm initialized specifically by its supported keySize.
- generateKeyPair() - Static method in class net.corda.core.crypto.CryptoUtils
-
A simple wrapper that will make it easier to swap out the EC algorithm we use in future
- generateKeyPair() - Method in class net.corda.node.internal.AbstractNode
-
- generateMappedObject(schema) - Method in class net.corda.contracts.asset.Cash.State
-
Object Relational Mapping support.
- generateMappedObject(schema) - Method in class net.corda.contracts.CommercialPaper.State
-
Object Relational Mapping support.
- generateMappedObject(schema) - Method in interface net.corda.core.schemas.QueryableState
-
Export a representation for the given schema.
- generateMappedObject(state, schema) - Method in interface net.corda.node.services.api.SchemaService
-
Map a state to a
class PersistentState
for the given schema, either via direct support from the state
or via custom logic in this service.
- generateMappedObject(state, schema) - Method in class net.corda.node.services.schema.NodeSchemaService
-
Map a state to a
class PersistentState
for the given schema, either via direct support from the state
or via custom logic in this service.
- generateMove(tx, paper, newOwner) - Method in class net.corda.contracts.CommercialPaper
-
Updates the given partial transaction with an input/output/command to reassign ownership of the paper.
- generateMove(tx, paper, newOwner) - Method in class net.corda.contracts.CommercialPaperLegacy
-
- generateMoveCommand() - Method in class net.corda.contracts.asset.Cash
-
- generateMoveCommand() - Method in class net.corda.contracts.asset.CommodityContract
-
- generateMoveCommand() - Method in class net.corda.contracts.asset.OnLedgerAsset
-
- generateOrFail($receiver, random, numberOfTries) - Static method in class net.corda.client.mock.GeneratorKt
-
- generatePaymentNetting(tx, issued, notary, states) - Method in class net.corda.contracts.asset.Obligation
-
- generateRedeem(tx, paper, vault) - Method in class net.corda.contracts.CommercialPaper
-
Intended to be called by the issuer of some commercial paper, when an owner has notified us that they wish
to redeem the paper. We must therefore send enough money to the key that owns the paper to satisfy the face
value, and then ensure the paper is removed from the ledger.
- generateRedeem(tx, paper, vault) - Method in class net.corda.contracts.CommercialPaperLegacy
-
- generateSetLifecycle(tx, statesAndRefs, lifecycle, notary) - Method in class net.corda.contracts.asset.Obligation
-
Generate a transaction changing the lifecycle of one or more state objects.
- generateSettle(tx, statesAndRefs, assetStatesAndRefs, moveCommand, notary) - Method in class net.corda.contracts.asset.Obligation
-
- generateSpend(tx, amount, to, acceptableStates, deriveState, generateMoveCommand) - Method in class net.corda.contracts.asset.OnLedgerAsset.Companion
-
Generate a transaction that moves an amount of currency to the given pubkey.
- generateSpend(tx, amount, to, acceptableStates, deriveState, generateMoveCommand) - Static method in class net.corda.contracts.asset.OnLedgerAsset
-
Generate a transaction that moves an amount of currency to the given pubkey.
- generateSpend(tx, amount, to, onlyFromParties) - Method in interface net.corda.core.node.services.VaultService
-
Generate a transaction that moves an amount of currency to the given pubkey.
- generateSpend(tx, amount, to, onlyFromParties) - Method in class net.corda.node.services.vault.NodeVaultService
-
Generate a transaction that moves an amount of currency to the given pubkey.
- generateToDisk(dirs, serviceId, serviceName, threshold) - Method in class net.corda.node.utilities.ServiceIdentityGenerator
-
Generates signing key pairs and a common distributed service identity for a set of nodes.
The key pairs and the group identity get serialized to disk in the corresponding node directories.
This method should be called before any of the nodes are started.
- Generator<A> - Class in net.corda.client.mock
-
This file defines a basic
class Generator
library for composing random generators of objects.
- Generator(generate) - Constructor for class net.corda.client.mock.Generator
-
This file defines a basic
class Generator
library for composing random generators of objects.
- Generator.Companion - Class in net.corda.client.mock
-
- GeneratorKt - Class in net.corda.client.mock
-
- GeneratorsKt - Class in net.corda.client.mock
-
- get(klass, origin) - Method in class net.corda.client.jfx.model.Models
-
- get(index) - Method in class net.corda.client.jfx.utils.AggregatedList
-
- get(index) - Method in class net.corda.client.jfx.utils.ChosenList
-
- get(index) - Method in class net.corda.client.jfx.utils.ConcatenatedList
-
- get(index) - Method in class net.corda.client.jfx.utils.FlattenedList
-
- get(index) - Method in class net.corda.client.jfx.utils.MappedList
-
- get(index) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- get(key) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- get(index) - Method in class net.corda.client.jfx.utils.ReplayedList
-
- get(name) - Method in class net.corda.core.node.CityDatabase
-
- get(obj) - Method in class net.corda.core.serialization.amqp.Choice.Companion
-
- get(describedType) - Method in class net.corda.core.serialization.amqp.CompositeType.Companion
-
- get(obj) - Method in class net.corda.core.serialization.amqp.Descriptor.Companion
-
- get(data) - Method in class net.corda.core.serialization.amqp.Envelope.Companion
-
- get(obj) - Method in class net.corda.core.serialization.amqp.Field.Companion
-
- get(describedType) - Method in class net.corda.core.serialization.amqp.RestrictedType.Companion
-
- get(obj) - Method in class net.corda.core.serialization.amqp.Schema.Companion
-
- get(actualClass, declaredType) - Method in class net.corda.core.serialization.amqp.SerializerFactory
-
Look up, and manufacture if necessary, a serializer for the given type.
- get(typeDescriptor, schema) - Method in class net.corda.core.serialization.amqp.SerializerFactory
-
Lookup and manufacture a serializer for the given AMQP type descriptor, assuming we also have the necessary types
contained in the
class Schema
.
- get(obj) - Method in class net.corda.core.serialization.amqp.TypeNotation.Companion
-
- get(name) - Method in interface net.corda.core.serialization.carpenter.SimpleFieldAccess
-
- Get(key) - Constructor for class net.corda.node.services.transactions.Commands.Get
-
- get(commit) - Method in class net.corda.node.services.transactions.DistributedImmutableMap
-
Gets a value for the given Commands.Get.key
- get(key) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- get_mapVersion() - Method in class net.corda.node.services.network.AbstractNetworkMapService
-
- get_networkMapRegistrationFuture() - Method in class net.corda.node.internal.AbstractNode
-
- getAcceptableContracts() - Method in class net.corda.contracts.asset.Obligation.Terms
-
The hash of the asset contract we
- getAcceptableFileExtensions() - Method in interface net.corda.node.services.api.AcceptsFileUpload
-
What file extensions are acceptable for the file to be handed to upload()
- getAcceptableFileExtensions() - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
What file extensions are acceptable for the file to be handed to upload()
- getAcceptableIssuedProducts() - Method in class net.corda.contracts.asset.Obligation.Terms
-
The parties whose assets we are willing to accept in payment for this debt.
- getAcceptablePrice() - Method in class net.corda.flows.TwoPartyTradeFlow.Buyer
-
- getActual() - Method in exception net.corda.node.services.persistence.NodeAttachmentService.HashMismatchException
-
- getActualTypeArguments() - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
-
- getAdded() - Method in class net.corda.client.jfx.model.Diff
-
- getAdditionalProperties() - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer.ThrowableProxy
-
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.custom.PublicKeySerializer
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.custom.X500NameSerializer
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.CustomSerializer
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAdditionalSerializers() - Method in class net.corda.core.serialization.amqp.CustomSerializer.ToString
-
This is a collection of custom serializers that this custom serializer depends on. e.g. for proxy objects
that refer to other custom types etc.
- getAddress() - Method in class net.corda.node.internal.NetworkMapInfo
-
- getAddresses() - Method in class net.corda.core.node.NodeInfo
-
- getAddressOfParty(partyInfo) - Method in interface net.corda.node.services.messaging.MessagingService
-
Given information about either a specific node or a service returns its corresponding address
- getAddressOfParty(partyInfo) - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
Given information about either a specific node or a service returns its corresponding address
- getAdvertisedServices() - Method in class net.corda.core.node.NodeInfo
-
- getAdvertisedServices() - Method in class net.corda.node.internal.AbstractNode
-
- getAlgorithm() - Method in class net.corda.core.crypto.composite.CompositeKey
-
- getAlgorithm() - Method in class net.corda.core.crypto.testing.DummyPublicKey
-
Deprecated.
- getAlgorithm() - Method in class net.corda.core.crypto.testing.NullPublicKey
-
- getAlgorithmName() - Method in class net.corda.core.crypto.SignatureScheme
-
- getAlgSpec() - Method in class net.corda.core.crypto.SignatureScheme
-
- getAllIdentities() - Method in interface net.corda.core.node.services.IdentityService
-
- getAllIdentities() - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
- getAllStateMachines() - Method in class net.corda.node.services.statemachine.StateMachineManager
-
- getAllSteps() - Method in class net.corda.core.utilities.ProgressTracker
-
A list of all steps in this ProgressTracker and the children, with the indent level provided starting at zero.
Note that UNSTARTED is never counted, and DONE is only counted at the calling level.
- getAlternativeOIDs() - Method in class net.corda.core.crypto.SignatureScheme
-
- getAmount() - Method in class net.corda.contracts.asset.Commands.Exit
-
- getAmount() - Method in class net.corda.contracts.asset.Cash.State
-
- getAmount() - Method in class net.corda.contracts.asset.Commands.Exit
-
- getAmount() - Method in class net.corda.contracts.asset.CommodityContract.State
-
- getAmount() - Method in class net.corda.contracts.asset.Commands.Exit
-
- getAmount() - Method in class net.corda.contracts.asset.Commands.Settle
-
- getAmount() - Method in class net.corda.contracts.asset.Obligation.State
-
- getAmount() - Method in interface net.corda.core.contracts.Commands.Exit
-
- getAmount() - Method in interface net.corda.core.contracts.FungibleAsset
-
- getAmount() - Method in class net.corda.core.contracts.SourceAndAmount
-
- getAmount() - Method in class net.corda.flows.CashExitFlow
-
- getAmount() - Method in class net.corda.flows.CashFlowCommand.ExitCash
-
- getAmount() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- getAmount() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- getAmount() - Method in class net.corda.flows.CashIssueFlow
-
- getAmount() - Method in class net.corda.flows.CashPaymentFlow
-
- getAmount() - Method in class net.corda.flows.IssuerFlow.IssuanceRequester
-
- getAmount() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- getAmountGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getAmountMissing() - Method in exception net.corda.core.contracts.InsufficientBalanceException
-
- getAmqpEnabled() - Method in class net.corda.core.serialization.CordaClassResolver
-
- getAmqpHeaderV1_0() - Static method in class net.corda.core.serialization.amqp.SchemaKt
-
- getAnnualCompoundCount() - Method in enum net.corda.contracts.Frequency
-
- getAnonymous() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- getAnonymous() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- getAnonymous() - Method in class net.corda.flows.CashIssueFlow
-
- getAnonymous() - Method in class net.corda.flows.CashPaymentFlow
-
- getAnonymous() - Method in class net.corda.flows.IssuerFlow.IssuanceRequester
-
- getAnonymous() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- getAnyNotary($this, type) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Returns a notary identity advertised by any of the nodes on the network (chosen at random)
- getAnyNotary(type) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Returns a notary identity advertised by any of the nodes on the network (chosen at random)
- getAppContext() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
-
- getArgs() - Method in class net.corda.jackson.StringToMethodCallParser.ParsedMethodCall
-
- getArgs() - Method in class net.corda.node.internal.NodeStartup
-
- getArgs() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
-
- getAssemble() - Method in class net.corda.client.jfx.utils.AggregatedList
-
- getAsset() - Method in class net.corda.contracts.CommercialPaper.Terms
-
- getAssetForSale() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- getAssetToSell() - Method in class net.corda.flows.TwoPartyTradeFlow.Seller
-
- getAttachment(index) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify getting an indexed attachment.
- getAttachment(id) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify getting an indexed attachment.
- getAttachmentData() - Method in class net.corda.core.contracts.AbstractAttachment
-
- getAttachments() - Method in class net.corda.core.flows.AppContext
-
- getAttachments() - Method in interface net.corda.core.node.ServicesForResolution
-
Provides access to storage of arbitrary JAR files (which may contain only data, no code).
- getAttachments() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getAttachments() - Method in class net.corda.core.transactions.LedgerTransaction
-
A list of
- getAttachments() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getAttachments() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getAttachments() - Method in class net.corda.core.transactions.WireTransaction
-
Hashes of the ZIP/JAR files that are needed to interpret the contents of this wire transaction.
- getAttachments() - Method in class net.corda.node.internal.AbstractNode
-
- getAttribute() - Method in class net.corda.core.node.services.vault.SortAttribute.Standard
-
- getAttributeChild() - Method in enum net.corda.core.node.services.vault.Sort.CommonStateAttribute
-
- getAttributeName() - Method in enum net.corda.core.node.services.vault.Sort.FungibleStateAttribute
-
- getAttributeName() - Method in enum net.corda.core.node.services.vault.Sort.LinearStateAttribute
-
- getAttributeName() - Method in enum net.corda.core.node.services.vault.Sort.VaultStateAttribute
-
- getAttributeParent() - Method in enum net.corda.core.node.services.vault.Sort.CommonStateAttribute
-
- getAuditEventType() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
- getAuditService() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getAuthorisedContractUpgrade(ref) - Method in interface net.corda.core.node.services.VaultService
-
Get contracts we would be willing to upgrade the suggested contract to.
- getAuthorisedContractUpgrade(ref) - Method in class net.corda.node.services.vault.NodeVaultService
-
Get contracts we would be willing to upgrade the suggested contract to.
- getAutoCommit() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getAvailableCommands() - Method in class net.corda.jackson.StringToMethodCallParser
-
Returns a string-to-string map of commands to a string describing available parameter types.
- getAvailableComponentHashes($this) - Static method in class net.corda.core.transactions.TraversableTransaction.DefaultImpls
-
Calculate the hashes of the sub-components of the transaction, that are used to build its Merkle tree.
The root of the tree is the transaction identifier. The tree structure is helpful for privacy, please
see the user-guide section "Transaction tear-offs" to learn more about this topic.
- getAvailableComponentHashes() - Method in interface net.corda.core.transactions.TraversableTransaction
-
Calculate the hashes of the sub-components of the transaction, that are used to build its Merkle tree.
The root of the tree is the transaction identifier. The tree structure is helpful for privacy, please
see the user-guide section "Transaction tear-offs" to learn more about this topic.
- getAvailableComponents($this) - Static method in class net.corda.core.transactions.TraversableTransaction.DefaultImpls
-
Returns a flattened list of all the components that are present in the transaction, in the following order:
- getAvailableComponents() - Method in interface net.corda.core.transactions.TraversableTransaction
-
Returns a flattened list of all the components that are present in the transaction, in the following order:
- getBackingMap() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- getBagOfCash() - Method in class net.corda.core.internal.Emoji
-
- getBasedir() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
Deprecated.
- getBaseDirectory() - Method in class net.corda.node.CmdLineOptions
-
- getBaseDirectory() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
This is not retrieved from the config file but rather from a command line argument.
- getBaseSerializer() - Method in class net.corda.core.serialization.NoReferencesSerializer
-
- getBatchUpdateSize() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getBeneficiary() - Method in class net.corda.contracts.asset.Obligation.State
-
The public key of the entity the contract pays to
- getBftReplicaId() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getBftReplicaId() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getBilateralNetState() - Method in class net.corda.contracts.asset.Obligation.State
-
Returns an object used to determine if two states can be subject to close-out netting. If two states return
equal objects, they can be close out netted together.
- getBilateralNetState() - Method in interface net.corda.contracts.BilateralNettableState
-
Returns an object used to determine if two states can be subject to close-out netting. If two states return
equal objects, they can be close out netted together.
- getBooks() - Method in class net.corda.core.internal.Emoji
-
- getBuffer() - Method in class net.corda.core.crypto.composite.CompositeSignature.State
-
- getBusyNodeLatch() - Method in class net.corda.node.internal.AbstractNode
-
- getBy() - Method in class net.corda.core.crypto.DigitalSignature.WithKey
-
- getBytes() - Method in class net.corda.core.utilities.ByteSequence
-
The underlying bytes.
- getBytes() - Method in class net.corda.core.utilities.OpaqueBytes
-
The underlying bytes.
- getCaCertStore() - Method in interface net.corda.core.node.services.IdentityService
-
- getCaCertStore() - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
Certificate store for certificate authority and intermediary certificates.
- getCache() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getCacheConcurrencyLevel() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
Determines the concurrency level of the Observable Cache.
- getCalendars() - Method in class net.corda.contracts.BusinessCalendar.Companion
-
- getCallback() - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
-
- getCallerIdentity() - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
-
- getCallSiteMap() - Method in class net.corda.client.rpc.internal.ObservableContext
-
- getCarpenterSchemas() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
The list of carpentable classes
- getCash() - Method in class net.corda.client.jfx.model.ContractStateModel
-
- getCASH($receiver) - Static method in class net.corda.contracts.asset.CashKt
-
An extension property that lets you write 100.DOLLARS.CASH
- getCASH_PROGRAM_ID() - Static method in class net.corda.contracts.asset.CashKt
-
- getCashBalances() - Method in interface net.corda.core.messaging.CordaRPCOps
-
- getCashBalances() - Method in interface net.corda.core.node.services.VaultService
-
Returns a map of how much cash we have in each currency, ignoring details like issuer. Note: currencies for
which we have no cash evaluate to null (not present in map), not 0.
- getCashBalances() - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
- getCashBalances() - Method in class net.corda.node.services.vault.NodeVaultService
-
Returns a map of how much cash we have in each currency, ignoring details like issuer. Note: currencies for
which we have no cash evaluate to null (not present in map), not 0.
- getCashStates() - Method in class net.corda.client.jfx.model.ContractStateModel
-
- getCatalog() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getCause() - Method in exception net.corda.core.CordaException
-
- getCause() - Method in exception net.corda.core.CordaRuntimeException
-
- getCause() - Method in class net.corda.core.flows.NotaryError.TransactionInvalid
-
- getCause() - Method in exception net.corda.core.node.services.StatesNotAvailableException
-
- getCause() - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer.ThrowableProxy
-
- getCert($receiver) - Static method in class net.corda.core.crypto.X509UtilitiesKt
-
- getCertificate() - Method in class net.corda.core.crypto.CertificateAndKeyPair
-
- getCertificate() - Method in class net.corda.core.identity.PartyAndCertificate
-
- getCertificate(alias) - Method in class net.corda.node.utilities.KeyStoreWrapper
-
- getCertificate() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- getCertificateAndKeyPair($receiver, alias, keyPassword) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Helper method to load a Certificate and KeyPair from their KeyStore.
The access details should match those of the createCAKeyStoreAndTrustStore call used to manufacture the keys.
- getCertificateChain(alias) - Method in class net.corda.node.utilities.KeyStoreWrapper
-
- getCertificateChainCheckPolicies() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getCertificateChainCheckPolicies() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getCertificateChainCheckPolicy() - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- getCertificateSigningService() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getCertificateSigningService() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getCertificateValidityWindow(before, after, parent) - Method in class net.corda.core.crypto.X509Utilities
-
Helper method to get a notBefore and notAfter pair from current day bounded by parent certificate validity range.
- getCertPath() - Method in class net.corda.core.identity.AnonymousPartyAndPath
-
- getCertPath() - Method in class net.corda.core.identity.PartyAndCertificate
-
- getCertPath() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- getCertService() - Method in class net.corda.node.utilities.registration.NetworkRegistrationHelper
-
- getChanged() - Method in interface net.corda.core.node.services.NetworkMapCache
-
Tracks changes to the network map cache
- getChanged() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
Tracks changes to the network map cache
- getChanges() - Method in class net.corda.core.utilities.ProgressTracker
-
An observable stream of changes: includes child steps, resets and any changes emitted by individual steps (e.g.
if a step changed its label or rendering).
- getChanges() - Method in class net.corda.core.utilities.ProgressTracker.Step
-
- getChanges() - Method in class net.corda.node.services.statemachine.StateMachineManager
-
An observable that emits triples of the changing flow, the type of change, and a process-specific ID number
which may change across restarts.
- getCheckAttachmentsOnLoad() - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
- getCHECKPOINT_CONTEXT() - Method in class net.corda.core.serialization.SerializationDefaults
-
- getCheckpointStorage() - Method in class net.corda.node.internal.AbstractNode
-
- getCheckpointStorage() - Method in class net.corda.node.services.statemachine.StateMachineManager
-
- getChildProgressTracker(step) - Method in class net.corda.core.utilities.ProgressTracker
-
- getChildren() - Method in class net.corda.core.crypto.composite.CompositeKey
-
- getChoices() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getCityMap() - Method in class net.corda.core.node.CityDatabase
-
- getClassLoader() - Method in class net.corda.core.flows.AppContext
-
- getClassloader() - Method in class net.corda.core.serialization.carpenter.ClassCarpenter
-
- getClause() - Method in class net.corda.core.contracts.clauses.FilterOn
-
- getClause() - Method in class net.corda.core.contracts.clauses.GroupClauseVerifier
-
- getClauses() - Method in class net.corda.core.contracts.clauses.AllOf
-
List of clauses under this composite clause
- getClauses() - Method in class net.corda.core.contracts.clauses.AnyOf
-
List of clauses under this composite clause
- getClauses() - Method in class net.corda.core.contracts.clauses.CompositeClause
-
List of clauses under this composite clause
- getClauses() - Method in class net.corda.core.contracts.clauses.FirstComposition
-
Deprecated.
List of clauses under this composite clause
- getClauses() - Method in class net.corda.core.contracts.clauses.FirstOf
-
List of clauses under this composite clause
- getClazz() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Implements
-
- getClazz() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Is
-
- getClazz() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
- getClazz() - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
- getClazz() - Method in class net.corda.core.serialization.amqp.ObjectSerializer
-
- getClientAddress() - Method in class net.corda.node.services.messaging.ObservableContext
-
- getClientAddressToObservables() - Method in class net.corda.node.services.messaging.ObservableContext
-
- getClientInfo() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getClientInfo(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getClientVersion() - Method in class net.corda.node.utilities.registration.HTTPNetworkRegistrationService.Companion
-
- getClock() - Method in interface net.corda.core.node.ServiceHub
-
- getClock() - Method in class net.corda.core.node.services.TimeWindowChecker
-
- getCode() - Method in enum net.corda.contracts.Tenor.TimeUnit
-
- getCode() - Method in class net.corda.core.serialization.amqp.Descriptor
-
- getCODE_BAG_OF_CASH() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_BOOKS() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_COOL_GUY() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_DIAMOND() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_FREE() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_GREEN_TICK() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_LEFT_ARROW() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_LIGHTBULB() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_NEWSPAPER() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_NO_ENTRY() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_PAPERCLIP() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_RIGHT_ARROW() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_SANTA_CLAUS() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_SKULL_AND_CROSSBONES() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_SLEEPING_FACE() - Static method in class net.corda.core.internal.Emoji
-
- getCODE_SOON() - Static method in class net.corda.core.internal.Emoji
-
- getColumn() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- getColumn() - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
-
- getColumnName(column) - Static method in class net.corda.core.node.services.vault.QueryCriteriaUtils
-
- getColumns() - Method in class net.corda.core.node.services.vault.Sort
-
- getColumnTransformer() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getCommand(index) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify getting an indexed command.
- getCommands() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getCommands() - Method in class net.corda.core.transactions.LedgerTransaction
-
Arbitrary data passed to the program of each input state.
- getCommands() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getCommands() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getCommands() - Method in class net.corda.core.transactions.WireTransaction
-
Ordered list of
- getCOMMODITY_PROGRAM_ID() - Static method in class net.corda.contracts.asset.CommodityContractKt
-
- getCommodityCode() - Method in class net.corda.contracts.Commodity
-
- getCommonName($receiver) - Static method in class net.corda.core.crypto.X509UtilitiesKt
-
- getCOMPOSITE_KEY() - Method in class net.corda.core.crypto.Crypto
-
Corda composite key type
- getCompositeKey() - Method in class net.corda.core.crypto.provider.CordaObjectIdentifier
-
- getCompositeSignature() - Method in class net.corda.core.crypto.provider.CordaObjectIdentifier
-
- getConfig() - Method in class net.corda.node.services.database.RequeryConfiguration
-
- getConfig() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- getConfig() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getConfig() - Method in class net.corda.node.services.schema.HibernateObserver
-
- getConfig() - Method in class net.corda.node.utilities.registration.NetworkRegistrationHelper
-
- getConfigFile() - Method in class net.corda.node.CmdLineOptions
-
- getConfiguration() - Method in class net.corda.node.internal.AbstractNode
-
- getConfiguration() - Method in class net.corda.node.internal.Node
-
- getConfiguration() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getConfiguration() - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
- getConfiguration() - Method in class net.corda.node.services.vault.NodeVaultService
-
- getConfirmed() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeResponse
-
- getConflict() - Method in class net.corda.core.flows.NotaryError.Conflict
-
- getConnection() - Method in class net.corda.node.services.database.HibernateConfiguration.NodeDatabaseConnectionProvider
-
- getConnection() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getConnection() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaDataSourceConnectionProvider
-
- getConnection() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- getConnection() - Method in class net.corda.node.utilities.ExposedTransaction
-
- getConnectionMaxRetryInterval() - Method in class net.corda.client.rpc.CordaRPCClientConfiguration
-
- getConnectionMaxRetryInterval() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
Maximum retry interval
- getConnectionProvider() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getConnectionRetryInterval() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The retry interval of artemis connections in milliseconds
- getConnectionRetryIntervalMultiplier() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The retry interval multiplier for exponential backoff
- getConstructor() - Method in class net.corda.core.serialization.ImmutableClassSerializer
-
- getConsumed() - Method in class net.corda.core.node.services.Vault.Update
-
- getConsumedTime() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getConsumedTime() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to timestamp recorded upon entering CONSUMED state
- getConsumerPoolSize() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The number of consumers to handle incoming messages
- getContent() - Method in class net.corda.core.internal.ThreadBox
-
- getContextData() - Method in class net.corda.node.services.api.AuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
Examples of this might be trade identifiers, system error codes, or source IP addresses, which could be useful
when searching the historic audit data for trails of evidence.
- getContextData() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- getContextData() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- getContextData() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- getContextData() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
Examples of this might be trade identifiers, system error codes, or source IP addresses, which could be useful
when searching the historic audit data for trails of evidence.
- getContextData() - Method in class net.corda.node.services.api.FlowStartEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- getContextData() - Method in class net.corda.node.services.api.SystemAuditEvent
-
Further tagged details that should be recorded along with the common data of the audit event.
- getContract() - Method in class net.corda.contracts.asset.Cash.State
-
An instance of the contract class that will verify this state.
- getContract() - Method in class net.corda.contracts.asset.CommodityContract.State
-
An instance of the contract class that will verify this state.
- getContract() - Method in class net.corda.contracts.asset.Obligation.State
-
An instance of the contract class that will verify this state.
- getContract() - Method in class net.corda.contracts.CommercialPaper.State
-
An instance of the contract class that will verify this state.
- getContract() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
An instance of the contract class that will verify this state.
- getContract() - Method in interface net.corda.core.contracts.ContractState
-
An instance of the contract class that will verify this state.
- getContractHash() - Method in class net.corda.contracts.asset.Commands.Move
-
Contract code the moved state
- getContractHash() - Method in class net.corda.contracts.asset.Commands.Move
-
Contract code the moved state
- getContractHash() - Method in class net.corda.contracts.asset.Commands.Move
-
Contract code the moved state
- getContractHash() - Method in class net.corda.contracts.Commands.Move
-
Contract code the moved state
- getContractHash() - Method in interface net.corda.core.contracts.MoveCommand
-
Contract code the moved state(s) are for the attention of, for example to indicate that the states are moved in
order to settle an obligation contract's state object(s).
- getContractState() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to serialized transaction Contract State
- getContractStateClassName() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getContractStateClassName() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
references a concrete ContractState that is
- getContractStateTypes() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- getContractType() - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- getContractTypeMappings() - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- getCoolGuy() - Method in class net.corda.core.internal.Emoji
-
- getCoordinate() - Method in class net.corda.core.node.WorldMapLocation
-
- getCorda() - Method in class net.corda.core.node.services.ServiceType.Companion
-
- getCORDA_CLIENT_CA() - Method in class net.corda.core.crypto.X509Utilities
-
- getCORDA_CLIENT_TLS() - Method in class net.corda.core.crypto.X509Utilities
-
- getCORDA_INTERMEDIATE_CA() - Method in class net.corda.core.crypto.X509Utilities
-
- getCORDA_ROOT_CA() - Method in class net.corda.core.crypto.X509Utilities
-
- getCordaModule() - Method in class net.corda.jackson.JacksonSupport
-
- getCordaPersistence() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- getCounterpartyMarker(party) - Method in class net.corda.core.flows.FlowLogic
-
Deprecated.
- getCountryCode() - Method in class net.corda.core.node.WorldMapLocation
-
- getCP_LEGACY_PROGRAM_ID() - Static method in class net.corda.contracts.CommercialPaperLegacyKt
-
Legacy version of
class CommercialPaper
that includes the full verification logic itself, rather than breaking it
into clauses. This is here just as an example for the contract tutorial.
- getCP_PROGRAM_ID() - Static method in class net.corda.contracts.CommercialPaperKt
-
This is an ultra-trivial implementation of commercial paper, which is essentially a simpler version of a corporate
bond. It can be seen as a company-specific currency. A company issues CP with a particular face value, say $100,
but sells it for less, say $90. The paper can be redeemed for cash at a given date in the future. Thus this example
would have a 10% interest rate with a single repayment. Commercial paper is often rolled over (the maturity date
is adjusted as if the paper was redeemed and immediately repurchased, but without having to front the cash).
- getCriteriaBuilder() - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- getCriteriaQuery() - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- getCurrencies() - Method in class net.corda.client.mock.EventGenerator
-
- getCurrency() - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- getCurrency() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getCurrencyGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getCurrencyMap() - Method in class net.corda.client.mock.EventGenerator
-
- getCurrent() - Method in class net.corda.core.messaging.DataFeed
-
Deprecated.
- getCurrentSigs() - Method in class net.corda.core.transactions.TransactionBuilder
-
Deprecated.
- getCurrentStep() - Method in class net.corda.core.utilities.ProgressTracker
-
Reading returns the value of stepsstepIndex, writing moves the position of the current tracker. Once moved to
the
class ProgressTracker.DONE
state, this tracker is finished and the current step cannot be moved again.
- getCurrentStepRecursive() - Method in class net.corda.core.utilities.ProgressTracker
-
Returns the current step, descending into children to find the deepest step we are up to.
- getCurrentUser() - Method in class net.corda.node.services.messaging.RpcContext
-
- getData() - Method in class net.corda.core.contracts.TransactionState
-
The custom contract state
- getData() - Method in class net.corda.core.utilities.UntrustworthyData
-
Deprecated.
- getData(id) - Method in class net.corda.node.services.FetchAttachmentsHandler
-
- getData(id) - Method in class net.corda.node.services.FetchDataHandler
-
- getData(id) - Method in class net.corda.node.services.FetchTransactionsHandler
-
- getData() - Method in interface net.corda.node.services.messaging.Message
-
- getDatabase() - Method in class net.corda.node.internal.AbstractNode
-
- getDatabase() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getDatabase() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getDatabase() - Method in class net.corda.node.services.statemachine.StateMachineManager
-
- getDatabase() - Method in class net.corda.node.services.vault.CashBalanceAsMetricsObserver
-
- getDatabase() - Method in class net.corda.node.utilities.CordaPersistence
-
Holds Exposed database, the field will be removed once Exposed library is removed
- getDatabase() - Method in class net.corda.node.utilities.ExposedTransactionManager.Companion
-
- getDatabaseSchema() - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
-
- getDatabaseTransaction() - Method in class net.corda.node.utilities.ExposedTransaction
-
- getDataSource() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaDataSourceConnectionProvider
-
- getDataSource() - Method in class net.corda.node.services.database.RequeryConfiguration
-
- getDataSource() - Method in class net.corda.node.utilities.CordaPersistence
-
- getDataSource() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- getDataSourceProperties() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getDataSourceProperties() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getDataTypePrefix() - Method in interface net.corda.node.services.api.AcceptsFileUpload
-
A string that prefixes the URLs, e.g. "attachments" or "interest-rates". Should be OK for URLs.
- getDataTypePrefix() - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
A string that prefixes the URLs, e.g. "attachments" or "interest-rates". Should be OK for URLs.
- getDays($receiver) - Static method in class net.corda.core.utilities.KotlinUtilsKt
-
Extension method for easier construction of Durations in terms of integer days: val twoDays = 2.days
.
- getDb() - Method in class net.corda.node.services.transactions.DistributedImmutableMap
-
- getDb() - Method in class net.corda.node.utilities.ExposedTransaction
-
- getDbCloser() - Method in class net.corda.node.internal.AbstractNode
-
- getDealBeingOffered() - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
-
- getDealRef() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- getDealReference() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
Deal State attributes
- getDebugTimestamp() - Method in interface net.corda.node.services.messaging.Message
-
- getDeclaredType() - Method in class net.corda.core.serialization.amqp.CollectionSerializer
-
- getDeclaredType() - Method in class net.corda.core.serialization.amqp.MapSerializer
-
- getDeclaringClass() - Method in class net.corda.core.node.services.vault.Column
-
- getDeclaringClass() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- getDefault() - Method in class net.corda.client.rpc.CordaRPCClientConfiguration.Companion
-
- getDefault() - Static method in class net.corda.client.rpc.CordaRPCClientConfiguration
-
- getDefault() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration.Companion
-
- getDefault() - Static method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
- getDefault() - Method in class net.corda.core.serialization.amqp.Field
-
- getDefault() - Method in class net.corda.core.serialization.amqp.PropertySerializer
-
- getDefault() - Method in class net.corda.node.services.messaging.RPCServerConfiguration.Companion
-
- getDEFAULT_EXPIRATION_PERIOD() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getDEFAULT_IDENTITY_SIGNATURE_SCHEME() - Method in class net.corda.core.crypto.X509Utilities
-
- getDEFAULT_MAX_BUCKETS() - Static method in class net.corda.node.utilities.JDBCHashMapKt
-
The default maximum size of the LRU cache.
Current computation is linear to max heap size, ensuring a minimum of 256 buckets.
- getDEFAULT_SESSION_ID() - Static method in class net.corda.node.services.api.ServiceHubInternalKt
-
Session ID to use for services listening for the first message in a session (before a
specific session ID has been established).
- getDEFAULT_SIGNATURE_SCHEME() - Method in class net.corda.core.crypto.Crypto
-
Our default signature scheme if no algorithm is specified (e.g. for key generation).
- getDEFAULT_TLS_SIGNATURE_SCHEME() - Method in class net.corda.core.crypto.X509Utilities
-
- getDefaultFractionDigits() - Method in class net.corda.contracts.Commodity
-
- getDelegate() - Method in class net.corda.core.serialization.GlobalTransientClassWhiteList
-
- getDelegate() - Method in class net.corda.core.serialization.LoggingWhitelist
-
- getDependencies() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
Maps a class to a list of classes that depend on it being built first
- getDependsOn() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
Maps a class to a list of classes it depends on being built before it
- getDesc() - Method in class net.corda.core.crypto.SignatureScheme
-
- getDescribed() - Method in class net.corda.core.serialization.amqp.Choice
-
- getDescribed() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- getDescribed() - Method in class net.corda.core.serialization.amqp.Descriptor
-
- getDescribed() - Method in class net.corda.core.serialization.amqp.Envelope
-
- getDescribed() - Method in class net.corda.core.serialization.amqp.Field
-
- getDescribed() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getDescribed() - Method in class net.corda.core.serialization.amqp.Schema
-
- getDescription() - Method in class net.corda.core.node.WorldMapLocation
-
- getDescription() - Method in class net.corda.node.services.api.AuditEvent
-
A human readable description of audit event including any permission check results.
- getDescription() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
A human readable description of audit event including any permission check results.
- getDescription() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
A human readable description of audit event including any permission check results.
- getDescription() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
A human readable description of audit event including any permission check results.
- getDescription() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
A human readable description of audit event including any permission check results.
- getDescription() - Method in class net.corda.node.services.api.FlowStartEvent
-
A human readable description of audit event including any permission check results.
- getDescription() - Method in class net.corda.node.services.api.SystemAuditEvent
-
A human readable description of audit event including any permission check results.
- getDescriptions() - Method in exception net.corda.core.transactions.SignedTransaction.SignaturesMissingException
-
- getDESCRIPTOR() - Method in class net.corda.core.serialization.amqp.Choice.Companion
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.Choice
-
- getDESCRIPTOR() - Method in class net.corda.core.serialization.amqp.CompositeType.Companion
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Implements
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Is
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
- getDESCRIPTOR() - Method in class net.corda.core.serialization.amqp.Descriptor.Companion
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.Descriptor
-
- getDESCRIPTOR() - Method in class net.corda.core.serialization.amqp.Envelope.Companion
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.Envelope
-
- getDESCRIPTOR() - Method in class net.corda.core.serialization.amqp.Field.Companion
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.Field
-
- getDESCRIPTOR() - Method in class net.corda.core.serialization.amqp.RestrictedType.Companion
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getDESCRIPTOR() - Method in class net.corda.core.serialization.amqp.Schema.Companion
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.Schema
-
- getDescriptor() - Method in class net.corda.core.serialization.amqp.TypeNotation
-
- getDescriptor() - Method in class net.corda.core.serialization.carpenter.Field
-
- getDESCRIPTOR_DOMAIN() - Static method in class net.corda.core.serialization.amqp.SchemaKt
-
- getDESCRIPTOR_OBJECT() - Method in class net.corda.core.serialization.amqp.Envelope.Companion
-
- getDESCRIPTOR_TOP_32BITS() - Static method in class net.corda.core.serialization.amqp.SchemaKt
-
- getDeserializationClassLoader() - Method in interface net.corda.core.serialization.SerializationContext
-
The class loader to use for deserialization.
- getDestination() - Method in class net.corda.core.contracts.AmountTransfer
-
- getDetectPublicIp() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getDevMode() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getDevMode() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getDevX509Name(commonName) - Method in class net.corda.core.crypto.X509Utilities
-
Deprecated.
- getDiamond() - Method in class net.corda.core.internal.Emoji
-
- getDir() - Method in class net.corda.node.shell.InteractiveShell.ShellLifecycle
-
- getDirection() - Method in enum net.corda.contracts.DateRollConvention
-
- getDirection() - Method in class net.corda.core.node.services.vault.Sort.SortColumn
-
- getDisplayName() - Method in class net.corda.contracts.Commodity
-
- getDisplayTokenSize() - Method in class net.corda.contracts.Commodity
-
- getDisplayTokenSize(token) - Method in class net.corda.core.contracts.Amount.Companion
-
Determines the representation of one Token quantity in BigDecimal. For Currency and Issued
the definitions is taken from Currency defaultFractionDigits property e.g. 2 for USD, or 0 for JPY
so that the automatic token size is the conventional minimum penny amount.
For other possible token types the asset token should implement TokenizableAssetInfo to
correctly report the designed nominal amount.
- getDisplayTokenSize() - Method in class net.corda.core.contracts.Amount
-
- getDisplayTokenSize() - Method in interface net.corda.core.contracts.TokenizableAssetInfo
-
- getDOLLARS($receiver) - Static method in class net.corda.core.contracts.ContractsDSL
-
- getDOLLARS($receiver) - Static method in class net.corda.core.contracts.ContractsDSL
-
- getDownloaded() - Method in class net.corda.core.flows.FetchDataFlow.Result
-
- getDueBefore() - Method in class net.corda.contracts.asset.Obligation.State
-
- getDueBefore() - Method in class net.corda.contracts.asset.Obligation.Terms
-
When the contract must be settled by.
- getDUMMY_CASH_ISSUER() - Static method in class net.corda.contracts.asset.CashKt
-
A dummy, randomly generated issuer party by the name of "Snake Oil Issuer"
- getDUMMY_CASH_ISSUER_KEY() - Static method in class net.corda.contracts.asset.CashKt
-
A randomly generated key.
- getDUMMY_OBLIGATION_ISSUER() - Static method in class net.corda.contracts.asset.ObligationKt
-
A dummy, randomly generated issuer party by the name of "Snake Oil Issuer"
- getDUMMY_OBLIGATION_ISSUER_KEY() - Static method in class net.corda.contracts.asset.ObligationKt
-
A randomly generated key.
- getDuplicates() - Method in exception net.corda.core.contracts.TransactionVerificationException.DuplicateInputStates
-
- getECDSA_SECP256K1_SHA256() - Method in class net.corda.core.crypto.Crypto
-
ECDSA signature scheme using the secp256k1 Koblitz curve.
- getECDSA_SECP256R1_SHA256() - Method in class net.corda.core.crypto.Crypto
-
ECDSA signature scheme using the secp256r1 (NIST P-256) curve.
- getEDDSA_ED25519_SHA512() - Method in class net.corda.core.crypto.Crypto
-
EdDSA signature scheme using the ed255519 twisted Edwards curve.
- getEmailAddress() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getEmailAddress() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getEmojiMode() - Method in class net.corda.core.internal.Emoji
-
When non-null, toString() methods are allowed to use emoji in the output as we're going to render them to a
sufficiently capable text surface.
- getEMPTY() - Method in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys.Companion
-
- getEncoded() - Method in class net.corda.core.crypto.composite.CompositeKey
-
- getEncoded() - Method in class net.corda.core.crypto.testing.DummyPublicKey
-
Deprecated.
- getEncoded() - Method in class net.corda.core.crypto.testing.NullPublicKey
-
- getEncumbrance() - Method in class net.corda.core.contracts.TransactionState
-
All contract states may be encumbered by up to one other state.
- getEntityStateClass() - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
-
- getEntityStateColumnName() - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
-
- getEntityStateListeners() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getEntries() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- getEntries() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
-
- getEntries() - Method in class net.corda.node.services.transactions.Commands.PutAll
-
- getEntries() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- getEnvelope() - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
-
- getEpochSeconds() - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
-
- getError() - Method in exception net.corda.core.flows.NotaryException
-
- getError() - Method in exception net.corda.core.node.services.UniquenessException
-
- getError() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
- getError() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationResponse
-
- getError() - Method in class net.corda.node.services.transactions.ClusterResponse.Error
-
- getError() - Method in class net.corda.node.services.transactions.ReplicaResponse.Error
-
- getErrorExitCashGenerator() - Method in class net.corda.client.mock.ErrorFlowsEventGenerator
-
- getErrorGenerator() - Method in class net.corda.client.mock.ErrorFlowsEventGenerator
-
- getErrorMessage() - Method in class net.corda.node.services.statemachine.SessionReject
-
- getErrorMoveGenerator() - Method in class net.corda.client.mock.ErrorFlowsEventGenerator
-
- getErrorResponse() - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
-
- getErrors() - Method in exception net.corda.node.shell.InteractiveShell.NoApplicableConstructor
-
- getEventSinkProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.EventSinkDelegate
-
- getEventStreamProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.EventStreamDelegate
-
- getException() - Method in class net.corda.core.utilities.Try.Failure
-
- getExceptionClass() - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer.ThrowableProxy
-
- getExchangeRate() - Method in class net.corda.client.jfx.model.ExchangeRateModel
-
- getExecutionPath(commands) - Method in class net.corda.core.contracts.clauses.Clause
-
Determine the subclauses which will be verified as a result of verifying this clause.
- getExecutionPath(commands) - Method in class net.corda.core.contracts.clauses.CompositeClause
-
Determine the subclauses which will be verified as a result of verifying this clause.
- getExecutionPath(commands) - Method in class net.corda.core.contracts.clauses.FilterOn
-
Determine the subclauses which will be verified as a result of verifying this clause.
- getExecutionPath(commands) - Method in class net.corda.core.contracts.clauses.GroupClauseVerifier
-
Determine the subclauses which will be verified as a result of verifying this clause.
- getExecutor() - Method in class net.corda.node.services.statemachine.StateMachineManager
-
- getExitCashGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getExitKeys() - Method in class net.corda.contracts.asset.Cash.State
-
There must be an ExitCommand signed by these keys to destroy the amount. While all states require their
owner to sign, some (i.e. cash) also require the issuer.
- getExitKeys() - Method in class net.corda.contracts.asset.CommodityContract.State
-
There must be an ExitCommand signed by these keys to destroy the amount. While all states require their
owner to sign, some (i.e. cash) also require the issuer.
- getExitKeys() - Method in class net.corda.contracts.asset.Obligation.State
-
There must be an ExitCommand signed by these keys to destroy the amount. While all states require their
owner to sign, some (i.e. cash) also require the issuer.
- getExitKeys() - Method in interface net.corda.core.contracts.FungibleAsset
-
There must be an ExitCommand signed by these keys to destroy the amount. While all states require their
owner to sign, some (i.e. cash) also require the issuer.
- getExpandedCompositeKeys($receiver) - Static method in class net.corda.core.crypto.composite.CompositeKeyKt
-
Expands all
class CompositeKey
s present in PublicKey iterable to set of single
PublicKeys.
If an element of the set is a single PublicKey it gives just that key, if it is a
class CompositeKey
it returns all leaf
keys for that composite element.
- getExpected() - Method in class net.corda.node.services.persistence.NodeAttachmentService.HashCheckingStream
-
- getExpected() - Method in exception net.corda.node.services.persistence.NodeAttachmentService.HashMismatchException
-
- getExpectedSize() - Method in class net.corda.node.services.persistence.NodeAttachmentService.HashCheckingStream
-
- getExpectedTypeName() - Method in exception net.corda.flows.TwoPartyTradeFlow.AssetMismatchException
-
- getExpires() - Method in class net.corda.node.services.network.NodeRegistration
-
- getExportJMXto() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getExportJMXto() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getExpr() - Method in class net.corda.contracts.Expression
-
- getExpression() - Method in class net.corda.core.node.services.vault.CriteriaExpression.Not
-
- getExpression() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
- getExternalId() - Method in class net.corda.core.contracts.UniqueIdentifier
-
- getExternalId() - Method in class net.corda.core.schemas.CommonSchemaV1.LinearState
-
Represents a
- getExternalId() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
Represents a
- getExtraAdvertisedServiceIds() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getExtraAuditData() - Method in class net.corda.core.utilities.ProgressTracker.Step
-
A flow may populate this property with flow specific context data.
The extra data will be recorded to the audit logs when the flow progresses.
Even if empty the basic details (i.e. label) of the step will be recorded for audit purposes.
- getExtraParticipants() - Method in class net.corda.core.flows.FinalityFlow
-
- getExtraRecipients() - Method in class net.corda.core.flows.FinalityFlow
-
- getFaceValue() - Method in class net.corda.contracts.CommercialPaper.State
-
- getFaceValue() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
- getFaceValue() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getFaceValueIssuerParty() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getFaceValueIssuerRef() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getFactory() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
- getFactory() - Method in class net.corda.core.serialization.CertPathSerializer
-
- getFactory() - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
-
- getFactory() - Method in class net.corda.node.internal.InitiatedFlowFactory.Core
-
- getFETCH_TOPIC() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getFiber() - Method in class net.corda.node.services.statemachine.FlowSession
-
- getFiber() - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
-
- getField(obj, name) - Method in class net.corda.core.serialization.carpenter.ClassCarpenter.Companion
-
- getField(obj, name) - Static method in class net.corda.core.serialization.carpenter.ClassCarpenter
-
- getField() - Method in class net.corda.core.serialization.carpenter.Field
-
- getFields() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- getFields() - Method in class net.corda.core.serialization.carpenter.Schema
-
- getFileName() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- getFilteredLeaves() - Method in class net.corda.core.transactions.FilteredTransaction
-
- getFilterStates() - Method in class net.corda.core.contracts.clauses.FilterOn
-
- getFirst() - Method in class net.corda.core.messaging.DataFeed
-
Deprecated.
- getFirstPayload() - Method in class net.corda.node.services.statemachine.SessionInit
-
- getFlow() - Method in class net.corda.node.services.statemachine.FlowSession
-
- getFlowFactory(initiatingFlowClass) - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getFlowId() - Method in class net.corda.core.node.services.Vault.Update
-
- getFlowId() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- getFlowId() - Method in interface net.corda.node.services.api.FlowAuditInfo
-
The stable identifier of the flow as stored with Checkpoints.
- getFlowId() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- getFlowId() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- getFlowId() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The stable identifier of the flow as stored with Checkpoints.
- getFlowId() - Method in class net.corda.node.services.api.FlowStartEvent
-
The stable identifier of the flow as stored with Checkpoints.
- getFlowInitiator() - Method in interface net.corda.core.internal.FlowStateMachine
-
- getFlowInitiator() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- getFlowLogicClassName() - Method in class net.corda.core.messaging.StateMachineInfo
-
- getFlowLogicClassName() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
-
- getFlowProgress() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
- getFlowType() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The concrete type of FlowLogic being referenced.
- getFlowType() - Method in interface net.corda.node.services.api.FlowAuditInfo
-
The concrete type of FlowLogic being referenced.
TODO This should be replaced with the fully versioned name/signature of the flow.
- getFlowType() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The concrete type of FlowLogic being referenced.
- getFlowType() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The concrete type of FlowLogic being referenced.
- getFlowType() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The concrete type of FlowLogic being referenced.
- getFlowType() - Method in class net.corda.node.services.api.FlowStartEvent
-
The concrete type of FlowLogic being referenced.
- getFlowVerison() - Method in class net.corda.node.services.statemachine.SessionInit
-
- getFlowVersionAndInitiatingClass($receiver) - Static method in class net.corda.node.services.statemachine.FlowStateMachineImplKt
-
- getFollowInputsOfType() - Method in class net.corda.core.contracts.TransactionGraphSearch.Query
-
- getForDay() - Method in class net.corda.contracts.FixOf
-
- getFormat() - Method in class net.corda.core.crypto.composite.CompositeKey
-
- getFormat() - Method in class net.corda.core.crypto.testing.DummyPublicKey
-
Deprecated.
- getFormat() - Method in class net.corda.core.crypto.testing.NullPublicKey
-
- getFree() - Method in class net.corda.core.internal.Emoji
-
- getFromDisk() - Method in class net.corda.core.flows.FetchDataFlow.Result
-
- getFromTime() - Method in class net.corda.core.contracts.TimeWindow
-
Returns the inclusive lower-bound of this
class TimeWindow
's interval, with null implying infinity.
- getFunction() - Method in class net.corda.client.jfx.utils.MappedList
-
- getFuture() - Method in class net.corda.core.messaging.DataFeed
-
Deprecated.
- getFuture() - Method in class net.corda.node.shell.FlowWatchPrintingSubscriber
-
- getFuzzyIdentityMatch() - Method in class net.corda.jackson.JacksonSupport.IdentityObjectMapper
-
- getFuzzyIdentityMatch() - Method in class net.corda.jackson.JacksonSupport.RpcObjectMapper
-
- getGenerate() - Method in class net.corda.client.mock.Generator
-
- getGenericComponentType() - Method in class net.corda.core.serialization.amqp.DeserializedGenericArrayType
-
- getGlobal() - Method in class net.corda.core.serialization.LoggingWhitelist
-
- getGloballySeen() - Method in class net.corda.core.serialization.LoggingWhitelist.Companion
-
- getGot() - Method in exception net.corda.core.flows.FetchDataFlow.DownloadedVsRequestedDataMismatch
-
- getGot() - Method in exception net.corda.core.flows.FetchDataFlow.DownloadedVsRequestedSizeMismatch
-
- getGreenTick() - Method in class net.corda.core.internal.Emoji
-
- getGroupByColumns() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- getGroupingKey() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
- getHardReferenceStore() - Method in class net.corda.client.rpc.internal.ObservableContext
-
- getHasEmojiTerminal() - Method in class net.corda.core.internal.Emoji
-
- getHasEnded() - Method in class net.corda.core.utilities.ProgressTracker
-
Returns true if the progress tracker has ended, either by reaching the
class ProgressTracker.DONE
step or prematurely with an error
- getHash() - Method in exception net.corda.core.contracts.AttachmentResolutionException
-
- getHash() - Method in exception net.corda.core.contracts.TransactionResolutionException
-
- getHash() - Method in class net.corda.core.crypto.MerkleTree
-
- getHash() - Method in class net.corda.core.crypto.MerkleTree.Leaf
-
- getHash() - Method in class net.corda.core.crypto.MerkleTree.Node
-
- getHash() - Method in class net.corda.core.crypto.PartialTree.IncludedLeaf
-
- getHash() - Method in class net.corda.core.crypto.PartialTree.Leaf
-
- getHash() - Method in class net.corda.core.serialization.SerializedBytes
-
- getHash() - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
-
- getHashes() - Method in class net.corda.core.flows.FetchDataFlow.Request
-
- getHelp() - Method in class net.corda.node.CmdLineOptions
-
- getHoldability() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getHolidayDates() - Method in class net.corda.contracts.BusinessCalendar
-
- getHolidayDates() - Method in class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
-
- getHost() - Method in class net.corda.core.utilities.NetworkHostAndPort
-
- getHours($receiver) - Static method in class net.corda.core.utilities.KotlinUtilsKt
-
Extension method for easier construction of Durations in terms of integer hours: val twoHours = 2.hours
.
- getId() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
-
- getId() - Method in interface net.corda.core.contracts.NamedByHash
-
- getId() - Method in class net.corda.core.contracts.UniqueIdentifier
-
- getId() - Method in class net.corda.core.flows.TransactionParts
-
- getId() - Method in interface net.corda.core.internal.FlowStateMachine
-
- getId() - Method in interface net.corda.core.messaging.FlowHandle
-
The started state machine's ID.
- getId() - Method in class net.corda.core.messaging.FlowHandleImpl
-
The started state machine
- getId() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
The started state machine
- getId() - Method in class net.corda.core.messaging.StateMachineInfo
-
- getId() - Method in class net.corda.core.messaging.StateMachineUpdate.Added
-
- getId() - Method in class net.corda.core.messaging.StateMachineUpdate
-
- getId() - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
-
- getId() - Method in class net.corda.core.node.services.ServiceType
-
- getId() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
- getId() - Method in class net.corda.core.schemas.CommonSchemaV1.Party
-
- getId() - Method in class net.corda.core.transactions.LedgerTransaction
-
The hash of the original serialised WireTransaction.
- getId() - Method in class net.corda.core.transactions.SignedTransaction
-
- getId() - Method in exception net.corda.core.transactions.SignedTransaction.SignaturesMissingException
-
- getId() - Method in class net.corda.core.transactions.WireTransaction
-
The transaction id is represented by the root hash of Merkle tree over the transaction components.
- getId() - Method in class net.corda.node.services.api.Checkpoint
-
- getId() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- getId() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- getIdentity() - Method in class net.corda.core.node.ServiceEntry
-
- getIdentity() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
-
- getIdentityService() - Method in interface net.corda.core.node.ServicesForResolution
-
- getIdentityService() - Method in class net.corda.jackson.JacksonSupport.IdentityObjectMapper
-
- getIdentityService() - Method in class net.corda.node.services.keys.E2ETestKeyManagementService
-
- getIdentityService() - Method in class net.corda.node.services.keys.PersistentKeyManagementService
-
- getIds() - Method in exception net.corda.core.serialization.MissingAttachmentsException
-
- getIfChangedSinceVersion() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- getIncludeSoftlockedStates() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- getIndex() - Method in class net.corda.core.contracts.StateRef
-
- getIndex() - Method in class net.corda.core.schemas.PersistentStateRef
-
- getIndex() - Method in interface net.corda.core.schemas.requery.Requery.PersistentState
-
- getIndex() - Method in class net.corda.node.utilities.StateRefColumns
-
- getIndexMap() - Method in class net.corda.client.jfx.utils.FlattenedList
-
- getInfo() - Method in class net.corda.core.node.ServiceEntry
-
- getInfo() - Method in class net.corda.node.internal.AbstractNode
-
- getInitialiseSerialization() - Method in class net.corda.node.internal.Node
-
- getInitiatedSessionId() - Method in class net.corda.node.services.statemachine.SessionConfirm
-
- getInitiatingFlowClass() - Method in class net.corda.node.services.statemachine.SessionInit
-
- getInitiatingParty() - Method in class net.corda.node.services.statemachine.FlowSession
-
- getInitiator() - Method in class net.corda.core.messaging.StateMachineInfo
-
- getInitiatorSessionId() - Method in class net.corda.node.services.statemachine.SessionConfirm
-
- getInitiatorSessionId() - Method in class net.corda.node.services.statemachine.SessionInit
-
- getInitiatorSessionId() - Method in interface net.corda.node.services.statemachine.SessionInitResponse
-
- getInitiatorSessionId() - Method in class net.corda.node.services.statemachine.SessionReject
-
- getInnerMap() - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- getInNodeNetworkMapService() - Method in class net.corda.node.internal.AbstractNode
-
- getInput() - Method in class net.corda.core.crypto.CertificateStream
-
- getInput(index) - Method in class net.corda.core.transactions.LedgerTransaction
-
- getInputIndex() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
- getInputs() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
-
- getInputs() - Method in class net.corda.core.flows.TransactionParts
-
- getInputs() - Method in class net.corda.core.transactions.BaseTransaction
-
The inputs of this transaction.
- getInputs() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getInputs() - Method in class net.corda.core.transactions.LedgerTransaction
-
The resolved input states which will be consumed/invalidated by the execution of this transaction.
- getInputs() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
- getInputs() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getInputs() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getInputs() - Method in class net.corda.core.transactions.WireTransaction
-
Pointers to the input states on the ledger,
- getInputStates() - Method in class net.corda.core.transactions.LedgerTransaction
-
- getInputStream() - Method in class net.corda.core.internal.InputStreamAndHash
-
- getInstance(calname) - Method in class net.corda.contracts.BusinessCalendar.Companion
-
Returns a business calendar that combines all the named holiday calendars into one list of holiday dates.
- getInstance(commodityCode) - Method in class net.corda.contracts.Commodity.Companion
-
- getInstance(encoded) - Method in class net.corda.core.crypto.composite.CompositeKey.Companion
-
Build a composite key from a DER encoded form.
- getInstance(asn1) - Method in class net.corda.core.crypto.composite.CompositeKey.Companion
-
- getInterfaces() - Method in class net.corda.core.serialization.carpenter.Schema
-
- getInverse() - Method in class net.corda.contracts.asset.Commands.SetLifecycle
-
- getIpDetectRequestProperty() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer.Companion
-
- getIpDetectResponseProperty() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer.Companion
-
- getIssuance() - Method in class net.corda.contracts.CommercialPaper.State
-
- getIssuance() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
- getIssuanceParty() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getIssuanceRef() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getIssueCashGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getIssuer() - Method in class net.corda.core.contracts.Issued
-
- getIssuerBankParty() - Method in class net.corda.flows.IssuerFlow.IssuanceRequester
-
- getIssuerConstraint() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- getIssuerConstraint() - Method in class net.corda.flows.CashPaymentFlow
-
- getIssueRef() - Method in class net.corda.flows.CashExitFlow
-
- getIssueRef() - Method in class net.corda.flows.CashFlowCommand.ExitCash
-
- getIssueRef() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- getIssueRef() - Method in class net.corda.flows.CashIssueFlow
-
- getIssueRefGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getIssuerGenerator() - Method in class net.corda.client.mock.ErrorFlowsEventGenerator
-
- getIssuerGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getIssuerParty() - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
Issuer attributes
- getIssuerParty() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
Issuer attributes
- getIssuerParty() - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- getIssuerPartyName() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- getIssuerPartyRef() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- getIssuerRef() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- getIssuerRef() - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- getIssuerRef() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- getIssuerRef() - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- getIssueToParty() - Method in class net.corda.flows.IssuerFlow.IssuanceRequester
-
- getIssueToParty() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- getIssueToPartyRef() - Method in class net.corda.flows.IssuerFlow.IssuanceRequester
-
- getJournalWriter() - Method in class net.corda.core.serialization.LoggingWhitelist.Companion
-
- getJvmName() - Method in class net.corda.core.serialization.carpenter.Schema
-
- getKey() - Method in class net.corda.core.schemas.CommonSchemaV1.Party
-
- getKey() - Method in class net.corda.node.services.transactions.Commands.Get
-
- getKey() - Method in class net.corda.node.utilities.JDBCHashMap.BlobMapTable
-
- getKey() - Method in class net.corda.node.utilities.JDBCHashSet.BlobSetTable
-
- getKEY_ALGORITHM() - Method in class net.corda.core.crypto.composite.CompositeKey.Companion
-
- getKeyHash() - Method in class net.corda.node.utilities.JDBCHashedTable
-
- getKeyManagementService() - Method in interface net.corda.core.node.ServiceHub
-
- getKeyPair() - Method in class net.corda.core.crypto.CertificateAndKeyPair
-
- getKeyPair($receiver, alias, keyPassword) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Extract public and private keys from a KeyStore file assuming storage alias is known.
- getKeys() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- getKeys($receiver) - Static method in class net.corda.core.crypto.CryptoUtils
-
- getKeys() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
-
- getKeys() - Method in interface net.corda.core.node.services.KeyManagementService
-
Returns a snapshot of the current signing
PublicKeys.
For each of these keys a
PrivateKey is available, that can be used later for signing.
- getKeys() - Method in class net.corda.node.services.keys.E2ETestKeyManagementService
-
Returns a snapshot of the current signing
PublicKeys.
For each of these keys a
PrivateKey is available, that can be used later for signing.
- getKeys() - Method in class net.corda.node.services.keys.PersistentKeyManagementService
-
Returns a snapshot of the current signing
PublicKeys.
For each of these keys a
PrivateKey is available, that can be used later for signing.
- getKeys() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- getKeySize() - Method in class net.corda.core.crypto.SignatureScheme
-
- getKEYSTORE_TYPE() - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
- getKeyStorePassword() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getKeyUsage() - Method in enum net.corda.core.crypto.CertificateType
-
- getKlass() - Method in class net.corda.client.jfx.model.TrackedDelegate
-
- getKlass() - Method in class net.corda.core.serialization.ImmutableClassSerializer
-
- getKryo() - Method in class net.corda.core.serialization.KryoSerializationCustomization
-
- getLabel() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- getLabel() - Method in class net.corda.core.serialization.amqp.Field
-
- getLabel() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getLabel() - Method in class net.corda.core.serialization.amqp.TypeNotation
-
- getLabel() - Method in class net.corda.core.utilities.ProgressTracker.Step
-
- getLatitude() - Method in class net.corda.core.node.WorldCoordinate
-
- getLeafKeys() - Method in class net.corda.core.crypto.composite.CompositeKey
-
Set of all leaf keys of that CompositeKey.
- getLeft() - Method in class net.corda.core.crypto.MerkleTree.Node
-
- getLeft() - Method in class net.corda.core.crypto.PartialTree.Node
-
- getLeft() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
-
- getLeftArrow() - Method in class net.corda.core.internal.Emoji
-
- getLeftTable() - Method in class net.corda.client.jfx.utils.LeftOuterJoinedMap
-
- getLegacyContract() - Method in interface net.corda.core.contracts.UpgradedContract
-
- getLegalContractReference() - Method in class net.corda.contracts.asset.Cash
-
TODO:
- getLegalContractReference() - Method in class net.corda.contracts.asset.CommodityContract
-
TODO:
- getLegalContractReference() - Method in class net.corda.contracts.asset.Obligation
-
TODO:
- getLegalContractReference() - Method in class net.corda.contracts.CommercialPaper
-
Unparsed reference to the natural language contract that this code is supposed to express (usually a hash of
the contract's contents).
- getLegalContractReference() - Method in class net.corda.contracts.CommercialPaperLegacy
-
Unparsed reference to the natural language contract that this code is supposed to express (usually a hash of
the contract's contents).
- getLegalContractReference() - Method in interface net.corda.core.contracts.Contract
-
Unparsed reference to the natural language contract that this code is supposed to express (usually a hash of
the contract's contents).
- getLegalIdentitiesAndCerts() - Method in class net.corda.core.node.NodeInfo
-
- getLegalIdentity() - Method in class net.corda.core.node.NodeInfo
-
- getLegalIdentityAndCert() - Method in class net.corda.core.node.NodeInfo
-
- getLegalIdentityKey($this) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- getLegalIdentityKey($this) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
Helper property to shorten code for fetching the the
PublicKey portion of the
Node's primary signing identity.
Typical use is during signing in flows and for unit test signing.
When this
PublicKey is passed into the signing methods below, or on the KeyManagementService
the matching
java.security.PrivateKey will be looked up internally and used to sign.
If the key is actually a CompositeKey, the first leaf key hosted on this node
will be used to create the signature.
- getLegalIdentityKey() - Method in interface net.corda.core.node.ServiceHub
-
Helper property to shorten code for fetching the the
PublicKey portion of the
Node's primary signing identity.
Typical use is during signing in flows and for unit test signing.
When this
PublicKey is passed into the signing methods below, or on the KeyManagementService
the matching
java.security.PrivateKey will be looked up internally and used to sign.
If the key is actually a CompositeKey, the first leaf key hosted on this node
will be used to create the signature.
- getLegalIdentityKey($this) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- getLegalName() - Method in class net.corda.node.internal.NetworkMapInfo
-
- getLifecycle() - Method in class net.corda.contracts.asset.Commands.SetLifecycle
-
- getLifecycle() - Method in class net.corda.contracts.asset.Obligation.State
-
- getLifecycleClause() - Method in class net.corda.contracts.asset.Clauses.Net
-
- getLightBulb() - Method in class net.corda.core.internal.Emoji
-
- getLinearId() - Method in interface net.corda.core.contracts.LinearState
-
Unique id shared by all LinearState states throughout history within the vaults of all parties.
Verify methods should check that one input and one output share the id in a transaction,
except at issuance/termination.
- getLinearId() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- getLineNumber() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- getLoaded() - Method in class net.corda.core.serialization.carpenter.ClassCarpenter
-
Returns a snapshot of the currently loaded classes as a map of full class name (package names+dots) -> class object
- getLoadOnInit() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- getLocation($receiver) - Static method in class net.corda.core.crypto.X509UtilitiesKt
-
- getLocationOrNull($receiver) - Static method in class net.corda.core.crypto.X509UtilitiesKt
-
- getLock() - Method in class net.corda.core.internal.ThreadBox
-
- getLockId() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getLockId() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getLockId() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
used to denote a state has been soft locked
- getLockUpdateTime() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getLockUpdateTime() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to the last time a lock was taken
- getLog() - Method in class net.corda.contracts.asset.OnLedgerAsset.Companion
-
- getLog() - Method in class net.corda.core.contracts.clauses.Clause.Companion
-
- getLog() - Method in class net.corda.core.node.services.TrustedAuthorityNotaryService
-
- getLog() - Method in class net.corda.core.serialization.LoggingWhitelist.Companion
-
- getLog() - Method in class net.corda.node.internal.AbstractNode
-
- getLog() - Method in class net.corda.node.internal.Node
-
- getLog() - Method in class net.corda.node.services.messaging.NodeLoginModule.Companion
-
- getLog() - Method in class net.corda.node.services.transactions.OutOfProcessTransactionVerifierService.Companion
-
- getLog() - Method in class net.corda.node.services.vault.HibernateVaultQueryImpl.Companion
-
- getLog() - Method in class net.corda.node.utilities.AbstractJDBCHashMap.Companion
-
- getLogger() - Method in class net.corda.core.contracts.clauses.FirstOf.Companion
-
- getLogger() - Method in class net.corda.core.flows.FlowLogic
-
This is where you should log things to.
- getLogger() - Method in interface net.corda.core.internal.FlowStateMachine
-
- getLogger() - Method in class net.corda.node.services.database.HibernateConfiguration.Companion
-
- getLogger() - Method in class net.corda.node.services.database.RequeryConfiguration.Companion
-
- getLogger() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache.Companion
-
- getLogger() - Method in class net.corda.node.services.schema.HibernateObserver.Companion
-
- getLogger() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
Return the logger for this state machine. The logger name incorporates id and so including it in the log message
is not necessary.
- getLogger() - Method in class net.corda.node.utilities.ServiceAffinityExecutor.Companion
-
- getLoggingLevel() - Method in class net.corda.node.CmdLineOptions
-
- getLogic() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- getLogic() - Method in class net.corda.node.services.statemachine.Change.Add
-
- getLogic() - Method in class net.corda.node.services.statemachine.StateMachineManager.Change
-
- getLogic() - Method in class net.corda.node.services.statemachine.Change.Removed
-
- getLogicRef() - Method in class net.corda.core.contracts.ScheduledActivity
-
- getLogMessage() - Method in exception net.corda.node.internal.SessionRejectException
-
- getLOGS_CAN_BE_FOUND_IN_STRING() - Method in class net.corda.node.internal.NodeStartup.Companion
-
- getLOGS_DIRECTORY_NAME() - Method in class net.corda.node.internal.NodeStartup.Companion
-
- getLogToConsole() - Method in class net.corda.node.CmdLineOptions
-
- getLongitude() - Method in class net.corda.core.node.WorldCoordinate
-
- getLowerBounds() - Method in class net.corda.core.serialization.amqp.SerializerFactory.AnyType
-
- getManager() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- getMandatory() - Method in class net.corda.core.serialization.amqp.Field
-
- getMandatory() - Method in class net.corda.core.serialization.amqp.PropertySerializer
-
- getMappedType() - Method in class net.corda.core.schemas.requery.converters.BlobConverter
-
- getMappedType() - Method in class net.corda.core.schemas.requery.converters.InstantConverter
-
- getMappedType() - Method in class net.corda.core.schemas.requery.converters.SecureHashConverter
-
- getMappedType() - Method in class net.corda.core.schemas.requery.converters.StateRefConverter
-
- getMappedTypes() - Method in class net.corda.core.schemas.MappedSchema
-
- getMapping() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getMapServiceRegistered() - Method in interface net.corda.core.node.services.NetworkMapCache
-
Future to track completion of the NetworkMapService registration.
- getMapServiceRegistered() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
Future to track completion of the NetworkMapService registration.
- getMapVersion() - Method in class net.corda.node.services.network.AbstractNetworkMapService
-
- getMapVersion() - Method in class net.corda.node.services.network.LastAcknowledgeInfo
-
- getMapVersion() - Method in class net.corda.node.services.network.NetworkMapService.Update
-
- getMapVersion() - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
-
- getMapVersion() - Method in class net.corda.node.services.network.NodeRegistrationInfo
-
- getMaturity() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getMaturityDate() - Method in class net.corda.contracts.CommercialPaper.State
-
- getMaturityDate() - Method in class net.corda.contracts.CommercialPaper.Terms
-
- getMaturityDate() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
- getMAX_FILE_SIZE() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer.Companion
-
10 MiB maximum allowed file size for attachments, including message headers. TODO: acquire this value from Network Map when supported.
- getMAX_FILE_SIZE() - Static method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
10 MiB maximum allowed file size for attachments, including message headers. TODO: acquire this value from Network Map when supported.
- getMAX_RETRIES() - Method in class net.corda.node.services.vault.NodeVaultService
-
- getMaxBuckets() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- getMaxFileSize() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
Maximum file size
- getMaxReconnectAttempts() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
- getMaxUnacknowledgedUpdates() - Method in class net.corda.node.services.network.AbstractNetworkMapService
-
Maximum number of unacknowledged updates to send to a node before automatically unregistering them for updates
- getMe() - Method in class net.corda.core.flows.FinalityFlow
-
- getMe() - Method in class net.corda.flows.TwoPartyTradeFlow.Seller
-
- getMerkleRoot() - Method in class net.corda.core.crypto.MetaData
-
- getMerkleTree(allLeavesHashes) - Method in class net.corda.core.crypto.MerkleTree.Companion
-
Merkle tree building using hashes, with zero hash padding to full power of 2.
- getMerkleTree() - Method in class net.corda.core.transactions.WireTransaction
-
Builds whole Merkle tree for a transaction.
- getMessage() - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
-
- getMessage() - Method in exception net.corda.core.CordaException
-
- getMessage() - Method in exception net.corda.core.CordaRuntimeException
-
- getMessage() - Method in exception net.corda.core.node.services.StatesNotAvailableException
-
- getMessage() - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer.ThrowableProxy
-
- getMessage() - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
-
- getMessage() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- getMessage() - Method in class net.corda.node.services.statemachine.SendOnly
-
- getMessage() - Method in interface net.corda.node.services.statemachine.SendRequest
-
- getMessageBroker() - Method in class net.corda.node.internal.Node
-
- getMessageRedeliveryDelaySeconds() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getMessageRedeliveryDelaySeconds() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getMessagesToRedeliver() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getMessagingServerAddress() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getMetaData() - Method in class net.corda.core.crypto.TransactionSignature
-
- getMetaData() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getMethod() - Method in class net.corda.jackson.StringToMethodCallParser.ParsedMethodCall
-
- getMethodMap() - Method in class net.corda.jackson.StringToMethodCallParser
-
The methods that can be invoked via this parser.
- getMethodName() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- getMethodName() - Method in exception net.corda.jackson.UnparseableCallException.UnknownMethod
-
- getMethodParamNames() - Method in class net.corda.jackson.StringToMethodCallParser
-
A map of method name to parameter names for the target type.
- getMetrics() - Method in class net.corda.node.services.api.MonitoringService
-
- getMidpoint() - Method in class net.corda.core.contracts.TimeWindow
-
Returns the midpoint of fromTime and untilTime if both are non-null, calculated as
fromTime + (untilTime - fromTime) / 2
, otherwise returns null.
- getMillis($receiver) - Static method in class net.corda.core.utilities.KotlinUtilsKt
-
Extension method for easier construction of Durations in terms of integer milliseconds: val twoMillis = 2.millis
.
- getMinimumPlatformVersion() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getMinimumPlatformVersion() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getMinimumPlatformVersion() - Method in class net.corda.node.services.network.AbstractNetworkMapService
-
- getMinimumServerProtocolVersion() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The minimum protocol version required from the server
- getMinutes($receiver) - Static method in class net.corda.core.utilities.KotlinUtilsKt
-
Extension method for easier construction of Durations in terms of integer minutes: val twoMinutes = 2.minutes
.
- getMissing() - Method in exception net.corda.core.transactions.SignedTransaction.SignaturesMissingException
-
- getModel() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getModification() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Instigator
-
- getModification() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
-
- getMonitoringService() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getMonitoringService() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getMonitoringService() - Method in class net.corda.node.services.transactions.OutOfProcessTransactionVerifierService
-
- getMoveCashGenerator() - Method in class net.corda.client.mock.ErrorFlowsEventGenerator
-
- getMoveCashGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getMultilateralNetState() - Method in class net.corda.contracts.asset.Obligation.State
-
Returns an object used to determine if two states can be subject to close-out netting. If two states return
equal objects, they can be close out netted together.
- getMultilateralNetState() - Method in interface net.corda.contracts.MultilateralNettableState
-
Returns an object used to determine if two states can be subject to close-out netting. If two states return
equal objects, they can be close out netted together.
- getMultiple() - Method in class net.corda.core.serialization.amqp.Field
-
- getMustSign() - Method in class net.corda.core.transactions.BaseTransaction
-
Public keys that need to be fulfilled by signatures in order for the transaction to be valid.
In a
class SignedTransaction
this list is used to check whether there are any missing signatures. Note that
there is nothing that forces the list to be the
correct list of signers for this transaction until
the transaction is verified by using
LedgerTransaction.verify
.
- getMustSign() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getMustSign() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getMutations() - Method in class net.corda.node.utilities.MutableClock
-
This is an observer on the mutation count of this Clock, which reflects the occurence of mutations.
- getMyAddress() - Method in interface net.corda.node.services.messaging.MessagingService
-
Returns an address that refers to this node.
- getMyAddress() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
Apart from the NetworkMapService this is the only other address accessible to the node outside of lookups against the NetworkMapCache.
- getMyIdentity() - Method in class net.corda.client.jfx.model.NetworkIdentityModel
-
- getMyIdentity() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getMyInfo() - Method in interface net.corda.core.node.ServiceHub
-
- getMyKey() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
-
- getMyKey() - Method in class net.corda.flows.TwoPartyDealFlow.Instigator
-
- getMyKey() - Method in class net.corda.flows.TwoPartyDealFlow.Primary
-
- getMyLegalName() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getMyLegalName() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getName() - Method in class net.corda.contracts.FixOf
-
- getName() - Method in class net.corda.contracts.Tenor
-
- getName() - Method in class net.corda.core.flows.FlowInitiator.Peer
-
- getName() - Method in class net.corda.core.flows.FlowInitiator.RPC
-
- getName() - Method in class net.corda.core.flows.FlowInitiator.Scheduled
-
- getName() - Method in class net.corda.core.flows.FlowInitiator.Shell
-
- getName() - Method in class net.corda.core.identity.AnonymousPartyAndPath
-
Get the X.500 name of the certificate for the anonymous party.
- getName() - Method in class net.corda.core.identity.Party
-
- getName() - Method in class net.corda.core.identity.PartyAndCertificate
-
- getName() - Method in class net.corda.core.node.services.ServiceInfo
-
- getName() - Method in class net.corda.core.node.services.vault.Column
-
- getName() - Method in class net.corda.core.schemas.CommonSchemaV1.Party
-
- getName() - Method in class net.corda.core.schemas.MappedSchema
-
- getName() - Method in class net.corda.core.serialization.amqp.Choice
-
- getName() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- getName() - Method in class net.corda.core.serialization.amqp.Descriptor
-
- getName() - Method in class net.corda.core.serialization.amqp.Field
-
- getName() - Method in class net.corda.core.serialization.amqp.PropertySerializer
-
- getName() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getName() - Method in class net.corda.core.serialization.amqp.TypeNotation
-
- getName() - Method in class net.corda.core.serialization.carpenter.Field
-
- getName() - Method in class net.corda.core.serialization.carpenter.Schema
-
- getName() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- getName() - Method in class net.corda.node.utilities.PartyColumns
-
- getNanos() - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
-
- getNetwork() - Method in class net.corda.node.internal.AbstractNode
-
- getNetwork() - Method in class net.corda.node.services.api.AbstractNodeService
-
- getNetworkIdentities() - Method in class net.corda.client.jfx.model.NetworkIdentityModel
-
- getNetworkMap() - Method in class net.corda.client.jfx.model.NodeMonitorModel
-
- getNetworkMap() - Method in class net.corda.core.node.services.ServiceType.Companion
-
- getNetworkMapAddress() - Method in class net.corda.node.internal.AbstractNode
-
- getNetworkMapAddress() - Method in class net.corda.node.internal.Node
-
- getNetworkMapCache() - Method in interface net.corda.core.node.ServiceHub
-
- getNetworkMapCache() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getNetworkMapCache() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- getNetworkMapConnectionFuture() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
A ListenableFuture which completes when the server successfully connects to the network map node. If a
non-recoverable error is encountered then the Future will complete with an exception.
- getNetworkMapNodes() - Method in interface net.corda.core.node.services.NetworkMapCache
-
A list of nodes that advertise a network map service
- getNetworkMapNodes() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
A list of nodes that advertise a network map service
- getNetworkMapRegistrationFuture() - Method in class net.corda.node.internal.AbstractNode
-
Completes once the node has successfully registered with the network map service
- getNetworkMapRegistrationFuture() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getNetworkMapSeq() - Method in class net.corda.node.internal.AbstractNode
-
Sequence number of changes sent to the network map service, when registering/de-registering this node.
- getNetworkMapService() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getNetworkMapService() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getNetworkService() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getNetworkTimeout() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getNewspaper() - Method in class net.corda.core.internal.Emoji
-
- getNewStep() - Method in class net.corda.core.utilities.Change.Position
-
- getNode() - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
-
- getNode() - Method in class net.corda.core.node.services.MapChange.Added
-
- getNode() - Method in class net.corda.core.node.services.NetworkMapCache.MapChange
-
- getNode() - Method in class net.corda.core.node.services.MapChange.Modified
-
- getNode() - Method in class net.corda.core.node.services.MapChange.Removed
-
- getNode() - Method in class net.corda.core.node.services.PartyInfo.Node
-
- getNode() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityResponse
-
- getNode() - Method in class net.corda.node.services.network.NodeRegistration
-
- getNodeByLegalIdentity(party) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Look up the node info for a specific party. Will attempt to de-anonymise the party if applicable; if the party
is anonymised and the well known party cannot be resolved, it is impossible ot identify the node and therefore this
returns null.
- getNodeByLegalIdentity(party) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
Look up the node info for a specific party. Will attempt to de-anonymise the party if applicable; if the party
is anonymised and the well known party cannot be resolved, it is impossible ot identify the node and therefore this
returns null.
- getNodeByLegalIdentityKey(identityKey) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Look up the node info for a specific peer key.
- getNodeByLegalIdentityKey(identityKey) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
Look up the node info for a specific peer key.
- getNodeByLegalName($this, principal) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Look up the node info for a legal name.
- getNodeByLegalName(principal) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Look up the node info for a legal name.
- getNodeExecutor() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getNodeRegistrations() - Method in class net.corda.node.services.network.AbstractNetworkMapService
-
- getNodeRegistrations() - Method in class net.corda.node.services.network.InMemoryNetworkMapService
-
- getNodeRegistrations() - Method in class net.corda.node.services.network.PersistentNetworkMapService
-
- getNodes() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
-
- getNodesByAdvertisedServiceIdentityKey($this, publicKey) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Look up all nodes advertising the service owned by publicKey
- getNodesByAdvertisedServiceIdentityKey(publicKey) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Look up all nodes advertising the service owned by publicKey
- getNodesWithService($this, serviceType) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Get the collection of nodes which advertise a specific service.
- getNodesWithService(serviceType) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Get the collection of nodes which advertise a specific service.
- getNoEntry() - Method in class net.corda.core.internal.Emoji
-
- getNoLocalShell() - Method in class net.corda.node.CmdLineOptions
-
- getNonce() - Method in class net.corda.contracts.asset.Commands.Issue
-
- getNonce() - Method in class net.corda.contracts.asset.Commands.Issue
-
- getNonce() - Method in class net.corda.contracts.asset.Commands.Issue
-
- getNonce() - Method in class net.corda.contracts.Commands.Issue
-
- getNonce() - Method in interface net.corda.core.contracts.IssueCommand
-
- getNormalMoveGenerator() - Method in class net.corda.client.mock.ErrorFlowsEventGenerator
-
- getNotaries() - Method in class net.corda.client.jfx.model.NetworkIdentityModel
-
- getNotarisedTransaction() - Method in class net.corda.core.flows.BroadcastTransactionFlow
-
- getNotary() - Method in class net.corda.client.mock.EventGenerator
-
- getNotary() - Method in class net.corda.core.contracts.TransactionState
-
Identity of the notary that ensures the state is not used as an input to a transaction more than once
- getNotary($this, principal) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Gets a notary identity by the given name.
- getNotary(principal) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Gets a notary identity by the given name.
- getNotary() - Method in class net.corda.core.node.services.ServiceType.Companion
-
- getNotary() - Method in class net.corda.core.transactions.BaseTransaction
-
If present,
- getNotary() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getNotary() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getNotary() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getNotary() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- getNotary() - Method in class net.corda.flows.CashIssueFlow
-
- getNotary() - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
-
- getNotary() - Method in class net.corda.flows.TwoPartyTradeFlow.Buyer
-
- getNotaryClusterAddresses() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getNotaryClusterAddresses() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getNotaryIdentity() - Method in class net.corda.core.node.NodeInfo
-
- getNotaryIdentityKey($this) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- getNotaryIdentityKey($this) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
Helper property to shorten code for fetching the the
PublicKey portion of the
Node's Notary signing identity. It is required that the Node hosts a notary service,
otherwise an IllegalArgumentException will be thrown.
Typical use is during signing in flows and for unit test signing.
When this
PublicKey is passed into the signing methods below, or on the KeyManagementService
the matching
java.security.PrivateKey will be looked up internally and used to sign.
If the key is actually a
net.corda.core.crypto.CompositeKey, the first leaf key hosted on this node
will be used to create the signature.
- getNotaryIdentityKey() - Method in interface net.corda.core.node.ServiceHub
-
Helper property to shorten code for fetching the the
PublicKey portion of the
Node's Notary signing identity. It is required that the Node hosts a notary service,
otherwise an IllegalArgumentException will be thrown.
Typical use is during signing in flows and for unit test signing.
When this
PublicKey is passed into the signing methods below, or on the KeyManagementService
the matching
java.security.PrivateKey will be looked up internally and used to sign.
If the key is actually a
net.corda.core.crypto.CompositeKey, the first leaf key hosted on this node
will be used to create the signature.
- getNotaryIdentityKey($this) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- getNotaryKey() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getNotaryKey() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
- getNotaryName() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- getNotaryName() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getNotaryName() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to the notary a state is attached to
- getNotaryNode() - Method in class net.corda.flows.TwoPartyDealFlow.Instigator
-
- getNotaryNode() - Method in class net.corda.flows.TwoPartyDealFlow.Primary
-
- getNotaryNode() - Method in class net.corda.flows.TwoPartyTradeFlow.Seller
-
- getNotaryNodeAddress() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getNotaryNodeAddress() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getNotaryNodes($this) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
A list of nodes that advertise a notary service
- getNotaryNodes() - Method in interface net.corda.core.node.services.NetworkMapCache
-
A list of nodes that advertise a notary service
- getNotaryParty() - Method in class net.corda.core.flows.NotaryFlow.Client
-
- getNotaryParty() - Method in class net.corda.flows.IssuerFlow.IssuanceRequester
-
- getNotaryParty() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- getNote() - Method in class net.corda.node.utilities.TxnNoteColumns
-
- getNoUpdate() - Method in class net.corda.core.node.services.Vault.Companion
-
- getNULL_PARTY() - Static method in class net.corda.core.crypto.testing.DummyKeysKt
-
- getNullabilityAnnotation() - Method in class net.corda.core.serialization.carpenter.Field
-
- getNullabilityAnnotation() - Method in class net.corda.core.serialization.carpenter.NonNullableField
-
- getNullabilityAnnotation() - Method in class net.corda.core.serialization.carpenter.NullableField
-
- getObj() - Method in class net.corda.core.serialization.amqp.Envelope
-
- getObj() - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
-
- getObjectPropertyProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.ObjectPropertyDelegate
-
- getObjectReferencesEnabled() - Method in interface net.corda.core.serialization.SerializationContext
-
Duplicate references to the same object preserved in the wire format and when deserialized when this is true,
otherwise they appear as new copies of the object.
- getObjects() - Method in class net.corda.core.serialization.carpenter.MetaCarpenterBase
-
a list of carpented classes loaded into the carpenters class loader
- getOBLIGATION_PROGRAM_ID() - Static method in class net.corda.contracts.asset.ObligationKt
-
- getObligor() - Method in class net.corda.contracts.asset.Obligation.State
-
Where the debt originates from
- getObservableEntries($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val nameToPerson: ObservableMap = (..)
val people: ObservableList = nameToPerson.getObservableValues()
- getObservableListProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableListDelegate
-
- getObservableListReadOnlyProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableListReadOnlyDelegate
-
- getObservableMap() - Method in class net.corda.client.rpc.internal.ObservableContext
-
- getObservableMap() - Method in class net.corda.node.services.messaging.ObservableContext
-
- getObservableProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableDelegate
-
- getObservableValue() - Method in class net.corda.client.jfx.utils.FlattenedList.WrappedObservableValue
-
- getObservableValue($receiver, key) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val nameToPerson: ObservableMap
= (..)
val john: ObservableValue = nameToPerson.getObservableValue("John")
- getObservableValueProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableValueDelegate
-
- getObservableValues($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
val nameToPerson: ObservableMap = (..)
val people: ObservableList = nameToPerson.getObservableValues()
- getObservationExecutorPoolSize() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The number of threads to use for observations
- getObservationSendExecutor() - Method in class net.corda.node.services.messaging.ObservableContext
-
- getObserverProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.ObserverDelegate
-
- getOf() - Method in class net.corda.contracts.Fix
-
- getOffset() - Method in enum net.corda.contracts.Frequency
-
- getOffset() - Method in class net.corda.core.utilities.ByteSequence
-
The start position of the sequence within the byte array.
- getOffset() - Method in class net.corda.core.utilities.OpaqueBytes
-
The start position of the sequence within the byte array.
- getOffsetDate(startDate, period, steps) - Method in class net.corda.contracts.BusinessCalendar.Companion
-
Calculates the date from @startDate moving forward @steps of time size @period. Does not apply calendar
logic / roll conventions.
- getOfStep() - Method in class net.corda.core.utilities.Change.Rendering
-
- getOfTenor() - Method in class net.corda.contracts.FixOf
-
- getOnDone() - Method in class net.corda.node.utilities.ANSIProgressRenderer
-
- getOperator() - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
-
- getOperator() - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
-
- getOperator() - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
-
- getOperator() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
-
- getOperator() - Method in class net.corda.core.node.services.vault.ColumnPredicate.NullExpression
-
- getOperator() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
-
- getOracleType() - Method in interface net.corda.contracts.FixableDealState
-
What oracle service to use for the fixing
- getOrderBy() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- getOrgName($receiver) - Static method in class net.corda.core.crypto.X509UtilitiesKt
-
- getOriginalExceptionClassName() - Method in exception net.corda.core.CordaException
-
- getOriginalExceptionClassName() - Method in exception net.corda.core.CordaRuntimeException
-
- getOriginalExceptionClassName() - Method in interface net.corda.core.CordaThrowable
-
- getOriginalMessage() - Method in exception net.corda.core.CordaException
-
- getOriginalMessage() - Method in exception net.corda.core.CordaRuntimeException
-
- getOriginalMessage() - Method in interface net.corda.core.CordaThrowable
-
- getOriginalState() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Instigator
-
- getOrThrow() - Method in class net.corda.core.utilities.Try.Failure
-
- getOrThrow() - Method in class net.corda.core.utilities.Try
-
- getOrThrow() - Method in class net.corda.core.utilities.Try.Success
-
- getOrThrow($receiver, timeout) - Static method in class net.corda.core.Utils
-
- getOtherParty() - Method in class net.corda.core.flows.SignTransactionFlow
-
- getOtherParty() - Method in class net.corda.flows.IssuerFlow.Issuer
-
- getOtherParty() - Method in class net.corda.flows.TwoPartyDealFlow.Acceptor
-
- getOtherParty() - Method in class net.corda.flows.TwoPartyDealFlow.Instigator
-
- getOtherParty() - Method in class net.corda.flows.TwoPartyDealFlow.Primary
-
- getOtherParty() - Method in class net.corda.flows.TwoPartyDealFlow.Secondary
-
- getOtherParty() - Method in class net.corda.flows.TwoPartyTradeFlow.Buyer
-
- getOtherParty() - Method in class net.corda.flows.TwoPartyTradeFlow.Seller
-
- getOtherParty() - Method in class net.corda.node.services.FetchDataHandler
-
- getOtherParty() - Method in class net.corda.node.services.NotifyTransactionHandler
-
- getOtherParty() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiating
-
- getOtherResults() - Method in class net.corda.core.node.services.Vault.Page
-
- getOtherSide() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Acceptor
-
- getOtherSide() - Method in class net.corda.core.flows.FetchDataFlow
-
- getOtherSide() - Method in class net.corda.core.flows.NotaryFlow.Service
-
- getOtherSide() - Method in class net.corda.core.flows.TransactionKeyFlow
-
- getOtherSide() - Method in class net.corda.node.services.TransactionKeyHandler
-
- getOurSessionId() - Method in class net.corda.node.services.statemachine.FlowSession
-
- getOuterTransaction() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- getOuterTransaction() - Method in class net.corda.node.utilities.ExposedTransaction
-
- getOutput(index) - Method in class net.corda.core.transactions.BaseTransaction
-
Helper to simplify getting an indexed output.
- getOutputs() - Method in class net.corda.core.transactions.BaseTransaction
-
Ordered list of states defined by this transaction,
- getOutputs() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getOutputs() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
- getOutputs() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getOutputs() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getOutputStates() - Method in class net.corda.core.transactions.BaseTransaction
-
- getOwner() - Method in class net.corda.contracts.asset.Cash.State
-
There must be a MoveCommand signed by this key to claim the amount.
- getOwner() - Method in class net.corda.contracts.asset.CommodityContract.State
-
There must be a MoveCommand signed by this key to claim the amount
- getOwner() - Method in class net.corda.contracts.asset.Obligation.State
-
There must be a MoveCommand signed by this key to claim the amount
- getOwner() - Method in class net.corda.contracts.CommercialPaper.State
-
There must be a MoveCommand signed by this key to claim the amount
- getOwner() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
There must be a MoveCommand signed by this key to claim the amount
- getOwner() - Method in interface net.corda.core.contracts.FungibleAsset
-
There must be a MoveCommand signed by this key to claim the amount
- getOwner() - Method in interface net.corda.core.contracts.OwnableState
-
There must be a MoveCommand signed by this key to claim the amount
- getOwner() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- getOwner() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- getOwner() - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- getOwner() - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- getOwnerKey() - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- getOwnerType() - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
-
- getOwningKey() - Method in class net.corda.core.identity.AbstractParty
-
- getOwningKey() - Method in class net.corda.core.identity.PartyAndCertificate
-
- getOwningKey() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
-
- getOwningKey() - Method in class net.corda.node.utilities.PartyColumns
-
- getP2P_CONTEXT() - Method in class net.corda.core.serialization.SerializationDefaults
-
- getP2pAddress() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getP2pPort() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- getPageNumber() - Method in class net.corda.core.node.services.vault.PageSpecification
-
- getPageSize() - Method in class net.corda.core.node.services.vault.PageSpecification
-
- getPaperclip() - Method in class net.corda.core.internal.Emoji
-
- getParamName() - Method in exception net.corda.jackson.UnparseableCallException.MissingParameter
-
- getParent() - Method in class net.corda.core.utilities.Change.Structural
-
- getParent() - Method in class net.corda.core.utilities.ProgressTracker
-
The parent of this tracker: set automatically by the parent when a tracker is added as a child
- getPartiallyResolvedTransactions() - Method in class net.corda.client.jfx.model.TransactionDataModel
-
- getPartiallySignedTx() - Method in class net.corda.core.flows.CollectSignaturesFlow
-
- getPartialMerkleTree() - Method in class net.corda.core.transactions.FilteredTransaction
-
- getParticipant() - Method in class net.corda.core.flows.FinalityFlow.Participant
-
- getParticipants() - Method in class net.corda.contracts.asset.Cash.State
-
A participant is any party that is able to consume this state in a valid transaction.
- getParticipants() - Method in class net.corda.contracts.asset.CommodityContract.State
-
A participant is any party that is able to consume this state in a valid transaction.
- getParticipants() - Method in class net.corda.contracts.asset.Obligation.State
-
A participant is any party that is able to consume this state in a valid transaction.
- getParticipants() - Method in class net.corda.contracts.CommercialPaper.State
-
A participant is any party that is able to consume this state in a valid transaction.
- getParticipants() - Method in class net.corda.contracts.CommercialPaperLegacy.State
-
A participant is any party that is able to consume this state in a valid transaction.
- getParticipants() - Method in interface net.corda.core.contracts.ContractState
-
A participant is any party that is able to consume this state in a valid transaction.
- getParticipants() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
-
- getParticipants() - Method in class net.corda.core.flows.BroadcastTransactionFlow
-
- getParticipants() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- getParticipants() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- getParticipants() - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- getParticipants() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- getParticipants() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
- getParties() - Method in class net.corda.client.jfx.model.NetworkIdentityModel
-
- getParties() - Method in class net.corda.client.mock.EventGenerator
-
- getParty() - Method in class net.corda.core.contracts.PartyAndReference
-
- getParty() - Method in class net.corda.core.flows.FlowInitiator.Peer
-
- getParty() - Method in class net.corda.core.identity.AnonymousPartyAndPath
-
- getParty() - Method in class net.corda.core.identity.PartyAndCertificate
-
- getParty() - Method in class net.corda.core.node.services.PartyInfo
-
- getParty() - Method in class net.corda.core.node.services.PartyInfo.Node
-
- getParty() - Method in class net.corda.core.node.services.PartyInfo.Service
-
- getPartyGenerator() - Method in class net.corda.client.mock.EventGenerator
-
- getPartyInfo(party) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Returns information about the party, which may be a specific node or a service
- getPartyInfo(party) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
Returns information about the party, which may be a specific node or a service
- getPartyKeys() - Method in class net.corda.contracts.clause.BilateralNetState
-
- getPartyKeys() - Method in class net.corda.node.internal.AbstractNode
-
- getPartyNodes() - Method in interface net.corda.core.node.services.NetworkMapCache
-
A list of all nodes the cache is aware of
- getPartyNodes() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
A list of all nodes the cache is aware of
- getPath() - Method in exception net.corda.core.serialization.AttachmentsClassLoader.OverlappingAttachments
-
- getPath() - Method in class net.corda.node.services.transactions.PathManager
-
- getPayload() - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
-
- getPayload() - Method in class net.corda.flows.TwoPartyDealFlow.Instigator
-
- getPayload() - Method in class net.corda.flows.TwoPartyDealFlow.Primary
-
- getPayload() - Method in class net.corda.node.services.statemachine.SessionData
-
- getPeer() - Method in interface net.corda.node.services.messaging.ReceivedMessage
-
The authenticated sender.
- getPeerParty() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
-
- getPeerSessionId() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
-
- getPennies() - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- getPermissionGranted() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
- getPermissionRequested() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
- getPersistedSize() - Method in class net.corda.core.schemas.requery.converters.BlobConverter
-
creates BLOB(INT.MAX) = 2 GB
- getPersistedSize() - Method in class net.corda.core.schemas.requery.converters.InstantConverter
-
- getPersistedSize() - Method in class net.corda.core.schemas.requery.converters.SecureHashConverter
-
SecureHash consists of 32 bytes which need VARCHAR(64) in hex
TODO: think about other hash widths
- getPersistedSize() - Method in class net.corda.core.schemas.requery.converters.StateRefConverter
-
- getPersistedType() - Method in class net.corda.core.schemas.requery.converters.BlobConverter
-
- getPersistedType() - Method in class net.corda.core.schemas.requery.converters.InstantConverter
-
- getPersistedType() - Method in class net.corda.core.schemas.requery.converters.SecureHashConverter
-
- getPersistedType() - Method in class net.corda.core.schemas.requery.converters.StateRefConverter
-
- getPlatform() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getPlatformClock() - Method in class net.corda.node.internal.AbstractNode
-
- getPlatformVersion() - Method in class net.corda.core.node.NodeInfo
-
- getPlatformVersion() - Method in class net.corda.node.internal.AbstractNode
-
- getPlatformVersion() - Method in class net.corda.node.internal.Node
-
- getPlatformVersion() - Method in interface net.corda.node.services.messaging.ReceivedMessage
-
Platform version of the sender's node.
- getPlatformVersion() - Method in class net.corda.node.VersionInfo
-
Platform version of the node which is an integer value which increments on any release where any of the public
- getPluginRegistries() - Method in class net.corda.node.internal.AbstractNode
-
Fetch CordaPluginRegistry classes registered in META-INF/services/net.corda.core.node.CordaPluginRegistry files that exist in the classpath
- getPolicy() - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- getPollInterval() - Method in class net.corda.node.utilities.registration.NetworkRegistrationHelper.Companion
-
- getPort() - Method in class net.corda.core.utilities.NetworkHostAndPort
-
- getPOUNDS($receiver) - Static method in class net.corda.core.contracts.ContractsDSL
-
- getPredicate() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
-
- getPredicate() - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
-
- getPredicate() - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
-
- getPreferedSerializationVersion() - Method in interface net.corda.core.serialization.SerializationContext
-
When serializing, use the format this header sequence represents.
- getPreviousNode() - Method in class net.corda.core.node.services.MapChange.Modified
-
- getPrice() - Method in class net.corda.flows.TwoPartyTradeFlow.Seller
-
- getPrice() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- getPrimTypes() - Method in class net.corda.core.serialization.amqp.PrimArraySerializer.Companion
-
- getPrincipal() - Method in class net.corda.node.services.api.AuditEvent
-
The responsible individual, node, or subsystem to which the audit event can be mapped.
- getPrincipal() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The responsible individual,
- getPrincipal() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The responsible individual,
- getPrincipal() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The responsible individual,
- getPrincipal() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The responsible individual,
- getPrincipal() - Method in class net.corda.node.services.api.FlowStartEvent
-
The responsible individual,
- getPrincipal() - Method in class net.corda.node.services.api.SystemAuditEvent
-
The responsible individual,
- getProduced() - Method in class net.corda.core.node.services.Vault.Update
-
- getProducerPoolBound() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The maximum number of producers to create to handle outgoing messages
- getProducerPoolBound() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The maximum number of producers to create to handle outgoing messages
- getProduct() - Method in class net.corda.contracts.asset.Obligation.Terms
-
- getProduct() - Method in class net.corda.core.contracts.Issued
-
- getProgress() - Method in interface net.corda.core.messaging.FlowProgressHandle
-
The stream of progress tracker events.
- getProgress() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
The stream of progress tracker events.
- getProgressTracker() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Acceptor
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Instigator
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.core.flows.CollectSignaturesFlow
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.core.flows.FinalityFlow
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.core.flows.FlowLogic
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.core.flows.NotaryFlow.Client
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.core.flows.SignTransactionFlow
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.core.flows.TransactionKeyFlow
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.AbstractCashFlow
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.IssuerFlow.Issuer
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.TwoPartyDealFlow.Acceptor
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.TwoPartyDealFlow.Instigator
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.TwoPartyDealFlow.Primary
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.TwoPartyDealFlow.Secondary
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.TwoPartyTradeFlow.Buyer
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.flows.TwoPartyTradeFlow.Seller
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.node.services.TransactionKeyHandler
-
Override this to provide a
class ProgressTracker
. If one is provided and stepped, the framework will do something
helpful with the progress reports e.g record to the audit service. If this flow is invoked as a subflow of another,
then the tracker will be made a child of the current step in the parent. If it's null, this flow doesn't track
progress.
- getProgressTracker() - Method in class net.corda.node.utilities.ANSIProgressRenderer
-
- getProgressTrackerStepAndUpdates() - Method in class net.corda.core.messaging.StateMachineInfo
-
- getProgressTracking() - Method in class net.corda.client.jfx.model.NodeMonitorModel
-
- getProperties() - Method in interface net.corda.core.serialization.SerializationContext
-
A map of any addition properties specific to the particular use case.
- getProperties() - Method in class net.corda.node.services.database.RequeryConfiguration
-
- getProps() - Method in class net.corda.core.serialization.ImmutableClassSerializer
-
- getPropsByName() - Method in class net.corda.core.serialization.ImmutableClassSerializer
-
- getProtocolVersion($this) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
Returns the RPC protocol version, which is the same the node's Platform Version. Exists since version 1 so guaranteed
to be present.
- getProtocolVersion() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Returns the RPC protocol version, which is the same the node's Platform Version. Exists since version 1 so guaranteed
to be present.
- getProtocolVersion() - Method in interface net.corda.core.messaging.RPCOps
-
Returns the RPC protocol version. Exists since version 0 so guaranteed to be present.
- getPROVIDER_NAME() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider.Companion
-
- getProviderName() - Method in class net.corda.core.crypto.SignatureScheme
-
- getProvides() - Method in class net.corda.core.serialization.amqp.CompositeType
-
- getProvides() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getProvides() - Method in class net.corda.core.serialization.amqp.TypeNotation
-
- getProxy() - Method in class net.corda.client.rpc.CordaRPCConnection
-
- getProxy() - Method in interface net.corda.client.rpc.internal.RPCClient.RPCConnection
-
- getProxyClass() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
- getProxyObservable() - Method in class net.corda.client.jfx.model.NodeMonitorModel
-
- getPublicKey() - Method in class net.corda.core.crypto.MetaData
-
- getPublicKey() - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
-
- getPurposes() - Method in enum net.corda.core.crypto.CertificateType
-
- getPUSH_ACK_TOPIC() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getPUSH_TOPIC() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getQuantity() - Method in class net.corda.contracts.asset.Obligation.State
-
- getQuantity() - Method in class net.corda.core.contracts.Amount
-
- getQuantity() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- getQuantity() - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
Amount attributes
- getQuantity() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
Amount attributes
- getQuantityDelta() - Method in class net.corda.core.contracts.AmountTransfer
-
- getQuery() - Method in class net.corda.core.contracts.TransactionGraphSearch
-
- getQUERY_TOPIC() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getQuoteColumnNames() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getQuoteTableNames() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getRaw() - Method in class net.corda.core.crypto.SignedData
-
- getRawType() - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
-
- getRawUpdates() - Method in interface net.corda.core.node.services.VaultService
-
Prefer the use of updates unless you know why you want to use this instead.
- getRawUpdates() - Method in class net.corda.node.services.vault.NodeVaultService
-
Prefer the use of updates unless you know why you want to use this instead.
- getReadMethod() - Method in class net.corda.core.serialization.amqp.PropertySerializer
-
- getReapInterval() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
The interval of unused observable reaping.
- getReapInterval() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The interval of subscription reaping
- getReason() - Method in exception net.corda.core.crypto.MerkleTreeException
-
- getReceivedMessages() - Method in class net.corda.node.services.statemachine.FlowSession
-
- getReceiveType() - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- getReceiveType() - Method in interface net.corda.node.services.statemachine.ReceiveRequest
-
- getReceiveType() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- getRecipient() - Method in class net.corda.flows.AbstractCashFlow.Result
-
- getRecipient() - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- getRecipient() - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- getRecipient() - Method in class net.corda.flows.CashIssueFlow
-
- getRecipient() - Method in class net.corda.flows.CashPaymentFlow
-
- getRecipientSessionId() - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
-
- getRecipientSessionId() - Method in interface net.corda.node.services.statemachine.ExistingSessionMessage
-
- getRecipientSessionId() - Method in class net.corda.node.services.statemachine.NormalSessionEnd
-
- getRecipientSessionId() - Method in class net.corda.node.services.statemachine.SessionData
-
- getRecipientSessionId($this) - Static method in class net.corda.node.services.statemachine.SessionInitResponse.DefaultImpls
-
- getRecipientSessionId() - Method in interface net.corda.node.services.statemachine.SessionInitResponse
-
- getRecommended($this, type, contract, party) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Get a recommended node that advertises a service, and is suitable for the specified contract and parties.
Implementations might understand, for example, the correct regulator to use for specific contracts/parties,
or the appropriate oracle for a contract.
- getRecommended(type, contract, party) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Get a recommended node that advertises a service, and is suitable for the specified contract and parties.
Implementations might understand, for example, the correct regulator to use for specific contracts/parties,
or the appropriate oracle for a contract.
- getRecordedTime() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getRecordedTime() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to timestamp recorded upon entering UNCONSUMED state
- getRef() - Method in interface net.corda.contracts.DealState
-
Human readable well known reference (e.g. trade reference)
- getRef() - Method in class net.corda.core.contracts.ScheduledStateRef
-
- getRef() - Method in class net.corda.core.contracts.SourceAndAmount
-
- getRef() - Method in class net.corda.core.contracts.StateAndRef
-
- getRef() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getReference() - Method in class net.corda.core.contracts.PartyAndReference
-
- getReg() - Method in class net.corda.node.services.network.NodeRegistrationInfo
-
- getREGISTER_TOPIC() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getRegisteredNodes() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
- getRegistration(type) - Method in class net.corda.core.serialization.CordaClassResolver
-
Returns the registration for the specified class, or null if the class is not registered.
- getRegulator() - Method in class net.corda.core.node.services.ServiceType.Companion
-
- getRegulatorNodes($this) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
A list of nodes that advertise a regulatory service. Identifying the correct regulator for a trade is outside
the scope of the network map service, and this is intended solely as a sanity check on configuration stored
elsewhere.
- getRegulatorNodes() - Method in interface net.corda.core.node.services.NetworkMapCache
-
A list of nodes that advertise a regulatory service. Identifying the correct regulator for a trade is outside
the scope of the network map service, and this is intended solely as a sanity check on configuration stored
elsewhere.
- getRejectMessage() - Method in exception net.corda.node.internal.SessionRejectException
-
- getReleaseVersion() - Method in class net.corda.node.VersionInfo
-
Release version string of the node.
- getRemoved() - Method in class net.corda.client.jfx.model.Diff
-
- getRenderBasicInfoToConsole() - Method in class net.corda.node.internal.Node.Companion
-
- getReplayedList() - Method in class net.corda.client.jfx.utils.ReplayedList
-
- getReplyTo() - Method in interface net.corda.node.services.messaging.ServiceRequestMessage
-
- getReplyTo() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- getReplyTo() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
-
- getReplyTo() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
-
- getReplyTo() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- getReplyTo() - Method in class net.corda.node.services.network.NetworkMapService.Update
-
- getReplyTo() - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
-
- getRequested() - Method in exception net.corda.core.flows.FetchDataFlow.DownloadedVsRequestedDataMismatch
-
- getRequested() - Method in exception net.corda.core.flows.FetchDataFlow.DownloadedVsRequestedSizeMismatch
-
- getRequested() - Method in exception net.corda.core.flows.FetchDataFlow.HashNotFound
-
- getRequestingParty() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
-
- getRequests() - Method in class net.corda.core.flows.FetchDataFlow
-
- getRequiredCommands() - Method in class net.corda.contracts.asset.Clauses.Issue
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.asset.Clauses.Issue
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.asset.Clauses.Issue
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.asset.Clauses.SetLifecycle
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.asset.Clauses.Settle
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.clause.NetClause
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.Clauses.Issue
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.Clauses.Move
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.contracts.Clauses.Redeem
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.core.contracts.clauses.Clause
-
Determine whether this clause runs or not
- getRequiredCommands() - Method in class net.corda.core.contracts.clauses.FilterOn
-
Determine whether this clause runs or not
- getRequiredFlows() - Method in class net.corda.core.node.CordaPluginRegistry
-
Deprecated.
- getRequiredSchemas() - Method in class net.corda.core.node.CordaPluginRegistry
-
Optionally, custom schemas to be used for contract state persistence and vault custom querying
- getRequiredSchemas() - Method in class net.corda.node.services.schema.NodeSchemaService
-
- getRequiredSigners(tx) - Method in class net.corda.core.contracts.TransactionType.General
-
Return the set of public keys that require signatures for the transaction type.
Note: the notary key is checked separately for all transactions and need not be included.
- getRequiredSigners(tx) - Method in class net.corda.core.contracts.TransactionType
-
Return the set of public keys that require signatures for the transaction type.
Note: the notary key is checked separately for all transactions and need not be included.
- getRequiredSigners(tx) - Method in class net.corda.core.contracts.TransactionType.NotaryChange
-
Return the set of public keys that require signatures for the transaction type.
Note: the notary key is checked separately for all transactions and need not be included.
- getRequires() - Method in class net.corda.core.serialization.amqp.Field
-
- getRequires() - Method in class net.corda.core.serialization.amqp.PropertySerializer
-
- getResolvedType() - Method in class net.corda.core.serialization.amqp.PropertySerializer
-
- getResourceAsStream(name) - Method in class net.corda.core.serialization.AttachmentsClassLoader
-
- getResult() - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
-
- getResult() - Method in class net.corda.node.services.statemachine.Change.Removed
-
- getResultFuture() - Method in interface net.corda.core.internal.FlowStateMachine
-
- getResultFuture() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
This future will complete when the call method returns.
- getRETRY_SLEEP() - Method in class net.corda.node.services.vault.NodeVaultService
-
- getRetryable() - Method in class net.corda.node.services.statemachine.FlowSession
-
- getReturnValue() - Method in interface net.corda.core.messaging.FlowHandle
-
A ListenableFuture of the flow's return value.
- getReturnValue() - Method in class net.corda.core.messaging.FlowHandleImpl
-
A
- getReturnValue() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
-
A
- getRevision() - Method in class net.corda.node.VersionInfo
-
The exact version control commit ID of the node build.
- getRevocationEnabled() - Method in class net.corda.core.flows.TransactionKeyFlow
-
- getRevocationEnabled() - Method in class net.corda.node.services.TransactionKeyHandler
-
- getRight() - Method in class net.corda.core.crypto.MerkleTree.Node
-
- getRight() - Method in class net.corda.core.crypto.PartialTree.Node
-
- getRight() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
-
- getRightArrow() - Method in class net.corda.core.internal.Emoji
-
- getRightFromLiteral() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
-
- getRightLiteral() - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
-
- getRightLiteral() - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
-
- getRightLiteral() - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
-
- getRightLiteral() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
-
- getRightTable() - Method in class net.corda.client.jfx.utils.LeftOuterJoinedMap
-
- getRightToLiteral() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
-
- getRole() - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- getRoot() - Method in class net.corda.core.crypto.PartialMerkleTree
-
- getRootCause($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- getRootHash() - Method in class net.corda.core.transactions.FilteredTransaction
-
- getRpc() - Method in class net.corda.jackson.JacksonSupport.RpcObjectMapper
-
- getRPC_CLIENT_CONTEXT() - Method in class net.corda.core.serialization.SerializationDefaults
-
- getRPC_SERVER_CONTEXT() - Method in class net.corda.core.serialization.SerializationDefaults
-
- getRpcAddress() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getRpcConfiguration() - Method in class net.corda.client.rpc.internal.RPCClient
-
- getRpcContext() - Static method in class net.corda.node.services.messaging.RPCServerKt
-
Returns a context specific to the current RPC call. Note that trying to call this function outside of an RPC will
throw. If you'd like to use the context outside of the call (e.g. in another thread) then pass the returned reference
around explicitly.
- getRpcFlows() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getRpcOps() - Method in class net.corda.node.internal.AbstractNode
-
- getRpcPort() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- getRpcRequestId() - Method in class net.corda.node.services.messaging.ObservableContext
-
- getRpcThreadPoolSize() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
-
The number of threads to use for handling RPC requests
- getRpcUsers() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getRpcUsers() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getRSA_SHA256() - Method in class net.corda.core.crypto.Crypto
-
RSA_SHA256 signature scheme using SHA256 as hash algorithm and MGF1 (with SHA256) as mask generation function.
Note: Recommended key size >= 3072 bits.
- getRunId() - Method in class net.corda.core.flows.FlowLogic
-
Returns a wrapped
java.util.UUID object that identifies this state machine run (i.e. subflows have the same
identifier as their parents).
- getRunOnStop() - Method in class net.corda.node.internal.AbstractNode
-
- getS() - Method in class net.corda.core.crypto.testing.DummyPublicKey
-
Deprecated.
- getSantaClaus() - Method in class net.corda.core.internal.Emoji
-
- getScheduledAt() - Method in interface net.corda.core.contracts.Scheduled
-
- getScheduledAt() - Method in class net.corda.core.contracts.ScheduledActivity
-
- getScheduledAt() - Method in class net.corda.core.contracts.ScheduledStateRef
-
- getScheduledMessageRedeliveries() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getScheduledState() - Method in class net.corda.core.flows.FlowInitiator.Scheduled
-
- getSchedulerService() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getSchema() - Method in class net.corda.core.serialization.amqp.Envelope
-
- getSchema() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getSchemaForDocumentation() - Method in class net.corda.core.serialization.amqp.custom.PublicKeySerializer
-
This exists purely for documentation and cross-platform purposes. It is not used by our serialization / deserialization
code path.
- getSchemaForDocumentation() - Method in class net.corda.core.serialization.amqp.custom.X500NameSerializer
-
This exists purely for documentation and cross-platform purposes. It is not used by our serialization / deserialization
code path.
- getSchemaForDocumentation() - Method in class net.corda.core.serialization.amqp.CustomSerializer
-
This exists purely for documentation and cross-platform purposes. It is not used by our serialization / deserialization
code path.
- getSchemaForDocumentation() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
This exists purely for documentation and cross-platform purposes. It is not used by our serialization / deserialization
code path.
- getSchemaForDocumentation() - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
This exists purely for documentation and cross-platform purposes. It is not used by our serialization / deserialization
code path.
- getSchemaForDocumentation() - Method in class net.corda.core.serialization.amqp.CustomSerializer.ToString
-
This exists purely for documentation and cross-platform purposes. It is not used by our serialization / deserialization
code path.
- getSchemaOptions() - Method in interface net.corda.node.services.api.SchemaService
-
Options configured for this node's schemas. A missing entry for a schema implies all properties are null.
- getSchemaOptions() - Method in class net.corda.node.services.schema.NodeSchemaService
-
Options configured for this node's schemas. A missing entry for a schema implies all properties are null.
- getSchemas() - Method in class net.corda.core.serialization.carpenter.MetaCarpenterBase
-
- getSchemaService() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getSchemaService() - Method in class net.corda.node.services.database.HibernateConfiguration
-
- getSchemeCodeName() - Method in class net.corda.core.crypto.MetaData
-
- getSchemeCodeName() - Method in class net.corda.core.crypto.SignatureScheme
-
- getSchemeNumberID() - Method in class net.corda.core.crypto.SignatureScheme
-
- getSecond() - Method in class net.corda.core.messaging.DataFeed
-
Deprecated.
- getSeconds($receiver) - Static method in class net.corda.core.utilities.KotlinUtilsKt
-
Extension method for easier construction of Durations in terms of integer seconds: val twoSeconds = 2.seconds
.
- getSELF_SIGNED_PRIVATE_KEY() - Method in class net.corda.node.utilities.registration.NetworkRegistrationHelper.Companion
-
- getSellerOwner() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- getSender() - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
-
- getSendToParty() - Method in class net.corda.node.services.statemachine.FlowSessionState
-
- getSendToParty() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
-
- getSendToParty() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiating
-
- getSeqNo() - Method in class net.corda.node.utilities.JDBCHashedTable
-
- getSerial() - Method in class net.corda.node.services.network.NodeRegistration
-
- getSERIALIZATION_FACTORY() - Method in class net.corda.core.serialization.SerializationDefaults
-
- getSerializationContext() - Method in class net.corda.client.rpc.internal.RPCClient
-
- getSerializedFiber() - Method in class net.corda.node.services.api.Checkpoint
-
- getServer() - Method in class net.corda.node.utilities.registration.HTTPNetworkRegistrationService
-
- getServerAddress() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getServerControl() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- getServerControl() - Method in class net.corda.node.services.messaging.ObservableContext
-
- getServerProtocolVersion() - Method in class net.corda.client.rpc.CordaRPCConnection
-
The RPC protocol version reported by the server
- getServerProtocolVersion() - Method in interface net.corda.client.rpc.internal.RPCClient.RPCConnection
-
The RPC protocol version reported by the server
- getServerThread() - Method in class net.corda.node.internal.AbstractNode
-
- getServerThread() - Method in class net.corda.node.internal.Node
-
- getService(provider) - Method in class net.corda.core.crypto.composite.CompositeSignature.Companion
-
- getService() - Method in class net.corda.core.flows.NotaryFlow.Service
-
- getService() - Method in class net.corda.core.node.services.PartyInfo.Service
-
- getServiceHub() - Method in class net.corda.core.flows.FlowLogic
-
Provides access to big, heavy classes that may be reconstructed from time to time, e.g. across restarts. It is
only available once the flow has started, which means it cannnot be accessed in the constructor. Either
access this lazily or from inside
FlowLogic.call
.
- getServiceHub() - Method in interface net.corda.core.internal.FlowStateMachine
-
- getServiceHub() - Method in class net.corda.core.serialization.SerializeAsTokenContext
-
- getServiceHub() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- getServiceHub() - Method in class net.corda.node.services.statemachine.StateMachineManager
-
- getServiceHubInternal() - Method in class net.corda.node.services.vault.CashBalanceAsMetricsObserver
-
- getServicePlugins() - Method in class net.corda.core.node.CordaPluginRegistry
-
Deprecated.
- getServices() - Method in class net.corda.core.node.services.NotaryService
-
- getServices() - Method in class net.corda.node.internal.AbstractNode
-
- getServices() - Method in class net.corda.node.services.api.AbstractNodeService
-
- getServices() - Method in class net.corda.node.services.events.ScheduledActivityObserver
-
- getServices() - Method in class net.corda.node.services.transactions.BFTNonValidatingNotaryService
-
- getServices() - Method in class net.corda.node.services.transactions.RaftNonValidatingNotaryService
-
- getServices() - Method in class net.corda.node.services.transactions.RaftValidatingNotaryService
-
- getServices() - Method in class net.corda.node.services.transactions.SimpleNotaryService
-
- getServices() - Method in class net.corda.node.services.transactions.ValidatingNotaryService
-
- getServiceType(namespace, typeId) - Method in class net.corda.core.node.services.ServiceType.Companion
-
- getSession() - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
- getSession() - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- getSession() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- getSession() - Method in class net.corda.node.services.statemachine.SendOnly
-
- getSession() - Method in interface net.corda.node.services.statemachine.SessionedFlowIORequest
-
- getSession() - Method in class net.corda.node.services.vault.NodeVaultService
-
- getSessionAndProducerPool() - Method in class net.corda.node.services.messaging.ObservableContext
-
- getSessionFactories() - Method in class net.corda.node.services.database.HibernateConfiguration
-
- getSessionID() - Method in interface net.corda.node.services.messaging.ServiceRequestMessage
-
- getSessionID() - Method in class net.corda.node.services.messaging.TopicSession
-
- getSessionID() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- getSessionID() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
-
- getSessionID() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
-
- getSessionID() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- getSha256() - Method in class net.corda.core.internal.InputStreamAndHash
-
- getSHA512_256() - Method in class net.corda.core.crypto.Crypto
-
SPHINCS-256 hash-based signature scheme. It provides 128bit security against post-quantum attackers
at the cost of larger key sizes and loss of compatibility.
- getSig() - Method in class net.corda.core.crypto.SignedData
-
- getSIGNATURE_ALGORITHM() - Method in class net.corda.core.crypto.composite.CompositeSignature.Companion
-
- getSignatureData() - Method in class net.corda.core.crypto.TransactionSignature
-
- getSignatureName() - Method in class net.corda.core.crypto.SignatureScheme
-
- getSignatureOID() - Method in class net.corda.core.crypto.SignatureScheme
-
- getSignatureType() - Method in class net.corda.core.crypto.MetaData
-
- getSignedInputs() - Method in class net.corda.core.crypto.MetaData
-
- getSigner(issuerKeyPair) - Static method in class net.corda.node.services.keys.KMSUtilsKt
-
- getSigners() - Method in class net.corda.core.contracts.AuthenticatedObject
-
- getSigners() - Method in class net.corda.core.contracts.Command
-
- getSigners() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getSigningParties() - Method in class net.corda.core.contracts.AuthenticatedObject
-
If any public keys were recognised,
- getSigs() - Method in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
-
- getSigs() - Method in class net.corda.core.transactions.SignedTransaction
-
- getSingleton() - Method in class net.corda.core.serialization.amqp.SingletonSerializer
-
- getSize() - Method in class net.corda.client.jfx.utils.AggregatedList
-
- getSize() - Method in class net.corda.client.jfx.utils.ChosenList
-
- getSize() - Method in class net.corda.client.jfx.utils.ConcatenatedList
-
- getSize() - Method in class net.corda.client.jfx.utils.FlattenedList
-
- getSize() - Method in class net.corda.client.jfx.utils.MappedList
-
- getSize() - Method in class net.corda.client.jfx.utils.MapValuesList
-
- getSize() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- getSize() - Method in class net.corda.client.jfx.utils.ReplayedList
-
- getSize() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
-
- getSize($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- getSize() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
-
- getSize() - Method in class net.corda.core.utilities.ByteSequence
-
The number of bytes this sequence represents.
- getSize() - Method in class net.corda.core.utilities.NonEmptySet
-
- getSize() - Method in class net.corda.core.utilities.OpaqueBytes
-
The number of bytes this sequence represents.
- getSize() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- getSize() - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- getSkullAndCrossbones() - Method in class net.corda.core.internal.Emoji
-
- getSleepingFace() - Method in class net.corda.core.internal.Emoji
-
- getSmm() - Method in class net.corda.node.internal.AbstractNode
-
- getSnapshot() - Method in class net.corda.core.messaging.DataFeed
-
- getSnapshot() - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- getSoon() - Method in class net.corda.core.internal.Emoji
-
- getSortAttribute() - Method in class net.corda.core.node.services.vault.Sort.SortColumn
-
- getSource() - Method in class net.corda.core.contracts.AmountTransfer
-
- getSource() - Method in class net.corda.core.contracts.SourceAndAmount
-
- getSource() - Method in class net.corda.core.serialization.amqp.RestrictedType
-
- getSourceIndex(index) - Method in class net.corda.client.jfx.utils.AggregatedList
-
We cannot implement this as aggregations are one to many
- getSourceIndex(index) - Method in class net.corda.client.jfx.utils.ConcatenatedList
-
- getSourceIndex(index) - Method in class net.corda.client.jfx.utils.FlattenedList
-
- getSourceIndex(index) - Method in class net.corda.client.jfx.utils.MappedList
-
- getSourceIndex(index) - Method in class net.corda.client.jfx.utils.ReplayedList
-
- getSourceList() - Method in class net.corda.client.jfx.utils.AssociatedList
-
- getSourceList() - Method in class net.corda.client.jfx.utils.FlattenedList
-
- getSourceMap() - Method in class net.corda.client.jfx.utils.MapValuesList
-
- getSpendLock() - Method in class net.corda.node.services.vault.NodeVaultService
-
- getSPHINCS256_SHA256() - Method in class net.corda.core.crypto.Crypto
-
- getSshdServer() - Method in class net.corda.node.CmdLineOptions
-
- getStackTrace() - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer.ThrowableProxy
-
- getStackTraceInCaseOfProblems() - Method in interface net.corda.node.services.statemachine.FlowIORequest
-
- getStackTraceInCaseOfProblems() - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- getStackTraceInCaseOfProblems() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- getStackTraceInCaseOfProblems() - Method in class net.corda.node.services.statemachine.SendOnly
-
- getStackTraceInCaseOfProblems() - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
-
- getStarted() - Method in class net.corda.node.internal.AbstractNode
-
- getStartPoints() - Method in class net.corda.core.contracts.TransactionGraphSearch
-
- getStartupComplete() - Method in class net.corda.node.internal.Node
-
- getSTATE($receiver) - Static method in class net.corda.contracts.asset.CashKt
-
An extension property that lets you get a cash state from an issued token, under the NULL_PARTY
- getState() - Method in class net.corda.core.contracts.StateAndRef
-
- getState() - Method in class net.corda.node.services.statemachine.FlowSession
-
- getStateAndRef() - Method in class net.corda.client.jfx.model.InputResolution.Resolved
-
- getStateHistory() - Method in class net.corda.core.node.services.UniquenessProvider.Conflict
-
- getStateMachineId() - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
-
- getStateMachineInfo() - Method in class net.corda.core.messaging.StateMachineUpdate.Added
-
- getStateMachineRecordedTransactionMapping() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- getStateMachineRunId() - Method in class net.corda.core.messaging.StateMachineTransactionMapping
-
- getStateMachineTransactionMapping() - Method in class net.corda.client.jfx.model.NodeMonitorModel
-
- getStateMachineUpdates() - Method in class net.corda.client.jfx.model.NodeMonitorModel
-
- getStatementCacheSize() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getStatementListeners() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getStateRef() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction.InputResolution
-
- getStateRef() - Method in class net.corda.client.jfx.model.InputResolution.Resolved
-
- getStateRef() - Method in class net.corda.client.jfx.model.InputResolution.Unresolved
-
- getStateRef() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
-
- getStateRef() - Method in class net.corda.core.schemas.PersistentState
-
- getStateRefs() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- getStates() - Method in class net.corda.core.node.services.Vault
-
- getStates() - Method in class net.corda.core.node.services.Vault.Page
-
- getStatesMetadata() - Method in class net.corda.core.node.services.Vault.Page
-
- getStateStatus() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
state lifecycle
- getStateTypes() - Method in class net.corda.core.node.services.Vault.Page
-
- getStateTypes() - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- getStaticServeDirs() - Method in class net.corda.core.node.CordaPluginRegistry
-
Deprecated.
- getStatus() - Method in class net.corda.core.node.services.vault.QueryCriteria.CommonQueryCriteria
-
- getStatus() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- getStatus() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- getStatus() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
- getStatus() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- getStatus() - Method in class net.corda.core.node.services.Vault.StateMetadata
-
- getStepIndex() - Method in class net.corda.core.utilities.ProgressTracker
-
The zero-based index of the current step in the steps array (i.e. with UNSTARTED and DONE)
- getSteps() - Method in class net.corda.core.utilities.ProgressTracker
-
The steps in this tracker, same as the steps passed to the constructor but with UNSTARTED and DONE inserted.
- getSTORAGE_CONTEXT() - Method in class net.corda.core.serialization.SerializationDefaults
-
- getStorePath() - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
- getStx() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
-
- getStx() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
-
- getStx() - Method in class net.corda.flows.AbstractCashFlow.Result
-
- getSubject($receiver) - Static method in class net.corda.core.crypto.X509UtilitiesKt
-
- getSubjectProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.SubjectDelegate
-
- getSubscribe() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
-
- getSubscribe() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- getSubscribers() - Method in class net.corda.node.services.network.AbstractNetworkMapService
-
- getSubscribers() - Method in class net.corda.node.services.network.InMemoryNetworkMapService
-
- getSubscribers() - Method in class net.corda.node.services.network.PersistentNetworkMapService
-
- getSubscription() - Method in class net.corda.node.services.messaging.ObservableSubscription
-
- getSUBSCRIPTION_TOPIC() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getSubType(subTypeId) - Method in class net.corda.core.node.services.ServiceType
-
- getSum() - Method in class net.corda.contracts.clause.AbstractIssue
-
- getSumOrZero() - Method in class net.corda.contracts.clause.AbstractIssue
-
- getSuperclass() - Method in class net.corda.core.serialization.carpenter.Schema
-
- getSuperClassSerializer() - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
- getSupportedKey($receiver, alias, keyPassword) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Extract a private key from a KeyStore file assuming storage alias is known.
By default, a JKS keystore returns PrivateKey implementations supported by the SUN provider.
For instance, if one imports a BouncyCastle ECC key, JKS will return a SUN ECC key implementation on getKey.
To convert to a supported implementation, an encode->decode method is applied to the keystore's returned object.
- getSupportedSignatureSchemes() - Method in class net.corda.core.crypto.Crypto
-
Supported digital signature schemes.
Note: Only the schemes added in this map will be supported (see
class Crypto
).
- getSuppressed() - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer.ThrowableProxy
-
- getSWISS_FRANCS($receiver) - Static method in class net.corda.core.contracts.ContractsDSL
-
- getTable() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- getTable() - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- getTablePrefix() - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
-
- getTableTransformer() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getTemplate() - Method in class net.corda.contracts.asset.Obligation.State
-
- getTemplate() - Method in class net.corda.contracts.clause.BilateralNetState
-
- getTemplate() - Method in class net.corda.contracts.clause.MultilateralNetState
-
- getTemplate() - Method in interface net.corda.contracts.clause.NetState
-
- getTEST_CALENDAR_DATA() - Method in class net.corda.contracts.BusinessCalendar.Companion
-
- getThreadLocal() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- getThreshold() - Method in class net.corda.core.crypto.composite.CompositeKey
-
- getTimeCondition() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- getTimestamp() - Method in class net.corda.core.crypto.MetaData
-
- getTimestamp() - Method in class net.corda.core.flows.TransactionParts
-
- getTimestamp() - Method in class net.corda.node.services.api.AuditEvent
-
The UTC time point at which the audit event happened.
- getTimestamp() - Method in class net.corda.node.services.api.FlowAppAuditEvent
-
The UTC time point at which the audit event happened.
- getTimestamp() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
-
The UTC time point at which the audit event happened.
- getTimestamp() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
-
The UTC time point at which the audit event happened.
- getTimestamp() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
-
The UTC time point at which the audit event happened.
- getTimestamp() - Method in class net.corda.node.services.api.FlowStartEvent
-
The UTC time point at which the audit event happened.
- getTimestamp() - Method in class net.corda.node.services.api.SystemAuditEvent
-
The UTC time point at which the audit event happened.
- getTimeTolerance() - Method in class net.corda.contracts.asset.Obligation.Terms
-
- getTimeWindow() - Method in class net.corda.core.transactions.BaseTransaction
-
If specified,
- getTimeWindow() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getTimeWindow() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getTimeWindowChecker() - Method in class net.corda.core.node.services.TrustedAuthorityNotaryService
-
- getTimeWindowChecker() - Method in class net.corda.node.services.transactions.RaftNonValidatingNotaryService
-
- getTimeWindowChecker() - Method in class net.corda.node.services.transactions.RaftValidatingNotaryService
-
- getTimeWindowChecker() - Method in class net.corda.node.services.transactions.SimpleNotaryService
-
- getTimeWindowChecker() - Method in class net.corda.node.services.transactions.ValidatingNotaryService
-
- getToken() - Method in class net.corda.contracts.CommercialPaper.State
-
- getToken() - Method in class net.corda.core.contracts.Amount
-
- getToken() - Method in class net.corda.core.contracts.AmountTransfer
-
- getToKey() - Method in class net.corda.client.jfx.utils.AggregatedList
-
- getTopic() - Method in class net.corda.node.services.messaging.TopicSession
-
- getTopicSession() - Method in interface net.corda.node.services.messaging.Message
-
- getTopicSession() - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
-
- getTopLevelTracker() - Method in class net.corda.core.utilities.ProgressTracker
-
Walks up the tree to find the top level tracker. If this is the top level tracker, returns 'this'
- getTotalStatesAvailable() - Method in class net.corda.core.node.services.Vault.Page
-
- getTracker() - Method in class net.corda.core.utilities.Change.Position
-
- getTracker() - Method in class net.corda.core.utilities.Change.Rendering
-
- getTracker() - Method in class net.corda.core.utilities.Change.Structural
-
- getTrackRpcCallSites() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
-
If set to true the client will track RPC call sites.
- getTransaction() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
-
- getTransaction(id) - Method in interface net.corda.core.node.services.TransactionStorage
-
Return the transaction with the given id, or null if no such transaction exists.
- getTransaction(id) - Method in class net.corda.node.services.persistence.DBTransactionStorage
-
Return the transaction with the given id, or null if no such transaction exists.
- getTransactionBoundaries() - Method in class net.corda.node.utilities.DatabaseTransaction
-
- getTransactionBoundaries() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- getTransactionCountLimit() - Method in class net.corda.core.flows.ResolveTransactionsFlow
-
The maximum number of transactions this flow will try to download before bailing out.
- getTransactionId() - Method in class net.corda.core.messaging.StateMachineTransactionMapping
-
- getTransactionId() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- getTransactionIsolation() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getTransactionIsolation() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getTransactionListenerFactories() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getTransactionMode() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getTransactionNotes(txnId) - Method in interface net.corda.core.node.services.VaultService
-
- getTransactionNotes(txnId) - Method in class net.corda.node.services.vault.NodeVaultService
-
- getTransactions() - Method in class net.corda.client.jfx.model.NodeMonitorModel
-
- getTransactions() - Method in class net.corda.core.contracts.TransactionGraphSearch
-
- getTransactions() - Method in class net.corda.core.flows.FinalityFlow
-
- getTransactions() - Method in class net.corda.node.services.persistence.DBTransactionStorage
-
- getTransactionVerifierService() - Method in interface net.corda.core.node.ServiceHub
-
- getTransport() - Method in class net.corda.client.rpc.internal.RPCClient
-
- getTrustedAliases() - Method in class net.corda.node.services.config.CertChainPolicyConfig
-
- getTrustedAliases() - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
-
- getTrustRoot() - Method in interface net.corda.core.node.services.IdentityService
-
- getTrustRoot() - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
- getTrustRootHolder() - Method in interface net.corda.core.node.services.IdentityService
-
- getTrustRootHolder() - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
- getTrustStorePassword() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getTx() - Method in class net.corda.core.flows.BroadcastTransactionFlow.NotifyTxRequest
-
- getTx() - Method in class net.corda.core.transactions.SignedTransaction
-
Lazily calculated access to the deserialised/hashed transaction data.
- getTx() - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
-
- getTxBits() - Method in class net.corda.core.transactions.SignedTransaction
-
- getTxhash() - Method in class net.corda.core.contracts.StateRef
-
- getTxId() - Method in exception net.corda.core.contracts.TransactionVerificationException
-
- getTxId() - Method in class net.corda.core.flows.NotaryError.Conflict
-
- getTxId() - Method in class net.corda.core.schemas.PersistentStateRef
-
- getTxId() - Method in interface net.corda.core.schemas.requery.Requery.PersistentState
-
- getTxId() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Boundary
-
- getTxId() - Method in class net.corda.node.utilities.StateRefColumns
-
- getTxId() - Method in class net.corda.node.utilities.TxnNoteColumns
-
- getTxSignature() - Method in class net.corda.node.services.transactions.ReplicaResponse.Signature
-
- getTxSignatures() - Method in class net.corda.node.services.transactions.ClusterResponse.Signatures
-
- getType() - Method in class net.corda.contracts.asset.Commands.Net
-
The type of netting to apply,
- getType() - Method in interface net.corda.contracts.NetCommand
-
- getType() - Method in class net.corda.core.node.services.ServiceInfo
-
- getType() - Method in class net.corda.core.node.services.vault.ColumnPredicate.AggregateFunction
-
- getType() - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
-
- getType() - Method in class net.corda.core.serialization.amqp.AMQPPrimitiveSerializer
-
The JVM type this can serialize and deserialize.
- getType() - Method in interface net.corda.core.serialization.amqp.AMQPSerializer
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.ArraySerializer
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.CollectionSerializer
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Implements
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Is
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.Field
-
- getType() - Method in class net.corda.core.serialization.amqp.MapSerializer
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.ObjectSerializer
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.amqp.PropertySerializer
-
- getType() - Method in class net.corda.core.serialization.amqp.SingletonSerializer
-
The JVM type this can serialize and deserialize.
- getType() - Method in class net.corda.core.serialization.carpenter.Field
-
- getType() - Method in class net.corda.core.transactions.BaseTransaction
-
Pointer to a class that defines the behaviour of this transaction
- getType() - Method in class net.corda.core.transactions.FilteredLeaves
-
- getType() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getType() - Method in interface net.corda.core.transactions.TraversableTransaction
-
- getType() - Method in class net.corda.node.services.api.RegulatorService.Companion
-
- getType() - Method in class net.corda.node.services.network.NetworkMapService.Companion
-
- getType() - Method in class net.corda.node.services.network.NodeRegistration
-
- getType() - Method in class net.corda.node.services.transactions.BFTNonValidatingNotaryService.Companion
-
- getType() - Method in class net.corda.node.services.transactions.RaftNonValidatingNotaryService.Companion
-
- getType() - Method in class net.corda.node.services.transactions.RaftValidatingNotaryService.Companion
-
- getType() - Method in class net.corda.node.services.transactions.SimpleNotaryService.Companion
-
- getType() - Method in class net.corda.node.services.transactions.ValidatingNotaryService.Companion
-
- getTypeAsClass($receiver, classLoaders) - Static method in class net.corda.core.serialization.carpenter.AMQPSchemaExtensionsKt
-
- getTypeClass() - Method in class net.corda.core.serialization.amqp.Choice.Companion
-
- getTypeClass() - Method in class net.corda.core.serialization.amqp.CompositeType.Companion
-
- getTypeClass() - Method in class net.corda.core.serialization.amqp.Descriptor.Companion
-
- getTypeClass() - Method in class net.corda.core.serialization.amqp.Envelope.Companion
-
- getTypeClass() - Method in class net.corda.core.serialization.amqp.Field.Companion
-
- getTypeClass() - Method in class net.corda.core.serialization.amqp.RestrictedType.Companion
-
- getTypeClass() - Method in class net.corda.core.serialization.amqp.Schema.Companion
-
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.AMQPPrimitiveSerializer
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in interface net.corda.core.serialization.amqp.AMQPSerializer
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.ArraySerializer
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.CollectionSerializer
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Implements
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Is
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.MapSerializer
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.ObjectSerializer
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeDescriptor() - Method in class net.corda.core.serialization.amqp.SingletonSerializer
-
Textual unique representation of the JVM type this represents. Will be encoded into the AMQP stream and
will appear in the schema.
- getTypeMap() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getTypeName() - Method in class net.corda.core.serialization.amqp.DeserializedGenericArrayType
-
- getTypeName() - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
-
- getTypeName() - Method in exception net.corda.flows.TwoPartyTradeFlow.AssetMismatchException
-
- getTypes() - Method in class net.corda.core.serialization.amqp.Schema
-
- getTypeToBuy() - Method in class net.corda.flows.TwoPartyTradeFlow.Buyer
-
- getUniqueMessageId() - Method in interface net.corda.node.services.messaging.Message
-
- getUniquenessProvider() - Method in class net.corda.core.node.services.TrustedAuthorityNotaryService
-
- getUniquenessProvider() - Method in class net.corda.node.services.transactions.RaftNonValidatingNotaryService
-
- getUniquenessProvider() - Method in class net.corda.node.services.transactions.RaftValidatingNotaryService
-
- getUniquenessProvider() - Method in class net.corda.node.services.transactions.SimpleNotaryService
-
- getUniquenessProvider() - Method in class net.corda.node.services.transactions.ValidatingNotaryService
-
- getUnlimitedReconnectAttempts() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration.Companion
-
- getUntilTime() - Method in class net.corda.core.contracts.TimeWindow
-
Returns the exclusive upper-bound of this
class TimeWindow
's interval, with null implying infinity.
- getUpdates() - Method in class net.corda.core.messaging.DataFeed
-
- getUpdates() - Method in interface net.corda.core.node.services.TransactionStorage
-
Get a synchronous Observable of updates. When observations are pushed to the Observer, the vault will already
incorporate the update.
- getUpdates() - Method in interface net.corda.core.node.services.VaultService
-
Get a synchronous Observable of updates. When observations are pushed to the Observer, the Vault will already incorporate
the update, and the database transaction associated with the update will have been committed and closed.
- getUpdates() - Method in class net.corda.node.services.persistence.DBTransactionStorage
-
Get a synchronous Observable of updates. When observations are pushed to the Observer, the vault will already
incorporate the update.
- getUpdates() - Method in class net.corda.node.services.vault.NodeVaultService
-
Get a synchronous Observable of updates. When observations are pushed to the Observer, the Vault will already incorporate
the update, and the database transaction associated with the update will have been committed and closed.
- getUpdatesPublisher() - Method in interface net.corda.core.node.services.VaultService
-
Enable creation of observables of updates.
- getUpdatesPublisher() - Method in class net.corda.node.services.vault.HibernateVaultQueryImpl
-
- getUpdatesPublisher() - Method in class net.corda.node.services.vault.NodeVaultService
-
Enable creation of observables of updates.
- getUpgradedContractClass() - Method in class net.corda.core.contracts.UpgradeCommand
-
- getUploaders() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
Deprecated.
- getUpperBounds() - Method in class net.corda.core.serialization.amqp.SerializerFactory.AnyType
-
- getUseCase() - Method in interface net.corda.core.serialization.SerializationContext
-
- getUseDefaultLogging() - Method in class net.corda.node.services.database.HibernateConfiguration
-
- getUseDefaultLogging() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getUseDefaultLogging() - Method in class net.corda.node.services.database.RequeryConfiguration
-
- getUseHTTPS() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getUser(username) - Method in interface net.corda.node.services.RPCUserService
-
- getUser(username) - Method in class net.corda.node.services.RPCUserServiceImpl
-
- getUsername() - Method in class net.corda.core.flows.FlowInitiator.RPC
-
- getUserReceiveType() - Method in class net.corda.node.services.statemachine.ReceiveOnly
-
- getUserReceiveType() - Method in interface net.corda.node.services.statemachine.ReceiveRequest
-
- getUserReceiveType() - Method in class net.corda.node.services.statemachine.SendAndReceive
-
- getUsers() - Method in interface net.corda.node.services.RPCUserService
-
- getUsers() - Method in class net.corda.node.services.RPCUserServiceImpl
-
- getUserService() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- getUseTestClock() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getUuid() - Method in class net.corda.core.flows.StateMachineRunId
-
- getUuid() - Method in class net.corda.core.schemas.CommonSchemaV1.LinearState
-
- getUuid() - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
- getValidatedTransactions() - Method in interface net.corda.core.node.ServiceHub
-
A map of hash->tx where tx has been signature/contract validated and the states are known to be correct.
The signatures aren't technically needed after that point, but we keep them around so that we can relay
the transaction data to other nodes that need it.
- getValidatedTransactions() - Method in interface net.corda.node.services.api.ServiceHubInternal
-
A map of hash->tx where tx has been signature/contract validated and the states are known to be correct.
The signatures aren't technically needed after that point, but we keep them around so that we can relay
the transaction data to other nodes that need it.
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.EventSinkDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.EventStreamDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.ObjectPropertyDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableListDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableListReadOnlyDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.ObservableValueDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.ObserverDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.SubjectDelegate
-
- getValue(thisRef, property) - Method in class net.corda.client.jfx.model.TrackedDelegate.WritableValueDelegate
-
- getValue() - Method in enum net.corda.contracts.DateRollDirection
-
- getValue() - Method in class net.corda.contracts.Fix
-
- getValue(x) - Method in class net.corda.contracts.math.Polynomial
-
- getValue(x) - Method in class net.corda.contracts.math.SplineFunction
-
- getValue() - Method in class net.corda.core.contracts.AuthenticatedObject
-
- getValue() - Method in class net.corda.core.contracts.Command
-
- getValue() - Method in class net.corda.core.internal.DeclaredField
-
- getValue(thisRef, property) - Method in class net.corda.core.internal.WriteOnceProperty
-
- getValue() - Method in class net.corda.core.serialization.amqp.Choice
-
- getValue(thisRef, property) - Method in class net.corda.core.utilities.TransientProperty
-
Deprecated.
- getValue() - Method in class net.corda.core.utilities.Try.Success
-
- getValue() - Method in class net.corda.node.utilities.JDBCHashMap.BlobMapTable
-
- getValueAt($receiver, index) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
- getValues() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- getValues() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
-
- getValues() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- getVault() - Method in class net.corda.node.services.vault.VaultSoftLockManager
-
- getVaultQueryService() - Method in interface net.corda.core.node.ServiceHub
-
- getVaultService() - Method in interface net.corda.core.node.ServiceHub
-
- getVaultStates() - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- getVaultTransactionNotes(txnId) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- getVaultTransactionNotes(txnId) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
- getVaultUpdates() - Method in class net.corda.client.jfx.model.NodeMonitorModel
-
- getVendor() - Method in class net.corda.node.VersionInfo
-
The node vendor
- getVerifierService() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getVerifierType() - Method in class net.corda.node.services.config.FullNodeConfiguration
-
- getVerifierType() - Method in interface net.corda.node.services.config.NodeConfiguration
-
- getVerifyKey() - Method in class net.corda.core.crypto.composite.CompositeSignature.State
-
- getVersion() - Method in class net.corda.core.schemas.MappedSchema
-
- getVersion() - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
-
- getVersion() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
-
- getVersionID() - Method in class net.corda.core.crypto.MetaData
-
- getVersionInfo() - Method in class net.corda.node.internal.Node
-
- getVersionInfo() - Method in class net.corda.node.internal.NodeStartup
-
- getVersionInfo() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- getVisibleInputs() - Method in class net.corda.core.crypto.MetaData
-
- getWarnings() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- getWebApis() - Method in class net.corda.core.node.CordaPluginRegistry
-
Deprecated.
- getWeight() - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
-
- getWellKnown() - Method in class net.corda.core.flows.FinalityFlow.Participant
-
- getWhitelist() - Method in class net.corda.core.serialization.amqp.SerializerFactory
-
- getWhitelist() - Method in class net.corda.core.serialization.CordaClassResolver
-
- getWhitelist() - Method in class net.corda.core.serialization.GlobalTransientClassWhiteList.Companion
-
- getWhitelist() - Method in interface net.corda.core.serialization.SerializationContext
-
A whitelist that contains (mostly for security purposes) which classes can be serialized and deserialized.
- getWHITESPACE() - Static method in class net.corda.core.utilities.LegalNameValidator
-
- getWindow() - Method in class net.corda.core.transactions.TransactionBuilder
-
- getWireReg() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
-
- getWireReg() - Method in class net.corda.node.services.network.NetworkMapService.Update
-
- getWithCommandOfType() - Method in class net.corda.core.contracts.TransactionGraphSearch.Query
-
- getWithInheritance() - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
- getWorldMapLocation() - Method in class net.corda.core.node.NodeInfo
-
- getWrapperType() - Method in class net.corda.core.flows.FetchDataFlow
-
- getWritableValueProperty() - Method in class net.corda.client.jfx.model.TrackedDelegate.WritableValueDelegate
-
- getWriteExecutor() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
-
- getX509Certificate($receiver, alias) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Extract public X509 certificate from a KeyStore file assuming storage alias is known.
- getX509Certificate(alias) - Method in class net.corda.node.utilities.KeyStoreWrapper
-
- getX509Name(myLegalName, nearestCity, email, country) - Static method in class net.corda.core.crypto.X509Utilities
-
Generate a distinguished name from the provided values.
- getX509Name(myLegalName, nearestCity, email) - Static method in class net.corda.core.crypto.X509Utilities
-
Generate a distinguished name from the provided values.
- getZeroHash() - Method in class net.corda.core.crypto.SecureHash.Companion
-
- getZone() - Method in class net.corda.node.serialization.NodeClock
-
- getZone() - Method in class net.corda.node.utilities.TestClock
-
- GlobalTransientClassWhiteList - Class in net.corda.core.serialization
-
- GlobalTransientClassWhiteList(delegate) - Constructor for class net.corda.core.serialization.GlobalTransientClassWhiteList
-
- GlobalTransientClassWhiteList.Companion - Class in net.corda.core.serialization
-
- greaterThan($receiver, value) - Method in class net.corda.core.node.services.vault.Builder
-
- greaterThan($receiver, value) - Static method in class net.corda.core.node.services.vault.Builder
-
- greaterThan(value) - Method in class net.corda.core.node.services.vault.Builder
-
- greaterThanOrEqual($receiver, value) - Method in class net.corda.core.node.services.vault.Builder
-
- greaterThanOrEqual($receiver, value) - Static method in class net.corda.core.node.services.vault.Builder
-
- greaterThanOrEqual(value) - Method in class net.corda.core.node.services.vault.Builder
-
- Group() - Constructor for class net.corda.contracts.asset.Clauses.Group
-
- Group() - Constructor for class net.corda.contracts.asset.Clauses.Group
-
Grouping clause to extract input and output states into matched groups and then run a set of clauses over
each group.
- Group() - Constructor for class net.corda.contracts.asset.Clauses.Group
-
Parent clause for clauses that operate on grouped states (those which are fungible).
- Group() - Constructor for class net.corda.contracts.Clauses.Group
-
- GroupClauseVerifier<S extends ContractState,C extends CommandData,K> - Class in net.corda.core.contracts.clauses
-
- GroupClauseVerifier(clause) - Constructor for class net.corda.core.contracts.clauses.GroupClauseVerifier
-
- groupStates(tx) - Method in class net.corda.contracts.asset.Clauses.Group
-
- groupStates(tx) - Method in class net.corda.contracts.asset.Clauses.Group
-
Group commodity states by issuance definition (issuer and underlying commodity).
- groupStates(tx) - Method in class net.corda.contracts.asset.Clauses.Group
-
- groupStates(tx) - Method in class net.corda.contracts.Clauses.Group
-
- groupStates(tx) - Method in class net.corda.core.contracts.clauses.GroupClauseVerifier
-
- groupStates(ofType, selector) - Method in class net.corda.core.transactions.LedgerTransaction
-
Given a type and a function that returns a grouping key, associates inputs and outputs together so that they
can be processed as one. The grouping key is any arbitrary object that can act as a map key (so must implement
equals and hashCode).
- IdentityObjectMapper(identityService, factory, fuzzyIdentityMatch) - Constructor for class net.corda.jackson.JacksonSupport.IdentityObjectMapper
-
- IdentityService - Interface in net.corda.core.node.services
-
An identity service maintains a directory of parties by their associated distinguished name/public keys and thus
supports lookup of a party given its key, or name. The service also manages the certificates linking confidential
identities back to the well known identity (i.e. the identity in the network map) of a party.
- IdentityService.DefaultImpls - Class in net.corda.core.node.services
-
An identity service maintains a directory of parties by their associated distinguished name/public keys and thus
supports lookup of a party given its key, or name. The service also manages the certificates linking confidential
identities back to the well known identity (i.e. the identity in the network map) of a party.
- IdentityService.UnknownAnonymousPartyException - Exception in net.corda.core.node.services
-
- IllegalFlowLogicException - Exception in net.corda.core.flows
-
- IllegalFlowLogicException(type, msg) - Constructor for exception net.corda.core.flows.IllegalFlowLogicException
-
- ImmutableClassSerializer<T> - Class in net.corda.core.serialization
-
Serializes properties and deserializes by using the constructor. This assumes that all backed properties are
set via the constructor and the class is immutable.
- ImmutableClassSerializer(klass) - Constructor for class net.corda.core.serialization.ImmutableClassSerializer
-
Serializes properties and deserializes by using the constructor. This assumes that all backed properties are
set via the constructor and the class is immutable.
- Implements(clazz) - Constructor for class net.corda.core.serialization.amqp.CustomSerializer.Implements
-
Additional base features for a custom serializer for all implementations of a particular interface or super class.
- importAttachment(jar) - Method in interface net.corda.core.node.services.AttachmentStorage
-
Inserts the given attachment into the store, does not close the input stream. This can be an intensive
operation due to the need to copy the bytes to disk and hash them along the way.
- importAttachment(jar) - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
Inserts the given attachment into the store, does not close the input stream. This can be an intensive
operation due to the need to copy the bytes to disk and hash them along the way.
- impure(valueClosure) - Method in class net.corda.client.mock.Generator.Companion
-
- in($receiver, collection) - Method in class net.corda.core.node.services.vault.Builder
-
- in($receiver, collection) - Static method in class net.corda.core.node.services.vault.Builder
-
- in(collection) - Method in class net.corda.core.node.services.vault.Builder
-
- IncludedLeaf(hash) - Constructor for class net.corda.core.crypto.PartialTree.IncludedLeaf
-
- indexOf(element) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- indexOfOrThrow($receiver, item) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- info - Variable in class net.corda.node.internal.AbstractNode
-
- initialiseDatabasePersistence(insideTransaction) - Method in class net.corda.node.internal.AbstractNode
-
- initialiseDatabasePersistence(insideTransaction) - Method in class net.corda.node.internal.Node
-
If the node is persisting to an embedded H2 database, then expose this via TCP with a JDBC URL of the form:
jdbc:h2:tcp://:/node
with username and password as per the DataSource connection details. The key element to enabling this support is to
ensure that you specify a JDBC connection URL of the form jdbc:h2:file: in the node config and that you include
the H2 option AUTO_SERVER_PORT set to the port you desire to use (0 will give a dynamically allocated port number)
but exclude the H2 option AUTO_SERVER=TRUE.
This is not using the H2 "automatic mixed mode" directly but leans on many of the underpinnings. For more details
on H2 URLs and configuration see: http://www.h2database.com/html/features.html#database_url
- initialiseSerialization() - Method in class net.corda.client.rpc.CordaRPCClient.Companion
-
- initialize(subject, callbackHandler, sharedState, options) - Method in class net.corda.node.services.messaging.NodeLoginModule
-
- Initiated(peerParty, peerSessionId) - Constructor for class net.corda.node.services.statemachine.FlowSessionState.Initiated
-
- InitiatedBy - Interface in net.corda.core.flows
-
This annotation is required by any
class FlowLogic
that is designed to be initiated by a counterparty flow. The class must
have at least a constructor which takes in a single
class Party
parameter which represents the
initiating counterparty. The
class FlowLogic
that does the initiating is specified by the value property and itself must be annotated
with
interface InitiatingFlow
.
- InitiatedFlowFactory<F extends FlowLogic<?>> - Interface in net.corda.node.internal
-
- InitiatedFlowFactory.CorDapp<F extends FlowLogic<?>> - Class in net.corda.node.internal
-
- InitiatedFlowFactory.Core<F extends FlowLogic<?>> - Class in net.corda.node.internal
-
- Initiating(otherParty) - Constructor for class net.corda.node.services.statemachine.FlowSessionState.Initiating
-
otherParty may be a specific peer or a service party
- InitiatingFlow - Interface in net.corda.core.flows
-
This annotation is required by any
class FlowLogic
which has been designated to initiate communication with a counterparty
and request they start their side of the flow communication.
- initLogging(cmdlineOptions) - Method in class net.corda.node.internal.NodeStartup
-
- initModel(klass) - Method in class net.corda.client.jfx.model.Models
-
- InMemoryIdentityService - Class in net.corda.node.services.identity
-
Simple identity service which caches parties and provides functionality for efficient lookup.
- InMemoryIdentityService(identities, certPaths, trustRoot, caCertificates) - Constructor for class net.corda.node.services.identity.InMemoryIdentityService
-
Simple identity service which caches parties and provides functionality for efficient lookup.
- InMemoryIdentityService(identities, certPaths, trustRoot) - Constructor for class net.corda.node.services.identity.InMemoryIdentityService
-
- InMemoryIdentityService.Companion - Class in net.corda.node.services.identity
-
- InMemoryNetworkMapCache - Class in net.corda.node.services.network
-
Extremely simple in-memory cache of the network map.
- InMemoryNetworkMapCache(serviceHub) - Constructor for class net.corda.node.services.network.InMemoryNetworkMapCache
-
Extremely simple in-memory cache of the network map.
- InMemoryNetworkMapCache.Companion - Class in net.corda.node.services.network
-
- InMemoryNetworkMapService - Class in net.corda.node.services.network
-
- InMemoryNetworkMapService(services, minimumPlatformVersion) - Constructor for class net.corda.node.services.network.InMemoryNetworkMapService
-
- InMemoryStateMachineRecordedTransactionMappingStorage - Class in net.corda.node.services.persistence
-
This is a temporary in-memory storage of a state machine id -> txhash mapping
- InMemoryStateMachineRecordedTransactionMappingStorage() - Constructor for class net.corda.node.services.persistence.InMemoryStateMachineRecordedTransactionMappingStorage
-
This is a temporary in-memory storage of a state machine id -> txhash mapping
- InMemoryTransactionVerifierService - Class in net.corda.node.services.transactions
-
- InMemoryTransactionVerifierService(numberOfWorkers) - Constructor for class net.corda.node.services.transactions.InMemoryTransactionVerifierService
-
- InOutGroup(inputs, outputs, groupingKey) - Constructor for class net.corda.core.transactions.LedgerTransaction.InOutGroup
-
A set of related inputs and outputs that are connected by some common attributes. An InOutGroup is calculated
using groupStates and is useful for handling cases where a transaction may contain similar but unrelated
state evolutions, for example, a transaction that moves cash in two different currencies. The numbers must add
up on both sides of the transaction, but the values must be summed independently per currency. Grouping can
be used to simplify this logic.
- InputResolution.Resolved - Class in net.corda.client.jfx.model
-
- InputResolution.Unresolved - Class in net.corda.client.jfx.model
-
- inputsOfType(clazz) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify getting all inputs states of a particular class, interface, or base class.
- inputStates() - Method in class net.corda.core.transactions.TransactionBuilder
-
- InputStreamAndHash - Class in net.corda.core.internal
-
- InputStreamAndHash(inputStream, sha256) - Constructor for class net.corda.core.internal.InputStreamAndHash
-
- InputStreamAndHash.Companion - Class in net.corda.core.internal
-
- InputStreamSerializer - Class in net.corda.core.serialization
-
- inRef(index) - Method in class net.corda.core.transactions.LedgerTransaction
-
Returns the typed input StateAndRef at the specified index
- inRefsOfType(clazz) - Method in class net.corda.core.transactions.LedgerTransaction
-
Helper to simplify getting all inputs states of a particular class, interface, or base class.
- install(reader) - Method in class net.corda.node.services.transactions.DistributedImmutableMap
-
Reads entries from disk and adds them to map.
- installCordaService(serviceClass) - Method in class net.corda.node.internal.AbstractNode
-
Use this method to install your Corda services in your tests. This is automatically done by the node when it
starts up for all classes it finds which are annotated with
interface CordaService
.
- installSnapshot(bytes) - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- INSTANCE - Static variable in class net.corda.client.jfx.model.Models
-
- INSTANCE - Static variable in class net.corda.client.jfx.utils.AmountBindings
-
Utility bindings for the
class Amount
type, similar in spirit to Bindings
- INSTANCE - Static variable in class net.corda.client.rpc.internal.RpcClientObservableSerializer
-
A Serializer to deserialise Observables once the corresponding Kryo instance has been provided with an
class ObservableContext
.
- INSTANCE - Static variable in class net.corda.contracts.ExpressionDeserializer
-
- INSTANCE - Static variable in class net.corda.contracts.ExpressionSerializer
-
- INSTANCE - Static variable in class net.corda.core.contracts.Requirements
-
- INSTANCE - Static variable in class net.corda.core.contracts.TransactionType.General
-
A general transaction type where transaction validity is determined by custom contract code
- INSTANCE - Static variable in class net.corda.core.contracts.TransactionType.NotaryChange
-
A special transaction type for reassigning a notary for a state. Validation does not involve running
any contract code, it just checks that the states are unmodified apart from the notary field.
- INSTANCE - Static variable in class net.corda.core.crypto.ContentSignerBuilder
-
Provide extra OID look up for signature algorithm not supported by bouncy castle.
This builder will use bouncy castle's JcaContentSignerBuilder as fallback for unknown algorithm.
- INSTANCE - Static variable in class net.corda.core.crypto.Crypto
-
This object controls and provides the available and supported signature schemes for Corda.
Any implemented
class SignatureScheme
should be strictly defined here.
However, only the schemes returned by {@link #listSupportedSignatureSchemes()} are supported.
Note that Corda currently supports the following signature schemes by their code names:
- INSTANCE - Static variable in class net.corda.core.crypto.provider.CordaObjectIdentifier
-
- INSTANCE - Static variable in class net.corda.core.crypto.testing.NullPublicKey
-
- INSTANCE - Static variable in class net.corda.core.crypto.testing.NullSignature
-
A signature with a key and value of zero. Useful when you want a signature object that you know won't ever be used.
- INSTANCE - Static variable in class net.corda.core.crypto.X509Utilities
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.APPROVING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.VERIFYING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.NOTARY
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.SIGNING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.COLLECTING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.VERIFYING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.BROADCASTING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.NOTARISING
-
- INSTANCE - Static variable in class net.corda.core.flows.FlowInitiator.Shell
-
- INSTANCE - Static variable in class net.corda.core.flows.NotaryError.TimeWindowInvalid
-
Thrown if the time specified in the
class TimeWindow
command is outside the allowed tolerance.
- INSTANCE - Static variable in class net.corda.core.flows.Companion.REQUESTING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.VALIDATING
-
- INSTANCE - Static variable in class net.corda.core.flows.NotaryFlow
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.RECEIVING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.SIGNING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.VERIFYING
-
- INSTANCE - Static variable in class net.corda.core.flows.Companion.AWAITING_KEY
-
- INSTANCE - Static variable in class net.corda.core.internal.Emoji
-
A simple wrapper class that contains icons and support for printing them only when we're connected to a terminal.
- INSTANCE - Static variable in class net.corda.core.node.CityDatabase
-
A simple lookup table of city names to their coordinates. Lookups are case insensitive.
- INSTANCE - Static variable in class net.corda.core.node.services.vault.Builder
-
- INSTANCE - Static variable in class net.corda.core.schemas.CommonSchema
-
JPA representation of the common schema entities
- INSTANCE - Static variable in class net.corda.core.schemas.CommonSchemaV1
-
First version of the Vault ORM schema
- INSTANCE - Static variable in class net.corda.core.schemas.requery.Requery
-
- INSTANCE - Static variable in class net.corda.core.serialization.AllButBlacklisted
-
This is a
interface ClassWhitelist
implementation where everything is whitelisted except for blacklisted classes and interfaces.
In practice, as flows are arbitrary code in which it is convenient to do many things,
we can often end up pulling in a lot of objects that do not make sense to put in a checkpoint.
Thus, by blacklisting classes/interfaces we don't expect to be serialised, we can better handle/monitor the aforementioned behaviour.
Inheritance works for blacklisted items, but one can specifically exclude classes from blacklisting as well.
- INSTANCE - Static variable in class net.corda.core.serialization.AllWhitelist
-
- INSTANCE - Static variable in class net.corda.core.serialization.amqp.custom.BigDecimalSerializer
-
A serializer for
BigDecimal, utilising the string based helper.
BigDecimal seems to have no import/export
features that are precision independent other than via a string. The format of the string is discussed in the
documentation for
BigDecimal.toString.
- INSTANCE - Static variable in class net.corda.core.serialization.amqp.custom.CurrencySerializer
-
A custom serializer for the
Currency class, utilizing the currency code string representation.
- INSTANCE - Static variable in class net.corda.core.serialization.amqp.custom.PublicKeySerializer
-
A serializer that writes out a public key in X.509 format.
- INSTANCE - Static variable in class net.corda.core.serialization.amqp.custom.X500NameSerializer
-
Custom serializer for X500 names that utilizes their ASN.1 encoding on the wire.
- INSTANCE - Static variable in class net.corda.core.serialization.amqp.SerializerFactory.AnyType
-
- INSTANCE - Static variable in class net.corda.core.serialization.carpenter.CarpenterSchemaFactory
-
- INSTANCE - Static variable in class net.corda.core.serialization.carpenter.FieldFactory
-
- INSTANCE - Static variable in class net.corda.core.serialization.CertPathSerializer
-
For serialising an
CertPath in an X.500 standard format.
- INSTANCE - Static variable in class net.corda.core.serialization.ClassSerializer
-
- INSTANCE - Static variable in class net.corda.core.serialization.CompositeKeySerializer
-
- INSTANCE - Static variable in class net.corda.core.serialization.DefaultKryoCustomizer
-
- INSTANCE - Static variable in class net.corda.core.serialization.ECPublicKeyImplSerializer
-
For serialising an ed25519 public key
- INSTANCE - Static variable in class net.corda.core.serialization.Ed25519PrivateKeySerializer
-
For serialising an ed25519 private key
- INSTANCE - Static variable in class net.corda.core.serialization.Ed25519PublicKeySerializer
-
For serialising an ed25519 public key
- INSTANCE - Static variable in class net.corda.core.serialization.EmptyWhitelist
-
- INSTANCE - Static variable in class net.corda.core.serialization.InputStreamSerializer
-
- INSTANCE - Static variable in class net.corda.core.serialization.KryoAMQPSerializer
-
This Kryo custom Serializer switches the object graph of anything annotated with @CordaSerializable
to using the AMQP serialization wire format, and simply writes that out as bytes to the wire.
- INSTANCE - Static variable in class net.corda.core.serialization.LoggerSerializer
-
For serialising a Logger.
- INSTANCE - Static variable in class net.corda.core.serialization.MetaDataSerializer
-
For serialising a MetaData object.
- INSTANCE - Static variable in class net.corda.core.serialization.PrivateKeySerializer
-
- INSTANCE - Static variable in class net.corda.core.serialization.PublicKeySerializer
-
For serialising a public key
- INSTANCE - Static variable in class net.corda.core.serialization.SerializationDefaults
-
Global singletons to be used as defaults that are injected elsewhere (generally, in the node or in RPC client).
- INSTANCE - Static variable in class net.corda.core.serialization.SerializedBytesSerializer
-
A serialiser that avoids writing the wrapper class to the byte stream, thus ensuring
class SerializedBytes
is a pure
type safety hack.
- INSTANCE - Static variable in class net.corda.core.serialization.SignedTransactionSerializer
-
- INSTANCE - Static variable in class net.corda.core.serialization.WireTransactionSerializer
-
A serialisation engine that knows how to deserialise code inside a sandbox
- INSTANCE - Static variable in class net.corda.core.serialization.X500NameSerializer
-
For serialising an X500Name without touching Sun internal classes.
- INSTANCE - Static variable in class net.corda.core.serialization.X509CertificateSerializer
-
For serialising an X509CertificateHolder in an X.500 standard format.
- INSTANCE - Static variable in class net.corda.core.utilities.ProgressTracker.DONE
-
- INSTANCE - Static variable in class net.corda.core.utilities.ProgressTracker.UNSTARTED
-
- INSTANCE - Static variable in class net.corda.flows.Companion.FINALISING_TX
-
- INSTANCE - Static variable in class net.corda.flows.Companion.GENERATING_ID
-
- INSTANCE - Static variable in class net.corda.flows.Companion.GENERATING_TX
-
- INSTANCE - Static variable in class net.corda.flows.Companion.SIGNING_TX
-
- INSTANCE - Static variable in class net.corda.flows.IssuerFlow
-
- INSTANCE - Static variable in class net.corda.flows.Companion.AWAITING_REQUEST
-
- INSTANCE - Static variable in class net.corda.flows.Companion.ISSUING
-
- INSTANCE - Static variable in class net.corda.flows.Companion.SENDING_CONFIRM
-
- INSTANCE - Static variable in class net.corda.flows.Companion.TRANSFERRING
-
- INSTANCE - Static variable in class net.corda.flows.TwoPartyDealFlow
-
Classes for manipulating a two party deal or agreement.
- INSTANCE - Static variable in class net.corda.flows.Companion.SENDING_PROPOSAL
-
- INSTANCE - Static variable in class net.corda.flows.Companion.COLLECTING_SIGNATURES
-
- INSTANCE - Static variable in class net.corda.flows.Companion.COPYING_TO_COUNTERPARTY
-
- INSTANCE - Static variable in class net.corda.flows.Companion.COPYING_TO_REGULATOR
-
- INSTANCE - Static variable in class net.corda.flows.Companion.RECEIVING
-
- INSTANCE - Static variable in class net.corda.flows.Companion.RECORDING
-
- INSTANCE - Static variable in class net.corda.flows.Companion.SIGNING
-
- INSTANCE - Static variable in class net.corda.flows.Companion.VERIFYING
-
- INSTANCE - Static variable in class net.corda.flows.Buyer.COLLECTING_SIGNATURES
-
- INSTANCE - Static variable in class net.corda.flows.Buyer.RECEIVING
-
- INSTANCE - Static variable in class net.corda.flows.Buyer.RECORDING
-
- INSTANCE - Static variable in class net.corda.flows.Buyer.SIGNING
-
- INSTANCE - Static variable in class net.corda.flows.Buyer.VERIFYING
-
- INSTANCE - Static variable in class net.corda.flows.TwoPartyTradeFlow
-
This asset trading flow implements a "delivery vs payment" type swap. It has two parties (B and S for buyer
and seller) and the following steps:
- INSTANCE - Static variable in class net.corda.flows.Companion.AWAITING_PROPOSAL
-
- INSTANCE - Static variable in class net.corda.flows.Companion.VERIFYING_AND_SIGNING
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.AmountDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.AmountSerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.AnonymousPartyDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.AnonymousPartySerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.CalendarDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.CalendarSerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.CompositeKeyDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.CompositeKeySerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport
-
Utilities and serialisers for working with JSON representations of basic types. This adds Jackson support for
the java.time API, some core types, and Kotlin data classes.
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.NodeInfoDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.NodeInfoSerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.OpaqueBytesDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.OpaqueBytesSerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.PartyDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.PartySerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.PublicKeyDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.PublicKeySerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.SecureHashSerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.ToStringSerializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.X500NameDeserializer
-
- INSTANCE - Static variable in class net.corda.jackson.JacksonSupport.X500NameSerializer
-
- INSTANCE - Static variable in class net.corda.node.services.config.ConfigHelper
-
- INSTANCE - Static variable in class net.corda.node.services.messaging.CertificateChainCheckPolicy.Any
-
- INSTANCE - Static variable in class net.corda.node.services.messaging.CertificateChainCheckPolicy.LeafMustMatch
-
- INSTANCE - Static variable in class net.corda.node.services.messaging.CertificateChainCheckPolicy.RootMustMatch
-
- INSTANCE - Static variable in class net.corda.node.services.messaging.RpcServerObservableSerializer
-
- INSTANCE - Static variable in class net.corda.node.services.messaging.TopicStringValidator
-
A singleton that's useful for validating topic strings
- INSTANCE - Static variable in class net.corda.node.services.statemachine.FlowLogicRefFactoryImpl
-
- INSTANCE - Static variable in class net.corda.node.services.Companion.SENDING_KEY
-
- INSTANCE - Static variable in class net.corda.node.services.transactions.BFTSMaRt
-
- INSTANCE - Static variable in class net.corda.node.services.transactions.DistributedImmutableMap.Commands
-
- INSTANCE - Static variable in class net.corda.node.services.vault.VaultSchema
-
JPA representation of the core Vault Schema
- INSTANCE - Static variable in class net.corda.node.services.vault.VaultSchemaV1
-
First version of the Vault ORM schema
- INSTANCE - Static variable in class net.corda.node.shell.InteractiveShell.InputStreamDeserializer
-
- INSTANCE - Static variable in class net.corda.node.shell.InteractiveShell
-
- INSTANCE - Static variable in class net.corda.node.utilities.AddressUtils
-
- INSTANCE - Static variable in class net.corda.node.utilities.ANSIProgressRenderer
-
Knows how to render a
class ProgressTracker
to the terminal using coloured, emoji-fied output. Useful when writing small
command line tools, demos, tests etc. Just set the progressTracker field and it will go ahead and start drawing
if the terminal supports it. Otherwise it just prints out the name of the step whenever it changes.
- INSTANCE - Static variable in class net.corda.node.utilities.CertPathColumnType
-
ColumnType for marshalling to/from database on behalf of
CertPath.
- INSTANCE - Static variable in class net.corda.node.utilities.InstantColumnType
-
ColumnType for marshalling to/from database on behalf of java.time.Instant.
- INSTANCE - Static variable in class net.corda.node.utilities.LocalDateColumnType
-
ColumnType for marshalling to/from database on behalf of java.time.LocalDate.
- INSTANCE - Static variable in class net.corda.node.utilities.LocalDateTimeColumnType
-
ColumnType for marshalling to/from database on behalf of java.time.LocalDateTime.
- INSTANCE - Static variable in class net.corda.node.utilities.PublicKeyColumnType
-
ColumnType for marshalling to/from database on behalf of
PublicKey.
- INSTANCE - Static variable in class net.corda.node.utilities.SecureHashColumnType
-
- INSTANCE - Static variable in class net.corda.node.utilities.ServiceIdentityGenerator
-
- INSTANCE - Static variable in class net.corda.node.utilities.UUIDStringColumnType
-
ColumnType for marshalling to/from database on behalf of
UUID, always using a string representation.
- INSTANCE - Static variable in class net.corda.node.utilities.X509CertificateColumnType
-
ColumnType for marshalling to/from database on behalf of X509CertificateHolder.
- INSTANCE - Static variable in class net.corda.schemas.CashSchema
-
An object used to fully qualify the
class CashSchema
family name (i.e. independent of version).
- INSTANCE - Static variable in class net.corda.schemas.CashSchemaV1
-
First version of a cash contract ORM schema that maps all fields of the
Cash contract state as it stood
at the time of writing.
- INSTANCE - Static variable in class net.corda.schemas.CommercialPaperSchema
-
- INSTANCE - Static variable in class net.corda.schemas.CommercialPaperSchemaV1
-
First version of a commercial paper contract ORM schema that maps all fields of the
CommercialPaper contract state
as it stood at the time of writing.
- instant() - Method in class net.corda.node.serialization.NodeClock
-
- instant($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
-
- instant() - Method in class net.corda.node.utilities.TestClock
-
- InstantColumnType - Class in net.corda.node.utilities
-
ColumnType for marshalling to/from database on behalf of java.time.Instant.
- InstantConverter - Class in net.corda.core.schemas.requery.converters
-
Converts from a Instant to a
java.sql.Timestamp for Java 8. Note that
when converting between the time type and the database type all times will be converted to the
UTC zone offset.
- InstantConverter() - Constructor for class net.corda.core.schemas.requery.converters.InstantConverter
-
Converts from a Instant to a
java.sql.Timestamp for Java 8. Note that
when converting between the time type and the database type all times will be converted to the
UTC zone offset.
- InstantProxy(epochSeconds, nanos) - Constructor for class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
-
- InstantSerializer - Class in net.corda.core.serialization.amqp.custom
-
A serializer for Instant that uses a proxy object to write out the seconds since the epoch and the nanos.
- InstantSerializer(factory) - Constructor for class net.corda.core.serialization.amqp.custom.InstantSerializer
-
A serializer for Instant that uses a proxy object to write out the seconds since the epoch and the nanos.
- InstantSerializer.InstantProxy - Class in net.corda.core.serialization.amqp.custom
-
- Instigator(originalState, modification, progressTracker) - Constructor for class net.corda.core.flows.AbstractStateReplacementFlow.Instigator
-
- Instigator(otherParty, payload, myKey, progressTracker) - Constructor for class net.corda.flows.TwoPartyDealFlow.Instigator
-
One side of the flow for inserting a pre-agreed deal.
- Instigator.Companion - Class in net.corda.core.flows
-
- InsufficientBalanceException - Exception in net.corda.core.contracts
-
- InsufficientBalanceException(amountMissing) - Constructor for exception net.corda.core.contracts.InsufficientBalanceException
-
- int($receiver) - Static method in class net.corda.client.mock.GeneratorKt
-
- InteractiveShell - Class in net.corda.node.shell
-
- InteractiveShell.InputStreamDeserializer - Class in net.corda.node.shell
-
- InteractiveShell.NoApplicableConstructor - Exception in net.corda.node.shell
-
- InteractiveShell.ShellLifecycle - Class in net.corda.node.shell
-
- InteractiveShellCommand - Class in net.corda.node.shell
-
Simply extends CRaSH BaseCommand to add easy access to the RPC ops class.
- InteractiveShellCommand() - Constructor for class net.corda.node.shell.InteractiveShellCommand
-
Simply extends CRaSH BaseCommand to add easy access to the RPC ops class.
- InterfaceMismatchException - Exception in net.corda.core.serialization.carpenter
-
- InterfaceMismatchException(msg) - Constructor for exception net.corda.core.serialization.carpenter.InterfaceMismatchException
-
- InterfaceSchema - Class in net.corda.core.serialization.carpenter
-
- InterfaceSchema(name, fields, superclass, interfaces) - Constructor for class net.corda.core.serialization.carpenter.InterfaceSchema
-
- internalRegisterFlowFactory(initiatingFlowClass, flowFactory, initiatedFlowClass, track) - Method in class net.corda.node.internal.AbstractNode
-
- InternalUtilsKt - Class in net.corda.core.internal
-
- interpolate(x) - Method in class net.corda.contracts.math.CubicSplineInterpolator
-
- interpolate(x) - Method in interface net.corda.contracts.math.Interpolator
-
- interpolate(x) - Method in class net.corda.contracts.math.LinearInterpolator
-
- Interpolator - Interface in net.corda.contracts.math
-
- InterpolatorFactory - Interface in net.corda.contracts.math
-
- intRange($receiver, range) - Static method in class net.corda.client.mock.GeneratorKt
-
- intRange($receiver, from, to) - Static method in class net.corda.client.mock.GeneratorKt
-
- InvalidNotaryChange(txId) - Constructor for exception net.corda.core.contracts.TransactionVerificationException.InvalidNotaryChange
-
- InvalidSignature() - Constructor for exception net.corda.node.services.network.NodeMapError.InvalidSignature
-
Thrown if the signature on the node info does not match the public key for the identity
- InvalidSubscriber() - Constructor for exception net.corda.node.services.network.NodeMapError.InvalidSubscriber
-
Thrown if the replyTo of a subscription change message is not a single message recipient
- invoke(proxy, method, arguments) - Method in class net.corda.client.rpc.internal.RPCClientProxyHandler
-
- invoke() - Method in class net.corda.jackson.StringToMethodCallParser.ParsedMethodCall
-
- invokeFlowAsync($this, logicType, flowInitiator, args) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
Will check logicType and args against a whitelist and if acceptable then construct and initiate the flow.
Note that you must be on the server thread to call this method. flowInitiator points how flow was started,
See:
class FlowInitiator
.
- invokeFlowAsync(logicType, flowInitiator, args) - Method in interface net.corda.node.services.api.ServiceHubInternal
-
Will check logicType and args against a whitelist and if acceptable then construct and initiate the flow.
Note that you must be on the server thread to call this method. flowInitiator points how flow was started,
See:
class FlowInitiator
.
- IQueryCriteriaParser - Interface in net.corda.core.node.services.vault
-
- Is(clazz) - Constructor for class net.corda.core.serialization.amqp.CustomSerializer.Is
-
Additional base features for a custom serializer for a particular class, that excludes subclasses.
- isBlank() - Method in class net.corda.node.services.messaging.TopicSession
-
- isCA() - Method in enum net.corda.core.crypto.CertificateType
-
- isClosed() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- isDefault() - Method in class net.corda.core.node.services.vault.PageSpecification
-
- isDirectory($receiver, options) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- isEmpty() - Method in class net.corda.client.jfx.utils.MapValuesList
-
- isEmpty() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- isEmpty() - Method in class net.corda.core.utilities.NonEmptySet
-
- isEmpty() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- isEmpty() - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- isFailure() - Method in class net.corda.core.utilities.Try.Failure
-
- isFailure() - Method in class net.corda.core.utilities.Try
-
- isFailure() - Method in class net.corda.core.utilities.Try.Success
-
- isFulfilledBy(key) - Method in class net.corda.core.crypto.composite.CompositeKey
-
Takes single PublicKey and checks if CompositeKey requirements hold for that key.
- isFulfilledBy(keysToCheck) - Method in class net.corda.core.crypto.composite.CompositeKey
-
Function checks if the public keys corresponding to the signatures are matched against the leaves of the composite
key tree in question, and the total combined weight of all children is calculated for every intermediary node.
If all thresholds are satisfied, the composite key requirement is considered to be met.
- isFulfilledBy($receiver, otherKey) - Static method in class net.corda.core.crypto.CryptoUtils
-
- isFulfilledBy($receiver, otherKeys) - Static method in class net.corda.core.crypto.CryptoUtils
-
- isFullyWildcarded() - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
-
- isModified() - Method in enum net.corda.contracts.DateRollConvention
-
- isNetworkMap() - Method in class net.corda.core.node.services.ServiceType
-
- isNotary($this, party) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Checks whether a given party is an advertised notary identity
- isNotary(party) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Checks whether a given party is an advertised notary identity
- isNotary() - Method in class net.corda.core.node.services.ServiceType
-
- isNotNull($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
- isNull($receiver) - Method in class net.corda.core.node.services.vault.Builder
-
- isNull($receiver) - Static method in class net.corda.core.node.services.vault.Builder
-
- isolatedTransaction(block) - Method in class net.corda.node.utilities.CordaPersistence
-
- isOnThread() - Method in class net.corda.node.utilities.AffinityExecutor.Gate
-
Returns true if the current thread is equal to the thread this executor is backed by.
- isOnThread() - Method in interface net.corda.node.utilities.AffinityExecutor
-
Returns true if the current thread is equal to the thread this executor is backed by.
- isOnThread() - Method in class net.corda.node.utilities.AffinityExecutor.ServiceAffinityExecutor
-
Returns true if the current thread is equal to the thread this executor is backed by.
- isPreviousCheckpointsPresent() - Method in class net.corda.node.internal.AbstractNode
-
- isPrimitive(type) - Method in class net.corda.core.serialization.amqp.SerializerFactory.Companion
-
- isPublic(address) - Method in class net.corda.node.utilities.AddressUtils
-
Returns true
if the provided address
is a public IP address or hostname.
- isPublic(hostText) - Method in class net.corda.node.utilities.AddressUtils
-
- isReadOnly() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- isRegistration() - Method in class net.corda.node.CmdLineOptions
-
- isRegularFile($receiver, options) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- isRelevant(ourKeys) - Method in interface net.corda.core.contracts.LinearState
-
True if this should be tracked by our vault(s).
- isSerializerFor(clazz) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Implements
-
This method should return true if the custom serializer can serialize an instance of the class passed as the
parameter.
- isSerializerFor(clazz) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Is
-
This method should return true if the custom serializer can serialize an instance of the class passed as the
parameter.
- isSerializerFor(clazz) - Method in class net.corda.core.serialization.amqp.CustomSerializer
-
This method should return true if the custom serializer can serialize an instance of the class passed as the
parameter.
- isSerializerFor(clazz) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
-
This method should return true if the custom serializer can serialize an instance of the class passed as the
parameter.
- isSerializerFor(clazz) - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
This method should return true if the custom serializer can serialize an instance of the class passed as the
parameter.
- IssuanceRequester(amount, issueToParty, issueToPartyRef, issuerBankParty, notaryParty, anonymous) - Constructor for class net.corda.flows.IssuerFlow.IssuanceRequester
-
IssuanceRequester should be used by a client to ask a remote node to issue some
interface FungibleAsset
with the given details.
Returns the transaction created by the Issuer to move the cash to the Requester.
- IssuanceRequestState(amount, issueToParty, issuerPartyRef, notaryParty, anonymous) - Constructor for class net.corda.flows.IssuerFlow.IssuanceRequestState
-
- isSubTypeOf(superType) - Method in class net.corda.core.node.services.ServiceType
-
- isSuccess() - Method in class net.corda.core.utilities.Try.Failure
-
- isSuccess() - Method in class net.corda.core.utilities.Try
-
- isSuccess() - Method in class net.corda.core.utilities.Try.Success
-
- Issue() - Constructor for class net.corda.contracts.asset.Clauses.Issue
-
- Issue(nonce) - Constructor for class net.corda.contracts.asset.Commands.Issue
-
Allows new cash states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- Issue() - Constructor for class net.corda.contracts.asset.Commands.Issue
-
Allows new cash states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- Issue() - Constructor for class net.corda.contracts.asset.Clauses.Issue
-
Standard issue clause, specialised to match the commodity issue command.
- Issue(nonce) - Constructor for class net.corda.contracts.asset.Commands.Issue
-
Allows new commodity states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- Issue() - Constructor for class net.corda.contracts.asset.Commands.Issue
-
Allows new commodity states to be issued into existence: the nonce ("number used once") ensures the transaction
has a unique ID even when there are no inputs.
- Issue() - Constructor for class net.corda.contracts.asset.Clauses.Issue
-
Generic issuance clause
- Issue(nonce) - Constructor for class net.corda.contracts.asset.Commands.Issue
-
Allows new obligation states to be issued into existence: the nonce ("number used once") ensures the
transaction has a unique ID even when there are no inputs.
- Issue() - Constructor for class net.corda.contracts.asset.Commands.Issue
-
Allows new obligation states to be issued into existence: the nonce ("number used once") ensures the
transaction has a unique ID even when there are no inputs.
- Issue() - Constructor for class net.corda.contracts.Clauses.Issue
-
- Issue(nonce) - Constructor for class net.corda.contracts.Commands.Issue
-
- Issue() - Constructor for class net.corda.contracts.Commands.Issue
-
- Issue() - Constructor for class net.corda.contracts.Commands.Issue
-
- IssueCash(amount, issueRef, recipient, notary, anonymous) - Constructor for class net.corda.flows.CashFlowCommand.IssueCash
-
A command to initiate the Cash flow with.
- IssueCommand - Interface in net.corda.core.contracts
-
A common issue command, to enforce that issue commands have a nonce value.
- Issued<P> - Class in net.corda.core.contracts
-
Definition for an issued product, which can be cash, a cash-like thing, assets, or generally anything else that's
quantifiable with integer quantities.
- Issued(issuer, product) - Constructor for class net.corda.core.contracts.Issued
-
Definition for an issued product, which can be cash, a cash-like thing, assets, or generally anything else that's
quantifiable with integer quantities.
- issued by($receiver, party) - Static method in class net.corda.contracts.asset.CashKt
-
- issued by($receiver, deposit) - Static method in class net.corda.contracts.asset.CashKt
-
- issued by($receiver, party) - Static method in class net.corda.contracts.asset.ObligationKt
-
- issued by($receiver, deposit) - Static method in class net.corda.core.contracts.ContractsDSL
-
- issued by($receiver, deposit) - Static method in class net.corda.core.contracts.ContractsDSL
-
- issuedBy($receiver, party) - Static method in class net.corda.contracts.asset.CashKt
-
- issuedBy($receiver, deposit) - Static method in class net.corda.contracts.asset.CashKt
-
- issuedBy($receiver, party) - Static method in class net.corda.contracts.asset.ObligationKt
-
- issuedBy($receiver, deposit) - Static method in class net.corda.core.contracts.ContractsDSL
-
- issuedBy($receiver, deposit) - Static method in class net.corda.core.contracts.ContractsDSL
-
- Issuer(otherParty) - Constructor for class net.corda.flows.IssuerFlow.Issuer
-
- Issuer.Companion - Class in net.corda.flows
-
- IssuerEvents() - Constructor for enum net.corda.client.mock.ErrorFlowsEventGenerator.IssuerEvents
-
- IssuerFlow - Class in net.corda.flows
-
- IssuerFlow.IssuanceRequester - Class in net.corda.flows
-
IssuanceRequester should be used by a client to ask a remote node to issue some
interface FungibleAsset
with the given details.
Returns the transaction created by the Issuer to move the cash to the Requester.
- IssuerFlow.IssuanceRequestState - Class in net.corda.flows
-
- IssuerFlow.Issuer - Class in net.corda.flows
-
- isSupportedSignatureScheme(signatureScheme) - Method in class net.corda.core.crypto.Crypto
-
- isUnwrappableAs(unwrapType) - Method in class net.corda.node.services.database.HibernateConfiguration.NodeDatabaseConnectionProvider
-
- isValid(publicKey, signatureData, clearData) - Method in class net.corda.core.crypto.Crypto
-
Utility to simplify the act of verifying a digital signature by identifying the signature scheme used from the input public key's type.
It returns true if it succeeds and false if not. In comparison to doVerify if the key and signature
do not match it returns false rather than throwing an exception. Normally you should use the function which throws,
as it avoids the risk of failing to test the result.
Use this method if the signature scheme is not a-priori known.
- isValid(signatureScheme, publicKey, signatureData, clearData) - Method in class net.corda.core.crypto.Crypto
-
Method to verify a digital signature. In comparison to doVerify if the key and signature
do not match it returns false rather than throwing an exception.
Use this method if the signature scheme type is a-priori unknown.
- isValid($receiver, content, signature) - Static method in class net.corda.core.crypto.CryptoUtils
-
Utility to simplify the act of verifying a signature. In comparison to verify if the key and signature
do not match it returns false rather than throwing an exception. Normally you should use the function which throws,
as it avoids the risk of failing to test the result, but this is for uses such as
java.security.Signature.verify
implementations.
- isValid(content) - Method in class net.corda.core.crypto.DigitalSignature.WithKey
-
Utility to simplify the act of verifying a signature. In comparison to verify doesn't throw an
exception, making it more suitable where a boolean is required, but normally you should use the function
which throws, as it avoids the risk of failing to test the result.
- isValid(timeWindow) - Method in class net.corda.core.node.services.TimeWindowChecker
-
- isValid(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- isValidatingNotary($this, party) - Static method in class net.corda.core.node.services.NetworkMapCache.DefaultImpls
-
Checks whether a given party is an advertised validating notary identity
- isValidatingNotary(party) - Method in interface net.corda.core.node.services.NetworkMapCache
-
Checks whether a given party is an advertised validating notary identity
- isValidatingNotary() - Method in class net.corda.core.node.services.ServiceType
-
- isVersion() - Method in class net.corda.node.CmdLineOptions
-
- isWorkingDay(date) - Method in class net.corda.contracts.BusinessCalendar
-
- isWorkingDay($receiver, accordingToCalendar) - Static method in class net.corda.contracts.FinanceTypesKt
-
- isWrapperFor(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- iterator() - Method in class net.corda.client.jfx.utils.MapValuesList
-
- iterator() - Method in class net.corda.core.utilities.NonEmptySet
-
- iterator() - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- sampleBernoulli($receiver, maxRatio, collection) - Static method in class net.corda.client.mock.GeneratorKt
-
- sampleBernoulli($receiver, collection, meanRatio) - Static method in class net.corda.client.mock.GeneratorKt
-
- save($receiver, keyStoreFilePath, storePassword) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
Helper method save KeyStore to storage.
- saveCertificateAsPEMFile(x509Certificate, filename) - Static method in class net.corda.core.crypto.X509Utilities
-
Helper method to store a .pem/.cer format file copy of a certificate if required for import into a PC/Mac, or for inspection.
- saveNewKeyPair(serviceName, privateKeyAlias, keyPair) - Method in class net.corda.node.utilities.KeyStoreWrapper
-
- savePublicKey(serviceName, pubKeyAlias, pubKey) - Method in class net.corda.node.utilities.KeyStoreWrapper
-
- SchedulableFlow - Interface in net.corda.core.flows
-
Any
class FlowLogic
which is schedulable and is designed to be invoked by a
interface SchedulableState
must have this annotation. If it's missing FlowLogicRefFactory.create will throw an exception when it comes time
to schedule the next activity in net.corda.core.contracts.SchedulableState.nextScheduledActivity.
- SchedulableState - Interface in net.corda.core.contracts
-
- Scheduled - Interface in net.corda.core.contracts
-
Something which is scheduled to happen at a point in time
- Scheduled(scheduledState) - Constructor for class net.corda.core.flows.FlowInitiator.Scheduled
-
Started as scheduled activity.
- ScheduledActivity - Class in net.corda.core.contracts
-
This class represents the lifecycle activity that a contract state of type
interface LinearState
would like to perform at a
given point in time. e.g. run a fixing flow.
- ScheduledActivity(logicRef, scheduledAt) - Constructor for class net.corda.core.contracts.ScheduledActivity
-
This class represents the lifecycle activity that a contract state of type
interface LinearState
would like to perform at a
given point in time. e.g. run a fixing flow.
- ScheduledActivityObserver - Class in net.corda.node.services.events
-
This observes the vault and schedules and unschedules activities appropriately based on state production and
consumption.
- ScheduledActivityObserver(services) - Constructor for class net.corda.node.services.events.ScheduledActivityObserver
-
This observes the vault and schedules and unschedules activities appropriately based on state production and
consumption.
- ScheduledStateRef - Class in net.corda.core.contracts
-
Represents a contract state (unconsumed output) of type
interface LinearState
and a point in time that a lifecycle event is
expected to take place for that contract state.
- ScheduledStateRef(ref, scheduledAt) - Constructor for class net.corda.core.contracts.ScheduledStateRef
-
Represents a contract state (unconsumed output) of type
interface LinearState
and a point in time that a lifecycle event is
expected to take place for that contract state.
- SchedulerService - Interface in net.corda.node.services.api
-
Provides access to schedule activity at some point in time. This interface might well be expanded to
increase the feature set in the future.
- scheduleStateActivity(action) - Method in interface net.corda.node.services.api.SchedulerService
-
Schedule a new activity for a TX output, probably because it was just produced.
- scheduleStateActivity(action) - Method in class net.corda.node.services.events.NodeSchedulerService
-
Schedule a new activity for a TX output, probably because it was just produced.
- Schema - Class in net.corda.core.serialization.amqp
-
This and the classes below are OO representations of the AMQP XML schema described in the specification. Their
Schema.toString
representations generate the associated XML form.
- Schema(types) - Constructor for class net.corda.core.serialization.amqp.Schema
-
This and the classes below are OO representations of the AMQP XML schema described in the specification. Their
Schema.toString
representations generate the associated XML form.
- Schema - Class in net.corda.core.serialization.carpenter
-
A Schema represents a desired class.
- Schema(name, fields, superclass, interfaces) - Constructor for class net.corda.core.serialization.carpenter.Schema
-
A Schema represents a desired class.
- Schema.Companion - Class in net.corda.core.serialization.amqp
-
- SchemaKt - Class in net.corda.core.serialization.amqp
-
- SchemaOptions(databaseSchema, tablePrefix) - Constructor for class net.corda.node.services.api.SchemaService.SchemaOptions
-
Represents any options configured on the node for a schema.
- SchemaOptions() - Constructor for class net.corda.node.services.api.SchemaService.SchemaOptions
-
Represents any options configured on the node for a schema.
- SchemaService - Interface in net.corda.node.services.api
-
A configuration and customisation point for Object Relational Mapping of contract state objects.
- SchemaService.SchemaOptions - Class in net.corda.node.services.api
-
Represents any options configured on the node for a schema.
- Secondary(progressTracker) - Constructor for class net.corda.flows.TwoPartyDealFlow.Secondary
-
Abstracted bilateral deal flow participant that is recipient of initial communication.
- Secondary() - Constructor for class net.corda.flows.TwoPartyDealFlow.Secondary
-
Abstracted bilateral deal flow participant that is recipient of initial communication.
- Secondary.Companion - Class in net.corda.flows
-
- SecureHash - Class in net.corda.core.crypto
-
Container for a cryptographically secure hash value.
Provides utilities for generating a cryptographic hash using different algorithms (currently only SHA-256 supported).
- secureHash($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
-
- SecureHash.Companion - Class in net.corda.core.crypto
-
- SecureHash.SHA256 - Class in net.corda.core.crypto
-
SHA-256 is part of the SHA-2 hash function family. Generated hash is fixed size, 256-bits (32-bytes)
- SecureHashColumnType - Class in net.corda.node.utilities
-
- SecureHashConverter - Class in net.corda.core.schemas.requery.converters
-
- SecureHashConverter() - Constructor for class net.corda.core.schemas.requery.converters.SecureHashConverter
-
- SecureHashDeserializer() - Constructor for class net.corda.jackson.JacksonSupport.SecureHashDeserializer
-
Implemented as a class so that we can instantiate for T.
- SecureHashKt - Class in net.corda.core.crypto
-
- secureRandomBytes(numOfBytes) - Static method in class net.corda.core.crypto.CryptoUtils
-
Generate a securely random
ByteArray of requested number of bytes. Usually used for seeds, nonces and keys.
- selectSchemas(state) - Method in interface net.corda.node.services.api.SchemaService
-
Given a state, select schemas to map it to that are supported by generateMappedObject and that are configured
for this node.
- selectSchemas(state) - Method in class net.corda.node.services.schema.NodeSchemaService
-
Given a state, select schemas to map it to that are supported by generateMappedObject and that are configured
for this node.
- Seller(otherParty, notaryNode, assetToSell, price, me, progressTracker) - Constructor for class net.corda.flows.TwoPartyTradeFlow.Seller
-
- Seller.Companion - Class in net.corda.flows
-
- SellerTradeInfo(assetForSale, price, sellerOwner) - Constructor for class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
-
- send(otherParty, payload) - Method in class net.corda.core.flows.FlowLogic
-
Queues the given payload for sending to the otherParty and continues without suspending.
- send(otherParty, payload, sessionFlow) - Method in interface net.corda.core.internal.FlowStateMachine
-
- send($receiver, topic, sessionID, payload, to, uuid) - Static method in class net.corda.node.services.messaging.MessagingKt
-
- send($receiver, topicSession, payload, to, uuid, retryId) - Static method in class net.corda.node.services.messaging.MessagingKt
-
- send(message, target, retryId) - Method in interface net.corda.node.services.messaging.MessagingService
-
Sends a message to the given receiver. The details of how receivers are identified is up to the messaging
implementation: the type system provides an opaque high level view, with more fine grained control being
available via type casting. Once this function returns the message is queued for delivery but not necessarily
delivered: if the recipients are offline then the message could be queued hours or days later.
- send(message, target, retryId) - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
Sends a message to the given receiver. The details of how receivers are identified is up to the messaging
implementation: the type system provides an opaque high level view, with more fine grained control being
available via type casting. Once this function returns the message is queued for delivery but not necessarily
delivered: if the recipients are offline then the message could be queued hours or days later.
- send(otherParty, payload, sessionFlow) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- sendAndReceive(receiveType, otherParty, payload) - Method in class net.corda.core.flows.FlowLogic
-
Serializes and queues the given payload object for sending to the otherParty. Suspends until a response
is received, which must be of the given receiveType. Remember that when receiving data from other parties the data
should not be trusted until it's been thoroughly verified for consistency and that all expectations are
satisfied, as a malicious peer may send you subtly corrupted data in order to exploit your code.
- sendAndReceive(receiveType, otherParty, payload, sessionFlow, retrySend) - Method in interface net.corda.core.internal.FlowStateMachine
-
- sendAndReceive(receiveType, otherParty, payload, sessionFlow, retrySend) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- SendAndReceive<T extends SessionMessage> - Class in net.corda.node.services.statemachine
-
- SendAndReceive(session, message, receiveType, userReceiveType) - Constructor for class net.corda.node.services.statemachine.SendAndReceive
-
- sendMessage(serverToClient) - Method in class net.corda.node.services.messaging.ObservableContext
-
- SendOnly - Class in net.corda.node.services.statemachine
-
- SendOnly(session, message) - Constructor for class net.corda.node.services.statemachine.SendOnly
-
- sendRequest($receiver, topic, request, target) - Static method in class net.corda.node.services.messaging.ServiceRequestMessageKt
-
- SendRequest - Interface in net.corda.node.services.statemachine
-
- sendRequest(nonce, transaction) - Method in class net.corda.node.services.transactions.OutOfProcessTransactionVerifierService
-
- sequence($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
-
data class Person(val height: ObservableValue)
val people: List = listOf(alice, bob)
val heights: ObservableList = people.map(Person::height).sequence()
- sequence(generators) - Method in class net.corda.client.mock.Generator.Companion
-
- sequence($receiver, offset, size) - Static method in class net.corda.core.utilities.ByteArrays
-
- SerialFilterKt - Class in net.corda.node
-
- SerializationAPIKt - Class in net.corda.core.serialization
-
- SerializationContext - Interface in net.corda.core.serialization
-
Parameters to serialization and deserialization.
- serializationContext($receiver) - Static method in class net.corda.core.serialization.SerializationTokenKt
-
- SerializationContext.UseCase - Enum in net.corda.core.serialization
-
The use case that we are serializing for, since it influences the implementations chosen.
- SerializationCustomization - Interface in net.corda.core.serialization
-
- SerializationDefaults - Class in net.corda.core.serialization
-
Global singletons to be used as defaults that are injected elsewhere (generally, in the node or in RPC client).
- SerializationFactory - Interface in net.corda.core.serialization
-
An abstraction for serializing and deserializing objects, with support for versioning of the wire format via
a header / prefix in the bytes.
- SerializationHelperKt - Class in net.corda.core.serialization.amqp
-
- SerializationOutput - Class in net.corda.core.serialization.amqp
-
Main entry point for serializing an object to AMQP.
- SerializationOutput() - Constructor for class net.corda.core.serialization.amqp.SerializationOutput
-
Main entry point for serializing an object to AMQP.
- SerializationOutput() - Constructor for class net.corda.core.serialization.amqp.SerializationOutput
-
Main entry point for serializing an object to AMQP.
- SerializationToken - Interface in net.corda.core.serialization
-
- SerializationTokenKt - Class in net.corda.core.serialization
-
- serialize(expr, generator, provider) - Method in class net.corda.contracts.ExpressionSerializer
-
- serialize(obj) - Method in class net.corda.core.serialization.amqp.SerializationOutput
-
Serialize the given object to AMQP, wrapped in our
class Envelope
wrapper which carries an AMQP 1.0 schema, and prefixed
with a header to indicate that this is serialized with AMQP and not
Kryo, and what version of the Corda implementation
of AMQP serialization contructed the serialized form.
- serialize($receiver, serializationFactory, context) - Static method in class net.corda.core.serialization.SerializationAPIKt
-
Convenience extension method for serializing an object of type T, utilising the defaults.
- serialize(obj, context) - Method in interface net.corda.core.serialization.SerializationFactory
-
Serialize an object to bytes using the preferred serialization format version from the context.
- serialize(value, gen, serializers) - Method in class net.corda.jackson.JacksonSupport.AmountSerializer
-
- serialize(obj, generator, provider) - Method in class net.corda.jackson.JacksonSupport.AnonymousPartySerializer
-
- serialize(obj, generator, context) - Method in class net.corda.jackson.JacksonSupport.CalendarSerializer
-
- serialize(obj, generator, provider) - Method in class net.corda.jackson.JacksonSupport.CompositeKeySerializer
-
- serialize(value, gen, serializers) - Method in class net.corda.jackson.JacksonSupport.NodeInfoSerializer
-
- serialize(value, gen, serializers) - Method in class net.corda.jackson.JacksonSupport.OpaqueBytesSerializer
-
- serialize(obj, generator, provider) - Method in class net.corda.jackson.JacksonSupport.PartySerializer
-
- serialize(obj, generator, provider) - Method in class net.corda.jackson.JacksonSupport.PublicKeySerializer
-
- serialize(obj, generator, provider) - Method in class net.corda.jackson.JacksonSupport.SecureHashSerializer
-
- serialize(obj, generator, provider) - Method in class net.corda.jackson.JacksonSupport.ToStringSerializer
-
- serialize(obj, generator, provider) - Method in class net.corda.jackson.JacksonSupport.X500NameSerializer
-
- SerializeAsToken - Interface in net.corda.core.serialization
-
This interface should be implemented by classes that want to substitute a token representation of themselves if
they are serialized because they have a lot of internal state that does not serialize (well).
- SerializeAsTokenContext - Class in net.corda.core.serialization
-
A context for mapping SerializationTokens to/from SerializeAsTokens.
- SerializeAsTokenContext(toBeTokenized, serializationFactory, context, serviceHub) - Constructor for class net.corda.core.serialization.SerializeAsTokenContext
-
- SerializeAsTokenSerializer<T extends SerializeAsToken> - Class in net.corda.core.serialization
-
- SerializeAsTokenSerializer() - Constructor for class net.corda.core.serialization.SerializeAsTokenSerializer
-
- SerializedBytes<T> - Class in net.corda.core.serialization
-
A type safe wrapper around a byte array that contains a serialised object. You can call SerializedBytes.deserialize
to get the original object back.
- SerializedBytes(bytes) - Constructor for class net.corda.core.serialization.SerializedBytes
-
A type safe wrapper around a byte array that contains a serialised object. You can call SerializedBytes.deserialize
to get the original object back.
- SerializedBytesSerializer - Class in net.corda.core.serialization
-
A serialiser that avoids writing the wrapper class to the byte stream, thus ensuring
class SerializedBytes
is a pure
type safety hack.
- serializedHash(x) - Static method in class net.corda.core.transactions.MerkleTransactionKt
-
- SerializerFactory - Class in net.corda.core.serialization.amqp
-
Factory of serializers designed to be shared across threads and invocations.
- SerializerFactory(whitelist) - Constructor for class net.corda.core.serialization.amqp.SerializerFactory
-
Factory of serializers designed to be shared across threads and invocations.
- SerializerFactory() - Constructor for class net.corda.core.serialization.amqp.SerializerFactory
-
Factory of serializers designed to be shared across threads and invocations.
- SerializerFactory.AnyType - Class in net.corda.core.serialization.amqp
-
- SerializerFactory.Companion - Class in net.corda.core.serialization.amqp
-
- serializeToBlob(value, finalizables) - Static method in class net.corda.node.utilities.JDBCHashMapKt
-
- Service(otherSide, service) - Constructor for class net.corda.core.flows.NotaryFlow.Service
-
A flow run by a notary service that handles notarisation requests.
- Service(service) - Constructor for class net.corda.core.node.services.PartyInfo.Service
-
- ServiceAffinityExecutor(threadName, numThreads) - Constructor for class net.corda.node.utilities.AffinityExecutor.ServiceAffinityExecutor
-
An executor backed by thread pool (which may often have a single thread) which makes it easy to schedule
tasks in the future and verify code is running on the executor.
- ServiceAffinityExecutor.Companion - Class in net.corda.node.utilities
-
- ServiceEntry - Class in net.corda.core.node
-
Information for an advertised service including the service specific identity information.
The identity can be used in flows and is distinct from the Node's legalIdentity
- ServiceEntry(info, identity) - Constructor for class net.corda.core.node.ServiceEntry
-
Information for an advertised service including the service specific identity information.
The identity can be used in flows and is distinct from the Node's legalIdentity
- ServiceHub - Interface in net.corda.core.node
-
A service hub simply vends references to the other services a node has. Some of those services may be missing or
mocked out. This class is useful to pass to chunks of pluggable code that might have need of many different kinds of
functionality and you don't want to hard-code which types in the interface.
- serviceHub - Variable in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- ServiceHub.DefaultImpls - Class in net.corda.core.node
-
A service hub simply vends references to the other services a node has. Some of those services may be missing or
mocked out. This class is useful to pass to chunks of pluggable code that might have need of many different kinds of
functionality and you don't want to hard-code which types in the interface.
- ServiceHubInternal - Interface in net.corda.node.services.api
-
- ServiceHubInternal.Companion - Class in net.corda.node.services.api
-
- ServiceHubInternal.DefaultImpls - Class in net.corda.node.services.api
-
- ServiceHubInternalKt - Class in net.corda.node.services.api
-
- serviceIdentities(type) - Method in class net.corda.core.node.NodeInfo
-
- ServiceIdentityGenerator - Class in net.corda.node.utilities
-
- ServiceInfo - Class in net.corda.core.node.services
-
A container for additional information for an advertised service.
- ServiceInfo(type, name) - Constructor for class net.corda.core.node.services.ServiceInfo
-
A container for additional information for an advertised service.
- ServiceInfo.Companion - Class in net.corda.core.node.services
-
- ServiceInfoKt - Class in net.corda.core.node.services
-
- ServiceRequestMessage - Interface in net.corda.node.services.messaging
-
Abstract superclass for request messages sent to services which expect a reply.
- ServiceRequestMessageKt - Class in net.corda.node.services.messaging
-
- services() - Method in class net.corda.node.shell.InteractiveShellCommand
-
- ServicesForResolution - Interface in net.corda.core.node
-
Subset of node services that are used for loading transactions from the wire into fully resolved, looked up
forms ready for verification.
- ServiceType - Class in net.corda.core.node.services
-
Identifier for service types a node can expose over the network to other peers. These types are placed into network
map advertisements. Services that are purely local and are not providing functionality to other parts of the network
don't need a declared service type.
- ServiceType.Companion - Class in net.corda.core.node.services
-
- SessionConfirm - Class in net.corda.node.services.statemachine
-
- SessionConfirm(initiatorSessionId, initiatedSessionId) - Constructor for class net.corda.node.services.statemachine.SessionConfirm
-
- SessionData - Class in net.corda.node.services.statemachine
-
- SessionData(recipientSessionId, payload) - Constructor for class net.corda.node.services.statemachine.SessionData
-
- SessionedFlowIORequest - Interface in net.corda.node.services.statemachine
-
- SessionEnd - Interface in net.corda.node.services.statemachine
-
- sessionFactoryForRegisteredSchemas() - Method in class net.corda.node.services.database.HibernateConfiguration
-
- sessionFactoryForSchema(schema) - Method in class net.corda.node.services.database.HibernateConfiguration
-
- sessionFactoryForSchemas(schemas) - Method in class net.corda.node.services.database.HibernateConfiguration
-
- sessionForModel(model) - Method in class net.corda.node.services.database.RequeryConfiguration
-
- SessionInit - Class in net.corda.node.services.statemachine
-
- SessionInit(initiatorSessionId, initiatingFlowClass, flowVerison, firstPayload) - Constructor for class net.corda.node.services.statemachine.SessionInit
-
- SessionInitResponse - Interface in net.corda.node.services.statemachine
-
- SessionInitResponse.DefaultImpls - Class in net.corda.node.services.statemachine
-
- SessionMessage - Interface in net.corda.node.services.statemachine
-
These internal messages define the flow session protocol.
- SessionMessageKt - Class in net.corda.node.services.statemachine
-
- SessionReject - Class in net.corda.node.services.statemachine
-
- SessionReject(initiatorSessionId, errorMessage) - Constructor for class net.corda.node.services.statemachine.SessionReject
-
- SessionRejectException - Exception in net.corda.node.internal
-
- SessionRejectException(rejectMessage, logMessage) - Constructor for exception net.corda.node.internal.SessionRejectException
-
- set(index, element) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- setAdvertisedServices(p) - Method in class net.corda.core.node.NodeInfo
-
- setAll(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- setAll(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- setAttachments(p) - Method in class net.corda.node.internal.AbstractNode
-
- setAutoCommit(autoCommit) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setCatalog(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setCause(cause) - Method in exception net.corda.core.CordaException
-
- setCause(cause) - Method in exception net.corda.core.CordaRuntimeException
-
- setCause(cause) - Method in interface net.corda.core.CordaThrowable
-
- setCheckAttachmentsOnLoad(p) - Method in class net.corda.node.services.persistence.NodeAttachmentService
-
- setCHECKPOINT_CONTEXT(p) - Method in class net.corda.core.serialization.SerializationDefaults
-
- setCheckpointStorage(p) - Method in class net.corda.node.internal.AbstractNode
-
- setChildProgressTracker(step, childProgressTracker) - Method in class net.corda.core.utilities.ProgressTracker
-
- setClientInfo(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setClientInfo(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setConsumedTime(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to timestamp recorded upon entering CONSUMED state
- setContractState(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to serialized transaction Contract State
- setContractStateClassName(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
references a concrete ContractState that is
- setCurrency(p) - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- setCurrency(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setCurrentStep(value) - Method in class net.corda.core.utilities.ProgressTracker
-
Reading returns the value of stepsstepIndex, writing moves the position of the current tracker. Once moved to
the
class ProgressTracker.DONE
state, this tracker is finished and the current step cannot be moved again.
- setDatabase(p) - Method in class net.corda.node.internal.AbstractNode
-
- setDatabase(p) - Method in class net.corda.node.utilities.CordaPersistence
-
Holds Exposed database, the field will be removed once Exposed library is removed
- setDataSource(p) - Method in class net.corda.node.utilities.CordaPersistence
-
- setDataSource(value) - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- setDbCloser(p) - Method in class net.corda.node.internal.AbstractNode
-
- setDealReference(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
Deal State attributes
- setExpires(p) - Method in class net.corda.node.services.network.NodeRegistration
-
- setExternalId(p) - Method in class net.corda.core.schemas.CommonSchemaV1.LinearState
-
Represents a
- setExternalId(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
Represents a
- setFaceValue(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setFaceValueIssuerParty(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setFaceValueIssuerRef(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setHoldability(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setId(p) - Method in class net.corda.core.schemas.CommonSchemaV1.Party
-
- setIndex(p) - Method in class net.corda.core.schemas.PersistentStateRef
-
- setIndex(p) - Method in interface net.corda.core.schemas.requery.Requery.PersistentState
-
- setInfo(p) - Method in class net.corda.node.internal.AbstractNode
-
- setInNodeNetworkMapService(p) - Method in class net.corda.node.internal.AbstractNode
-
- setIssuanceParty(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setIssuanceRef(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setIssuerParty(p) - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
Issuer attributes
- setIssuerParty(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
Issuer attributes
- setIssuerParty(p) - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- setIssuerRef(p) - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- setIssuerRef(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- setIssuerRef(p) - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- setKey(p) - Method in class net.corda.core.schemas.CommonSchemaV1.Party
-
- SetLifecycle() - Constructor for class net.corda.contracts.asset.Clauses.SetLifecycle
-
Obligation-specific clause for changing the lifecycle of one or more states.
- SetLifecycle(lifecycle) - Constructor for class net.corda.contracts.asset.Commands.SetLifecycle
-
A command stating that the beneficiary is moving the contract into the defaulted state as it has not been settled
by the due date, or resetting a defaulted contract back to the issued state.
- setLifecycle(p) - Method in class net.corda.contracts.asset.Obligation.State
-
- setLockId(p) - Method in class net.corda.core.transactions.TransactionBuilder
-
- setLockId(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
used to denote a state has been soft locked
- setLockUpdateTime(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to the last time a lock was taken
- setMaturity(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setMessage(message) - Method in exception net.corda.core.CordaException
-
- setMessage(message) - Method in exception net.corda.core.CordaRuntimeException
-
- setMessage(message) - Method in interface net.corda.core.CordaThrowable
-
- setMessageBroker(p) - Method in class net.corda.node.internal.Node
-
- setName(p) - Method in class net.corda.core.schemas.CommonSchemaV1.Party
-
- setName(p) - Method in class net.corda.core.serialization.carpenter.Field
-
- setNetwork(p) - Method in class net.corda.node.internal.AbstractNode
-
- setNetworkMapSeq(p) - Method in class net.corda.node.internal.AbstractNode
-
Sequence number of changes sent to the network map service, when registering/de-registering this node.
- setNetworkTimeout(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setNotary(p) - Method in class net.corda.core.transactions.TransactionBuilder
-
- setNotaryKey(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
- setNotaryName(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to the notary a state is attached to
- setNotaryParty(p) - Method in class net.corda.core.flows.NotaryFlow.Client
-
- setOnDone(p) - Method in class net.corda.node.utilities.ANSIProgressRenderer
-
- setOriginalExceptionClassName(p) - Method in exception net.corda.core.CordaException
-
- setOriginalExceptionClassName(p) - Method in exception net.corda.core.CordaRuntimeException
-
- setOriginalExceptionClassName(p) - Method in interface net.corda.core.CordaThrowable
-
- setOwner(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- setOwner(p) - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- setOwner(p) - Method in class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
-
- setOwnerKey(p) - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- setP2P_CONTEXT(p) - Method in class net.corda.core.serialization.SerializationDefaults
-
- setParticipants(p) - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
- setParticipants(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- setParticipants(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
- setPennies(p) - Method in class net.corda.schemas.CashSchemaV1.PersistentCashState
-
- setProgressTracker(value) - Method in class net.corda.node.utilities.ANSIProgressRenderer
-
- setQuantity(p) - Method in class net.corda.core.schemas.CommonSchemaV1.FungibleState
-
Amount attributes
- setQuantity(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
Amount attributes
- setQuery(p) - Method in class net.corda.core.contracts.TransactionGraphSearch
-
- setReadOnly(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setRecordedTime(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
refers to timestamp recorded upon entering UNCONSUMED state
- setRegisteredNodes(p) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
-
- setRenderBasicInfoToConsole(p) - Method in class net.corda.node.internal.Node.Companion
-
- setRPC_CLIENT_CONTEXT(p) - Method in class net.corda.core.serialization.SerializationDefaults
-
- setRPC_SERVER_CONTEXT(p) - Method in class net.corda.core.serialization.SerializationDefaults
-
- setSavepoint() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setSavepoint(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setSchema(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setSERIALIZATION_FACTORY(p) - Method in class net.corda.core.serialization.SerializationDefaults
-
- setServiceHub(p) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
-
- setSmm(p) - Method in class net.corda.node.internal.AbstractNode
-
- setState(p) - Method in class net.corda.node.services.statemachine.FlowSession
-
- setStateRef(p) - Method in class net.corda.core.schemas.PersistentState
-
- setStateStatus(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
state lifecycle
- setStateTypes(p) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
-
- setSTORAGE_CONTEXT(p) - Method in class net.corda.core.serialization.SerializationDefaults
-
- setThreadLocalTx(tx) - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
-
- setTimeWindow(timeWindow) - Method in class net.corda.core.transactions.TransactionBuilder
-
Sets the
class TimeWindow
for this transaction, replacing the existing
class TimeWindow
if there is one. To be valid, the
transaction must then be signed by the notary service within this window of time. In this way, the notary acts as
the Timestamp Authority.
- setTimeWindow(time, timeTolerance) - Method in class net.corda.core.transactions.TransactionBuilder
-
The
class TimeWindow
for the transaction can also be defined as time +/- timeTolerance. The tolerance should be
chosen such that your code can finish building the transaction and sending it to the Timestamp Authority within
that window of time, taking into account factors such as network latency. Transactions being built by a group of
collaborating parties may therefore require a higher time tolerance than a transaction being built by a single
node.
- Settle() - Constructor for class net.corda.contracts.asset.Clauses.Settle
-
Obligation-specific clause for settling an outstanding obligation by witnessing
change of ownership of other states to fulfil
- Settle(amount) - Constructor for class net.corda.contracts.asset.Commands.Settle
-
A command stating that the obligor is settling some or all of the amount owed by transferring a suitable
state object to the beneficiary. If this reduces the balance to zero, the state object is destroyed.
- setTransactionCountLimit(p) - Method in class net.corda.core.flows.ResolveTransactionsFlow
-
The maximum number of transactions this flow will try to download before bailing out.
- setTransactionIsolation(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setTxId(p) - Method in class net.corda.core.schemas.PersistentStateRef
-
- setTxId(p) - Method in interface net.corda.core.schemas.requery.Requery.PersistentState
-
- setTypeMap(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
-
- setup() - Method in class net.corda.node.services.network.AbstractNetworkMapService
-
- setUuid(p) - Method in class net.corda.core.schemas.CommonSchemaV1.LinearState
-
- setUuid(p) - Method in class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
- setValue(value) - Method in class net.corda.core.internal.DeclaredField
-
- setValue(thisRef, property, value) - Method in class net.corda.core.internal.WriteOnceProperty
-
- setWindow(p) - Method in class net.corda.core.transactions.TransactionBuilder
-
- sha256(bytes) - Method in class net.corda.core.crypto.SecureHash.Companion
-
- sha256(str) - Method in class net.corda.core.crypto.SecureHash.Companion
-
- sha256(bytes) - Static method in class net.corda.core.crypto.SecureHash
-
- sha256(str) - Static method in class net.corda.core.crypto.SecureHash
-
- SHA256(bytes) - Constructor for class net.corda.core.crypto.SecureHash.SHA256
-
SHA-256 is part of the SHA-2 hash function family. Generated hash is fixed size, 256-bits (32-bytes)
- sha256($receiver) - Static method in class net.corda.core.crypto.SecureHashKt
-
- sha256($receiver) - Static method in class net.corda.core.crypto.SecureHashKt
-
- sha256Twice(bytes) - Method in class net.corda.core.crypto.SecureHash.Companion
-
- sha256Twice(bytes) - Static method in class net.corda.core.crypto.SecureHash
-
- ShellLifecycle(dir) - Constructor for class net.corda.node.shell.InteractiveShell.ShellLifecycle
-
- sign($receiver, bytesToSign) - Static method in class net.corda.core.crypto.CryptoUtils
-
Utility to simplify the act of signing a byte array.
- sign($receiver, bytesToSign, publicKey) - Static method in class net.corda.core.crypto.CryptoUtils
-
- sign($receiver, bytesToSign) - Static method in class net.corda.core.crypto.CryptoUtils
-
Helper function to sign with a key pair.
- sign($receiver, bytesToSign) - Static method in class net.corda.core.crypto.CryptoUtils
-
- sign($receiver, metaData) - Static method in class net.corda.core.crypto.CryptoUtils
-
Helper function for signing.
- sign(bytes, publicKey) - Method in interface net.corda.core.node.services.KeyManagementService
-
Using the provided signing
PublicKey internally looks up the matching
PrivateKey and signs the data.
- sign(bits) - Method in class net.corda.core.node.services.TrustedAuthorityNotaryService
-
- sign(bytes, publicKey) - Method in class net.corda.node.services.keys.E2ETestKeyManagementService
-
Using the provided signing
PublicKey internally looks up the matching
PrivateKey and signs the data.
- sign(bytes, publicKey) - Method in class net.corda.node.services.keys.PersistentKeyManagementService
-
Using the provided signing
PublicKey internally looks up the matching
PrivateKey and signs the data.
- sign(bytes) - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- Signature(txSignature) - Constructor for class net.corda.node.services.transactions.ReplicaResponse.Signature
-
- Signatures(txSignatures) - Constructor for class net.corda.node.services.transactions.ClusterResponse.Signatures
-
- SignatureScheme - Class in net.corda.core.crypto
-
This class is used to define a digital signature scheme.
- SignatureScheme(schemeNumberID, schemeCodeName, signatureOID, alternativeOIDs, providerName, algorithmName, signatureName, algSpec, keySize, desc) - Constructor for class net.corda.core.crypto.SignatureScheme
-
This class is used to define a digital signature scheme.
- SignaturesMissingException(missing, descriptions, id) - Constructor for exception net.corda.core.transactions.SignedTransaction.SignaturesMissingException
-
- SignatureType - Enum in net.corda.core.crypto
-
Supported Signature types:
- SignatureType() - Constructor for enum net.corda.core.crypto.SignatureType
-
Supported Signature types:
- SignedData<T> - Class in net.corda.core.crypto
-
A serialized piece of data and its signature. Enforces signature validity in order to deserialize the data
contained within.
- SignedData(raw, sig) - Constructor for class net.corda.core.crypto.SignedData
-
A serialized piece of data and its signature. Enforces signature validity in order to deserialize the data
contained within.
- SignedTransaction - Class in net.corda.core.transactions
-
SignedTransaction wraps a serialized WireTransaction. It contains one or more signatures, each one for
a public key (including composite keys) that is mentioned inside a transaction command. SignedTransaction is the top level transaction type
and the type most frequently passed around the network and stored. The identity of a transaction is the hash of Merkle root
of a WireTransaction, therefore if you are storing data keyed by WT hash be aware that multiple different STs may
map to the same key (and they could be different in important ways, like validity!). The signatures on a
SignedTransaction might be invalid or missing: the type does not imply validity.
A transaction ID should be the hash of the
class WireTransaction
Merkle tree root. Thus adding or removing a signature does not change it.
- SignedTransaction(txBits, sigs) - Constructor for class net.corda.core.transactions.SignedTransaction
-
SignedTransaction wraps a serialized WireTransaction. It contains one or more signatures, each one for
a public key (including composite keys) that is mentioned inside a transaction command. SignedTransaction is the top level transaction type
and the type most frequently passed around the network and stored. The identity of a transaction is the hash of Merkle root
of a WireTransaction, therefore if you are storing data keyed by WT hash be aware that multiple different STs may
map to the same key (and they could be different in important ways, like validity!). The signatures on a
SignedTransaction might be invalid or missing: the type does not imply validity.
A transaction ID should be the hash of the
class WireTransaction
Merkle tree root. Thus adding or removing a signature does not change it.
- SignedTransaction(wtx, sigs) - Constructor for class net.corda.core.transactions.SignedTransaction
-
- SignedTransaction.SignaturesMissingException - Exception in net.corda.core.transactions
-
- SignedTransactionSerializer - Class in net.corda.core.serialization
-
- SignersMissing(txId, missing) - Constructor for exception net.corda.core.contracts.TransactionVerificationException.SignersMissing
-
- signInitialTransaction($this, builder, publicKey) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- signInitialTransaction($this, builder) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- signInitialTransaction($this, builder, signingPubKeys) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
-
- signInitialTransaction($this, builder, publicKey) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
Helper method to construct an initial partially signed transaction from a
class TransactionBuilder
using keys stored inside the node.
- signInitialTransaction($this, builder) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
Helper method to construct an initial partially signed transaction from a TransactionBuilder
using the default identity key contained in the node.
- signInitialTransaction($this, builder, signingPubKeys) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
-
Helper method to construct an initial partially signed transaction from a
class TransactionBuilder
using a set of keys all held in this node.
- signInitialTransaction(builder, publicKey) - Method in interface net.corda.core.node.ServiceHub
-
Helper method to construct an initial partially signed transaction from a
class TransactionBuilder
using keys stored inside the node.
- signInitialTransaction(builder) - Method in interface net.corda.core.node.ServiceHub
-
Helper method to construct an initial partially signed transaction from a TransactionBuilder
using the default identity key contained in the node.
- signInitialTransaction(builder, signingPubKeys) - Method in interface net.corda.core.node.ServiceHub
-
Helper method to construct an initial partially signed transaction from a
class TransactionBuilder
using a set of keys all held in this node.
- signInitialTransaction($this, builder, publicKey) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- signInitialTransaction($this, builder) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- signInitialTransaction($this, builder, signingPubKeys) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- SignTransactionFlow - Class in net.corda.core.flows
-
- SignTransactionFlow(otherParty, progressTracker) - Constructor for class net.corda.core.flows.SignTransactionFlow
-
- SignTransactionFlow.Companion - Class in net.corda.core.flows
-
- signWith(key) - Method in class net.corda.core.transactions.TransactionBuilder
-
Deprecated.
- SimpleFieldAccess - Interface in net.corda.core.serialization.carpenter
-
Any object that implements this interface is expected to expose its own fields via the get method, exactly
as if this.class.getMethod("get" + name.capitalize()).invoke(this)
had been called. It is intended as a more
convenient alternative to reflection.
- SimpleNotaryService - Class in net.corda.node.services.transactions
-
A simple Notary service that does not perform transaction validation
- SimpleNotaryService(services) - Constructor for class net.corda.node.services.transactions.SimpleNotaryService
-
A simple Notary service that does not perform transaction validation
- SimpleNotaryService.Companion - Class in net.corda.node.services.transactions
-
- SingleMessageRecipient - Interface in net.corda.core.messaging
-
A base class for the case of point-to-point messages
- SingletonSerializationToken - Class in net.corda.core.serialization
-
A class representing a
interface SerializationToken
for some object that is not serializable but can be looked up
(when deserialized) via just the class name.
- singletonSerializationToken(toBeTokenized) - Method in class net.corda.core.serialization.SingletonSerializationToken.Companion
-
- SingletonSerializationToken.Companion - Class in net.corda.core.serialization
-
- SingletonSerializeAsToken - Class in net.corda.core.serialization
-
A base class for implementing large objects / components / services that need to serialize themselves to a string token
to indicate which instance the token is a serialized form of.
- SingletonSerializeAsToken() - Constructor for class net.corda.core.serialization.SingletonSerializeAsToken
-
A base class for implementing large objects / components / services that need to serialize themselves to a string token
to indicate which instance the token is a serialized form of.
- SingletonSerializer - Class in net.corda.core.serialization.amqp
-
A custom serializer that transports nothing on the wire (except a boolean "false", since AMQP does not support
absolutely nothing, or null as a described type) when we have a singleton within the node that we just
want converting back to that singleton instance on the receiving JVM.
- SingletonSerializer(type, singleton, factory) - Constructor for class net.corda.core.serialization.amqp.SingletonSerializer
-
A custom serializer that transports nothing on the wire (except a boolean "false", since AMQP does not support
absolutely nothing, or null as a described type) when we have a singleton within the node that we just
want converting back to that singleton instance on the receiving JVM.
- size() - Method in class net.corda.client.jfx.utils.AggregatedList
-
- size() - Method in class net.corda.client.jfx.utils.ChosenList
-
- size() - Method in class net.corda.client.jfx.utils.ConcatenatedList
-
- size() - Method in class net.corda.client.jfx.utils.FlattenedList
-
- size() - Method in class net.corda.client.jfx.utils.MappedList
-
- size() - Method in class net.corda.client.jfx.utils.MapValuesList
-
- size() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- size() - Method in class net.corda.client.jfx.utils.ReplayedList
-
- size() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
-
- size() - Method in class net.corda.core.utilities.NonEmptySet
-
- Size() - Constructor for class net.corda.node.services.transactions.Commands.Size
-
- size(commit) - Method in class net.corda.node.services.transactions.DistributedImmutableMap
-
- size() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- size() - Method in class net.corda.node.utilities.AbstractJDBCHashSet
-
- sleep(millis) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl.Companion
-
Provide a mechanism to sleep within a Strand without locking any transactional state
- smm - Variable in class net.corda.node.internal.AbstractNode
-
- snapshot(writer) - Method in class net.corda.node.services.transactions.DistributedImmutableMap
-
Writes out all map entries to disk. Note that this operation does not load all entries into memory, as the
SnapshotWriter is using a disk-backed buffer internally, and iterating map entries results in only a
fixed number of recently accessed entries to ever be kept in memory.
- softLockedStates(lockId) - Method in interface net.corda.core.node.services.VaultService
-
- softLockedStates(lockId) - Method in class net.corda.node.services.vault.NodeVaultService
-
- softLockRelease(lockId, stateRefs) - Method in interface net.corda.core.node.services.VaultService
-
Release all or an explicitly specified set of
class StateRef
for a given
UUID unique identifier.
A vault soft lock manager is automatically notified of a Flows that are terminated, such that any soft locked states
may be released.
In the case of coin selection, softLock are automatically released once previously gathered unconsumed input refs
are consumed as part of cash spending.
- softLockRelease(lockId, stateRefs) - Method in class net.corda.node.services.vault.NodeVaultService
-
Release all or an explicitly specified set of
class StateRef
for a given
UUID unique identifier.
A vault soft lock manager is automatically notified of a Flows that are terminated, such that any soft locked states
may be released.
In the case of coin selection, softLock are automatically released once previously gathered unconsumed input refs
are consumed as part of cash spending.
- softLockReserve(lockId, stateRefs) - Method in interface net.corda.core.node.services.VaultService
-
Reserve a set of
class StateRef
for a given
UUID unique identifier.
Typically, the unique identifier will refer to a Flow lockId associated with a
Transaction in an in-flight flow.
In the case of coin selection, soft locks are automatically taken upon gathering relevant unconsumed input refs.
- softLockReserve(lockId, stateRefs) - Method in class net.corda.node.services.vault.NodeVaultService
-
Reserve a set of
class StateRef
for a given
UUID unique identifier.
Typically, the unique identifier will refer to a Flow lockId associated with a
Transaction in an in-flight flow.
In the case of coin selection, soft locks are automatically taken upon gathering relevant unconsumed input refs.
- Sort - Class in net.corda.core.node.services.vault
-
Sort allows specification of a set of entity attribute names and their associated directionality
and null handling, to be applied upon processing a query specification.
- Sort(columns) - Constructor for class net.corda.core.node.services.vault.Sort
-
Sort allows specification of a set of entity attribute names and their associated directionality
and null handling, to be applied upon processing a query specification.
- Sort.Attribute - Interface in net.corda.core.node.services.vault
-
- Sort.CommonStateAttribute - Enum in net.corda.core.node.services.vault
-
- Sort.Direction - Enum in net.corda.core.node.services.vault
-
- Sort.FungibleStateAttribute - Enum in net.corda.core.node.services.vault
-
- Sort.LinearStateAttribute - Enum in net.corda.core.node.services.vault
-
- Sort.SortColumn - Class in net.corda.core.node.services.vault
-
- Sort.VaultStateAttribute - Enum in net.corda.core.node.services.vault
-
- SortAttribute - Class in net.corda.core.node.services.vault
-
- SortAttribute.Custom - Class in net.corda.core.node.services.vault
-
entityStateClass should reference a persistent state entity
entityStateColumnName should reference an entity attribute name as defined by the associated mapped schema
(for example,
CashSchemaV1.PersistentCashStatecurrency.name)
- SortAttribute.Standard - Class in net.corda.core.node.services.vault
-
sortAttribute refers to common table attributes defined in the node schemas:
VaultState, VaultLinearStates, VaultFungibleStates
- SortColumn(sortAttribute, direction) - Constructor for class net.corda.core.node.services.vault.Sort.SortColumn
-
- SourceAndAmount<T,P> - Class in net.corda.core.contracts
-
Simple data class to associate the origin, owner, or holder of a particular Amount object.
- SourceAndAmount(source, amount, ref) - Constructor for class net.corda.core.contracts.SourceAndAmount
-
Simple data class to associate the origin, owner, or holder of a particular Amount object.
- sourceChanged(c) - Method in class net.corda.client.jfx.utils.AggregatedList
-
- sourceChanged(change) - Method in class net.corda.client.jfx.utils.ConcatenatedList
-
- sourceChanged(c) - Method in class net.corda.client.jfx.utils.FlattenedList
-
- sourceChanged(change) - Method in class net.corda.client.jfx.utils.MappedList
-
- sourceChanged(c) - Method in class net.corda.client.jfx.utils.ReplayedList
-
- SplineFunction - Class in net.corda.contracts.math
-
A spline is function piecewise-defined by polynomial functions.
Points at which polynomial pieces connect are known as knots.
- SplineFunction(segmentMap) - Constructor for class net.corda.contracts.math.SplineFunction
-
A spline is function piecewise-defined by polynomial functions.
Points at which polynomial pieces connect are known as knots.
- spliterator() - Method in class net.corda.core.utilities.NonEmptySet
-
- splitEvenly(partitions) - Method in class net.corda.core.contracts.Amount
-
This method provides a token conserving divide mechanism.
- sqlType() - Method in class net.corda.node.utilities.CertPathColumnType
-
- sqlType() - Method in class net.corda.node.utilities.InstantColumnType
-
- sqlType() - Method in class net.corda.node.utilities.LocalDateColumnType
-
- sqlType() - Method in class net.corda.node.utilities.LocalDateTimeColumnType
-
- sqlType() - Method in class net.corda.node.utilities.PublicKeyColumnType
-
- sqlType() - Method in class net.corda.node.utilities.SecureHashColumnType
-
- sqlType() - Method in class net.corda.node.utilities.UUIDStringColumnType
-
- sqlType() - Method in class net.corda.node.utilities.X509CertificateColumnType
-
- StackSnapshot - Exception in net.corda.node.services.statemachine
-
- StackSnapshot() - Constructor for exception net.corda.node.services.statemachine.StackSnapshot
-
- StackTraceElementProxy(declaringClass, methodName, fileName, lineNumber) - Constructor for class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
-
- StackTraceElementSerializer - Class in net.corda.core.serialization.amqp.custom
-
- StackTraceElementSerializer(factory) - Constructor for class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer
-
- StackTraceElementSerializer.StackTraceElementProxy - Class in net.corda.core.serialization.amqp.custom
-
- Standard(attribute) - Constructor for class net.corda.core.node.services.vault.SortAttribute.Standard
-
sortAttribute refers to common table attributes defined in the node schemas:
VaultState, VaultLinearStates, VaultFungibleStates
- start(username, password) - Method in class net.corda.client.rpc.CordaRPCClient
-
- start(rpcOpsClass, username, password) - Method in class net.corda.client.rpc.internal.RPCClient
-
Returns an
interface RPCClient.RPCConnection
containing a proxy that lets you invoke RPCs on the server. Calls on it block, and if
the server throws an exception then it will be rethrown on the client. Proxies are thread safe and may be used to
invoke multiple RPCs in parallel.
- start() - Method in class net.corda.client.rpc.internal.RPCClientProxyHandler
-
Start the client. This creates the per-client queue, starts the consumer session and the reaper.
- start() - Method in class net.corda.core.node.services.NotaryService
-
- start() - Method in class net.corda.node.internal.AbstractNode
-
- start() - Method in class net.corda.node.internal.Node
-
- start() - Method in class net.corda.node.services.events.NodeSchedulerService
-
- start() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
The server will make sure the bridge exists on network map changes, see method updateBridgesOnNetworkChange
We assume network map will be updated accordingly when the client node register with the network map server.
- start() - Method in interface net.corda.node.services.messaging.MessagingServiceBuilder
-
- start(rpcOps, userService) - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
- start(activeMqServerControl) - Method in class net.corda.node.services.messaging.RPCServer
-
- start() - Method in class net.corda.node.services.statemachine.StateMachineManager
-
- start() - Method in class net.corda.node.services.transactions.BFTNonValidatingNotaryService
-
- start(responseConsumer) - Method in class net.corda.node.services.transactions.OutOfProcessTransactionVerifierService
-
- start() - Method in class net.corda.node.services.transactions.RaftNonValidatingNotaryService
-
- start() - Method in class net.corda.node.services.transactions.RaftUniquenessProvider
-
- start() - Method in class net.corda.node.services.transactions.RaftValidatingNotaryService
-
- start() - Method in class net.corda.node.services.transactions.SimpleNotaryService
-
- start() - Method in class net.corda.node.services.transactions.ValidatingNotaryService
-
- start(config) - Method in class net.corda.node.shell.InteractiveShell.ShellLifecycle
-
- StartableByRPC - Interface in net.corda.core.flows
-
Any
class FlowLogic
which is to be started by the RPC interface (net.corda.core.messaging.CordaRPCOps.startFlowDynamic
and net.corda.core.messaging.CordaRPCOps.startTrackedFlowDynamic) must have this annotation. If it's missing the
flow will not be allowed to start and an exception will be thrown.
- startFlow(proxy) - Method in class net.corda.flows.CashFlowCommand.ExitCash
-
- startFlow(proxy) - Method in class net.corda.flows.CashFlowCommand.IssueCash
-
- startFlow(proxy) - Method in class net.corda.flows.CashFlowCommand.PayCash
-
- startFlow(proxy) - Method in class net.corda.flows.CashFlowCommand
-
- startFlow($this, logic) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
-
- startFlow(logic) - Method in interface net.corda.node.services.api.ServiceHubInternal
-
- startFlow(logic, flowInitiator) - Method in interface net.corda.node.services.api.ServiceHubInternal
-
Starts an already constructed flow. Note that you must be on the server thread to call this method.
- startFlowDynamic(logicType, args) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- startFlowDynamic(logicType, args) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
- startFlowPermission(className) - Static method in class net.corda.node.services.RPCUserServiceKt
-
- startFlowPermission(clazz) - Static method in class net.corda.node.services.RPCUserServiceKt
-
- startMessagingService(rpcOps) - Method in class net.corda.node.internal.AbstractNode
-
- startMessagingService(rpcOps) - Method in class net.corda.node.internal.Node
-
- startNode(conf, versionInfo, startTime, cmdlineOptions) - Method in class net.corda.node.internal.NodeStartup
-
- startShell(dir, runLocalShell, runSSHServer, node) - Method in class net.corda.node.shell.InteractiveShell
-
Starts an interactive shell connected to the local terminal. This shell gives administrator access to the node
internals.
- startTrackedFlowDynamic(logicType, args) - Method in interface net.corda.core.messaging.CordaRPCOps
-
Start the given flow with the given arguments, returning an Observable with a single observation of the
result of running the flow. logicType must be annotated with
interface StartableByRPC
.
- startTrackedFlowDynamic(logicType, args) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Start the given flow with the given arguments, returning an Observable with a single observation of the
result of running the flow. logicType must be annotated with
interface StartableByRPC
.
- State(amount, owner) - Constructor for class net.corda.contracts.asset.Cash.State
-
A state representing a cash claim against some party.
- State(deposit, amount, owner) - Constructor for class net.corda.contracts.asset.Cash.State
-
- State(amount, owner) - Constructor for class net.corda.contracts.asset.CommodityContract.State
-
A state representing a commodity claim against some party
- State(deposit, amount, owner) - Constructor for class net.corda.contracts.asset.CommodityContract.State
-
- State(lifecycle, obligor, template, quantity, beneficiary) - Constructor for class net.corda.contracts.asset.Obligation.State
-
A state representing the obligation of one party (obligor) to deliver a specified number of
units of an underlying asset (described as token.acceptableIssuedProducts) to the beneficiary
no later than the specified time.
- State(issuance, owner, faceValue, maturityDate) - Constructor for class net.corda.contracts.CommercialPaper.State
-
- State(issuance, owner, faceValue, maturityDate) - Constructor for class net.corda.contracts.CommercialPaperLegacy.State
-
- State(buffer, verifyKey) - Constructor for class net.corda.core.crypto.composite.CompositeSignature.State
-
- StateAndRef<T extends ContractState> - Class in net.corda.core.contracts
-
A StateAndRef is simply a (state, ref) pair. For instance, a vault (which holds available assets) contains these.
- StateAndRef(state, ref) - Constructor for class net.corda.core.contracts.StateAndRef
-
A StateAndRef is simply a (state, ref) pair. For instance, a vault (which holds available assets) contains these.
- StateMachineInfo - Class in net.corda.core.messaging
-
- StateMachineInfo(id, flowLogicClassName, initiator, progressTrackerStepAndUpdates) - Constructor for class net.corda.core.messaging.StateMachineInfo
-
- StateMachineManager - Class in net.corda.node.services.statemachine
-
A StateMachineManager is responsible for coordination and persistence of multiple
class FlowStateMachineImpl
objects.
Each such object represents an instantiation of a (two-party) flow that has reached a particular point.
- StateMachineManager(serviceHub, checkpointStorage, executor, database, unfinishedFibers) - Constructor for class net.corda.node.services.statemachine.StateMachineManager
-
A StateMachineManager is responsible for coordination and persistence of multiple
class FlowStateMachineImpl
objects.
Each such object represents an instantiation of a (two-party) flow that has reached a particular point.
- StateMachineManager.Change - Class in net.corda.node.services.statemachine
-
- StateMachineManager.Companion - Class in net.corda.node.services.statemachine
-
- StateMachineManager.FiberScheduler - Class in net.corda.node.services.statemachine
-
- stateMachineRecordedTransactionMapping($this) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
Deprecated.
- stateMachineRecordedTransactionMapping() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Deprecated.
- stateMachineRecordedTransactionMappingFeed() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Returns a snapshot list of existing state machine id - recorded transaction hash mappings, and a stream of future
such mappings as well.
- stateMachineRecordedTransactionMappingFeed() - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Returns a snapshot list of existing state machine id - recorded transaction hash mappings, and a stream of future
such mappings as well.
- StateMachineRecordedTransactionMappingStorage - Interface in net.corda.node.services.api
-
This is the interface to storage storing state machine -> recorded tx mappings. Any time a transaction is recorded
during a flow run addMapping should be called.
- StateMachineRunId - Class in net.corda.core.flows
-
A unique identifier for a single state machine run, valid across node restarts. Note that a single run always
has at least one flow, but that flow may also invoke sub-flows: they all share the same run id.
- StateMachineRunId(uuid) - Constructor for class net.corda.core.flows.StateMachineRunId
-
A unique identifier for a single state machine run, valid across node restarts. Note that a single run always
has at least one flow, but that flow may also invoke sub-flows: they all share the same run id.
- StateMachineRunId.Companion - Class in net.corda.core.flows
-
- stateMachinesAndUpdates($this) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
Deprecated.
- stateMachinesAndUpdates() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Deprecated.
- stateMachinesFeed() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Returns a data feed of currently in-progress state machine infos and an observable of future state machine adds/removes.
- stateMachinesFeed() - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Returns a data feed of currently in-progress state machine infos and an observable of future state machine adds/removes.
- StateMachineTransactionMapping - Class in net.corda.core.messaging
-
- StateMachineTransactionMapping(stateMachineRunId, transactionId) - Constructor for class net.corda.core.messaging.StateMachineTransactionMapping
-
- StateMachineUpdate - Class in net.corda.core.messaging
-
- StateMachineUpdate.Added - Class in net.corda.core.messaging
-
- StateMachineUpdate.Removed - Class in net.corda.core.messaging
-
- StateMetadata(ref, contractStateClassName, recordedTime, consumedTime, status, notaryName, notaryKey, lockId, lockUpdateTime) - Constructor for class net.corda.core.node.services.Vault.StateMetadata
-
- StatePersistable - Interface in net.corda.core.schemas
-
Marker interface to denote a persistable Corda state entity that will always have a transaction id and index
- StateRef - Class in net.corda.core.contracts
-
A stateref is a pointer (reference) to a state, this is an equivalent of an "outpoint" in Bitcoin. It records which
transaction defined the state and where in that transaction it was.
- StateRef(txhash, index) - Constructor for class net.corda.core.contracts.StateRef
-
A stateref is a pointer (reference) to a state, this is an equivalent of an "outpoint" in Bitcoin. It records which
transaction defined the state and where in that transaction it was.
- stateRef($receiver, txIdColumnName, indexColumnName) - Static method in class net.corda.node.utilities.DatabaseSupportKt
-
- StateRefColumns - Class in net.corda.node.utilities
-
- StateRefColumns(txId, index) - Constructor for class net.corda.node.utilities.StateRefColumns
-
- StateRefConverter - Class in net.corda.core.schemas.requery.converters
-
- StateRefConverter() - Constructor for class net.corda.core.schemas.requery.converters.StateRefConverter
-
- StateReplacementException - Exception in net.corda.core.flows
-
- StateReplacementException(message, cause) - Constructor for exception net.corda.core.flows.StateReplacementException
-
- StateReplacementException(message) - Constructor for exception net.corda.core.flows.StateReplacementException
-
- StateReplacementException() - Constructor for exception net.corda.core.flows.StateReplacementException
-
- states(clazzes, statuses, includeSoftLockedStates) - Method in interface net.corda.core.node.services.VaultService
-
Deprecated.
- states(clazzes, statuses, includeSoftLockedStates) - Method in class net.corda.node.services.vault.NodeVaultService
-
- statesForRefs(refs) - Method in interface net.corda.core.node.services.VaultService
-
Deprecated.
- statesForRefs(refs) - Method in class net.corda.node.services.vault.NodeVaultService
-
- StatesNotAvailableException - Exception in net.corda.core.node.services
-
- StatesNotAvailableException(message, cause) - Constructor for exception net.corda.core.node.services.StatesNotAvailableException
-
- StateStatus() - Constructor for enum net.corda.core.node.services.Vault.StateStatus
-
- staticField($receiver, name) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- staticField($receiver, name) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- step(newObject) - Method in class net.corda.core.serialization.carpenter.MetaCarpenterBase
-
- Step(label) - Constructor for class net.corda.core.utilities.ProgressTracker.Step
-
The superclass of all step objects.
- stop() - Method in class net.corda.core.node.services.NotaryService
-
- stop() - Method in class net.corda.node.internal.AbstractNode
-
- stop() - Method in class net.corda.node.internal.Node
-
- stop() - Method in class net.corda.node.services.messaging.ArtemisMessagingServer
-
- stop() - Method in interface net.corda.node.services.messaging.MessagingService
-
Initiates shutdown: if called from a thread that isn't controlled by the executor passed to the constructor
then this will block until all in-flight messages have finished being handled and acknowledged. If called
from a thread that's a part of the
interface AffinityExecutor
given to the constructor,
it returns immediately and shutdown is asynchronous.
- stop() - Method in class net.corda.node.services.messaging.NodeMessagingClient
-
Initiates shutdown: if called from a thread that isn't controlled by the executor passed to the constructor
then this will block until all in-flight messages have finished being handled and acknowledged. If called
from a thread that's a part of the
interface AffinityExecutor
given to the constructor,
it returns immediately and shutdown is asynchronous.
- stop(allowedUnsuspendedFiberCount) - Method in class net.corda.node.services.statemachine.StateMachineManager
-
Start the shutdown process, bringing the
class StateMachineManager
to a controlled stop. When this method returns,
all Fibers have been suspended and checkpointed, or have completed.
- stop() - Method in class net.corda.node.services.transactions.BFTNonValidatingNotaryService
-
- stop() - Method in class net.corda.node.services.transactions.RaftNonValidatingNotaryService
-
- stop() - Method in class net.corda.node.services.transactions.RaftUniquenessProvider
-
- stop() - Method in class net.corda.node.services.transactions.RaftValidatingNotaryService
-
- stop() - Method in class net.corda.node.services.transactions.SimpleNotaryService
-
- stop() - Method in class net.corda.node.services.transactions.ValidatingNotaryService
-
- store($receiver, out, password) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
-
- stream($receiver, parallel) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- stream() - Method in class net.corda.core.utilities.NonEmptySet
-
- string($receiver, meanSize) - Static method in class net.corda.client.mock.GeneratorKt
-
- StringToMethodCallParser<T> - Class in net.corda.jackson
-
This class parses strings in a format designed for human usability into
class StringToMethodCallParser.ParsedMethodCall
objects representing a
ready-to-invoke call on the given target object. The strings accepted by this class are a minor variant of
Yaml and can be easily typed at a command line. Intended use cases include
things like the Corda shell, text-based RPC dispatch, simple scripting and so on.
- StringToMethodCallParser(targetType, om) - Constructor for class net.corda.jackson.StringToMethodCallParser
-
This class parses strings in a format designed for human usability into
class StringToMethodCallParser.ParsedMethodCall
objects representing a
ready-to-invoke call on the given target object. The strings accepted by this class are a minor variant of
Yaml and can be easily typed at a command line. Intended use cases include
things like the Corda shell, text-based RPC dispatch, simple scripting and so on.
- StringToMethodCallParser(targetType) - Constructor for class net.corda.jackson.StringToMethodCallParser
-
This class parses strings in a format designed for human usability into
class StringToMethodCallParser.ParsedMethodCall
objects representing a
ready-to-invoke call on the given target object. The strings accepted by this class are a minor variant of
Yaml and can be easily typed at a command line. Intended use cases include
things like the Corda shell, text-based RPC dispatch, simple scripting and so on.
- StringToMethodCallParser(targetType) - Constructor for class net.corda.jackson.StringToMethodCallParser
-
Same as the regular constructor but takes a Kotlin reflection
KClass instead of a Java
Class.
- StringToMethodCallParser.Companion - Class in net.corda.jackson
-
- StringToMethodCallParser.ParsedMethodCall - Class in net.corda.jackson
-
- StringToMethodCallParser.UnparseableCallException - Exception in net.corda.jackson
-
- Structural(tracker, parent) - Constructor for class net.corda.core.utilities.Change.Structural
-
- StructuresKt - Class in net.corda.core.contracts
-
- SubClass(clazz, superClassSerializer) - Constructor for class net.corda.core.serialization.amqp.CustomSerializer.SubClass
-
This custom serializer represents a sort of symbolic link from a subclass to a super class, where the super
class custom serializer is responsible for the "on the wire" format but we want to create a reference to the
subclass in the schema, so that we can distinguish between subclasses.
- subFlow(subLogic) - Method in class net.corda.core.flows.FlowLogic
-
Invokes the given subflow. This function returns once the subflow completes successfully with the result
returned by that subflow's
FlowLogic.call
method. If the subflow has a progress tracker, it is attached to the
current step in this flow's progress tracker.
- SubjectDelegate(klass, subjectProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.SubjectDelegate
-
- subList(fromIndex, toIndex) - Method in class net.corda.client.jfx.utils.MapValuesList
-
- submitRequest(request) - Method in class net.corda.node.utilities.registration.HTTPNetworkRegistrationService
-
Submits a CSR to the signing service and returns an opaque request ID.
- submitRequest(request) - Method in interface net.corda.node.utilities.registration.NetworkRegistrationService
-
Submits a CSR to the signing service and returns an opaque request ID.
- SubscribeRequest(subscribe, replyTo, sessionID) - Constructor for class net.corda.node.services.network.NetworkMapService.SubscribeRequest
-
- SubscribeResponse(confirmed) - Constructor for class net.corda.node.services.network.NetworkMapService.SubscribeResponse
-
- subSequence(offset, size) - Method in class net.corda.core.utilities.ByteSequence
-
Create a sub-sequence backed by the same array.
- success(generate) - Method in class net.corda.client.mock.Generator.Companion
-
- Success(value) - Constructor for class net.corda.core.utilities.Try.Success
-
- sum(amounts, token) - Method in class net.corda.client.jfx.utils.AmountBindings
-
- sum($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
-
- sum($receiver, groupByColumns, orderBy) - Method in class net.corda.core.node.services.vault.Builder
-
aggregate functions
- sum($receiver, groupByColumns, orderBy) - Static method in class net.corda.core.node.services.vault.Builder
-
- sum($receiver, groupByColumns) - Static method in class net.corda.core.node.services.vault.Builder
-
- sum($receiver) - Static method in class net.corda.core.node.services.vault.Builder
-
- sumAmountExchange(amounts, currency, exchangeRate) - Method in class net.corda.client.jfx.utils.AmountBindings
-
- sumAmountsDue(balances) - Static method in class net.corda.contracts.asset.ObligationKt
-
Calculate the total balance movement for each party in the transaction, based off a summary of balances between
each obligor and beneficiary.
- sumCash($receiver) - Static method in class net.corda.contracts.asset.CashKt
-
Sums the cash states in the list, throwing an exception if there are none, or if any of the cash
states cannot be added together (i.e. are different currencies or issuers).
- sumCashBy($receiver, owner) - Static method in class net.corda.contracts.asset.CashKt
-
Sums the cash states in the list belonging to a single owner, throwing an exception
if there are none, or if any of the cash states cannot be added together (i.e. are
different currencies or issuers).
- sumCashOrNull($receiver) - Static method in class net.corda.contracts.asset.CashKt
-
Sums the cash states in the list, returning null if there are none.
- sumCashOrZero($receiver, currency) - Static method in class net.corda.contracts.asset.CashKt
-
Sums the cash states in the list, returning zero of the given currency+issuer if there are none.
- sumCommodities($receiver) - Static method in class net.corda.contracts.asset.CommodityContractKt
-
Sums the cash states in the list, throwing an exception if there are none, or if any of the cash
states cannot be added together (i.e. are different currencies).
- sumCommoditiesOrNull($receiver) - Static method in class net.corda.contracts.asset.CommodityContractKt
-
Sums the cash states in the list, returning null if there are none.
- sumCommoditiesOrZero($receiver, currency) - Static method in class net.corda.contracts.asset.CommodityContractKt
-
Sums the cash states in the list, returning zero of the given currency if there are none.
- sumFungibleOrNull($receiver) - Static method in class net.corda.core.contracts.FungibleAssetKt
-
Sums the asset states in the list, returning null if there are none.
- sumFungibleOrZero($receiver, token) - Static method in class net.corda.core.contracts.FungibleAssetKt
-
Sums the asset states in the list, returning zero of the given token if there are none.
- sumObligations($receiver) - Static method in class net.corda.contracts.asset.ObligationKt
-
Sums the obligation states in the list, throwing an exception if there are none. All state objects in the list are presumed to be nettable.
- sumObligationsOrNull($receiver) - Static method in class net.corda.contracts.asset.ObligationKt
-
Sums the obligation states in the list, returning null if there are none.
- sumObligationsOrZero($receiver, issuanceDef) - Static method in class net.corda.contracts.asset.ObligationKt
-
Sums the obligation states in the list, returning zero of the given product if there are none.
- sumOrNull($receiver) - Static method in class net.corda.core.contracts.AmountKt
-
- sumOrThrow($receiver) - Static method in class net.corda.core.contracts.AmountKt
-
- sumOrZero($receiver, token) - Static method in class net.corda.core.contracts.AmountKt
-
- supportedSchemas() - Method in class net.corda.contracts.asset.Cash.State
-
Object Relational Mapping support.
- supportedSchemas() - Method in class net.corda.contracts.CommercialPaper.State
-
Object Relational Mapping support.
- supportedSchemas() - Method in interface net.corda.core.schemas.QueryableState
-
Enumerate the schemas this state can export representations of itself as.
- supportsAggressiveRelease() - Method in class net.corda.node.services.database.HibernateConfiguration.NodeDatabaseConnectionProvider
-
- SWISS_FRANCS(amount) - Static method in class net.corda.core.contracts.ContractsDSL
-
- SystemAuditEvent - Class in net.corda.node.services.api
-
Sealed data class to mark system related events as a distinct category.
- SystemAuditEvent(timestamp, principal, description, contextData) - Constructor for class net.corda.node.services.api.SystemAuditEvent
-
Sealed data class to mark system related events as a distinct category.
- validate(data) - Method in interface net.corda.core.utilities.UntrustworthyData.Validator
-
- validateCertificateChain(trustedRoot, certificates) - Method in class net.corda.core.crypto.X509Utilities
-
- validateHandshake(handshake) - Method in class net.corda.flows.TwoPartyDealFlow.Acceptor
-
- validateHandshake(handshake) - Method in class net.corda.flows.TwoPartyDealFlow.Secondary
-
- validateIdentity(otherSide, anonymousOtherSide) - Method in class net.corda.core.flows.TransactionKeyFlow.Companion
-
- validateLegalName(normalizedLegalName) - Static method in class net.corda.core.utilities.LegalNameValidator
-
The validation function will validate the input string using the following rules:
- validateTimeWindow(t) - Method in class net.corda.core.node.services.TrustedAuthorityNotaryService
-
- validateTimeWindow(t) - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
-
- validateTransaction(wtx) - Method in class net.corda.node.services.transactions.ValidatingNotaryFlow
-
- validateType($receiver, classLoaders) - Static method in class net.corda.core.serialization.carpenter.AMQPSchemaExtensionsKt
-
- validateX500Name(x500Name) - Static method in class net.corda.core.utilities.LegalNameValidator
-
- ValidatingNotaryFlow - Class in net.corda.node.services.transactions
-
A notary commit flow that makes sure a given transaction is valid before committing it. This does mean that the calling
party has to reveal the whole transaction history; however, we avoid complex conflict resolution logic where a party
has its input states "blocked" by a transaction from another party, and needs to establish whether that transaction was
indeed valid.
- ValidatingNotaryFlow(otherSide, service) - Constructor for class net.corda.node.services.transactions.ValidatingNotaryFlow
-
A notary commit flow that makes sure a given transaction is valid before committing it. This does mean that the calling
party has to reveal the whole transaction history; however, we avoid complex conflict resolution logic where a party
has its input states "blocked" by a transaction from another party, and needs to establish whether that transaction was
indeed valid.
- ValidatingNotaryService - Class in net.corda.node.services.transactions
-
A Notary service that validates the transaction chain of the submitted transaction before committing it
- ValidatingNotaryService(services) - Constructor for class net.corda.node.services.transactions.ValidatingNotaryService
-
A Notary service that validates the transaction chain of the submitted transaction before committing it
- ValidatingNotaryService.Companion - Class in net.corda.node.services.transactions
-
- value() - Method in interface net.corda.core.flows.InitiatedBy
-
- valueFromDB(value) - Method in class net.corda.node.utilities.CertPathColumnType
-
- valueFromDB(value) - Method in class net.corda.node.utilities.InstantColumnType
-
- valueFromDB(value) - Method in class net.corda.node.utilities.LocalDateColumnType
-
- valueFromDB(value) - Method in class net.corda.node.utilities.LocalDateTimeColumnType
-
- valueFromDB(value) - Method in class net.corda.node.utilities.PublicKeyColumnType
-
- valueFromDB(value) - Method in class net.corda.node.utilities.SecureHashColumnType
-
- valueFromDB(value) - Method in class net.corda.node.utilities.UUIDStringColumnType
-
- valueFromDB(value) - Method in class net.corda.node.utilities.X509CertificateColumnType
-
- valueFromRow(row) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
Implementation should return the value object marshalled from the database table row.
- valueFromRow(row) - Method in class net.corda.node.utilities.JDBCHashMap
-
Implementation should return the value object marshalled from the database table row.
- values() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
-
- values() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
-
- values() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
-
- Vault<T extends ContractState> - Class in net.corda.core.node.services
-
A vault (name may be temporary) wraps a set of states that are useful for us to keep track of, for instance,
because we own them. This class represents an immutable, stable state of a vault: it is guaranteed not to
change out from underneath you, even though the canonical currently-best-known vault may change as we learn
about new transactions from our peers and generate new transactions that consume states ourselves.
- Vault(states) - Constructor for class net.corda.core.node.services.Vault
-
A vault (name may be temporary) wraps a set of states that are useful for us to keep track of, for instance,
because we own them. This class represents an immutable, stable state of a vault: it is guaranteed not to
change out from underneath you, even though the canonical currently-best-known vault may change as we learn
about new transactions from our peers and generate new transactions that consume states ourselves.
- Vault.Companion - Class in net.corda.core.node.services
-
- Vault.Page<T extends ContractState> - Class in net.corda.core.node.services
-
Returned in queries VaultService.queryBy and VaultService.trackBy.
A Page contains:
- Vault.StateMetadata - Class in net.corda.core.node.services
-
- Vault.StateStatus - Enum in net.corda.core.node.services
-
- Vault.Update - Class in net.corda.core.node.services
-
Represents an update observed by the vault that will be notified to observers. Include the
class StateRef
s of
transaction outputs that were consumed (inputs) and the
interface ContractState
s produced (outputs) to/by the transaction
or transactions observed and the vault.
- vaultAndUpdates() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Deprecated.
- vaultAndUpdates() - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Returns a data feed of head states in the vault and an observable of future updates to the vault.
- VaultCustomQueryCriteria(expression, status) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
VaultCustomQueryCriteria: provides query by custom attributes defined in a contracts
QueryableState implementation.
(see Persistence documentation for more information)
- VaultCustomQueryCriteria(expression) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
VaultCustomQueryCriteria: provides query by custom attributes defined in a contracts
QueryableState implementation.
(see Persistence documentation for more information)
- VaultFungibleStates(participants, owner, quantity, issuerParty, issuerRef) - Constructor for class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- VaultFungibleStates(_owner, _quantity, _issuerParty, _issuerRef, _participants) - Constructor for class net.corda.node.services.vault.VaultSchemaV1.VaultFungibleStates
-
- VaultLinearStates(participants, externalId, uuid, dealReference) - Constructor for class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
- VaultLinearStates(uid, _dealReference, _participants) - Constructor for class net.corda.node.services.vault.VaultSchemaV1.VaultLinearStates
-
- vaultQuery($this, contractType) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultQuery(contractType) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- vaultQueryBy(criteria, paging, sorting, contractType) - Method in interface net.corda.core.messaging.CordaRPCOps
-
Returns a snapshot of vault states for a given query criteria (and optional order and paging specification)
- vaultQueryBy(criteria, paging, sorting, contractType) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Returns a snapshot of vault states for a given query criteria (and optional order and paging specification)
- vaultQueryByCriteria($this, criteria, contractType) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultQueryByCriteria(criteria, contractType) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- vaultQueryByWithPagingSpec($this, contractType, criteria, paging) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultQueryByWithPagingSpec(contractType, criteria, paging) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- vaultQueryByWithSorting($this, contractType, criteria, sorting) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultQueryByWithSorting(contractType, criteria, sorting) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- VaultQueryCriteria(status, contractStateTypes, stateRefs, notaryName, includeSoftlockedStates, timeCondition) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- VaultQueryCriteria(status, contractStateTypes, stateRefs, notaryName, includeSoftlockedStates) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- VaultQueryCriteria(status, contractStateTypes, stateRefs, notaryName) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- VaultQueryCriteria(status, contractStateTypes, stateRefs) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- VaultQueryCriteria(status, contractStateTypes) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- VaultQueryCriteria(status) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- VaultQueryCriteria() - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- VaultQueryException - Exception in net.corda.core.node.services
-
- VaultQueryException(description) - Constructor for exception net.corda.core.node.services.VaultQueryException
-
- VaultQueryService - Interface in net.corda.core.node.services
-
- VaultQueryService.DefaultImpls - Class in net.corda.core.node.services
-
- VaultQueryServiceKt - Class in net.corda.core.node.services
-
- VaultSchema - Class in net.corda.node.services.vault
-
JPA representation of the core Vault Schema
- VaultSchemaV1 - Class in net.corda.node.services.vault
-
First version of the Vault ORM schema
- VaultSchemaV1.VaultFungibleStates - Class in net.corda.node.services.vault
-
- VaultSchemaV1.VaultLinearStates - Class in net.corda.node.services.vault
-
- VaultSchemaV1.VaultStates - Class in net.corda.node.services.vault
-
- VaultService - Interface in net.corda.core.node.services
-
A
interface VaultService
is responsible for securely and safely persisting the current state of a vault to storage. The
vault service vends immutable snapshots of the current vault for working with: if you build a transaction based
on a vault that isn't current, be aware that it may end up being invalid if the states that were used have been
consumed by someone else first!
- VaultService.DefaultImpls - Class in net.corda.core.node.services
-
A
interface VaultService
is responsible for securely and safely persisting the current state of a vault to storage. The
vault service vends immutable snapshots of the current vault for working with: if you build a transaction based
on a vault that isn't current, be aware that it may end up being invalid if the states that were used have been
consumed by someone else first!
- VaultServiceKt - Class in net.corda.core.node.services
-
- VaultSoftLockManager - Class in net.corda.node.services.vault
-
- VaultSoftLockManager(vault, smm) - Constructor for class net.corda.node.services.vault.VaultSoftLockManager
-
- VaultStateAttribute(attributeName) - Constructor for enum net.corda.core.node.services.vault.Sort.VaultStateAttribute
-
- VaultStates(notaryName, notaryKey, contractStateClassName, contractState, stateStatus, recordedTime, consumedTime, lockId, lockUpdateTime) - Constructor for class net.corda.node.services.vault.VaultSchemaV1.VaultStates
-
- VaultStateStatusConverter - Class in net.corda.core.schemas.requery.converters
-
- VaultStateStatusConverter() - Constructor for class net.corda.core.schemas.requery.converters.VaultStateStatusConverter
-
- vaultTrack($this, contractType) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultTrack(contractType) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- vaultTrackBy(criteria, paging, sorting, contractType) - Method in interface net.corda.core.messaging.CordaRPCOps
-
Returns a snapshot (as per queryBy) and an observable of future updates to the vault for the given query criteria.
- vaultTrackBy(criteria, paging, sorting, contractType) - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Returns a snapshot (as per queryBy) and an observable of future updates to the vault for the given query criteria.
- vaultTrackByCriteria($this, contractType, criteria) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultTrackByCriteria(contractType, criteria) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- vaultTrackByWithPagingSpec($this, contractType, criteria, paging) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultTrackByWithPagingSpec(contractType, criteria, paging) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- vaultTrackByWithSorting($this, contractType, criteria, sorting) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
- vaultTrackByWithSorting(contractType, criteria, sorting) - Method in interface net.corda.core.messaging.CordaRPCOps
-
- VerificationResultForUnknownTransaction(nonce) - Constructor for exception net.corda.node.services.transactions.OutOfProcessTransactionVerifierService.VerificationResultForUnknownTransaction
-
- verified() - Method in class net.corda.core.crypto.SignedData
-
Return the deserialized data if the signature can be verified.
- verifiedTransactions($this) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
-
Deprecated.
- verifiedTransactions() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Deprecated.
- verifiedTransactionsFeed() - Method in interface net.corda.core.messaging.CordaRPCOps
-
Returns a data feed of all recorded transactions and an observable of future recorded ones.
- verifiedTransactionsFeed() - Method in class net.corda.node.internal.CordaRPCOpsImpl
-
Returns a data feed of all recorded transactions and an observable of future recorded ones.
- VERIFIER_ROLE - Static variable in class net.corda.node.services.messaging.NodeLoginModule
-
- VerifierType - Enum in net.corda.node.services.config
-
- VerifierType() - Constructor for enum net.corda.node.services.config.VerifierType
-
- verify(tx) - Method in class net.corda.contracts.asset.Cash
-
Takes an object that represents a state transition, and ensures the inputs/outputs/commands make sense.
Must throw an exception if there's a problem that should prevent state transition. Takes a single object
rather than an argument so that additional data can be added without breaking binary compatibility with
existing contract code.
- verify(tx) - Method in class net.corda.contracts.asset.CommodityContract
-
Takes an object that represents a state transition, and ensures the inputs/outputs/commands make sense.
Must throw an exception if there's a problem that should prevent state transition. Takes a single object
rather than an argument so that additional data can be added without breaking binary compatibility with
existing contract code.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.asset.Clauses.Net
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.asset.Clauses.SetLifecycle
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.asset.Clauses.Settle
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.asset.Clauses.VerifyLifecycle
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx) - Method in class net.corda.contracts.asset.Obligation
-
Takes an object that represents a state transition, and ensures the inputs/outputs/commands make sense.
Must throw an exception if there's a problem that should prevent state transition. Takes a single object
rather than an argument so that additional data can be added without breaking binary compatibility with
existing contract code.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.clause.AbstractConserveAmount
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.clause.AbstractIssue
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.clause.NetClause
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.clause.NoZeroSizedOutputs
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.Clauses.Issue
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.Clauses.Move
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.contracts.Clauses.Redeem
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx) - Method in class net.corda.contracts.CommercialPaper
-
Takes an object that represents a state transition, and ensures the inputs/outputs/commands make sense.
Must throw an exception if there's a problem that should prevent state transition. Takes a single object
rather than an argument so that additional data can be added without breaking binary compatibility with
existing contract code.
- verify(tx) - Method in class net.corda.contracts.CommercialPaperLegacy
-
Takes an object that represents a state transition, and ensures the inputs/outputs/commands make sense.
Must throw an exception if there's a problem that should prevent state transition. Takes a single object
rather than an argument so that additional data can be added without breaking binary compatibility with
existing contract code.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.clauses.AllOf
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.clauses.AnyOf
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.clauses.Clause
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.clauses.FilterOn
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.clauses.FirstComposition
-
Deprecated.
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.clauses.FirstOf
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.clauses.GroupClauseVerifier
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx) - Method in interface net.corda.core.contracts.Contract
-
Takes an object that represents a state transition, and ensures the inputs/outputs/commands make sense.
Must throw an exception if there's a problem that should prevent state transition. Takes a single object
rather than an argument so that additional data can be added without breaking binary compatibility with
existing contract code.
- verify(tx, inputs, outputs, commands, groupingKey) - Method in class net.corda.core.contracts.LinearState.ClauseVerifier
-
Verify the transaction matches the conditions from this clause. For example, a "no zero amount output" clause
would check each of the output states that it applies to, looking for a zero amount, and throw IllegalStateException
if any matched.
- verify(tx) - Method in class net.corda.core.contracts.TransactionType
-
Check that the transaction is valid based on:
- verify($receiver, content, signature) - Static method in class net.corda.core.crypto.CryptoUtils
-
Utility to simplify the act of verifying a signature.
- verify($receiver, signatureData, clearData) - Static method in class net.corda.core.crypto.CryptoUtils
-
Helper function to verify a signature.
- verify($receiver, transactionSignature) - Static method in class net.corda.core.crypto.CryptoUtils
-
Helper function to verify a metadata attached signature. It is noted that the transactionSignature contains
signatureData and a
class MetaData
object that contains the signer's public key and the transaction's Merkle root.
- verify($receiver, signatureData, clearData) - Static method in class net.corda.core.crypto.CryptoUtils
-
Helper function for the signers to verify their own signature.
- verify(content) - Method in class net.corda.core.crypto.DigitalSignature.WithKey
-
Utility to simplify the act of verifying a signature.
- verify(content) - Method in class net.corda.core.crypto.DigitalSignature.WithKey
-
Utility to simplify the act of verifying a signature.
- verify(merkleRootHash, hashesToCheck) - Method in class net.corda.core.crypto.PartialMerkleTree
-
- verify() - Method in class net.corda.core.crypto.TransactionSignature
-
Function to auto-verify a
class MetaData
object's signature.
Note that
class MetaData
contains both public key and merkle root of the transaction.
- verify(tx) - Method in class net.corda.core.flows.ContractUpgradeFlow.Companion
-
- verify(input, output, commandData) - Method in class net.corda.core.flows.ContractUpgradeFlow.Companion
-
- verify(tx) - Static method in class net.corda.core.flows.ContractUpgradeFlow
-
- verify(input, output, commandData) - Static method in class net.corda.core.flows.ContractUpgradeFlow
-
- verify(transaction) - Method in interface net.corda.core.node.services.TransactionVerifierService
-
- verify() - Method in class net.corda.core.transactions.FilteredTransaction
-
Runs verification of Partial Merkle Branch against rootHash.
- verify() - Method in class net.corda.core.transactions.LedgerTransaction
-
Verifies this transaction and throws an exception if not valid, depending on the type. For general transactions:
- verify(services, checkSufficientSignatures) - Method in class net.corda.core.transactions.SignedTransaction
-
- verify(services) - Method in class net.corda.core.transactions.SignedTransaction
-
- verify(services) - Method in class net.corda.core.transactions.TransactionBuilder
-
- verify(transaction) - Method in class net.corda.node.services.transactions.InMemoryTransactionVerifierService
-
- verify(transaction) - Method in class net.corda.node.services.transactions.OutOfProcessTransactionVerifierService
-
- verifyAndRegisterAnonymousIdentity(anonymousIdentity, wellKnownIdentity) - Method in interface net.corda.core.node.services.IdentityService
-
Verify and then store an anonymous identity.
- verifyAndRegisterAnonymousIdentity(anonymousIdentity, wellKnownIdentity) - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
Verify and then store an anonymous identity.
- verifyAnonymousIdentity(anonymousIdentity, party) - Method in interface net.corda.core.node.services.IdentityService
-
Verify an anonymous identity.
- verifyAnonymousIdentity(anonymousIdentity, party) - Method in class net.corda.node.services.identity.InMemoryIdentityService
-
Verify an anonymous identity.
- verifyClause(tx, clause, commands) - Static method in class net.corda.core.contracts.clauses.ClauseVerifier
-
Verify a transaction against the given list of clauses.
- verifyData(data) - Method in class net.corda.core.crypto.SignedData
-
Verify the wrapped data after the signature has been verified and the data deserialised. Provided as an extension
point for subclasses.
- verifyData(data) - Method in class net.corda.node.services.network.WireNodeRegistration
-
Verify the wrapped data after the signature has been verified and the data deserialised. Provided as an extension
point for subclasses.
- VerifyingNettyConnectorFactory - Class in net.corda.node.services.messaging
-
- VerifyingNettyConnectorFactory() - Constructor for class net.corda.node.services.messaging.VerifyingNettyConnectorFactory
-
- VerifyLifecycle() - Constructor for class net.corda.contracts.asset.Clauses.VerifyLifecycle
-
Obligation-specific clause for verifying that all states are in
normal lifecycle. In a group clause set, this must be run after
any lifecycle change clause, which is the only clause that involve
non-standard lifecycle states on input/output.
- verifyNetCommand(inputs, outputs, command, netState) - Method in class net.corda.contracts.clause.NetClause
-
Verify a netting command. This handles both close-out and payment netting.
- verifyProposal(proposal) - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Acceptor
-
Check the state change proposal to confirm that it's acceptable to this node. Rules for verification depend
on the change proposed, and may further depend on the node itself (for example configuration). The
proposal is returned if acceptable, otherwise a
exception StateReplacementException
is thrown.
- verifyProposal(proposal) - Method in class net.corda.node.services.ContractUpgradeHandler
-
Check the state change proposal to confirm that it's acceptable to this node. Rules for verification depend
on the change proposed, and may further depend on the node itself (for example configuration). The
proposal is returned if acceptable, otherwise a
exception StateReplacementException
is thrown.
- verifyProposal(proposal) - Method in class net.corda.node.services.NotaryChangeHandler
-
Check the notary change proposal.
- verifyRequiredSignatures() - Method in class net.corda.core.transactions.SignedTransaction
-
Verifies the signatures on this transaction and throws if any are missing. In this context, "verifying" means
checking they are valid signatures and that their public keys are in the contained transactions
BaseTransaction.mustSign property.
- verifySignaturesExcept(allowedToBeMissing) - Method in class net.corda.core.transactions.SignedTransaction
-
Verifies the signatures on this transaction and throws if any are missing which aren't passed as parameters.
In this context, "verifying" means checking they are valid signatures and that their public keys are in
the contained transactions BaseTransaction.mustSign property.
- verifySigners(tx) - Method in class net.corda.core.contracts.TransactionType
-
Check that the list of signers includes all the necessary keys
- verifyTransaction(tx) - Method in class net.corda.core.contracts.TransactionType.General
-
Implement type specific transaction validation logic
- verifyTransaction(tx) - Method in class net.corda.core.contracts.TransactionType.NotaryChange
-
Check that the difference between inputs and outputs is only the notary field, and that all required signing
public keys are present.
- verifyTransaction(tx) - Method in class net.corda.core.contracts.TransactionType
-
Implement type specific transaction validation logic
- version() - Method in interface net.corda.core.flows.InitiatingFlow
-
- VersionInfo - Class in net.corda.node
-
Encapsulates various pieces of version information of the node.
- VersionInfo(platformVersion, releaseVersion, revision, vendor) - Constructor for class net.corda.node.VersionInfo
-
Encapsulates various pieces of version information of the node.
- visit(parser) - Method in class net.corda.core.node.services.vault.QueryCriteria.CommonQueryCriteria
-
- visit(parser) - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
-
- visit(parser) - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
-
- visit(parser) - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
-
- visit(parser) - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
-
- visit(parser) - Method in class net.corda.core.node.services.vault.QueryCriteria
-
- visitParameter(mv, idx) - Method in class net.corda.core.serialization.carpenter.Field
-