Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 

A

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
An class AbstractParty contains the common elements of class Party and class AnonymousParty, specifically the owning key of the party. In most cases class Party or class AnonymousParty should be used, depending on use-case.
AbstractParty(owningKey) - Constructor for class net.corda.core.identity.AbstractParty
An class AbstractParty contains the common elements of class Party and class AnonymousParty, specifically the owning key of the party. In most cases class Party or class AnonymousParty should be used, depending on use-case.
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
The class AbstractStateReplacementFlow.Instigator assembles the transaction for state replacement and sends out change proposals to all participants (class AbstractStateReplacementFlow.Acceptor) of that state. If participants agree to the proposed change, they each sign the transaction. Finally, class AbstractStateReplacementFlow.Instigator sends the transaction containing all participants' signatures to the notary for signature, and then back to each participant so they can record it and use the new updated state for future transactions.
AbstractStateReplacementFlow.Proposal<M> - Class in net.corda.core.flows
The class AbstractStateReplacementFlow.Proposal contains the details of proposed state modification. This is the message sent by the class AbstractStateReplacementFlow.Instigator to all participants(class AbstractStateReplacementFlow.Acceptor) during the state replacement process.
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
Helper method to append an additional signature to an existing (partially) class SignedTransaction.
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
Helper method to append an additional signature to an existing (partially) class SignedTransaction.
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.

B

banJavaSerialisation(conf) - Method in class net.corda.node.internal.NodeStartup
 
base58toBase64($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Encoding changer. Base58-String to Base64-String, i.e. "SGVsbG8gV29ybGQ=" -> JxF12TrwUP45BMd"
base58ToByteArray($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
 
base58toHex($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Encoding changer. Base58-String to Hex-String, i.e. "SGVsbG8gV29ybGQ=" -> "48656C6C6F20576F726C64"
base58ToRealString($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Base58-String to the actual real String, i.e. "JxF12TrwUP45BMd" -> "Hello World".
base64toBase58($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Encoding changer. Base64-String to Base58-String, i.e. "SGVsbG8gV29ybGQ=" -> JxF12TrwUP45BMd"
base64ToByteArray($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
 
base64toHex($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Encoding changer. Base64-String to Hex-String, i.e. "SGVsbG8gV29ybGQ=" -> "48656C6C6F20576F726C64"
base64ToRealString($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Base64-String to the actual real String, i.e. "SGVsbG8gV29ybGQ=" -> "Hello World".
BaseTransaction - Class in net.corda.core.transactions
An abstract class defining fields shared by all transaction types in the system.
BaseTransaction(inputs, outputs, notary, mustSign, type, timeWindow) - Constructor for class net.corda.core.transactions.BaseTransaction
An abstract class defining fields shared by all transaction types in the system.
between($receiver, parties) - Static method in class net.corda.contracts.asset.ObligationKt
 
between(fromTime, untilTime) - Static method in class net.corda.core.contracts.TimeWindow
Creates a class TimeWindow with the time interval [fromTime, untilTime). midpoint will return fromTime + (untilTime - fromTime) / 2.
between(fromTime, untilTime) - Method in class net.corda.core.contracts.TimeWindow.Companion
Creates a class TimeWindow with the time interval [fromTime, untilTime). midpoint will return fromTime + (untilTime - fromTime) / 2.
between($receiver, from, to) - Method in class net.corda.core.node.services.vault.Builder
 
between($receiver, from, to) - Static method in class net.corda.core.node.services.vault.Builder
 
between(from, to) - Method in class net.corda.core.node.services.vault.Builder
 
Between(rightFromLiteral, rightToLiteral) - Constructor for class net.corda.core.node.services.vault.ColumnPredicate.Between
 
BFTNonValidatingNotaryService - Class in net.corda.node.services.transactions
A non-validating notary service operated by a group of parties that don't necessarily trust each other.
BFTNonValidatingNotaryService(services) - Constructor for class net.corda.node.services.transactions.BFTNonValidatingNotaryService
A non-validating notary service operated by a group of parties that don't necessarily trust each other.
BFTNonValidatingNotaryService.Companion - Class in net.corda.node.services.transactions
 
BFTSMaRt - Class in net.corda.node.services.transactions
Implements a replicated transaction commit log based on the BFT-SMaRt consensus algorithm. Every replica in the cluster is running a class BFTSMaRt.Replica maintaining the state, and a class BFTSMaRt.Client is used to relay state modification requests to all class BFTSMaRt.Replicas.
BFTSMaRt.Client - Class in net.corda.node.services.transactions
 
BFTSMaRt.ClusterResponse - Class in net.corda.node.services.transactions
An aggregate response from all replica (class BFTSMaRt.Replica) replies sent from class BFTSMaRt.Client back to the calling application.
BFTSMaRt.CommitRequest - Class in net.corda.node.services.transactions
BFTSMaRt.Replica - Class in net.corda.node.services.transactions
Maintains the commit log and executes commit commands received from the class BFTSMaRt.Client.
BFTSMaRt.ReplicaResponse - Class in net.corda.node.services.transactions
BFTSMaRtConfig - Class in net.corda.node.services.transactions
BFT SMaRt can only be configured via files in a configHome directory. Each instance of this class creates such a configHome, accessible via path. The files are deleted on PathManager.close typically via use, see class PathManager for details.
BFTSMaRtConfig(replicaAddresses, debug) - Constructor for class net.corda.node.services.transactions.BFTSMaRtConfig
BFT SMaRt can only be configured via files in a configHome directory. Each instance of this class creates such a configHome, accessible via path. The files are deleted on PathManager.close typically via use, see class PathManager for details.
BFTSMaRtConfig.Companion - Class in net.corda.node.services.transactions
 
BFTSMaRtConfigKt - Class in net.corda.node.services.transactions
 
bftSMaRtSerialFilter(clazz) - Static method in class net.corda.node.services.transactions.BFTSMaRtConfigKt
 
BigDecimalSerializer - Class in net.corda.core.serialization.amqp.custom
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.
BilateralNetState<P> - Class in net.corda.contracts.clause
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.
BilateralNetState(partyKeys, template) - Constructor for 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.
BilateralNettableState<N extends BilateralNettableState<N>> - Interface in net.corda.contracts
Interface for state objects that support being netted with other state objects.
BinaryComparison(operator, rightLiteral) - Constructor for class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
 
BinaryComparisonOperator - Enum in net.corda.core.node.services.vault
 
BinaryComparisonOperator() - Constructor for enum net.corda.core.node.services.vault.BinaryComparisonOperator
 
BinaryLogical(left, right, operator) - Constructor for class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
 
BinaryLogicalOperator - Enum in net.corda.core.node.services.vault
 
BinaryLogicalOperator() - Constructor for enum net.corda.core.node.services.vault.BinaryLogicalOperator
 
bind($receiver, function) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
data class Person(val height: ObservableValue) val person: ObservableValue = (..) val personHeight: ObservableValue = person.bind { it.height }
bindOut($receiver, function) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
A variant of bind that has out variance on the output type. This is sometimes useful when kotlin is too eager to propagate variance constraints and type inference fails.
BlobConverter - Class in net.corda.core.schemas.requery.converters
Converts from a ByteArray to a Blob.
BlobConverter() - Constructor for class net.corda.core.schemas.requery.converters.BlobConverter
Converts from a ByteArray to a Blob.
BlobMapTable(tableName) - Constructor for class net.corda.node.utilities.JDBCHashMap.BlobMapTable
 
BlobSetTable(tableName) - Constructor for class net.corda.node.utilities.JDBCHashSet.BlobSetTable
 
borrow() - Method in class net.corda.core.internal.LazyPool
 
borrow(stickTo) - Method in class net.corda.core.internal.LazyStickyPool
 
borrow() - Method in class net.corda.core.internal.LazyStickyPool
 
Boundary(txId) - Constructor for class net.corda.node.utilities.DatabaseTransactionManager.Boundary
 
broadcastTransaction(stx, participants) - Method in class net.corda.core.flows.FinalityFlow
Broadcast a transaction to the participants. By default calls class BroadcastTransactionFlow, however can be overridden for more complex transaction delivery protocols (for example where not all parties know each other). This implementation will filter out any participants for whom there is no well known identity.
BroadcastTransactionFlow - Class in net.corda.core.flows
Notify the specified parties about a transaction. The remote peers will download this transaction and its dependency graph, verifying them all. The flow returns when all peers have acknowledged the transactions as valid. Normally you wouldn't use this directly, it would be called via class FinalityFlow.
BroadcastTransactionFlow(notarisedTransaction, participants) - Constructor for class net.corda.core.flows.BroadcastTransactionFlow
Notify the specified parties about a transaction. The remote peers will download this transaction and its dependency graph, verifying them all. The flow returns when all peers have acknowledged the transactions as valid. Normally you wouldn't use this directly, it would be called via class FinalityFlow.
BroadcastTransactionFlow.NotifyTxRequest - Class in net.corda.core.flows
 
bufferUntilDatabaseCommit($receiver) - Static method in class net.corda.node.utilities.CordaPersistenceKt
Buffer observations until after the current database transaction has been closed. Observations are never dropped, simply delayed.
bufferUntilSubscribed($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
Returns an Observable that buffers events until subscribed.
build(threshold) - Method in class net.corda.core.crypto.composite.CompositeKey.Builder
Builds the class CompositeKey. If threshold is not specified, it will default to the total (aggregated) weight of the children, effectively generating an "N of N" requirement. During process removes single keys wrapped in class CompositeKey and enforces ordering on child nodes.
build(signatureScheme, privateKey, provider, random) - Method in class net.corda.core.crypto.ContentSignerBuilder
 
build(merkleRoot, includeHashes) - Method in class net.corda.core.crypto.PartialMerkleTree.Companion
 
build(schema) - Method in class net.corda.core.serialization.carpenter.ClassCarpenter
Generate bytecode for the given schema and load into the JVM. The returned class object can be used to construct instances of the generated class.
build() - Method in class net.corda.core.serialization.carpenter.MetaCarpenter
 
build() - Method in class net.corda.core.serialization.carpenter.MetaCarpenterBase
 
build() - Method in class net.corda.core.serialization.carpenter.TestMetaCarpenter
 
Builder(notary) - Constructor for class net.corda.core.contracts.General.Builder
Just uses the default class TransactionBuilder with no special logic
Builder(notary) - Constructor for class net.corda.core.contracts.NotaryChange.Builder
A transaction builder that automatically sets the transaction type to class TransactionType.NotaryChange and adds the list of participants to the signers set for every input state.
Builder() - Constructor for class net.corda.core.crypto.composite.CompositeKey.Builder
A helper class for building a class CompositeKey.
Builder - Class in net.corda.core.node.services.vault
 
builder(block) - Static method in class net.corda.core.node.services.vault.QueryCriteriaUtils
 
buildFilteredTransaction(filtering) - Method in class net.corda.core.transactions.WireTransaction
Build filtered transaction using provided filtering functions.
buildKeystore() - Method in class net.corda.node.utilities.registration.NetworkRegistrationHelper
 
buildMerkleTransaction(wtx, filtering) - Static method in class net.corda.core.transactions.FilteredTransaction
Construction of filtered transaction with Partial Merkle Tree.
buildMerkleTransaction(wtx, filtering) - Method in class net.corda.core.transactions.FilteredTransaction.Companion
Construction of filtered transaction with Partial Merkle Tree.
BuiltInExceptionsWhitelist - Class in net.corda.core.serialization
 
BuiltInExceptionsWhitelist() - Constructor for class net.corda.core.serialization.BuiltInExceptionsWhitelist
 
BusinessCalendar - Class in net.corda.contracts
A business calendar performs date calculations that take into account national holidays and weekends. This is a typical feature of financial contracts, in which a business may not want a payment event to fall on a day when no staff are around to handle problems.
BusinessCalendar(holidayDates) - Constructor for class net.corda.contracts.BusinessCalendar
A business calendar performs date calculations that take into account national holidays and weekends. This is a typical feature of financial contracts, in which a business may not want a payment event to fall on a day when no staff are around to handle problems.
BusinessCalendar.Companion - Class in net.corda.contracts
 
BusinessCalendar.UnknownCalendar - Exception in net.corda.contracts
 
BusinessCalendarWrapper(holidayDates) - Constructor for class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
 
Buyer(otherParty, notary, acceptablePrice, typeToBuy) - Constructor for class net.corda.flows.TwoPartyTradeFlow.Buyer
 
Buyer.COLLECTING_SIGNATURES - Class in net.corda.flows
 
Buyer.RECEIVING - Class in net.corda.flows
 
Buyer.RECORDING - Class in net.corda.flows
 
Buyer.SIGNING - Class in net.corda.flows
 
Buyer.VERIFYING - Class in net.corda.flows
 
by($receiver, expr) - Method in class net.corda.core.contracts.Requirements
Deprecated. 
byKeys($receiver) - Static method in class net.corda.core.crypto.CryptoUtils
Returns the set of all PublicKeys of the signatures
ByteArrays - Class in net.corda.core.utilities
 
bytes($receiver, size) - Static method in class net.corda.client.mock.GeneratorKt
 
bytes() - Method in class net.corda.core.crypto.MetaData
 
ByteSequence - Class in net.corda.core.utilities
An abstraction of a byte array, with offset and size that does no copying of bytes unless asked to.
ByteSequence.Companion - Class in net.corda.core.utilities
 
bytesFromBlob(blob) - Static method in class net.corda.node.utilities.JDBCHashMapKt
 
bytesToBlob(value, finalizables) - Static method in class net.corda.node.utilities.JDBCHashMapKt
 

C

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 CompositeKeys.
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
The class CollectSignaturesFlow is used to automate the collection of counter-party signatures for a given transaction.
CollectSignaturesFlow(partiallySignedTx, progressTracker) - Constructor for class net.corda.core.flows.CollectSignaturesFlow
The class CollectSignaturesFlow is used to automate the collection of counter-party signatures for a given transaction.
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
Maps the given function to the values from this class Try.Success and other, or returns this if this is a class Try.Failure or other if other is a class Try.Failure.
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
Helper to simplify getting all class Command items with a interface CommandData of a particular class, interface, or base class.
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
An object used to fully qualify the class CommercialPaperSchema family name (i.e. independent of version).
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
A helper class for building a class CompositeKey.
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
Dedicated class for storing a set of signatures that comprise class CompositeKey.
CompositeSignature() - Constructor for class net.corda.core.crypto.composite.CompositeSignature
Dedicated class for storing a set of signatures that comprise class CompositeKey.
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
class PartiallyResolvedTransaction holds a class SignedTransaction that has zero or more inputs resolved. The intent is to prepare clients for cases where an input can only be resolved in the future/cannot be resolved at all (for example because of permissioning)
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
The class AbstractStateReplacementFlow.Proposal contains the details of proposed state modification. This is the message sent by the class AbstractStateReplacementFlow.Instigator to all participants(class AbstractStateReplacementFlow.Acceptor) during the state replacement process.
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
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
copy(participants, linearId, dealRef, status) - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
LinearStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultLinearState
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
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
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 StateRefs of transaction outputs that were consumed (inputs) and the interface ContractStates 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
Embedded class StateRef representation used in state mapping.
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
An identifier for the endpoint interface MessagingService message handlers listen at.
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 is the factory of class MapValuesList.
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
Helper method to create an additional signature for an existing (partially) class SignedTransaction.
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
Helper method to create an additional signature for an existing (partially) class SignedTransaction.
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
Interpolates values between the given data points using a class SplineFunction.
CubicSplineInterpolator(xs, ys) - Constructor for class net.corda.contracts.math.CubicSplineInterpolator
Interpolates values between the given data points using a class SplineFunction.
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
Return the current class FlowStateMachineImpl or null if executing outside of one.
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
Additional base features over and above class CustomSerializer.Implements or class CustomSerializer.Is custom serializer for when the serialized form should be the serialized form of a proxy class, and the object can be re-created from that proxy on deserialization.
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.

D

database - Variable in class net.corda.node.internal.AbstractNode
 
database - Variable in class net.corda.node.utilities.CordaPersistence
Holds Exposed database, the field will be removed once Exposed library is removed
DatabaseConfigurationException(msg) - Constructor for exception net.corda.node.internal.AbstractNode.DatabaseConfigurationException
 
DatabaseSupportKt - Class in net.corda.node.utilities
 
DatabaseTransaction - Class in net.corda.node.utilities
 
DatabaseTransaction(isolation, threadLocal, transactionBoundaries, cordaPersistence) - Constructor for class net.corda.node.utilities.DatabaseTransaction
 
DatabaseTransactionManager - Class in net.corda.node.utilities
 
DatabaseTransactionManager(initDataSource) - Constructor for class net.corda.node.utilities.DatabaseTransactionManager
 
DatabaseTransactionManager.Boundary - Class in net.corda.node.utilities
 
DatabaseTransactionManager.Companion - Class in net.corda.node.utilities
 
DataFeed<A,B> - Class in net.corda.core.messaging
The Data feed contains a snapshot of the requested data and an Observable of future updates.
DataFeed(snapshot, updates) - Constructor for class net.corda.core.messaging.DataFeed
The Data feed contains a snapshot of the requested data and an Observable of future updates.
DateRollConvention - Enum in net.corda.contracts
This reflects what happens if a date on which a business event is supposed to happen actually falls upon a non-working day. Depending on the accounting requirement, we can move forward until we get to a business day, or backwards. There are some additional rules which are explained in the individual cases below.
DateRollConvention(direction, isModified) - Constructor for enum net.corda.contracts.DateRollConvention
This reflects what happens if a date on which a business event is supposed to happen actually falls upon a non-working day. Depending on the accounting requirement, we can move forward until we get to a business day, or backwards. There are some additional rules which are explained in the individual cases below.
DateRollDirection - Enum in net.corda.contracts
This is utilised in the enum DateRollConvention class to determine which way we should initially step when finding a business day.
DateRollDirection(value) - Constructor for enum net.corda.contracts.DateRollDirection
This is utilised in the enum DateRollConvention class to determine which way we should initially step when finding a business day.
DayCountBasisDay - Enum in net.corda.contracts
This forms the day part of the "Day Count Basis" used for interest calculation. Note that the first character cannot be a number (enum naming constraints), so we drop that in the toString lest some people get confused.
DayCountBasisDay() - Constructor for enum net.corda.contracts.DayCountBasisDay
This forms the day part of the "Day Count Basis" used for interest calculation. Note that the first character cannot be a number (enum naming constraints), so we drop that in the toString lest some people get confused.
DayCountBasisYear - Enum in net.corda.contracts
This forms the year part of the "Day Count Basis" used for interest calculation.
DayCountBasisYear() - Constructor for enum net.corda.contracts.DayCountBasisYear
This forms the year part of the "Day Count Basis" used for interest calculation.
daysToMaturity(startDate, calendar) - Method in class net.corda.contracts.Tenor
 
DBCheckpointStorage - Class in net.corda.node.services.persistence
Simple checkpoint key value storage in DB using the underlying JDBCHashMap and transactional context of the call sites.
DBCheckpointStorage() - Constructor for class net.corda.node.services.persistence.DBCheckpointStorage
Simple checkpoint key value storage in DB using the underlying JDBCHashMap and transactional context of the call sites.
DBTransactionMappingStorage - Class in net.corda.node.services.persistence
Database storage of a txhash -> state machine id mapping.
DBTransactionMappingStorage() - Constructor for class net.corda.node.services.persistence.DBTransactionMappingStorage
Database storage of a txhash -> state machine id mapping.
DBTransactionStorage - Class in net.corda.node.services.persistence
 
DBTransactionStorage() - Constructor for class net.corda.node.services.persistence.DBTransactionStorage
 
DealState - Interface in net.corda.contracts
Interface representing an agreement that exposes various attributes that are common. Implementing it simplifies implementation of general flows that manipulate many agreement types.
deauthoriseContractUpgrade(state) - Method in interface net.corda.core.messaging.CordaRPCOps
Authorise a contract state upgrade. This will remove the upgrade authorisation from the vault.
deauthoriseContractUpgrade(stateAndRef) - Method in interface net.corda.core.node.services.VaultService
Authorise a contract state upgrade. This will remove the upgrade authorisation from the vault.
deauthoriseContractUpgrade(state) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Authorise a contract state upgrade. This will remove the upgrade authorisation from the vault.
deauthoriseContractUpgrade(stateAndRef) - Method in class net.corda.node.services.vault.NodeVaultService
Authorise a contract state upgrade. This will remove the upgrade authorisation from the vault.
debug($receiver, msg) - Static method in class net.corda.core.utilities.KotlinUtilsKt
Log a DEBUG level message produced by evaluating the given lamdba, but only if DEBUG logging is enabled.
DeclaredField<T> - Class in net.corda.core.internal
A simple wrapper around a Field object providing type safe read and write access using value, ignoring the field's visibility.
DeclaredField(clazz, name, receiver) - Constructor for class net.corda.core.internal.DeclaredField
A simple wrapper around a Field object providing type safe read and write access using value, ignoring the field's visibility.
declaredField($receiver, name) - Static method in class net.corda.core.internal.InternalUtilsKt
Returns a class DeclaredField wrapper around the declared (possibly non-public) instance field of the receiver object.
declaredField($receiver, clazz, name) - Static method in class net.corda.core.internal.InternalUtilsKt
Returns a class DeclaredField wrapper around the (possibly non-public) instance field of the receiver object, but declared in its superclass clazz.
decodePrivateKey(encodedKey) - Method in class net.corda.core.crypto.Crypto
Decode a PKCS8 encoded key to its PrivateKey object. Use this method if the key type is a-priori unknown.
decodePrivateKey(schemeCodeName, encodedKey) - Method in class net.corda.core.crypto.Crypto
Decode a PKCS8 encoded key to its PrivateKey object based on the input scheme code name. This should be used when the type key is known, e.g. during Kryo deserialisation or with key caches or key managers.
decodePrivateKey(signatureScheme, encodedKey) - Method in class net.corda.core.crypto.Crypto
Decode a PKCS8 encoded key to its PrivateKey object based on the input scheme code name. This should be used when the type key is known, e.g. during Kryo deserialisation or with key caches or key managers.
decodePublicKey(encodedKey) - Method in class net.corda.core.crypto.Crypto
Decode an X509 encoded key to its PublicKey object. Use this method if the key type is a-priori unknown.
decodePublicKey(schemeCodeName, encodedKey) - Method in class net.corda.core.crypto.Crypto
Decode an X509 encoded key to its PrivateKey object based on the input scheme code name. This should be used when the type key is known, e.g. during Kryo deserialisation or with key caches or key managers.
decodePublicKey(signatureScheme, encodedKey) - Method in class net.corda.core.crypto.Crypto
Decode an X509 encoded key to its PrivateKey object based on the input scheme code name. This should be used when the type key is known, e.g. during Kryo deserialisation or with key caches or key managers.
DEFAULT_PAGE_NUM - Static variable in class net.corda.core.node.services.vault.QueryCriteriaUtils
Pagination and Ordering
DEFAULT_PAGE_SIZE - Static variable in class net.corda.core.node.services.vault.QueryCriteriaUtils
 
DefaultKryoCustomizer - Class in net.corda.core.serialization
 
deleteIfExists($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
 
deregisterForUpdates(network, service) - Method in interface net.corda.node.services.api.NetworkMapCacheInternal
Deregister from updates from the given map service.
deregisterForUpdates(network, service) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
Unsubscribes from updates from the given map service.
DeregistrationFailed() - Constructor for exception net.corda.node.services.api.NetworkCacheError.DeregistrationFailed
Indicates a failure to deregister, because of a rejected request from the remote node
deriveKeyPair(signatureScheme, privateKey, seed) - Method in class net.corda.core.crypto.Crypto
Deterministically generate/derive a KeyPair using an existing private key and a seed as inputs. This operation is currently supported for ECDSA secp256r1 (NIST P-256), ECDSA secp256k1 and EdDSA ed25519.
deriveKeyPair(privateKey, seed) - Method in class net.corda.core.crypto.Crypto
Deterministically generate/derive a KeyPair using an existing private key and a seed as inputs. Use this method if the class SignatureScheme of the private key input is not known.
deriveKeyPairFromEntropy(signatureScheme, entropy) - Method in class net.corda.core.crypto.Crypto
Returns a key pair derived from the given BigInteger entropy. This is useful for unit tests and other cases where you want hard-coded private keys. Currently, EDDSA_ED25519_SHA512 is the sole scheme supported for this operation.
deriveKeyPairFromEntropy(entropy) - Method in class net.corda.core.crypto.Crypto
Returns a DEFAULT_SIGNATURE_SCHEME key pair derived from the given BigInteger entropy.
deriveState(txState, amount, owner) - Method in class net.corda.contracts.asset.Cash
Derive a new transaction state based on the given example, with amount and owner modified. This allows concrete implementations to have fields in their state which we don't know about here, and we simply leave them untouched when sending out "change" from spending/exiting.
deriveState(txState, amount, owner) - Method in class net.corda.contracts.asset.CommodityContract
Derive a new transaction state based on the given example, with amount and owner modified. This allows concrete implementations to have fields in their state which we don't know about here, and we simply leave them untouched when sending out "change" from spending/exiting.
deriveState(txState, amount, owner) - Method in class net.corda.contracts.asset.OnLedgerAsset
Derive a new transaction state based on the given example, with amount and owner modified. This allows concrete implementations to have fields in their state which we don't know about here, and we simply leave them untouched when sending out "change" from spending/exiting.
DescribedTypePropertySerializer(name, readMethod, resolvedType, lazyTypeSerializer) - Constructor for class net.corda.core.serialization.amqp.PropertySerializer.DescribedTypePropertySerializer
A property serializer for a complex type (another object).
Descriptor - Class in net.corda.core.serialization.amqp
 
Descriptor(name, code) - Constructor for class net.corda.core.serialization.amqp.Descriptor
 
Descriptor.Companion - Class in net.corda.core.serialization.amqp
 
descriptorsIncludingSuperclasses() - Method in class net.corda.core.serialization.carpenter.Schema
 
DeserializationInput - Class in net.corda.core.serialization.amqp
Main entry point for deserializing an AMQP encoded object.
DeserializationInput() - Constructor for class net.corda.core.serialization.amqp.DeserializationInput
Main entry point for deserializing an AMQP encoded object.
DeserializationInput() - Constructor for class net.corda.core.serialization.amqp.DeserializationInput
Main entry point for deserializing an AMQP encoded object.
deserialize(parser, context) - Method in class net.corda.contracts.ExpressionDeserializer
 
deserialize(bytes, clazz) - Method in class net.corda.core.serialization.amqp.DeserializationInput
This is the main entry point for deserialization of AMQP payloads, and expects a byte sequence involving a header indicating what version of Corda serialization was used, followed by an class Envelope which carries the object to be deserialized and a schema describing the types of the objects.
deserialize(byteSequence, clazz, context) - Method in interface net.corda.core.serialization.SerializationFactory
Deserialize the bytes in to an object, using the prefixed bytes to determine the format.
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.AmountDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.AnonymousPartyDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.CalendarDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.CompositeKeyDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.NodeInfoDeserializer
 
deserialize(parser, ctxt) - Method in class net.corda.jackson.JacksonSupport.OpaqueBytesDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.PartyDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.PublicKeyDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.SecureHashDeserializer
 
deserialize(parser, context) - Method in class net.corda.jackson.JacksonSupport.X500NameDeserializer
 
deserialize(p, ctxt) - Method in class net.corda.node.shell.InteractiveShell.InputStreamDeserializer
 
DeserializedGenericArrayType - Class in net.corda.core.serialization.amqp
Implementation of GenericArrayType that we can actually construct.
DeserializedGenericArrayType(componentType) - Constructor for class net.corda.core.serialization.amqp.DeserializedGenericArrayType
Implementation of GenericArrayType that we can actually construct.
DeserializedParameterizedType - Class in net.corda.core.serialization.amqp
Implementation of ParameterizedType that we can actually construct, and a parser from the string representation of the JDK implementation which we use as the textual format in the AMQP schema.
DeserializedParameterizedType(rawType, params, ownerType) - Constructor for class net.corda.core.serialization.amqp.DeserializedParameterizedType
Implementation of ParameterizedType that we can actually construct, and a parser from the string representation of the JDK implementation which we use as the textual format in the AMQP schema.
DeserializedParameterizedType.Companion - Class in net.corda.core.serialization.amqp
 
deserializeFromBlob(blob) - Static method in class net.corda.node.utilities.JDBCHashMapKt
 
Diff<T extends ContractState> - Class in net.corda.client.jfx.model
 
Diff(added, removed) - Constructor for class net.corda.client.jfx.model.Diff
 
DigitalSignature - Class in net.corda.core.crypto
A wrapper around a digital signature.
DigitalSignature(bits) - Constructor for class net.corda.core.crypto.DigitalSignature
A wrapper around a digital signature.
DigitalSignature.WithKey - Class in net.corda.core.crypto
A digital signature that identifies who the public key is owned by.
Direction() - Constructor for enum net.corda.core.contracts.TransactionVerificationException.Direction
 
Direction() - Constructor for enum net.corda.core.node.services.vault.Sort.Direction
 
disableWhitelist() - Method in class net.corda.core.serialization.CordaClassResolver
 
dispose() - Method in class net.corda.node.services.transactions.BFTSMaRt.Client
 
dispose() - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
 
DistributedImmutableMap<K,V> - Class in net.corda.node.services.transactions
A distributed map state machine that doesn't allow overriding values. The state machine is replicated across a Copycat Raft cluster.
DistributedImmutableMap(db, tableName) - Constructor for class net.corda.node.services.transactions.DistributedImmutableMap
A distributed map state machine that doesn't allow overriding values. The state machine is replicated across a Copycat Raft cluster.
DistributedImmutableMap.Commands - Class in net.corda.node.services.transactions
 
DistributedImmutableMap.Companion - Class in net.corda.node.services.transactions
 
div($receiver, divider) - Static method in class net.corda.core.internal.InternalUtilsKt
 
div($receiver, other) - Static method in class net.corda.core.internal.InternalUtilsKt
Allows you to write code like: Paths.get("someDir") / "subdir" / "filename" but using the Paths API to avoid platform separator problems.
div($receiver, other) - Static method in class net.corda.core.internal.InternalUtilsKt
 
DOLLARS(amount) - Static method in class net.corda.core.contracts.ContractsDSL
 
DOLLARS(amount) - Static method in class net.corda.core.contracts.ContractsDSL
 
doSign(privateKey, clearData) - Method in class net.corda.core.crypto.Crypto
Generic way to sign ByteArray data with a PrivateKey. Strategy on on identifying the actual signing scheme is based on the PrivateKey type, but if the schemeCodeName is known, then better use doSign(signatureScheme: String, privateKey: PrivateKey, clearData: ByteArray).
doSign(schemeCodeName, privateKey, clearData) - Method in class net.corda.core.crypto.Crypto
Generic way to sign ByteArray data with a PrivateKey and a known schemeCodeName String.
doSign(signatureScheme, privateKey, clearData) - Method in class net.corda.core.crypto.Crypto
Generic way to sign ByteArray data with a PrivateKey and a known Signature.
doSign(privateKey, metaData) - Method in class net.corda.core.crypto.Crypto
Generic way to sign class MetaData objects with a PrivateKey. class MetaData is a wrapper over the transaction's Merkle root in order to attach extra information, such as a timestamp or partial and blind signature indicators.
double($receiver) - Static method in class net.corda.client.mock.GeneratorKt
 
doubleRange($receiver, from, to) - Static method in class net.corda.client.mock.GeneratorKt
 
doVerify(schemeCodeName, publicKey, signatureData, clearData) - Method in class net.corda.core.crypto.Crypto
Utility to simplify the act of verifying a digital signature. It returns true if it succeeds, but it always throws an exception if verification fails.
doVerify(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, but it always throws an exception if verification fails. Strategy on identifying the actual signing scheme is based on the PublicKey type, but if the schemeCodeName is known, then better use doVerify(schemeCodeName: String, publicKey: PublicKey, signatureData: ByteArray, clearData: ByteArray).
doVerify(signatureScheme, publicKey, signatureData, clearData) - Method in class net.corda.core.crypto.Crypto
Method to verify a digital signature. It returns true if it succeeds, but it always throws an exception if verification fails.
doVerify(publicKey, transactionSignature) - Method in class net.corda.core.crypto.Crypto
Utility to simplify the act of verifying a class TransactionSignature. It returns true if it succeeds, but it always throws an exception if verification fails.
DownloadedVsRequestedDataMismatch(requested, got) - Constructor for exception net.corda.core.flows.FetchDataFlow.DownloadedVsRequestedDataMismatch
 
DownloadedVsRequestedSizeMismatch(requested, got) - Constructor for exception net.corda.core.flows.FetchDataFlow.DownloadedVsRequestedSizeMismatch
 
drawBanner(versionInfo) - Method in class net.corda.node.internal.NodeStartup
 
DummyAuditService - Class in net.corda.node.services.api
Empty do nothing AuditService as placeholder. TODO Write a full implementation that expands all the audit events to the database.
DummyAuditService() - Constructor for class net.corda.node.services.api.DummyAuditService
Empty do nothing AuditService as placeholder. TODO Write a full implementation that expands all the audit events to the database.
DummyKeysKt - Class in net.corda.core.crypto.testing
 
DummyPublicKey - Class in net.corda.core.crypto.testing
Deprecated. 
DummyPublicKey(s) - Constructor for class net.corda.core.crypto.testing.DummyPublicKey
Deprecated.
 
DuplicateInputStates(txId, duplicates) - Constructor for exception net.corda.core.contracts.TransactionVerificationException.DuplicateInputStates
 
DuplicateNameException - Exception in net.corda.core.serialization.carpenter
 
DuplicateNameException() - Constructor for exception net.corda.core.serialization.carpenter.DuplicateNameException
 

E

E2ETestKeyManagementService - Class in net.corda.node.services.keys
A simple in-memory KMS that doesn't bother saving keys to disk. A real implementation would:
E2ETestKeyManagementService(identityService, initialKeys) - Constructor for class net.corda.node.services.keys.E2ETestKeyManagementService
A simple in-memory KMS that doesn't bother saving keys to disk. A real implementation would:
ECPublicKeyImplSerializer - Class in net.corda.core.serialization
For serialising an ed25519 public key
Ed25519PrivateKeySerializer - Class in net.corda.core.serialization
For serialising an ed25519 private key
Ed25519PublicKeySerializer - Class in net.corda.core.serialization
For serialising an ed25519 public key
elapsedTime(block) - Static method in class net.corda.core.internal.InternalUtilsKt
Executes the given code block and returns a Duration of how long it took to execute in nanosecond precision.
elementFromRow(row) - Method in class net.corda.node.utilities.AbstractJDBCHashSet
Implementation should return the element object marshalled from the database table row.
elementFromRow(row) - Method in class net.corda.node.utilities.JDBCHashSet
Implementation should return the element object marshalled from the database table row.
Emoji - Class in net.corda.core.internal
A simple wrapper class that contains icons and support for printing them only when we're connected to a terminal.
EmptyWhitelist - Class in net.corda.core.serialization
 
enableWhitelist() - Method in class net.corda.core.serialization.CordaClassResolver
 
EncodingUtils - Class in net.corda.core.crypto
 
endWithError(error) - Method in class net.corda.core.utilities.ProgressTracker
Ends the progress tracker with the given error, bypassing any remaining steps. changes will emit the exception as an error.
engineGeneratePrivate(keySpec) - Method in class net.corda.core.crypto.composite.KeyFactory
 
engineGeneratePublic(keySpec) - Method in class net.corda.core.crypto.composite.KeyFactory
 
engineGetKeySpec(key, keySpec) - Method in class net.corda.core.crypto.composite.KeyFactory
 
engineGetParameter(param) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineInitSign(privateKey) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineInitVerify(publicKey) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineSetParameter(param, value) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineSetParameter(params) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineSign() - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineTranslateKey(key) - Method in class net.corda.core.crypto.composite.KeyFactory
 
engineUpdate(b) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineUpdate(b, off, len) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineVerify(sigBytes) - Method in class net.corda.core.crypto.composite.CompositeSignature
 
engineVerify(sigBytes) - Method in class net.corda.core.crypto.composite.CompositeSignature.State
 
entropyToKeyPair(entropy) - Static method in class net.corda.core.crypto.CryptoUtils
Returns a key pair derived from the given private key entropy. This is useful for unit tests and other cases where you want hard-coded private keys. This currently works for the default signature scheme EdDSA ed25519 only.
entrySet() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
 
entrySet() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
 
entrySet() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
 
Envelope - Class in net.corda.core.serialization.amqp
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.
Envelope(obj, schema) - Constructor for 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.
Envelope.Companion - Class in net.corda.core.serialization.amqp
 
equal($receiver, value) - Method in class net.corda.core.node.services.vault.Builder
 
equal($receiver, value) - Static method in class net.corda.core.node.services.vault.Builder
 
equal(value) - Method in class net.corda.core.node.services.vault.Builder
 
EqualityComparison(operator, rightLiteral) - Constructor for class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
 
EqualityComparisonOperator - Enum in net.corda.core.node.services.vault
 
EqualityComparisonOperator() - Constructor for enum net.corda.core.node.services.vault.EqualityComparisonOperator
 
equals(p) - Method in class net.corda.client.jfx.model.Diff
 
equals(p) - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
 
equals(p) - Method in class net.corda.client.jfx.model.InputResolution.Resolved
 
equals(p) - Method in class net.corda.client.jfx.model.InputResolution.Unresolved
 
equals(p) - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
 
equals(p) - Method in class net.corda.client.rpc.CordaRPCClientConfiguration
 
equals(p) - Method in class net.corda.client.rpc.internal.ObservableContext
 
equals(p) - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Exit
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Issue
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Move
 
equals(p) - Method in class net.corda.contracts.asset.Cash.State
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Exit
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Issue
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Move
 
equals(p) - Method in class net.corda.contracts.asset.CommodityContract.State
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Exit
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Issue
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Move
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Net
 
equals(p) - Method in class net.corda.contracts.asset.Commands.SetLifecycle
 
equals(p) - Method in class net.corda.contracts.asset.Commands.Settle
 
equals(p) - Method in class net.corda.contracts.asset.Obligation.State
 
equals(p) - Method in class net.corda.contracts.asset.Obligation.Terms
 
equals(other) - Method in class net.corda.contracts.BusinessCalendar
 
equals(p) - Method in class net.corda.contracts.clause.BilateralNetState
 
equals(p) - Method in class net.corda.contracts.clause.MultilateralNetState
 
equals(p) - Method in class net.corda.contracts.Commands.Issue
 
equals(p) - Method in class net.corda.contracts.Commands.Move
 
equals(p) - Method in class net.corda.contracts.CommercialPaper.State
 
equals(p) - Method in class net.corda.contracts.CommercialPaper.Terms
 
equals(p) - Method in class net.corda.contracts.CommercialPaperLegacy.State
 
equals(p) - Method in class net.corda.contracts.Commodity
 
equals(p) - Method in class net.corda.contracts.Expression
 
equals(p) - Method in class net.corda.contracts.Fix
 
equals(p) - Method in class net.corda.contracts.FixOf
 
equals(p) - Method in class net.corda.contracts.Tenor
 
equals(other) - Method in class net.corda.core.contracts.AbstractAttachment
 
equals(p) - Method in class net.corda.core.contracts.Amount
 
equals(other) - Method in class net.corda.core.contracts.AmountTransfer
Checks value equality of AmountTransfer objects, but also matches the reversed source and destination equivalent.
equals(p) - Method in class net.corda.core.contracts.AuthenticatedObject
 
equals(p) - Method in class net.corda.core.contracts.Command
 
equals(p) - Method in class net.corda.core.contracts.Issued
 
equals(p) - Method in class net.corda.core.contracts.PartyAndReference
 
equals(p) - Method in class net.corda.core.contracts.ScheduledActivity
 
equals(p) - Method in class net.corda.core.contracts.ScheduledStateRef
 
equals(p) - Method in class net.corda.core.contracts.SourceAndAmount
 
equals(p) - Method in class net.corda.core.contracts.StateAndRef
 
equals(p) - Method in class net.corda.core.contracts.StateRef
 
equals(p) - Method in class net.corda.core.contracts.TransactionState
 
equals(other) - Method in class net.corda.core.contracts.TypeOnlyCommandData
 
equals(other) - Method in class net.corda.core.contracts.UniqueIdentifier
 
equals(p) - Method in class net.corda.core.contracts.UpgradeCommand
 
equals(other) - Method in exception net.corda.core.CordaException
 
equals(other) - Method in exception net.corda.core.CordaRuntimeException
 
equals(p) - Method in class net.corda.core.crypto.CertificateAndKeyPair
 
equals(other) - Method in class net.corda.core.crypto.composite.CompositeKey
 
equals(p) - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
 
equals(p) - Method in class net.corda.core.crypto.composite.CompositeSignature.State
 
equals(p) - Method in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
 
equals(p) - Method in class net.corda.core.crypto.MerkleTree.Leaf
 
equals(p) - Method in class net.corda.core.crypto.MerkleTree.Node
 
equals(other) - Method in class net.corda.core.crypto.MetaData
 
equals(p) - Method in class net.corda.core.crypto.PartialTree.IncludedLeaf
 
equals(p) - Method in class net.corda.core.crypto.PartialTree.Leaf
 
equals(p) - Method in class net.corda.core.crypto.PartialTree.Node
 
equals(p) - Method in class net.corda.core.crypto.SignatureScheme
 
equals(other) - Method in class net.corda.core.crypto.testing.DummyPublicKey
Deprecated.
 
equals(p) - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
 
equals(p) - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
 
equals(p) - Method in class net.corda.core.flows.AppContext
 
equals(p) - Method in class net.corda.core.flows.BroadcastTransactionFlow.NotifyTxRequest
 
equals(p) - Method in class net.corda.core.flows.FetchDataFlow.Request
 
equals(p) - Method in class net.corda.core.flows.FetchDataFlow.Result
 
equals(p) - Method in class net.corda.core.flows.FinalityFlow.Participant
 
equals(p) - Method in class net.corda.core.flows.FlowInitiator.Peer
 
equals(p) - Method in class net.corda.core.flows.FlowInitiator.RPC
 
equals(p) - Method in class net.corda.core.flows.FlowInitiator.Scheduled
 
equals(p) - Method in class net.corda.core.flows.NotaryError.Conflict
 
equals(p) - Method in class net.corda.core.flows.NotaryError.TransactionInvalid
 
equals(p) - Method in class net.corda.core.flows.StateMachineRunId
 
equals(p) - Method in class net.corda.core.flows.TransactionParts
 
equals(other) - Method in class net.corda.core.identity.AbstractParty
Anonymised parties do not include any detail apart from owning key, so equality is dependent solely on the key
equals(other) - Method in class net.corda.core.identity.AnonymousPartyAndPath
 
equals(other) - Method in class net.corda.core.identity.PartyAndCertificate
 
equals(p) - Method in class net.corda.core.internal.InputStreamAndHash
 
equals(p) - Method in class net.corda.core.messaging.DataFeed
 
equals(p) - Method in class net.corda.core.messaging.FlowHandleImpl
 
equals(p) - Method in class net.corda.core.messaging.FlowProgressHandleImpl
 
equals(p) - Method in class net.corda.core.messaging.StateMachineInfo
 
equals(p) - Method in class net.corda.core.messaging.StateMachineTransactionMapping
 
equals(p) - Method in class net.corda.core.messaging.StateMachineUpdate.Added
 
equals(p) - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
 
equals(p) - Method in class net.corda.core.node.NodeInfo
 
equals(p) - Method in class net.corda.core.node.ServiceEntry
 
equals(p) - Method in class net.corda.core.node.services.MapChange.Added
 
equals(p) - Method in class net.corda.core.node.services.MapChange.Modified
 
equals(p) - Method in class net.corda.core.node.services.MapChange.Removed
 
equals(p) - Method in class net.corda.core.node.services.PartyInfo.Node
 
equals(p) - Method in class net.corda.core.node.services.PartyInfo.Service
 
equals(p) - Method in class net.corda.core.node.services.ServiceInfo
 
equals(other) - Method in class net.corda.core.node.services.ServiceType
 
equals(p) - Method in class net.corda.core.node.services.UniquenessProvider.Conflict
 
equals(p) - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
 
equals(p) - Method in class net.corda.core.node.services.vault.ColumnPredicate.AggregateFunction
 
equals(p) - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
 
equals(p) - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
 
equals(p) - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
 
equals(p) - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
 
equals(p) - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
 
equals(p) - Method in class net.corda.core.node.services.vault.ColumnPredicate.NullExpression
 
equals(p) - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
 
equals(p) - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
 
equals(p) - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
 
equals(p) - Method in class net.corda.core.node.services.vault.CriteriaExpression.Not
 
equals(p) - Method in class net.corda.core.node.services.Vault.Page
 
equals(p) - Method in class net.corda.core.node.services.vault.PageSpecification
 
equals(p) - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
 
equals(p) - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
 
equals(p) - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
 
equals(p) - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
 
equals(p) - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
 
equals(p) - Method in class net.corda.core.node.services.vault.Sort
 
equals(p) - Method in class net.corda.core.node.services.vault.Sort.SortColumn
 
equals(p) - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
 
equals(p) - Method in class net.corda.core.node.services.vault.SortAttribute.Standard
 
equals(p) - Method in class net.corda.core.node.services.Vault.StateMetadata
 
equals(p) - Method in class net.corda.core.node.services.Vault.Update
 
equals(p) - Method in class net.corda.core.node.WorldCoordinate
 
equals(p) - Method in class net.corda.core.node.WorldMapLocation
 
equals(p) - Method in class net.corda.core.schemas.PersistentStateRef
 
equals(p) - Method in class net.corda.core.serialization.amqp.Choice
 
equals(p) - Method in class net.corda.core.serialization.amqp.CompositeType
 
equals(p) - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
 
equals(p) - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
 
equals(p) - Method in class net.corda.core.serialization.amqp.Descriptor
 
equals(other) - Method in class net.corda.core.serialization.amqp.DeserializedGenericArrayType
 
equals(other) - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
 
equals(p) - Method in class net.corda.core.serialization.amqp.Envelope
 
equals(p) - Method in class net.corda.core.serialization.amqp.Field
 
equals(p) - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
 
equals(p) - Method in class net.corda.core.serialization.amqp.RestrictedType
 
equals(p) - Method in class net.corda.core.serialization.amqp.Schema
 
equals(p) - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
 
equals(other) - Method in class net.corda.core.transactions.BaseTransaction
 
equals(other) - Method in class net.corda.core.transactions.LedgerTransaction
 
equals(p) - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
 
equals(p) - Method in class net.corda.core.transactions.SignedTransaction
 
equals(other) - Method in class net.corda.core.transactions.WireTransaction
 
equals(other) - Method in class net.corda.core.utilities.ByteSequence
 
equals(p) - Method in class net.corda.core.utilities.NetworkHostAndPort
 
equals(other) - Method in class net.corda.core.utilities.NonEmptySet
 
equals(p) - Method in class net.corda.core.utilities.Change.Position
 
equals(p) - Method in class net.corda.core.utilities.Change.Rendering
 
equals(p) - Method in class net.corda.core.utilities.Change.Structural
 
equals(other) - Method in class net.corda.core.utilities.ProgressTracker.DONE
 
equals(other) - Method in class net.corda.core.utilities.ProgressTracker.UNSTARTED
 
equals(p) - Method in class net.corda.core.utilities.Try.Failure
 
equals(p) - Method in class net.corda.core.utilities.Try.Success
 
equals(p) - Method in class net.corda.flows.AbstractCashFlow.Result
 
equals(p) - Method in class net.corda.flows.CashFlowCommand.ExitCash
 
equals(p) - Method in class net.corda.flows.CashFlowCommand.IssueCash
 
equals(p) - Method in class net.corda.flows.CashFlowCommand.PayCash
 
equals(p) - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
 
equals(p) - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
 
equals(p) - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
 
equals(p) - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
 
equals(p) - Method in class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
 
equals(p) - Method in class net.corda.node.CmdLineOptions
 
equals(p) - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
 
equals(p) - Method in class net.corda.node.internal.InitiatedFlowFactory.Core
 
equals(p) - Method in class net.corda.node.internal.NetworkMapInfo
 
equals(other) - Method in class net.corda.node.services.api.Checkpoint
 
equals(p) - Method in class net.corda.node.services.api.FlowAppAuditEvent
 
equals(p) - Method in class net.corda.node.services.api.FlowErrorAuditEvent
 
equals(p) - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
 
equals(p) - Method in class net.corda.node.services.api.FlowProgressAuditEvent
 
equals(p) - Method in class net.corda.node.services.api.FlowStartEvent
 
equals(p) - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
 
equals(p) - Method in class net.corda.node.services.api.SystemAuditEvent
 
equals(p) - Method in class net.corda.node.services.config.CertChainPolicyConfig
 
equals(p) - Method in class net.corda.node.services.config.FullNodeConfiguration
 
equals(p) - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
 
equals(p) - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
 
equals(p) - Method in class net.corda.node.services.messaging.RpcContext
 
equals(p) - Method in class net.corda.node.services.messaging.RPCServerConfiguration
 
equals(p) - Method in class net.corda.node.services.messaging.TopicSession
 
equals(p) - Method in class net.corda.node.services.network.LastAcknowledgeInfo
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityResponse
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.RegistrationResponse
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.SubscribeResponse
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.Update
 
equals(p) - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
 
equals(p) - Method in class net.corda.node.services.network.NodeRegistration
 
equals(p) - Method in class net.corda.node.services.network.NodeRegistrationInfo
 
equals(p) - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
 
equals(p) - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
 
equals(p) - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
 
equals(p) - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiating
 
equals(p) - Method in class net.corda.node.services.statemachine.NormalSessionEnd
 
equals(p) - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
 
equals(p) - Method in class net.corda.node.services.statemachine.ReceiveOnly
 
equals(p) - Method in class net.corda.node.services.statemachine.SendAndReceive
 
equals(p) - Method in class net.corda.node.services.statemachine.SendOnly
 
equals(p) - Method in class net.corda.node.services.statemachine.SessionConfirm
 
equals(p) - Method in class net.corda.node.services.statemachine.SessionData
 
equals(p) - Method in class net.corda.node.services.statemachine.SessionInit
 
equals(p) - Method in class net.corda.node.services.statemachine.SessionReject
 
equals(p) - Method in class net.corda.node.services.statemachine.Change.Add
 
equals(p) - Method in class net.corda.node.services.statemachine.Change.Removed
 
equals(p) - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
 
equals(p) - Method in class net.corda.node.services.transactions.ClusterResponse.Error
 
equals(p) - Method in class net.corda.node.services.transactions.ClusterResponse.Signatures
 
equals(p) - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
 
equals(p) - Method in class net.corda.node.services.transactions.ReplicaResponse.Error
 
equals(p) - Method in class net.corda.node.services.transactions.ReplicaResponse.Signature
 
equals(p) - Method in class net.corda.node.utilities.DatabaseTransactionManager.Boundary
 
equals(p) - Method in class net.corda.node.utilities.PartyAndCertificateColumns
 
equals(p) - Method in class net.corda.node.utilities.PartyColumns
 
equals(p) - Method in class net.corda.node.utilities.StateRefColumns
 
equals(p) - Method in class net.corda.node.utilities.TxnNoteColumns
 
equals(p) - Method in class net.corda.node.VersionInfo
 
Error(error) - Constructor for class net.corda.node.services.transactions.ClusterResponse.Error
 
Error(error) - Constructor for class net.corda.node.services.transactions.ReplicaResponse.Error
 
ErrorFlowsEventGenerator - Class in net.corda.client.mock
class Generators for incoming/outgoing events of starting different cash flows. It invokes flows that throw exceptions for use in explorer flow triage. Exceptions are of kind spending/exiting too much cash.
ErrorFlowsEventGenerator(parties, currencies, notary) - Constructor for class net.corda.client.mock.ErrorFlowsEventGenerator
class Generators for incoming/outgoing events of starting different cash flows. It invokes flows that throw exceptions for use in explorer flow triage. Exceptions are of kind spending/exiting too much cash.
ErrorFlowsEventGenerator.IssuerEvents - Enum in net.corda.client.mock
 
ErrorSessionEnd - Class in net.corda.node.services.statemachine
 
ErrorSessionEnd(recipientSessionId, errorResponse) - Constructor for class net.corda.node.services.statemachine.ErrorSessionEnd
 
EUR - Static variable in class net.corda.core.contracts.ContractsDSL
 
EventGenerator - Class in net.corda.client.mock
class Generators for incoming/outgoing cash flow events between parties. It doesn't necessarily generate correct events! Especially at the beginning of simulation there might be few insufficient spend errors.
EventGenerator(parties, currencies, notary) - Constructor for class net.corda.client.mock.EventGenerator
class Generators for incoming/outgoing cash flow events between parties. It doesn't necessarily generate correct events! Especially at the beginning of simulation there might be few insufficient spend errors.
EventSinkDelegate(klass, eventSinkProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.EventSinkDelegate
 
EventStreamDelegate(klass, eventStreamProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.EventStreamDelegate
 
exactAdd($receiver, b) - Static method in class net.corda.core.utilities.KotlinUtilsKt
Like the + operator but throws ArithmeticException in case of integer overflow.
exactAdd($receiver, b) - Static method in class net.corda.core.utilities.KotlinUtilsKt
Like the + operator but throws ArithmeticException in case of integer overflow.
ExcessivelyLargeTransactionGraph() - Constructor for exception net.corda.core.flows.ResolveTransactionsFlow.ExcessivelyLargeTransactionGraph
 
exchange(currency, exchangeRate) - Method in class net.corda.client.jfx.utils.AmountBindings
 
exchangeAmount($receiver, amount, to) - Static method in class net.corda.client.jfx.model.ExchangeRateModelKt
 
exchangeDouble($receiver, amount, to) - Static method in class net.corda.client.jfx.model.ExchangeRateModelKt
 
ExchangeRate - Interface in net.corda.client.jfx.model
 
ExchangeRateModel - Class in net.corda.client.jfx.model
This model provides an exchange rate from arbitrary currency to arbitrary currency. TODO hook up an actual oracle
ExchangeRateModel() - Constructor for class net.corda.client.jfx.model.ExchangeRateModel
This model provides an exchange rate from arbitrary currency to arbitrary currency. TODO hook up an actual oracle
ExchangeRateModelKt - Class in net.corda.client.jfx.model
 
execute(command) - Method in class net.corda.node.utilities.AffinityExecutor.Gate
 
executeASAP($this, runnable) - Static method in class net.corda.node.utilities.AffinityExecutor.DefaultImpls
If isOnThread() then runnable is invoked immediately, otherwise the closure is queued onto the backing thread.
executeASAP(runnable) - Method in interface net.corda.node.utilities.AffinityExecutor
If isOnThread() then runnable is invoked immediately, otherwise the closure is queued onto the backing thread.
executeCommand(command) - Method in class net.corda.node.services.transactions.BFTSMaRt.Replica
Implement logic to execute the command and commit the transaction to the log. Helper methods are provided for transaction processing: commitInputStates, BFTSMaRt.Replica.validateTimeWindow, and sign.
ExistingSessionMessage - Interface in net.corda.node.services.statemachine
 
exists($receiver, options) - Static method in class net.corda.core.internal.InternalUtilsKt
 
Exit(amount) - Constructor for 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.
Exit(amount) - Constructor for 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.
Exit(amount) - Constructor for 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.
ExitCash(amount, issueRef) - Constructor for class net.corda.flows.CashFlowCommand.ExitCash
Exit cash from the ledger.
ExposedTransaction - Class in net.corda.node.utilities
Wrapper of class DatabaseTransaction, because the class is effectively used for ExposedTransaction.connection method only not all methods are implemented. The class will obsolete when Exposed library is phased out.
ExposedTransaction(db, databaseTransaction) - Constructor for class net.corda.node.utilities.ExposedTransaction
Wrapper of class DatabaseTransaction, because the class is effectively used for ExposedTransaction.connection method only not all methods are implemented. The class will obsolete when Exposed library is phased out.
ExposedTransactionManager - Class in net.corda.node.utilities
Delegates methods to class DatabaseTransactionManager. The class will obsolete when Exposed library is phased out.
ExposedTransactionManager() - Constructor for class net.corda.node.utilities.ExposedTransactionManager
Delegates methods to class DatabaseTransactionManager. The class will obsolete when Exposed library is phased out.
ExposedTransactionManager.Companion - Class in net.corda.node.utilities
 
Expression - Class in net.corda.contracts
Represents a textual expression of e.g. a formula
Expression(expr) - Constructor for class net.corda.contracts.Expression
Represents a textual expression of e.g. a formula
ExpressionDeserializer - Class in net.corda.contracts
 
ExpressionSerializer - Class in net.corda.contracts
 
extractAmountsDue(product, states) - Static method in class net.corda.contracts.asset.ObligationKt
Convert a list of settlement states into total from each obligor to a beneficiary.
extractCommands(commands) - Method in class net.corda.contracts.asset.Cash
 
extractCommands(commands) - Method in class net.corda.contracts.asset.CommodityContract
 
extractCommands(commands) - Method in class net.corda.contracts.asset.OnLedgerAsset
 
extractFile($this, path, outputTo) - Static method in class net.corda.core.contracts.Attachment.DefaultImpls
Finds the named file case insensitively and copies it to the output stream.
extractFile(path, outputTo) - Method in interface net.corda.core.contracts.Attachment
Finds the named file case insensitively and copies it to the output stream.
extractFile($receiver, path, outputTo) - Static method in class net.corda.core.contracts.StructuresKt
 
extractParticipants(ltx) - Method in class net.corda.core.flows.FinalityFlow
Helper function to extract all participants from a ledger transaction. Intended to help implement FinalityFlow.lookupParties overriding functions.

F

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
Class that holds filtered leaves for a partial Merkle transaction. We assume mixed leaf types, notice that every field from class WireTransaction can be used in class PartialMerkleTree calculation.
FilteredLeaves(inputs, attachments, outputs, commands, notary, mustSign, type, timeWindow) - Constructor for class net.corda.core.transactions.FilteredLeaves
Class that holds filtered leaves for a partial Merkle transaction. We assume mixed leaf types, notice that every field from class WireTransaction can be used in class PartialMerkleTree calculation.
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
Helper to simplify finding a single input interface ContractState matching a Predicate.
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
Helper to simplify finding a single output class StateAndRef matching a Predicate.
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
Returns the given function applied to the value from this class Try.Success, or returns this if this is a class Try.Failure.
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 holds information on who started the flow. We have different ways of doing that: via RPC class FlowInitiator.RPC, communication started by peer node class FlowInitiator.Peer, scheduled flows class FlowInitiator.Scheduled or via the Corda Shell class FlowInitiator.Shell.
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
A class for conversion to and from class FlowLogic and interface FlowLogicRef instances.
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
interface FlowProgressHandle is a serialisable handle for the started flow, parameterised by the type of the flow's return value.
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
class FlowSessionState describes the session's state.
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
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
FungibleAssetQueryCriteria(participants, owner, quantity, issuerPartyName, issuerRef) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
FungibleAssetQueryCriteria(participants, owner, quantity, issuerPartyName) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
FungibleAssetQueryCriteria(participants, owner, quantity) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
FungibleAssetQueryCriteria(participants, owner) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
FungibleAssetQueryCriteria(participants) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
FungibleAssetQueryCriteria() - Constructor for class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
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
 

G

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
Just uses the default class TransactionBuilder with no special logic
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
Get all identities known to the service. This is expensive, and IdentityService.partyFromKey or IdentityService.partyFromX500Name should be used in preference where possible.
getAllIdentities() - Method in class net.corda.node.services.identity.InMemoryIdentityService
Get all identities known to the service. This is expensive, and InMemoryIdentityService.partyFromKey or InMemoryIdentityService.partyFromX500Name should be used in preference where possible.
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 CompositeKeys 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
The id of the contained class WireTransaction.
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
Helper to simplify getting an indexed input interface ContractState.
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
Returns the value if a class Try.Success otherwise throws the exception if a class Try.Failure.
getOrThrow() - Method in class net.corda.core.utilities.Try
Returns the value if a class Try.Success otherwise throws the exception if a class Try.Failure.
getOrThrow() - Method in class net.corda.core.utilities.Try.Success
Returns the value if a class Try.Success otherwise throws the exception if a class Try.Failure.
getOrThrow($receiver, timeout) - Static method in class net.corda.core.Utils
Same as Future.get but with a more descriptive name, and doesn't throw ExecutionException, instead throwing its cause
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
Helper property to return a list of interface ContractState objects, rather than the often less convenient class TransactionState
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
The implementation of the interface CordaRPCOps interface used by this node.
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
Set to true once AbstractNode.start has been successfully called.
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
The type of netting to apply, see enum NetType for options.
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
The use case we are serializing or deserializing for. See enum SerializationContext.UseCase.
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).

H

handle() - Method in class net.corda.node.services.transactions.PathManager
 
Handler(topicSession, callback) - Constructor for class net.corda.node.services.messaging.NodeMessagingClient.Handler
A registration to handle messages of different types
Handshake(payload, publicKey) - Constructor for class net.corda.flows.TwoPartyDealFlow.Handshake
 
hash($receiver) - Static method in class net.corda.core.contracts.StructuresKt
Returns the SHA-256 hash of the serialised contents of this state (not cached!)
HashCheckingStream(expected, expectedSize, input, counter, stream) - Constructor for class net.corda.node.services.persistence.NodeAttachmentService.HashCheckingStream
Wraps a stream and hashes data as it is read: if the entire stream is consumed, then at the end the hash of the read data is compared to the expected hash and exception NodeAttachmentService.HashMismatchException is thrown by either NodeAttachmentService.HashCheckingStream.read or NodeAttachmentService.HashCheckingStream.close if they didn't match. The goal of this is to detect cases where attachments in the store have been tampered with or corrupted and no longer match their file name. It won't always work: if we read a zip for our own uses and skip around inside it, we haven't read the whole file, so we can't check the hash. But when copying it over the network this will provide an additional safety check against user error.
hashCode() - Method in class net.corda.client.jfx.model.Diff
 
hashCode() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
 
hashCode() - Method in class net.corda.client.jfx.model.InputResolution.Resolved
 
hashCode() - Method in class net.corda.client.jfx.model.InputResolution.Unresolved
 
hashCode() - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
 
hashCode() - Method in class net.corda.client.rpc.CordaRPCClientConfiguration
 
hashCode() - Method in class net.corda.client.rpc.internal.ObservableContext
 
hashCode() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Exit
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Issue
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Move
 
hashCode() - Method in class net.corda.contracts.asset.Cash.State
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Exit
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Issue
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Move
 
hashCode() - Method in class net.corda.contracts.asset.CommodityContract.State
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Exit
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Issue
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Move
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Net
 
hashCode() - Method in class net.corda.contracts.asset.Commands.SetLifecycle
 
hashCode() - Method in class net.corda.contracts.asset.Commands.Settle
 
hashCode() - Method in class net.corda.contracts.asset.Obligation.State
 
hashCode() - Method in class net.corda.contracts.asset.Obligation.Terms
 
hashCode() - Method in class net.corda.contracts.BusinessCalendar
 
hashCode() - Method in class net.corda.contracts.clause.BilateralNetState
 
hashCode() - Method in class net.corda.contracts.clause.MultilateralNetState
 
hashCode() - Method in class net.corda.contracts.Commands.Issue
 
hashCode() - Method in class net.corda.contracts.Commands.Move
 
hashCode() - Method in class net.corda.contracts.CommercialPaper.State
 
hashCode() - Method in class net.corda.contracts.CommercialPaper.Terms
 
hashCode() - Method in class net.corda.contracts.CommercialPaperLegacy.State
 
hashCode() - Method in class net.corda.contracts.Commodity
 
hashCode() - Method in class net.corda.contracts.Expression
 
hashCode() - Method in class net.corda.contracts.Fix
 
hashCode() - Method in class net.corda.contracts.FixOf
 
hashCode() - Method in class net.corda.contracts.Tenor
 
hashCode() - Method in class net.corda.core.contracts.AbstractAttachment
 
hashCode() - Method in class net.corda.core.contracts.Amount
 
hashCode() - Method in class net.corda.core.contracts.AmountTransfer
HashCode ensures that reversed source and destination equivalents will hash to the same value.
hashCode() - Method in class net.corda.core.contracts.AuthenticatedObject
 
hashCode() - Method in class net.corda.core.contracts.Command
 
hashCode() - Method in class net.corda.core.contracts.Issued
 
hashCode() - Method in class net.corda.core.contracts.PartyAndReference
 
hashCode() - Method in class net.corda.core.contracts.ScheduledActivity
 
hashCode() - Method in class net.corda.core.contracts.ScheduledStateRef
 
hashCode() - Method in class net.corda.core.contracts.SourceAndAmount
 
hashCode() - Method in class net.corda.core.contracts.StateAndRef
 
hashCode() - Method in class net.corda.core.contracts.StateRef
 
hashCode() - Method in class net.corda.core.contracts.TransactionState
 
hashCode() - Method in class net.corda.core.contracts.TypeOnlyCommandData
 
hashCode() - Method in class net.corda.core.contracts.UniqueIdentifier
 
hashCode() - Method in class net.corda.core.contracts.UpgradeCommand
 
hashCode() - Method in exception net.corda.core.CordaException
 
hashCode() - Method in exception net.corda.core.CordaRuntimeException
 
hashCode() - Method in class net.corda.core.crypto.CertificateAndKeyPair
 
hashCode() - Method in class net.corda.core.crypto.composite.CompositeKey
 
hashCode() - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
 
hashCode() - Method in class net.corda.core.crypto.composite.CompositeSignature.State
 
hashCode() - Method in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
 
hashCode() - Method in class net.corda.core.crypto.MerkleTree.Leaf
 
hashCode() - Method in class net.corda.core.crypto.MerkleTree.Node
 
hashCode() - Method in class net.corda.core.crypto.MetaData
 
hashCode() - Method in class net.corda.core.crypto.PartialTree.IncludedLeaf
 
hashCode() - Method in class net.corda.core.crypto.PartialTree.Leaf
 
hashCode() - Method in class net.corda.core.crypto.PartialTree.Node
 
hashCode() - Method in class net.corda.core.crypto.SignatureScheme
 
hashCode() - Method in class net.corda.core.crypto.testing.DummyPublicKey
Deprecated.
 
hashCode() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
 
hashCode() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
 
hashCode() - Method in class net.corda.core.flows.AppContext
 
hashCode() - Method in class net.corda.core.flows.BroadcastTransactionFlow.NotifyTxRequest
 
hashCode() - Method in class net.corda.core.flows.FetchDataFlow.Request
 
hashCode() - Method in class net.corda.core.flows.FetchDataFlow.Result
 
hashCode() - Method in class net.corda.core.flows.FinalityFlow.Participant
 
hashCode() - Method in class net.corda.core.flows.FlowInitiator.Peer
 
hashCode() - Method in class net.corda.core.flows.FlowInitiator.RPC
 
hashCode() - Method in class net.corda.core.flows.FlowInitiator.Scheduled
 
hashCode() - Method in class net.corda.core.flows.NotaryError.Conflict
 
hashCode() - Method in class net.corda.core.flows.NotaryError.TransactionInvalid
 
hashCode() - Method in class net.corda.core.flows.StateMachineRunId
 
hashCode() - Method in class net.corda.core.flows.TransactionParts
 
hashCode() - Method in class net.corda.core.identity.AbstractParty
 
hashCode() - Method in class net.corda.core.identity.AnonymousPartyAndPath
 
hashCode() - Method in class net.corda.core.identity.PartyAndCertificate
 
hashCode() - Method in class net.corda.core.internal.InputStreamAndHash
 
hashCode() - Method in class net.corda.core.messaging.DataFeed
 
hashCode() - Method in class net.corda.core.messaging.FlowHandleImpl
 
hashCode() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
 
hashCode() - Method in class net.corda.core.messaging.StateMachineInfo
 
hashCode() - Method in class net.corda.core.messaging.StateMachineTransactionMapping
 
hashCode() - Method in class net.corda.core.messaging.StateMachineUpdate.Added
 
hashCode() - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
 
hashCode() - Method in class net.corda.core.node.NodeInfo
 
hashCode() - Method in class net.corda.core.node.ServiceEntry
 
hashCode() - Method in class net.corda.core.node.services.MapChange.Added
 
hashCode() - Method in class net.corda.core.node.services.MapChange.Modified
 
hashCode() - Method in class net.corda.core.node.services.MapChange.Removed
 
hashCode() - Method in class net.corda.core.node.services.PartyInfo.Node
 
hashCode() - Method in class net.corda.core.node.services.PartyInfo.Service
 
hashCode() - Method in class net.corda.core.node.services.ServiceInfo
 
hashCode() - Method in class net.corda.core.node.services.ServiceType
 
hashCode() - Method in class net.corda.core.node.services.UniquenessProvider.Conflict
 
hashCode() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
 
hashCode() - Method in class net.corda.core.node.services.vault.ColumnPredicate.AggregateFunction
 
hashCode() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
 
hashCode() - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
 
hashCode() - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
 
hashCode() - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
 
hashCode() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
 
hashCode() - Method in class net.corda.core.node.services.vault.ColumnPredicate.NullExpression
 
hashCode() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
 
hashCode() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
 
hashCode() - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
 
hashCode() - Method in class net.corda.core.node.services.vault.CriteriaExpression.Not
 
hashCode() - Method in class net.corda.core.node.services.Vault.Page
 
hashCode() - Method in class net.corda.core.node.services.vault.PageSpecification
 
hashCode() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
 
hashCode() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
 
hashCode() - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
 
hashCode() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
 
hashCode() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
 
hashCode() - Method in class net.corda.core.node.services.vault.Sort
 
hashCode() - Method in class net.corda.core.node.services.vault.Sort.SortColumn
 
hashCode() - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
 
hashCode() - Method in class net.corda.core.node.services.vault.SortAttribute.Standard
 
hashCode() - Method in class net.corda.core.node.services.Vault.StateMetadata
 
hashCode() - Method in class net.corda.core.node.services.Vault.Update
 
hashCode() - Method in class net.corda.core.node.WorldCoordinate
 
hashCode() - Method in class net.corda.core.node.WorldMapLocation
 
hashCode() - Method in class net.corda.core.schemas.PersistentStateRef
 
hashCode() - Method in class net.corda.core.serialization.amqp.Choice
 
hashCode() - Method in class net.corda.core.serialization.amqp.CompositeType
 
hashCode() - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
 
hashCode() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
 
hashCode() - Method in class net.corda.core.serialization.amqp.Descriptor
 
hashCode() - Method in class net.corda.core.serialization.amqp.DeserializedGenericArrayType
 
hashCode() - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
 
hashCode() - Method in class net.corda.core.serialization.amqp.Envelope
 
hashCode() - Method in class net.corda.core.serialization.amqp.Field
 
hashCode() - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
 
hashCode() - Method in class net.corda.core.serialization.amqp.RestrictedType
 
hashCode() - Method in class net.corda.core.serialization.amqp.Schema
 
hashCode() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
 
hashCode() - Method in class net.corda.core.transactions.BaseTransaction
 
hashCode() - Method in class net.corda.core.transactions.LedgerTransaction
 
hashCode() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
 
hashCode() - Method in class net.corda.core.transactions.SignedTransaction
 
hashCode() - Method in class net.corda.core.transactions.WireTransaction
 
hashCode() - Method in class net.corda.core.utilities.ByteSequence
 
hashCode() - Method in class net.corda.core.utilities.NetworkHostAndPort
 
hashCode() - Method in class net.corda.core.utilities.NonEmptySet
 
hashCode() - Method in class net.corda.core.utilities.Change.Position
 
hashCode() - Method in class net.corda.core.utilities.Change.Rendering
 
hashCode() - Method in class net.corda.core.utilities.Change.Structural
 
hashCode() - Method in class net.corda.core.utilities.Try.Failure
 
hashCode() - Method in class net.corda.core.utilities.Try.Success
 
hashCode() - Method in class net.corda.flows.AbstractCashFlow.Result
 
hashCode() - Method in class net.corda.flows.CashFlowCommand.ExitCash
 
hashCode() - Method in class net.corda.flows.CashFlowCommand.IssueCash
 
hashCode() - Method in class net.corda.flows.CashFlowCommand.PayCash
 
hashCode() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
 
hashCode() - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
 
hashCode() - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
 
hashCode() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
 
hashCode() - Method in class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
 
hashCode() - Method in class net.corda.node.CmdLineOptions
 
hashCode() - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
 
hashCode() - Method in class net.corda.node.internal.InitiatedFlowFactory.Core
 
hashCode() - Method in class net.corda.node.internal.NetworkMapInfo
 
hashCode() - Method in class net.corda.node.services.api.Checkpoint
 
hashCode() - Method in class net.corda.node.services.api.FlowAppAuditEvent
 
hashCode() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
 
hashCode() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
 
hashCode() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
 
hashCode() - Method in class net.corda.node.services.api.FlowStartEvent
 
hashCode() - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
 
hashCode() - Method in class net.corda.node.services.api.SystemAuditEvent
 
hashCode() - Method in class net.corda.node.services.config.CertChainPolicyConfig
 
hashCode() - Method in class net.corda.node.services.config.FullNodeConfiguration
 
hashCode() - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
 
hashCode() - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
 
hashCode() - Method in class net.corda.node.services.messaging.RpcContext
 
hashCode() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
 
hashCode() - Method in class net.corda.node.services.messaging.TopicSession
 
hashCode() - Method in class net.corda.node.services.network.LastAcknowledgeInfo
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityResponse
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationResponse
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeResponse
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.Update
 
hashCode() - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
 
hashCode() - Method in class net.corda.node.services.network.NodeRegistration
 
hashCode() - Method in class net.corda.node.services.network.NodeRegistrationInfo
 
hashCode() - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
 
hashCode() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
 
hashCode() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
 
hashCode() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiating
 
hashCode() - Method in class net.corda.node.services.statemachine.NormalSessionEnd
 
hashCode() - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
 
hashCode() - Method in class net.corda.node.services.statemachine.ReceiveOnly
 
hashCode() - Method in class net.corda.node.services.statemachine.SendAndReceive
 
hashCode() - Method in class net.corda.node.services.statemachine.SendOnly
 
hashCode() - Method in class net.corda.node.services.statemachine.SessionConfirm
 
hashCode() - Method in class net.corda.node.services.statemachine.SessionData
 
hashCode() - Method in class net.corda.node.services.statemachine.SessionInit
 
hashCode() - Method in class net.corda.node.services.statemachine.SessionReject
 
hashCode() - Method in class net.corda.node.services.statemachine.Change.Add
 
hashCode() - Method in class net.corda.node.services.statemachine.Change.Removed
 
hashCode() - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
 
hashCode() - Method in class net.corda.node.services.transactions.ClusterResponse.Error
 
hashCode() - Method in class net.corda.node.services.transactions.ClusterResponse.Signatures
 
hashCode() - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
 
hashCode() - Method in class net.corda.node.services.transactions.ReplicaResponse.Error
 
hashCode() - Method in class net.corda.node.services.transactions.ReplicaResponse.Signature
 
hashCode() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Boundary
 
hashCode() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
 
hashCode() - Method in class net.corda.node.utilities.PartyColumns
 
hashCode() - Method in class net.corda.node.utilities.StateRefColumns
 
hashCode() - Method in class net.corda.node.utilities.TxnNoteColumns
 
hashCode() - Method in class net.corda.node.VersionInfo
 
hashConcat(other) - Method in class net.corda.core.crypto.SecureHash
 
HashMismatchException(expected, actual) - Constructor for exception net.corda.node.services.persistence.NodeAttachmentService.HashMismatchException
 
HashNotFound(requested) - Constructor for exception net.corda.core.flows.FetchDataFlow.HashNotFound
 
hasListed(type) - Method in class net.corda.core.serialization.AllButBlacklisted
This implementation supports inheritance; thus, if a superclass or superinterface is blacklisted, so is the input class.
hasListed(type) - Method in class net.corda.core.serialization.AllWhitelist
 
hasListed(type) - Method in class net.corda.core.serialization.BuiltInExceptionsWhitelist
 
hasListed(type) - Method in interface net.corda.core.serialization.ClassWhitelist
 
hasListed(type) - Method in class net.corda.core.serialization.EmptyWhitelist
 
hasListed(type) - Method in class net.corda.core.serialization.GlobalTransientClassWhiteList
 
hasListed(type) - Method in class net.corda.core.serialization.LoggingWhitelist
 
head() - Method in class net.corda.core.utilities.NonEmptySet
Returns the first element of the set.
hexToBase58($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Encoding changer. Hex-String to Base58-String, i.e. "48656C6C6F20576F726C64" -> "JxF12TrwUP45BMd"
hexToBase64($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Encoding changer. Hex-String to Base64-String, i.e. "48656C6C6F20576F726C64" -> "SGVsbG8gV29ybGQ="
hexToByteArray($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Hex-String to ByteArray. Accept any hex form (capitalized, lowercase, mixed).
hexToRealString($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
HEX-String to the actual real String, i.e. "48656C6C6F20576F726C64" -> "Hello World".
HibernateConfiguration - Class in net.corda.node.services.database
 
HibernateConfiguration(schemaService, useDefaultLogging) - Constructor for class net.corda.node.services.database.HibernateConfiguration
 
HibernateConfiguration(schemaService) - Constructor for class net.corda.node.services.database.HibernateConfiguration
 
HibernateConfiguration.Companion - Class in net.corda.node.services.database
 
HibernateConfiguration.NodeDatabaseConnectionProvider - Class in net.corda.node.services.database
 
HibernateObserver - Class in net.corda.node.services.schema
A vault observer that extracts Object Relational Mappings for contract states that support it, and persists them with Hibernate.
HibernateObserver(vaultUpdates, config) - Constructor for class net.corda.node.services.schema.HibernateObserver
A vault observer that extracts Object Relational Mappings for contract states that support it, and persists them with Hibernate.
HibernateObserver.Companion - Class in net.corda.node.services.schema
 
HibernateQueryCriteriaParser - Class in net.corda.node.services.vault
 
HibernateQueryCriteriaParser(contractType, contractTypeMappings, criteriaBuilder, criteriaQuery, vaultStates) - Constructor for class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
HibernateVaultQueryImpl - Class in net.corda.node.services.vault
 
HibernateVaultQueryImpl(hibernateConfig, updatesPublisher) - Constructor for class net.corda.node.services.vault.HibernateVaultQueryImpl
 
HibernateVaultQueryImpl.Companion - Class in net.corda.node.services.vault
 
HTTPNetworkRegistrationService - Class in net.corda.node.utilities.registration
 
HTTPNetworkRegistrationService(server) - Constructor for class net.corda.node.utilities.registration.HTTPNetworkRegistrationService
 
HTTPNetworkRegistrationService.Companion - Class in net.corda.node.utilities.registration
 

I

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
Returns the index of the given item or throws IllegalArgumentException if not found.
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
This flow enables a client to request issuance of some interface FungibleAsset from a server acting as an issuer (see class Issued) of FungibleAssets.
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
A class for conversion to and from class FlowLogic and interface FlowLogicRef instances.
INSTANCE - Static variable in class net.corda.node.services.Companion.SENDING_KEY
 
INSTANCE - Static variable in class net.corda.node.services.transactions.BFTSMaRt
Implements a replicated transaction commit log based on the BFT-SMaRt consensus algorithm. Every replica in the cluster is running a class BFTSMaRt.Replica maintaining the state, and a class BFTSMaRt.Client is used to relay state modification requests to all class BFTSMaRt.Replicas.
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
ColumnType for marshalling to/from database on behalf of class SecureHash.
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
An object used to fully qualify the class CommercialPaperSchema family name (i.e. independent of version).
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
The class AbstractStateReplacementFlow.Instigator assembles the transaction for state replacement and sends out change proposals to all participants (class AbstractStateReplacementFlow.Acceptor) of that state. If participants agree to the proposed change, they each sign the transaction. Finally, class AbstractStateReplacementFlow.Instigator sends the transaction containing all participants' signatures to the notary for signature, and then back to each participant so they can record it and use the new updated state for future transactions.
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
Returns true iff the class Try is a class Try.Success.
isFailure() - Method in class net.corda.core.utilities.Try
Returns true iff the class Try is a class Try.Success.
isFailure() - Method in class net.corda.core.utilities.Try.Success
Returns true iff the class Try is a class 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
Returns true iff the class Try is a class Try.Failure.
isSuccess() - Method in class net.corda.core.utilities.Try
Returns true iff the class Try is a class Try.Failure.
isSuccess() - Method in class net.corda.core.utilities.Try.Success
Returns true iff the class Try is a class Try.Failure.
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 refers to a Node acting as a Bank Issuer of interface FungibleAsset, and processes requests from a class IssuerFlow.IssuanceRequester client. Returns the generated transaction representing the transfer of the interface FungibleAsset to the issue requester.
Issuer.Companion - Class in net.corda.flows
 
IssuerEvents() - Constructor for enum net.corda.client.mock.ErrorFlowsEventGenerator.IssuerEvents
 
IssuerFlow - Class in net.corda.flows
This flow enables a client to request issuance of some interface FungibleAsset from a server acting as an issuer (see class Issued) of FungibleAssets.
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
Issuer refers to a Node acting as a Bank Issuer of interface FungibleAsset, and processes requests from a class IssuerFlow.IssuanceRequester client. Returns the generated transaction representing the transfer of the interface FungibleAsset to the issue requester.
isSupportedSignatureScheme(signatureScheme) - Method in class net.corda.core.crypto.Crypto
Check if the requested class SignatureScheme is supported by the system.
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
 

J

JacksonSupport - Class in net.corda.jackson
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.
JacksonSupport.AmountDeserializer - Class in net.corda.jackson
 
JacksonSupport.AmountSerializer - Class in net.corda.jackson
 
JacksonSupport.AnonymousPartyDeserializer - Class in net.corda.jackson
 
JacksonSupport.AnonymousPartySerializer - Class in net.corda.jackson
 
JacksonSupport.BusinessCalendarWrapper - Class in net.corda.jackson
 
JacksonSupport.CalendarDeserializer - Class in net.corda.jackson
 
JacksonSupport.CalendarSerializer - Class in net.corda.jackson
 
JacksonSupport.CompositeKeyDeserializer - Class in net.corda.jackson
 
JacksonSupport.CompositeKeySerializer - Class in net.corda.jackson
 
JacksonSupport.IdentityObjectMapper - Class in net.corda.jackson
 
JacksonSupport.NodeInfoDeserializer - Class in net.corda.jackson
 
JacksonSupport.NodeInfoSerializer - Class in net.corda.jackson
 
JacksonSupport.NoPartyObjectMapper - Class in net.corda.jackson
 
JacksonSupport.OpaqueBytesDeserializer - Class in net.corda.jackson
 
JacksonSupport.OpaqueBytesSerializer - Class in net.corda.jackson
 
JacksonSupport.PartyDeserializer - Class in net.corda.jackson
 
JacksonSupport.PartyObjectMapper - Interface in net.corda.jackson
 
JacksonSupport.PartySerializer - Class in net.corda.jackson
 
JacksonSupport.PublicKeyDeserializer - Class in net.corda.jackson
 
JacksonSupport.PublicKeySerializer - Class in net.corda.jackson
 
JacksonSupport.RpcObjectMapper - Class in net.corda.jackson
 
JacksonSupport.SecureHashDeserializer<T extends SecureHash> - Class in net.corda.jackson
Implemented as a class so that we can instantiate for T.
JacksonSupport.SecureHashSerializer - Class in net.corda.jackson
 
JacksonSupport.ToStringSerializer - Class in net.corda.jackson
 
JacksonSupport.X500NameDeserializer - Class in net.corda.jackson
 
JacksonSupport.X500NameSerializer - Class in net.corda.jackson
 
JDBCHashedTable - Class in net.corda.node.utilities
 
JDBCHashedTable(tableName) - Constructor for class net.corda.node.utilities.JDBCHashedTable
 
JDBCHashMap<K,V> - Class in net.corda.node.utilities
A convenient JDBC table backed hash map with iteration order based on insertion order. See class AbstractJDBCHashMap for further implementation details.
JDBCHashMap(tableName, loadOnInit, maxBuckets) - Constructor for class net.corda.node.utilities.JDBCHashMap
A convenient JDBC table backed hash map with iteration order based on insertion order. See class AbstractJDBCHashMap for further implementation details.
JDBCHashMap.BlobMapTable - Class in net.corda.node.utilities
 
JDBCHashMapKt - Class in net.corda.node.utilities
 
JDBCHashSet<K> - Class in net.corda.node.utilities
A convenient JDBC table backed hash set with iteration order based on insertion order. See class AbstractJDBCHashSet and class AbstractJDBCHashMap for further implementation details.
JDBCHashSet(tableName, loadOnInit, maxBuckets) - Constructor for class net.corda.node.utilities.JDBCHashSet
A convenient JDBC table backed hash set with iteration order based on insertion order. See class AbstractJDBCHashSet and class AbstractJDBCHashMap for further implementation details.
JDBCHashSet.BlobSetTable - Class in net.corda.node.utilities
 
jdbcSession() - Method in class net.corda.node.services.database.RequeryConfiguration
 
JPY - Static variable in class net.corda.core.contracts.ContractsDSL
 
justTransition(to) - Method in class net.corda.core.internal.LifeCycle
Transition the state to to without performing a current state check.

K

KeyFactory - Class in net.corda.core.crypto.composite
 
KeyFactory() - Constructor for class net.corda.core.crypto.composite.KeyFactory
 
keyFromRow(row) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
Implementation should return the key object marshalled from the database table row.
keyFromRow(row) - Method in class net.corda.node.utilities.JDBCHashMap
Implementation should return the key object marshalled from the database table row.
KeyManagementService - Interface in net.corda.core.node.services
The KMS is responsible for storing and using private keys to sign things. An implementation of this may, for example, call out to a hardware security module that enforces various auditing and frequency-of-use requirements.
keySet() - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
 
keySet() - Method in class net.corda.core.crypto.provider.CordaSecurityProvider
 
keySet() - Method in class net.corda.node.utilities.AbstractJDBCHashMap
 
KeyStoreUtilitiesKt - Class in net.corda.node.utilities
 
KeyStoreWrapper - Class in net.corda.node.utilities
 
KeyStoreWrapper(storePath, storePassword) - Constructor for class net.corda.node.utilities.KeyStoreWrapper
 
KMSUtilsKt - Class in net.corda.node.services.keys
 
KotlinConfigurationTransactionWrapper - Class in net.corda.node.services.database
Requery KotlinConfiguration wrapper class to enable us to pass in an existing database connection and associated transaction context.
KotlinConfigurationTransactionWrapper(model, dataSource, mapping, platform, cache, useDefaultLogging, statementCacheSize, batchUpdateSize, quoteTableNames, quoteColumnNames, tableTransformer, columnTransformer, transactionMode, transactionIsolation, statementListeners, entityStateListeners, transactionListeners, writeExecutor) - Constructor for class net.corda.node.services.database.KotlinConfigurationTransactionWrapper
Requery KotlinConfiguration wrapper class to enable us to pass in an existing database connection and associated transaction context.
KotlinConfigurationTransactionWrapper.CordaConnection - Class in net.corda.node.services.database
 
KotlinConfigurationTransactionWrapper.CordaDataSourceConnectionProvider - Class in net.corda.node.services.database
 
KotlinUtilsKt - Class in net.corda.core.utilities
 
KryoAMQPSerializer - Class in net.corda.core.serialization
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.
KryoClientSerializationScheme - Class in net.corda.client.rpc.serialization
 
KryoClientSerializationScheme() - Constructor for class net.corda.client.rpc.serialization.KryoClientSerializationScheme
 
KryoKt - Class in net.corda.core.serialization
 
KryoSerializationCustomization - Class in net.corda.core.serialization
 
KryoSerializationCustomization(kryo) - Constructor for class net.corda.core.serialization.KryoSerializationCustomization
 
KryoServerSerializationScheme - Class in net.corda.node.serialization
 
KryoServerSerializationScheme() - Constructor for class net.corda.node.serialization.KryoServerSerializationScheme
 

L

last($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
 
LastAcknowledgeInfo - Class in net.corda.node.services.network
 
LastAcknowledgeInfo(mapVersion) - Constructor for class net.corda.node.services.network.LastAcknowledgeInfo
 
lastIndexOf(element) - Method in class net.corda.client.jfx.utils.MapValuesList
 
LazyPool<A> - Class in net.corda.core.internal
A lazy pool of resources A.
LazyPool(clear, shouldReturnToPool, bound, newInstance) - Constructor for class net.corda.core.internal.LazyPool
A lazy pool of resources A.
LazyStickyPool<A> - Class in net.corda.core.internal
A class LazyStickyPool is a lazy pool of resources where a borrow may "stick" the borrowed instance to an object. Any subsequent borrows using the same object will return the same pooled instance.
LazyStickyPool(size, newInstance) - Constructor for class net.corda.core.internal.LazyStickyPool
A class LazyStickyPool is a lazy pool of resources where a borrow may "stick" the borrowed instance to an object. Any subsequent borrows using the same object will return the same pooled instance.
Leaf(hash) - Constructor for class net.corda.core.crypto.MerkleTree.Leaf
 
Leaf(hash) - Constructor for class net.corda.core.crypto.PartialTree.Leaf
 
LedgerTransaction - Class in net.corda.core.transactions
A LedgerTransaction is derived from a class WireTransaction. It is the result of doing the following operations:
LedgerTransaction(inputs, outputs, commands, attachments, id, notary, signers, timeWindow, type) - Constructor for class net.corda.core.transactions.LedgerTransaction
A LedgerTransaction is derived from a class WireTransaction. It is the result of doing the following operations:
LedgerTransaction.InOutGroup<T extends ContractState,K> - Class in net.corda.core.transactions
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.
leftOuterJoin($receiver, rightTable, leftToJoinKey, rightToJoinKey, assemble) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
data class Person(val name: String, val managerName: String) val people: ObservableList = (..) val managerEmployeeMapping: ObservableList> = people.leftOuterJoin(people, Person::name, Person::managerName) { manager, employees -> Pair(manager, employees) }
leftOuterJoin($receiver, rightTable, leftToJoinKey, rightToJoinKey) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
data class Person(name: String, favouriteSpecies: Species) data class Animal(name: String, species: Species) val people: ObservableList = (..) val animals: ObservableList = (..) val peopleToFavouriteAnimals: ObservableMap> = people.leftOuterJoin(animals, Person::favouriteSpecies, Animal::species)
LeftOuterJoinedMap<K,A,B,C> - Class in net.corda.client.jfx.utils
class LeftOuterJoinedMap implements a special case of a left outer join where we're matching on primary keys of both tables.
LeftOuterJoinedMap(leftTable, rightTable, assemble) - Constructor for class net.corda.client.jfx.utils.LeftOuterJoinedMap
class LeftOuterJoinedMap implements a special case of a left outer join where we're matching on primary keys of both tables.
LegalNameValidator - Class in net.corda.core.utilities
 
lessThan($receiver, value) - Method in class net.corda.core.node.services.vault.Builder
 
lessThan($receiver, value) - Static method in class net.corda.core.node.services.vault.Builder
 
lessThan(value) - Method in class net.corda.core.node.services.vault.Builder
 
lessThanOrEqual($receiver, value) - Method in class net.corda.core.node.services.vault.Builder
 
lessThanOrEqual($receiver, value) - Static method in class net.corda.core.node.services.vault.Builder
 
lessThanOrEqual(value) - Method in class net.corda.core.node.services.vault.Builder
 
Lifecycle() - Constructor for enum net.corda.contracts.asset.Obligation.Lifecycle
Represents where in its lifecycle a contract state is, which in turn controls the commands that can be applied to the state. Most states will not leave the NORMAL lifecycle. Note that settled (as an end lifecycle) is represented by absence of the state on transaction output.
LifeCycle<S extends Enum<S>> - Class in net.corda.core.internal
This class provides simple tracking of the lifecycle of a service-type object. S is an enum enumerating the possible states the service can be in.
LifeCycle(initial) - Constructor for class net.corda.core.internal.LifeCycle
This class provides simple tracking of the lifecycle of a service-type object. S is an enum enumerating the possible states the service can be in.
lift($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
val aliceHeight: ObservableValue = (..) val bobHeight: ObservableValue = (..) fun sumHeight(a: Long, b: Long): Long { .. }
lift($receiver, arg0) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
 
lift($receiver, arg0, arg1) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
 
lift($receiver, arg0, arg1, arg2) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
 
lift($receiver, arg0, arg1, arg2, arg3) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
 
like($receiver, string) - Method in class net.corda.core.node.services.vault.Builder
 
like($receiver, string) - Static method in class net.corda.core.node.services.vault.Builder
 
Likeness(operator, rightLiteral) - Constructor for class net.corda.core.node.services.vault.ColumnPredicate.Likeness
 
LikenessOperator - Enum in net.corda.core.node.services.vault
 
LikenessOperator() - Constructor for enum net.corda.core.node.services.vault.LikenessOperator
 
LinearInterpolator - Class in net.corda.contracts.math
Interpolates values between the given data points using straight lines.
LinearInterpolator(xs, ys) - Constructor for class net.corda.contracts.math.LinearInterpolator
Interpolates values between the given data points using straight lines.
LinearInterpolator.Factory - Class in net.corda.contracts.math
 
LinearState - Interface in net.corda.core.contracts
A state that evolves by superseding itself, all of which share the common "linearId".
LinearState(externalId, uuid) - Constructor for class net.corda.core.schemas.CommonSchemaV1.LinearState
 
LinearState(uid) - Constructor for class net.corda.core.schemas.CommonSchemaV1.LinearState
 
LinearState.ClauseVerifier<S extends LinearState,C extends CommandData> - Class in net.corda.core.contracts
Standard clause to verify the LinearState safety properties.
LinearStateAttribute(attributeName) - Constructor for enum net.corda.core.node.services.vault.Sort.LinearStateAttribute
 
LinearStateQueryCriteria(participants, linearId, dealRef, status) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
LinearStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultLinearState
LinearStateQueryCriteria(participants, linearId, dealRef) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
LinearStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultLinearState
LinearStateQueryCriteria(participants, linearId) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
LinearStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultLinearState
LinearStateQueryCriteria(participants) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
LinearStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultLinearState
LinearStateQueryCriteria() - Constructor for class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
LinearStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultLinearState
list($receiver, block) - Static method in class net.corda.core.internal.InternalUtilsKt
 
listIterator() - Method in class net.corda.client.jfx.utils.MapValuesList
 
listIterator(index) - Method in class net.corda.client.jfx.utils.MapValuesList
 
load(txid) - Method in class net.corda.core.flows.FetchAttachmentsFlow
 
load(txid) - Method in class net.corda.core.flows.FetchDataFlow
 
load(txid) - Method in class net.corda.core.flows.FetchTransactionsFlow
 
load(name, bytes) - Method in class net.corda.core.serialization.carpenter.CarpenterClassLoader
 
loadCertificateFromPEMFile(filename) - Static method in class net.corda.core.crypto.X509Utilities
Helper method to load back a .pem/.cer format file copy of a certificate.
loadConfig() - Method in class net.corda.node.CmdLineOptions
 
loadConfig(baseDirectory, configFile, allowMissingConfig, configOverrides) - Method in class net.corda.node.services.config.ConfigHelper
 
loadConfigFile(cmdlineOptions) - Method in class net.corda.node.internal.NodeStartup
 
loadKeyStore(keyStoreFilePath, storePassword) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
Helper method to open an existing keystore for modification/read.
loadKeyStore(input, storePassword) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
Helper method to open an existing keystore for modification/read.
loadOrCreateKeyStore(keyStoreFilePath, storePassword) - Static method in class net.corda.node.utilities.KeyStoreUtilitiesKt
Helper method to either open an existing keystore for modification, or create a new blank keystore.
loadState($this, stateRef) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
 
loadState($this, stateRef) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
Given a class StateRef loads the referenced transaction and looks up the specified output interface ContractState.
loadState(stateRef) - Method in interface net.corda.core.node.ServiceHub
Given a class StateRef loads the referenced transaction and looks up the specified output interface ContractState.
loadState(stateRef) - Method in interface net.corda.core.node.ServicesForResolution
Given a class StateRef loads the referenced transaction and looks up the specified output interface ContractState.
loadState($this, stateRef) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
 
localDate($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
 
LocalDateColumnType - Class in net.corda.node.utilities
ColumnType for marshalling to/from database on behalf of java.time.LocalDate.
localDateTime($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
 
LocalDateTimeColumnType - Class in net.corda.node.utilities
ColumnType for marshalling to/from database on behalf of java.time.LocalDateTime.
localWriteObject(data, func) - Method in class net.corda.core.serialization.amqp.PrimArraySerializer
 
locked(body) - Method in class net.corda.core.internal.ThreadBox
 
logElapsedTime($receiver, label, body) - Static method in class net.corda.core.internal.InternalUtilsKt
 
logElapsedTime(label, logger, body) - Static method in class net.corda.core.internal.InternalUtilsKt
 
LoggerSerializer - Class in net.corda.core.serialization
For serialising a Logger.
LoggingWhitelist - Class in net.corda.core.serialization
This class is not currently used, but can be installed to log a large number of missing entries from the whitelist and was used to track down the initial set.
LoggingWhitelist(delegate, global) - Constructor for class net.corda.core.serialization.LoggingWhitelist
This class is not currently used, but can be installed to log a large number of missing entries from the whitelist and was used to track down the initial set.
LoggingWhitelist.Companion - Class in net.corda.core.serialization
 
login() - Method in class net.corda.node.services.messaging.NodeLoginModule
 
logout() - Method in class net.corda.node.services.messaging.NodeLoginModule
 
logStartupInfo(versionInfo, cmdlineOptions, conf) - Method in class net.corda.node.internal.NodeStartup
 
long($receiver) - Static method in class net.corda.client.mock.GeneratorKt
 
longRange($receiver, range) - Static method in class net.corda.client.mock.GeneratorKt
 
longRange($receiver, from, to) - Static method in class net.corda.client.mock.GeneratorKt
 
lookup(publicKey) - Method in class net.corda.client.jfx.model.NetworkIdentityModel
 
lookupParties(ltx) - Method in class net.corda.core.flows.FinalityFlow
Resolve the parties involved in a transaction.
lookupParties(ltx) - Method in class net.corda.core.flows.ManualFinalityFlow
Resolve the parties involved in a transaction.

M

main(args) - Static method in class net.corda.node.Corda
 
make(type, factory) - Method in class net.corda.core.serialization.amqp.ArraySerializer.Companion
 
make(name, cl) - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType.Companion
 
make(type, factory) - Method in class net.corda.core.serialization.amqp.PrimArraySerializer.Companion
 
make(name, readMethod, resolvedType, factory) - Method in class net.corda.core.serialization.amqp.PropertySerializer.Companion
 
makeAllButBlacklistedClassResolver() - Static method in class net.corda.core.serialization.CordaClassResolverKt
 
makeCoreNotaryService(type, tokenizableServices) - Method in class net.corda.node.internal.AbstractNode
 
makeIdentityService(trustRoot, clientCa, legalIdentity) - Method in class net.corda.node.internal.AbstractNode
 
makeKeyManagementService(identityService) - Method in class net.corda.node.internal.AbstractNode
 
makeMessagingService() - Method in class net.corda.node.internal.AbstractNode
 
makeMessagingService() - Method in class net.corda.node.internal.Node
 
makeNetworkMapService() - Method in class net.corda.node.internal.AbstractNode
 
makeNoWhitelistClassResolver() - Static method in class net.corda.core.serialization.CordaClassResolverKt
 
makeServiceEntries() - Method in class net.corda.node.internal.AbstractNode
A service entry contains the advertised class ServiceInfo along with the service identity. The identity name is taken from the configuration or, if non specified, generated by combining the node's legal name and the service id.
makeSessionFactoryForModel(model) - Method in class net.corda.node.services.database.RequeryConfiguration
 
makeStandardClassResolver() - Static method in class net.corda.core.serialization.CordaClassResolverKt
 
makeTransactionStorage() - Method in class net.corda.node.internal.AbstractNode
 
makeTransactionVerifierService() - Method in class net.corda.node.internal.AbstractNode
 
makeTransactionVerifierService() - Method in class net.corda.node.internal.Node
 
ManualFinalityFlow - Class in net.corda.core.flows
Alternative finality flow which only does not attempt to take participants from the transaction, but instead all participating parties must be provided manually.
ManualFinalityFlow(transactions, recipients, progressTracker) - Constructor for class net.corda.core.flows.ManualFinalityFlow
Alternative finality flow which only does not attempt to take participants from the transaction, but instead all participating parties must be provided manually.
ManualFinalityFlow(transaction, extraParticipants) - Constructor for class net.corda.core.flows.ManualFinalityFlow
 
map($receiver, function) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
val person: ObservableValue = (..) val personName: ObservableValue = person.map { it.name }
map($receiver, cached, function) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
val dogs: ObservableList = (..) val dogOwners: ObservableList = dogs.map { it.owner }
map(function) - Method in class net.corda.client.mock.Generator
 
map(function) - Method in class net.corda.core.utilities.Try
Maps the given function to the value from this class Try.Success, or returns this if this is a class Try.Failure.
map($receiver, mapper) - Static method in class net.corda.core.Utils
 
MapChange.Added - Class in net.corda.core.node.services
 
MapChange.Modified - Class in net.corda.core.node.services
 
MapChange.Removed - Class in net.corda.core.node.services
 
MappedList<A,B> - Class in net.corda.client.jfx.utils
This is a variant of EasyBind.map where the mapped list is backed, therefore the mapping function will only be run when an element is inserted or updated. Use this instead of EasyBind.map to trade off memory vs CPU, or if (god forbid) the mapped function is side-effecting.
MappedList(list, function) - Constructor for class net.corda.client.jfx.utils.MappedList
This is a variant of EasyBind.map where the mapped list is backed, therefore the mapping function will only be run when an element is inserted or updated. Use this instead of EasyBind.map to trade off memory vs CPU, or if (god forbid) the mapped function is side-effecting.
MappedSchema - Class in net.corda.core.schemas
A database schema that might be configured for this node. As well as a name and version for identifying the schema, also list the classes that may be used in the generated object graph in order to configure the ORM tool.
MappedSchema(schemaFamily, version, mappedTypes) - Constructor for class net.corda.core.schemas.MappedSchema
A database schema that might be configured for this node. As well as a name and version for identifying the schema, also list the classes that may be used in the generated object graph in order to configure the ORM tool.
MapSerializer - Class in net.corda.core.serialization.amqp
Serialization / deserialization of certain supported Map types.
MapSerializer(declaredType, factory) - Constructor for class net.corda.core.serialization.amqp.MapSerializer
Serialization / deserialization of certain supported Map types.
MapSerializer.Companion - Class in net.corda.core.serialization.amqp
 
MapSerializerKt - Class in net.corda.core.serialization.amqp
 
MapValuesList<K,A,C> - Class in net.corda.client.jfx.utils
class MapValuesList takes an ObservableMap and returns its values as an ObservableList. The order of returned elements is deterministic but unspecified.
MapValuesList.Companion - Class in net.corda.client.jfx.utils
 
match($receiver, success, failure) - Static method in class net.corda.core.Utils
 
matchedClauses(commands) - Method in class net.corda.core.contracts.clauses.AllOf
Determine which clauses are matched by the supplied commands.
matchedClauses(commands) - Method in class net.corda.core.contracts.clauses.AnyOf
Determine which clauses are matched by the supplied commands.
matchedClauses(commands) - Method in class net.corda.core.contracts.clauses.CompositeClause
Determine which clauses are matched by the supplied commands.
matchedClauses(commands) - Method in class net.corda.core.contracts.clauses.FirstComposition
Deprecated.
Determine which clauses are matched by the supplied commands.
matchedClauses(commands) - Method in class net.corda.core.contracts.clauses.FirstOf
Determine which clauses are matched by the supplied commands.
matches($receiver, commands) - Static method in class net.corda.core.contracts.clauses.ClauseKt
Determine if the given list of commands matches the required commands for a clause to trigger.
max($receiver, groupByColumns, orderBy) - Method in class net.corda.core.node.services.vault.Builder
 
max($receiver, groupByColumns, orderBy) - Static method in class net.corda.core.node.services.vault.Builder
 
max($receiver, groupByColumns) - Static method in class net.corda.core.node.services.vault.Builder
 
max($receiver) - Static method in class net.corda.core.node.services.vault.Builder
 
MAX_DEPTH - Static variable in class net.corda.core.serialization.amqp.DeserializedParameterizedType
 
MAX_PAGE_SIZE - Static variable in class net.corda.core.node.services.vault.QueryCriteriaUtils
Note: use class PageSpecification to correctly handle a number of bounded pages of a pre-configured page size.
maxFaultyReplicas(clusterSize) - Static method in class net.corda.node.services.transactions.BFTSMaRtConfigKt
 
maybeRegisterWithNetworkAndExit(cmdlineOptions, conf) - Method in class net.corda.node.internal.NodeStartup
 
maybeWriteToDisk(downloaded) - Method in class net.corda.core.flows.FetchAttachmentsFlow
 
maybeWriteToDisk(downloaded) - Method in class net.corda.core.flows.FetchDataFlow
 
MerkleTransactionKt - Class in net.corda.core.transactions
 
MerkleTree - Class in net.corda.core.crypto
Creation and verification of a Merkle Tree for a Wire Transaction.
MerkleTree.Companion - Class in net.corda.core.crypto
 
MerkleTree.Leaf - Class in net.corda.core.crypto
 
MerkleTree.Node - Class in net.corda.core.crypto
 
MerkleTreeException - Exception in net.corda.core.crypto
 
MerkleTreeException(reason) - Constructor for exception net.corda.core.crypto.MerkleTreeException
 
Message - Interface in net.corda.node.services.messaging
A message is defined, at this level, to be a (topic, timestamp, byte arrays) triple, where the topic is a string in Java-style reverse dns form, with "platform." being a prefix reserved by the platform for its own use. Vendor specific messages can be defined, but use your domain name as the prefix e.g. "uk.co.bigbank.messages.SomeMessage".
MessageHandlerRegistration - Interface in net.corda.node.services.messaging
 
MessageRecipientGroup - Interface in net.corda.core.messaging
A base class for a set of recipients specifically identified by the sender.
MessageRecipients - Interface in net.corda.core.messaging
The interface for a group of message recipients (which may contain only one recipient)
MessagingKt - Class in net.corda.node.services.messaging
 
MessagingService - Interface in net.corda.node.services.messaging
A interface MessagingService sits at the boundary between a message routing / networking layer and the core platform code.
MessagingServiceBuilder<T extends MessagingService> - Interface in net.corda.node.services.messaging
This class lets you start up a interface MessagingService. Its purpose is to stop you from getting access to the methods on the messaging service interface until you have successfully started up the system. One of these objects should be the only way to obtain a reference to a interface MessagingService. Startup may be a slow process: some implementations may let you cast the returned future to an object that lets you get status info.
MetaCarpenter - Class in net.corda.core.serialization.carpenter
 
MetaCarpenter(schemas) - Constructor for class net.corda.core.serialization.carpenter.MetaCarpenter
 
MetaCarpenterBase - Class in net.corda.core.serialization.carpenter
Take a dependency tree of class CarpenterSchemas and reduce it to zero by carpenting those classes that require it. As classes are carpented check for depdency resolution, if now free generate a class Schema for that class and add it to the list of classes (CarpenterSchemas.carpenterSchemas) that require carpenting
MetaCarpenterBase(schemas) - Constructor for class net.corda.core.serialization.carpenter.MetaCarpenterBase
Take a dependency tree of class CarpenterSchemas and reduce it to zero by carpenting those classes that require it. As classes are carpented check for depdency resolution, if now free generate a class Schema for that class and add it to the list of classes (CarpenterSchemas.carpenterSchemas) that require carpenting
MetaData - Class in net.corda.core.crypto
A class MetaData object adds extra information to a transaction. MetaData is used to support a universal digital signature model enabling full, partial, fully or partially blind and metaData attached signatures, (such as an attached timestamp). A MetaData object contains both the merkle root of the transaction and the signer's public key. When signatureType is set to FULL, then visibleInputs and signedInputs can be ignored. Note: We could omit signatureType as it can always be defined by combining visibleInputs and signedInputs, but it helps to speed up the process when FULL is used, and thus we can bypass the extra check on boolean arrays.
MetaData(schemeCodeName, versionID, signatureType, timestamp, visibleInputs, signedInputs, merkleRoot, publicKey) - Constructor for class net.corda.core.crypto.MetaData
A class MetaData object adds extra information to a transaction. MetaData is used to support a universal digital signature model enabling full, partial, fully or partially blind and metaData attached signatures, (such as an attached timestamp). A MetaData object contains both the merkle root of the transaction and the signer's public key. When signatureType is set to FULL, then visibleInputs and signedInputs can be ignored. Note: We could omit signatureType as it can always be defined by combining visibleInputs and signedInputs, but it helps to speed up the process when FULL is used, and thus we can bypass the extra check on boolean arrays.
MetaDataSerializer - Class in net.corda.core.serialization
For serialising a MetaData object.
min($receiver, groupByColumns, orderBy) - Method in class net.corda.core.node.services.vault.Builder
 
min($receiver, groupByColumns, orderBy) - Static method in class net.corda.core.node.services.vault.Builder
 
min($receiver, groupByColumns) - Static method in class net.corda.core.node.services.vault.Builder
 
min($receiver) - Static method in class net.corda.core.node.services.vault.Builder
 
minClusterSize(maxFaultyReplicas) - Static method in class net.corda.node.services.transactions.BFTSMaRtConfigKt
 
minCorrectReplicas(clusterSize) - Static method in class net.corda.node.services.transactions.BFTSMaRtConfigKt
 
minus(other) - Method in class net.corda.core.contracts.Amount
A checked addition operator is supported to simplify netting of Amounts. If this leads to the Amount going negative this will throw IllegalArgumentException.
MissingAttachmentsException - Exception in net.corda.core.serialization
Thrown during deserialisation to indicate that an attachment needed to construct the class WireTransaction is not found
MissingAttachmentsException(ids) - Constructor for exception net.corda.core.serialization.MissingAttachmentsException
Thrown during deserialisation to indicate that an attachment needed to construct the class WireTransaction is not found
MissingParameter(methodName, paramName, command) - Constructor for exception net.corda.jackson.UnparseableCallException.MissingParameter
 
Models - Class in net.corda.client.jfx.model
 
ModelsKt - Class in net.corda.client.jfx.model
 
Modified(node, previousNode) - Constructor for class net.corda.core.node.services.MapChange.Modified
 
MonitoringService - Class in net.corda.node.services.api
Provides access to various metrics and ways to notify monitoring services of things, for sysadmin purposes. This is not an interface because it is too lightweight to bother mocking out.
MonitoringService(metrics) - Constructor for class net.corda.node.services.api.MonitoringService
Provides access to various metrics and ways to notify monitoring services of things, for sysadmin purposes. This is not an interface because it is too lightweight to bother mocking out.
MoreThanOneNotary(txId) - Constructor for exception net.corda.core.contracts.TransactionVerificationException.MoreThanOneNotary
 
Move(contractHash) - Constructor for class net.corda.contracts.asset.Commands.Move
A command stating that money has been moved, optionally to fulfil another contract.
Move() - Constructor for class net.corda.contracts.asset.Commands.Move
A command stating that money has been moved, optionally to fulfil another contract.
move(newAmount, newOwner) - Method in class net.corda.contracts.asset.Cash.State
 
Move(contractHash) - Constructor for class net.corda.contracts.asset.Commands.Move
A command stating that money has been moved, optionally to fulfil another contract.
Move() - Constructor for class net.corda.contracts.asset.Commands.Move
A command stating that money has been moved, optionally to fulfil another contract.
move(newAmount, newOwner) - Method in class net.corda.contracts.asset.CommodityContract.State
 
Move(contractHash) - Constructor for class net.corda.contracts.asset.Commands.Move
A command stating that a debt has been moved, optionally to fulfil another contract.
Move() - Constructor for class net.corda.contracts.asset.Commands.Move
A command stating that a debt has been moved, optionally to fulfil another contract.
move(newAmount, newOwner) - Method in class net.corda.contracts.asset.Obligation.State
 
Move() - Constructor for class net.corda.contracts.Clauses.Move
 
Move(contractHash) - Constructor for class net.corda.contracts.Commands.Move
 
Move() - Constructor for class net.corda.contracts.Commands.Move
 
Move() - Constructor for class net.corda.contracts.Commands.Move
 
move(newAmount, newOwner) - Method in interface net.corda.core.contracts.FungibleAsset
 
moveBusinessDays(date, direction, i) - Method in class net.corda.contracts.BusinessCalendar
Returns a date which is the inbound date plus/minus a given number of business days. TODO: Make more efficient if necessary
MoveCommand - Interface in net.corda.core.contracts
A common move command for contract states which can change owner.
moveTo($receiver, target, options) - Static method in class net.corda.core.internal.InternalUtilsKt
 
MultilateralNetState<P> - Class in net.corda.contracts.clause
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.
MultilateralNetState(template) - Constructor for 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.
MultilateralNettableState<T> - Interface in net.corda.contracts
Interface for state objects that support being netted with other state objects.
MustContainOneOf(trustedAliases) - Constructor for class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
 
MutableClassWhitelist - Interface in net.corda.core.serialization
 
MutableClock - Class in net.corda.node.utilities
An abstract class with helper methods for a type of Clock that might have it's concept of "now" adjusted externally.
MutableClock() - Constructor for class net.corda.node.utilities.MutableClock
An abstract class with helper methods for a type of Clock that might have it's concept of "now" adjusted externally.
myAddresses() - Method in class net.corda.node.internal.AbstractNode
Return list of node's addresses. It's overridden in MockNetwork as we don't have real addresses for MockNodes.
myAddresses() - Method in class net.corda.node.internal.Node
Return list of node's addresses. It's overridden in MockNetwork as we don't have real addresses for MockNodes.

N

NamedByHash - Interface in net.corda.core.contracts
Implemented by anything that can be named by a secure hash value (e.g. transactions, attachments).
nameForType(type) - Method in class net.corda.core.serialization.amqp.SerializerFactory.Companion
 
nameOrNull() - Method in class net.corda.core.identity.AbstractParty
 
nameOrNull() - Method in class net.corda.core.identity.AnonymousParty
 
nameOrNull() - Method in class net.corda.core.identity.Party
 
nativeSQL(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
Net() - Constructor for class net.corda.contracts.asset.Clauses.Net
Clause for supporting netting of obligations.
Net(type) - Constructor for 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.
net(other) - Method in class net.corda.contracts.asset.Obligation.State
Perform bilateral netting of this state with another state. The two states must be compatible (as in bilateralNetState objects are equal).
net(other) - Method in interface net.corda.contracts.BilateralNettableState
Perform bilateral netting of this state with another state. The two states must be compatible (as in bilateralNetState objects are equal).
net.corda.client.jfx.model - package net.corda.client.jfx.model
 
net.corda.client.jfx.utils - package net.corda.client.jfx.utils
 
net.corda.client.mock - package net.corda.client.mock
 
net.corda.client.rpc - package net.corda.client.rpc
 
net.corda.client.rpc.internal - package net.corda.client.rpc.internal
 
net.corda.client.rpc.serialization - package net.corda.client.rpc.serialization
 
net.corda.contracts - package net.corda.contracts
 
net.corda.contracts.asset - package net.corda.contracts.asset
 
net.corda.contracts.clause - package net.corda.contracts.clause
 
net.corda.contracts.math - package net.corda.contracts.math
 
net.corda.core - package net.corda.core
 
net.corda.core.concurrent - package net.corda.core.concurrent
 
net.corda.core.contracts - package net.corda.core.contracts
 
net.corda.core.contracts.clauses - package net.corda.core.contracts.clauses
 
net.corda.core.crypto - package net.corda.core.crypto
 
net.corda.core.crypto.composite - package net.corda.core.crypto.composite
 
net.corda.core.crypto.provider - package net.corda.core.crypto.provider
 
net.corda.core.crypto.testing - package net.corda.core.crypto.testing
 
net.corda.core.flows - package net.corda.core.flows
 
net.corda.core.identity - package net.corda.core.identity
 
net.corda.core.internal - package net.corda.core.internal
 
net.corda.core.messaging - package net.corda.core.messaging
 
net.corda.core.node - package net.corda.core.node
 
net.corda.core.node.services - package net.corda.core.node.services
 
net.corda.core.node.services.vault - package net.corda.core.node.services.vault
 
net.corda.core.schemas - package net.corda.core.schemas
 
net.corda.core.schemas.requery - package net.corda.core.schemas.requery
 
net.corda.core.schemas.requery.converters - package net.corda.core.schemas.requery.converters
 
net.corda.core.serialization - package net.corda.core.serialization
 
net.corda.core.serialization.amqp - package net.corda.core.serialization.amqp
 
net.corda.core.serialization.amqp.custom - package net.corda.core.serialization.amqp.custom
 
net.corda.core.serialization.carpenter - package net.corda.core.serialization.carpenter
 
net.corda.core.transactions - package net.corda.core.transactions
 
net.corda.core.utilities - package net.corda.core.utilities
 
net.corda.flows - package net.corda.flows
 
net.corda.jackson - package net.corda.jackson
 
net.corda.node - package net.corda.node
 
net.corda.node.internal - package net.corda.node.internal
 
net.corda.node.serialization - package net.corda.node.serialization
 
net.corda.node.services - package net.corda.node.services
 
net.corda.node.services.api - package net.corda.node.services.api
 
net.corda.node.services.config - package net.corda.node.services.config
 
net.corda.node.services.database - package net.corda.node.services.database
 
net.corda.node.services.events - package net.corda.node.services.events
 
net.corda.node.services.identity - package net.corda.node.services.identity
 
net.corda.node.services.keys - package net.corda.node.services.keys
 
net.corda.node.services.messaging - package net.corda.node.services.messaging
 
net.corda.node.services.network - package net.corda.node.services.network
 
net.corda.node.services.persistence - package net.corda.node.services.persistence
 
net.corda.node.services.schema - package net.corda.node.services.schema
 
net.corda.node.services.statemachine - package net.corda.node.services.statemachine
 
net.corda.node.services.transactions - package net.corda.node.services.transactions
 
net.corda.node.services.vault - package net.corda.node.services.vault
 
net.corda.node.shell - package net.corda.node.shell
 
net.corda.node.utilities - package net.corda.node.utilities
 
net.corda.node.utilities.registration - package net.corda.node.utilities.registration
 
net.corda.schemas - package net.corda.schemas
 
netAmountsDue(balances) - Static method in class net.corda.contracts.asset.ObligationKt
Net off the amounts due between parties.
NetClause<C extends CommandData,P> - Class in net.corda.contracts.clause
Clause for netting contract states. Currently only supports obligation contract.
NetClause() - Constructor for class net.corda.contracts.clause.NetClause
Clause for netting contract states. Currently only supports obligation contract.
NetCommand - Interface in net.corda.contracts
A common netting command for contracts whose states can be netted.
NetState<P> - Interface in net.corda.contracts.clause
Common interface for the state subsets used when determining nettability of two or more states. Exposes the underlying issued thing.
NettableState<N extends BilateralNettableState<N>,T> - Interface in net.corda.contracts
 
NetType - Enum in net.corda.contracts
Enum for the types of netting that can be applied to state objects. Exact behaviour for each type of netting is left to the contract to determine.
NetType() - Constructor for enum net.corda.contracts.NetType
Enum for the types of netting that can be applied to state objects. Exact behaviour for each type of netting is left to the contract to determine.
network - Variable in class net.corda.node.internal.AbstractNode
 
NetworkCacheError - Exception in net.corda.node.services.api
 
NetworkCacheError.DeregistrationFailed - Exception in net.corda.node.services.api
Indicates a failure to deregister, because of a rejected request from the remote node
NetworkHostAndPort - Class in net.corda.core.utilities
Tuple of host and port. Use parseNetworkHostAndPort on untrusted data.
NetworkHostAndPort(host, port) - Constructor for class net.corda.core.utilities.NetworkHostAndPort
Tuple of host and port. Use parseNetworkHostAndPort on untrusted data.
NetworkHostAndPort.Companion - Class in net.corda.core.utilities
 
NetworkHostAndPortKt - Class in net.corda.core.utilities
 
NetworkIdentityModel - Class in net.corda.client.jfx.model
 
NetworkIdentityModel() - Constructor for class net.corda.client.jfx.model.NetworkIdentityModel
 
NetworkMapCache - Interface in net.corda.core.node.services
A network map contains lists of nodes on the network along with information about their identity keys, services they provide and host names or IP addresses where they can be connected to. The cache wraps around a map fetched from an authoritative service, and adds easy lookup of the data stored within it. Generally it would be initialised with a specified network map service, which it fetches data from and then subscribes to updates of.
NetworkMapCache.DefaultImpls - Class in net.corda.core.node.services
A network map contains lists of nodes on the network along with information about their identity keys, services they provide and host names or IP addresses where they can be connected to. The cache wraps around a map fetched from an authoritative service, and adds easy lookup of the data stored within it. Generally it would be initialised with a specified network map service, which it fetches data from and then subscribes to updates of.
NetworkMapCache.MapChange - Class in net.corda.core.node.services
 
NetworkMapCacheInternal - Interface in net.corda.node.services.api
 
networkMapFeed() - Method in interface net.corda.core.messaging.CordaRPCOps
Returns all parties currently visible on the network with their advertised services and an observable of future updates to the network.
networkMapFeed() - Method in class net.corda.node.internal.CordaRPCOpsImpl
Returns all parties currently visible on the network with their advertised services and an observable of future updates to the network.
NetworkMapInfo - Class in net.corda.node.internal
 
NetworkMapInfo(address, legalName) - Constructor for class net.corda.node.internal.NetworkMapInfo
 
NetworkMapService - Interface in net.corda.node.services.network
A network map contains lists of nodes on the network along with information about their identity keys, services they provide and host names or IP addresses where they can be connected to. This information is cached locally within nodes, by the interface NetworkMapCache. Currently very basic consensus controls are applied, using signed changes which replace each other based on a serial number present in the change.
NetworkMapService.Companion - Class in net.corda.node.services.network
 
NetworkMapService.FetchMapRequest - Class in net.corda.node.services.network
 
NetworkMapService.FetchMapResponse - Class in net.corda.node.services.network
 
NetworkMapService.QueryIdentityRequest - Class in net.corda.node.services.network
 
NetworkMapService.QueryIdentityResponse - Class in net.corda.node.services.network
 
NetworkMapService.RegistrationRequest - Class in net.corda.node.services.network
 
NetworkMapService.RegistrationResponse - Class in net.corda.node.services.network
If error is null then the registration was successful. If not null then it wasn't and it explains why
NetworkMapService.SubscribeRequest - Class in net.corda.node.services.network
 
NetworkMapService.SubscribeResponse - Class in net.corda.node.services.network
 
NetworkMapService.Update - Class in net.corda.node.services.network
 
NetworkMapService.UpdateAcknowledge - Class in net.corda.node.services.network
 
networkMapUpdates($this) - Static method in class net.corda.core.messaging.CordaRPCOps.DefaultImpls
Deprecated. 
networkMapUpdates() - Method in interface net.corda.core.messaging.CordaRPCOps
Deprecated. 
NetworkRegistrationHelper - Class in net.corda.node.utilities.registration
This checks the config.certificatesDirectory field for certificates required to connect to a Corda network. If the certificates are not found, a org.bouncycastle.pkcs.PKCS10CertificationRequest will be submitted to Corda network permissioning server using interface NetworkRegistrationService. This process will enter a polling loop until the request has been approved, and then the certificate chain will be downloaded and stored in KeyStore reside in the certificates directory.
NetworkRegistrationHelper(config, certService) - Constructor for class net.corda.node.utilities.registration.NetworkRegistrationHelper
This checks the config.certificatesDirectory field for certificates required to connect to a Corda network. If the certificates are not found, a org.bouncycastle.pkcs.PKCS10CertificationRequest will be submitted to Corda network permissioning server using interface NetworkRegistrationService. This process will enter a polling loop until the request has been approved, and then the certificate chain will be downloaded and stored in KeyStore reside in the certificates directory.
NetworkRegistrationHelper.Companion - Class in net.corda.node.utilities.registration
 
NetworkRegistrationService - Interface in net.corda.node.utilities.registration
 
newInstance(described) - Method in class net.corda.core.serialization.amqp.Choice.Companion
 
newInstance(described) - Method in class net.corda.core.serialization.amqp.CompositeType.Companion
 
newInstance(described) - Method in class net.corda.core.serialization.amqp.Descriptor.Companion
 
newInstance(described) - Method in class net.corda.core.serialization.amqp.Envelope.Companion
 
newInstance(described) - Method in class net.corda.core.serialization.amqp.Field.Companion
 
newInstance(described) - Method in class net.corda.core.serialization.amqp.RestrictedType.Companion
 
newInstance(described) - Method in class net.corda.core.serialization.amqp.Schema.Companion
 
newInstance(name, fields, superclass, interfaces, isInterface) - Method in class net.corda.core.serialization.carpenter.CarpenterSchemaFactory
 
newInstance() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas.CarpenterSchemaConstructor
 
newInstance(mandatory, name, field) - Method in class net.corda.core.serialization.carpenter.FieldFactory
 
newSecureRandom() - Static method in class net.corda.core.crypto.CryptoUtils
Get an instance of SecureRandom to avoid blocking, due to waiting for additional entropy, when possible. In this version, the NativePRNGNonBlocking is exclusively used on Linux OS to utilize dev/urandom because in high traffic /dev/random may wait for a certain amount of "noise" to be generated on the host machine before returning a result.
newTransaction(isolation) - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
 
newTransaction(isolation) - Method in class net.corda.node.utilities.ExposedTransactionManager
 
nextCertificate() - Method in class net.corda.core.crypto.CertificateStream
 
nextFixingOf() - Method in interface net.corda.contracts.FixableDealState
When is the next fixing and what is the fixing for?
nextScheduledActivity(thisStateRef, flowLogicRefFactory) - Method in interface net.corda.core.contracts.SchedulableState
Indicate whether there is some activity to be performed at some future point in time with respect to this interface ContractState, what that activity is and at what point in time it should be initiated. This can be used to implement deadlines for payment or processing of financial instruments according to a schedule.
nextStep() - Method in class net.corda.core.utilities.ProgressTracker
Iterates the progress tracker. If the current step has a child, the child is iterated instead (recursively). Returns the latest step at the bottom of the step tree.
NoApplicableConstructor(errors) - Constructor for exception net.corda.node.shell.InteractiveShell.NoApplicableConstructor
 
Node(hash, left, right) - Constructor for class net.corda.core.crypto.MerkleTree.Node
 
Node(left, right) - Constructor for class net.corda.core.crypto.PartialTree.Node
 
Node(node) - Constructor for class net.corda.core.node.services.PartyInfo.Node
 
Node - Class in net.corda.node.internal
A Node manages a standalone server that takes part in the P2P network. It creates the services found in interface ServiceHub, loads important data off disk and starts listening for connections.
Node(configuration, advertisedServices, versionInfo, clock, initialiseSerialization) - Constructor for class net.corda.node.internal.Node
A Node manages a standalone server that takes part in the P2P network. It creates the services found in interface ServiceHub, loads important data off disk and starts listening for connections.
Node.Companion - Class in net.corda.node.internal
 
NODE_DATABASE_PREFIX - Static variable in class net.corda.node.utilities.DatabaseSupportKt
Table prefix for all tables owned by the node module.
NODE_ROLE - Static variable in class net.corda.node.services.messaging.NodeLoginModule
 
NodeAndWeight(node, weight) - Constructor for 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.
NodeAttachmentService - Class in net.corda.node.services.persistence
Stores attachments in H2 database.
NodeAttachmentService(storePath, dataSourceProperties, metrics) - Constructor for class net.corda.node.services.persistence.NodeAttachmentService
Stores attachments in H2 database.
NodeAttachmentService.Companion - Class in net.corda.node.services.persistence
 
NodeAttachmentService.HashCheckingStream - Class in net.corda.node.services.persistence
Wraps a stream and hashes data as it is read: if the entire stream is consumed, then at the end the hash of the read data is compared to the expected hash and exception NodeAttachmentService.HashMismatchException is thrown by either NodeAttachmentService.HashCheckingStream.read or NodeAttachmentService.HashCheckingStream.close if they didn't match. The goal of this is to detect cases where attachments in the store have been tampered with or corrupted and no longer match their file name. It won't always work: if we read a zip for our own uses and skip around inside it, we haven't read the whole file, so we can't check the hash. But when copying it over the network this will provide an additional safety check against user error.
NodeAttachmentService.HashMismatchException - Exception in net.corda.node.services.persistence
 
NodeClock - Class in net.corda.node.serialization
A Clock that tokenizes itself when serialized, and delegates to an underlying Clock implementation.
NodeClock(delegateClock) - Constructor for class net.corda.node.serialization.NodeClock
A Clock that tokenizes itself when serialized, and delegates to an underlying Clock implementation.
NodeClock() - Constructor for class net.corda.node.serialization.NodeClock
A Clock that tokenizes itself when serialized, and delegates to an underlying Clock implementation.
NodeConfiguration - Interface in net.corda.node.services.config
 
NodeDatabaseConnectionProvider() - Constructor for class net.corda.node.services.database.HibernateConfiguration.NodeDatabaseConnectionProvider
 
nodeIdentity() - Method in interface net.corda.core.messaging.CordaRPCOps
Returns Node's identity, assuming this will not change while the node is running.
nodeIdentity() - Method in class net.corda.node.internal.CordaRPCOpsImpl
Returns Node's identity, assuming this will not change while the node is running.
nodeIdentityFromParty(party) - Method in interface net.corda.core.messaging.CordaRPCOps
Returns a node's identity from the network map cache, where known.
nodeIdentityFromParty(party) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Returns a node's identity from the network map cache, where known.
NodeInfo - Class in net.corda.core.node
Info about a network node that acts on behalf of some form of contract party.
NodeInfo(addresses, legalIdentityAndCert, legalIdentitiesAndCerts, platformVersion, advertisedServices, worldMapLocation) - Constructor for class net.corda.core.node.NodeInfo
Info about a network node that acts on behalf of some form of contract party.
NodeLoginModule - Class in net.corda.node.services.messaging
Clients must connect to us with a username and password and must use TLS. If a someone connects with ArtemisMessagingComponent.NODE_USER then we confirm it's just us as the node by checking their TLS certificate is the same as our one in our key store. Then they're given full access to all valid queues. If they connect with ArtemisMessagingComponent.PEER_USER then we confirm they belong on our P2P network by checking their root CA is the same as our root CA. If that's the case the only access they're given is the ablility send to our P2P address. In both cases the messages these authenticated nodes send to us are tagged with their subject DN and we assume the CN within that is their legal name. Otherwise if the username is neither of the above we assume it's an RPC user and authenticate against our list of valid RPC users. RPC clients are given permission to perform RPC and nothing else.
NodeLoginModule() - Constructor for class net.corda.node.services.messaging.NodeLoginModule
Clients must connect to us with a username and password and must use TLS. If a someone connects with ArtemisMessagingComponent.NODE_USER then we confirm it's just us as the node by checking their TLS certificate is the same as our one in our key store. Then they're given full access to all valid queues. If they connect with ArtemisMessagingComponent.PEER_USER then we confirm they belong on our P2P network by checking their root CA is the same as our root CA. If that's the case the only access they're given is the ablility send to our P2P address. In both cases the messages these authenticated nodes send to us are tagged with their subject DN and we assume the CN within that is their legal name. Otherwise if the username is neither of the above we assume it's an RPC user and authenticate against our list of valid RPC users. RPC clients are given permission to perform RPC and nothing else.
NodeLoginModule.Companion - Class in net.corda.node.services.messaging
 
NodeMapError - Exception in net.corda.node.services.network
 
NodeMapError.InvalidSignature - Exception in net.corda.node.services.network
Thrown if the signature on the node info does not match the public key for the identity
NodeMapError.InvalidSubscriber - Exception in net.corda.node.services.network
Thrown if the replyTo of a subscription change message is not a single message recipient
NodeMessagingClient - Class in net.corda.node.services.messaging
This class implements the interface MessagingService API using Apache Artemis, the successor to their ActiveMQ product. Artemis is a message queue broker and here we run a client connecting to the specified broker instance class ArtemisMessagingServer. It's primarily concerned with peer-to-peer messaging.
NodeMessagingClient(config, versionInfo, serverAddress, myIdentity, nodeExecutor, database, networkMapRegistrationFuture, monitoringService, advertisedAddress) - Constructor for class net.corda.node.services.messaging.NodeMessagingClient
This class implements the interface MessagingService API using Apache Artemis, the successor to their ActiveMQ product. Artemis is a message queue broker and here we run a client connecting to the specified broker instance class ArtemisMessagingServer. It's primarily concerned with peer-to-peer messaging.
NodeMessagingClient.Companion - Class in net.corda.node.services.messaging
 
NodeMessagingClient.Handler - Class in net.corda.node.services.messaging
A registration to handle messages of different types
NodeMonitorModel - Class in net.corda.client.jfx.model
This model exposes raw event streams to and from the node.
NodeMonitorModel() - Constructor for class net.corda.client.jfx.model.NodeMonitorModel
This model exposes raw event streams to and from the node.
NodeRegistration - Class in net.corda.node.services.network
A node registration state in the network map.
NodeRegistration(node, serial, type, expires) - Constructor for class net.corda.node.services.network.NodeRegistration
A node registration state in the network map.
NodeRegistrationInfo - Class in net.corda.node.services.network
 
NodeRegistrationInfo(reg, mapVersion) - Constructor for class net.corda.node.services.network.NodeRegistrationInfo
 
NodeSchedulerService - Class in net.corda.node.services.events
A first pass of a simple interface SchedulerService that works with class MutableClocks for testing, demonstrations and simulations that also encompasses the class Vault observer for processing transactions.
NodeSchedulerService(services, schedulerTimerExecutor, unfinishedSchedules) - Constructor for class net.corda.node.services.events.NodeSchedulerService
A first pass of a simple interface SchedulerService that works with class MutableClocks for testing, demonstrations and simulations that also encompasses the class Vault observer for processing transactions.
NodeSchedulerService.Companion - Class in net.corda.node.services.events
 
NodeSchemaService - Class in net.corda.node.services.schema
Most basic implementation of interface SchemaService.
NodeSchemaService(customSchemas) - Constructor for class net.corda.node.services.schema.NodeSchemaService
Most basic implementation of interface SchemaService.
NodeSchemaService() - Constructor for class net.corda.node.services.schema.NodeSchemaService
Most basic implementation of interface SchemaService.
NodeStartup - Class in net.corda.node.internal
This class is responsible for starting a Node from command line arguments.
NodeStartup(args) - Constructor for class net.corda.node.internal.NodeStartup
This class is responsible for starting a Node from command line arguments.
NodeStartup.Companion - Class in net.corda.node.internal
 
NodeVaultService - Class in net.corda.node.services.vault
Currently, the node vault service is a very simple RDBMS backed implementation. It will change significantly when we add further functionality as the design for the vault and vault service matures.
NodeVaultService(services, dataSourceProperties) - Constructor for class net.corda.node.services.vault.NodeVaultService
Currently, the node vault service is a very simple RDBMS backed implementation. It will change significantly when we add further functionality as the design for the vault and vault service matures.
NonEmptySet<T> - Class in net.corda.core.utilities
An immutable ordered non-empty set.
NonEmptySet.Companion - Class in net.corda.core.utilities
 
noneOrSingle($receiver, predicate) - Static method in class net.corda.core.internal.InternalUtilsKt
Returns the single element matching the given predicate, or null if the collection is empty, or throws exception if more than one element was found.
noneOrSingle($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
Returns the single element, or null if the list is empty, or throws an exception if it has more than one element.
noNetworkMapConfigured() - Method in class net.corda.node.internal.AbstractNode
This is overriden by the mock node implementation to enable operation without any network map service
NonNullableField - Class in net.corda.core.serialization.carpenter
 
NonNullableField(field) - Constructor for class net.corda.core.serialization.carpenter.NonNullableField
 
NonNullableField(name, field) - Constructor for class net.corda.core.serialization.carpenter.NonNullableField
 
nonNullValueToString(value) - Method in class net.corda.node.utilities.InstantColumnType
 
nonNullValueToString(value) - Method in class net.corda.node.utilities.LocalDateColumnType
 
nonNullValueToString(value) - Method in class net.corda.node.utilities.LocalDateTimeColumnType
 
NonValidatingNotaryFlow - Class in net.corda.node.services.transactions
 
NonValidatingNotaryFlow(otherSide, service) - Constructor for class net.corda.node.services.transactions.NonValidatingNotaryFlow
 
NoPartyObjectMapper(factory) - Constructor for class net.corda.jackson.JacksonSupport.NoPartyObjectMapper
 
NoReferencesSerializer<T> - Class in net.corda.core.serialization
 
NoReferencesSerializer(baseSerializer) - Constructor for class net.corda.core.serialization.NoReferencesSerializer
 
normaliseLegalName(legalName) - Static method in class net.corda.core.utilities.LegalNameValidator
The normalize function will trim the input string, replace any multiple spaces with a single space, and normalize the string according to NFKC normalization form.
NormalSessionEnd - Class in net.corda.node.services.statemachine
 
NormalSessionEnd(recipientSessionId) - Constructor for class net.corda.node.services.statemachine.NormalSessionEnd
 
Not(expression) - Constructor for class net.corda.core.node.services.vault.CriteriaExpression.Not
 
NotaryChange.Builder - Class in net.corda.core.contracts
A transaction builder that automatically sets the transaction type to class TransactionType.NotaryChange and adds the list of participants to the signers set for every input state.
NotaryChangeFlow<T extends ContractState> - Class in net.corda.core.flows
A flow to be used for changing a state's Notary. This is required since all input states to a transaction must point to the same notary.
NotaryChangeFlow(originalState, newNotary, progressTracker) - Constructor for class net.corda.core.flows.NotaryChangeFlow
A flow to be used for changing a state's Notary. This is required since all input states to a transaction must point to the same notary.
NotaryChangeHandler - Class in net.corda.node.services
 
NotaryChangeHandler(otherSide) - Constructor for class net.corda.node.services.NotaryChangeHandler
 
NotaryChangeInWrongTransactionType(txId, txNotary, outputNotary) - Constructor for exception net.corda.core.contracts.TransactionVerificationException.NotaryChangeInWrongTransactionType
 
NotaryError - Class in net.corda.core.flows
 
NotaryError.Conflict - Class in net.corda.core.flows
 
NotaryError.TimeWindowInvalid - Class in net.corda.core.flows
Thrown if the time specified in the class TimeWindow command is outside the allowed tolerance.
NotaryError.TransactionInvalid - Class in net.corda.core.flows
 
NotaryException - Exception in net.corda.core.flows
 
NotaryException(error) - Constructor for exception net.corda.core.flows.NotaryException
 
NotaryFlow - Class in net.corda.core.flows
 
NotaryFlow.Client - Class in net.corda.core.flows
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.
NotaryFlow.Service - Class in net.corda.core.flows
A flow run by a notary service that handles notarisation requests.
notaryParty - Variable in class net.corda.core.flows.NotaryFlow.Client
 
NotaryService - Class in net.corda.core.node.services
 
NotaryService() - Constructor for class net.corda.core.node.services.NotaryService
 
notEqual($receiver, value) - Method in class net.corda.core.node.services.vault.Builder
 
notEqual($receiver, value) - Static method in class net.corda.core.node.services.vault.Builder
 
notEqual(value) - Method in class net.corda.core.node.services.vault.Builder
 
notify($this, tx) - Static method in class net.corda.core.node.services.VaultService.DefaultImpls
Same as notifyAll but with a single transaction.
notify(tx) - Method in interface net.corda.core.node.services.VaultService
Same as notifyAll but with a single transaction.
notifyAll(txns) - Method in interface net.corda.core.node.services.VaultService
Possibly update the vault by marking as spent states that these transactions consume, and adding any relevant new states that they create. You should only insert transactions that have been successfully verified here!
notifyAll(txns) - Method in class net.corda.node.services.vault.NodeVaultService
Possibly update the vault by marking as spent states that these transactions consume, and adding any relevant new states that they create. You should only insert transactions that have been successfully verified here!
notifyMutationObservers() - Method in class net.corda.node.utilities.MutableClock
Must be called by subclasses when they mutate (but not just with the passage of time as per the "wall clock").
NotifyTransactionHandler - Class in net.corda.node.services
 
NotifyTransactionHandler(otherParty) - Constructor for class net.corda.node.services.NotifyTransactionHandler
 
NotifyTxRequest(tx) - Constructor for class net.corda.core.flows.BroadcastTransactionFlow.NotifyTxRequest
 
notIn($receiver, collection) - Method in class net.corda.core.node.services.vault.Builder
 
notIn($receiver, collection) - Static method in class net.corda.core.node.services.vault.Builder
 
notIn(collection) - Method in class net.corda.core.node.services.vault.Builder
 
notLike($receiver, string) - Method in class net.corda.core.node.services.vault.Builder
 
notLike($receiver, string) - Static method in class net.corda.core.node.services.vault.Builder
 
notNull($receiver) - Method in class net.corda.core.node.services.vault.Builder
 
notNull($receiver) - Static method in class net.corda.core.node.services.vault.Builder
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.CertPathColumnType
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.InstantColumnType
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.LocalDateColumnType
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.LocalDateTimeColumnType
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.PublicKeyColumnType
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.SecureHashColumnType
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.UUIDStringColumnType
 
notNullValueToDB(value) - Method in class net.corda.node.utilities.X509CertificateColumnType
 
notUsed($receiver) - Static method in class net.corda.client.rpc.UtilsKt
This function should be invoked on any unwanted Observables returned from RPC to release the server resources.
novate(centralParty) - Method in class net.corda.core.contracts.AmountTransfer
Novation is a common financial operation in which a bilateral exchange is modified so that the same relative asset exchange happens, but with each party exchanging versus a central counterparty, or clearing house.
NoZeroSizedOutputs<S extends FungibleAsset<T>,C extends CommandData,T> - Class in net.corda.contracts.clause
Clause for fungible asset contracts, which enforces that no output state should have a balance of zero.
NoZeroSizedOutputs() - Constructor for class net.corda.contracts.clause.NoZeroSizedOutputs
Clause for fungible asset contracts, which enforces that no output state should have a balance of zero.
NullableField - Class in net.corda.core.serialization.carpenter
 
NullableField(field) - Constructor for class net.corda.core.serialization.carpenter.NullableField
 
NullableField(name, field) - Constructor for class net.corda.core.serialization.carpenter.NullableField
 
NullablePrimitiveException - Exception in net.corda.core.serialization.carpenter
 
NullablePrimitiveException(msg) - Constructor for exception net.corda.core.serialization.carpenter.NullablePrimitiveException
 
NullExpression(operator) - Constructor for class net.corda.core.node.services.vault.ColumnPredicate.NullExpression
 
NullOperator - Enum in net.corda.core.node.services.vault
 
NullOperator() - Constructor for enum net.corda.core.node.services.vault.NullOperator
 
NullPublicKey - Class in net.corda.core.crypto.testing
 
NullSignature - Class in net.corda.core.crypto.testing
A signature with a key and value of zero. Useful when you want a signature object that you know won't ever be used.
nullTest(mv, slot) - Method in class net.corda.core.serialization.carpenter.Field
 
nullTest(mv, slot) - Method in class net.corda.core.serialization.carpenter.NonNullableField
 
nullTest(mv, slot) - Method in class net.corda.core.serialization.carpenter.NullableField
 

O

objectAndEnvelope<T> - Class in net.corda.core.serialization.amqp
 
objectAndEnvelope(obj, envelope) - Constructor for class net.corda.core.serialization.amqp.objectAndEnvelope
 
objectMapper() - Method in class net.corda.node.shell.InteractiveShellCommand
 
ObjectPropertyDelegate(klass, objectPropertyProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.ObjectPropertyDelegate
 
ObjectSerializer - Class in net.corda.core.serialization.amqp
Responsible for serializing and deserializing a regular object instance via a series of properties (matched with a constructor).
ObjectSerializer(clazz, factory) - Constructor for class net.corda.core.serialization.amqp.ObjectSerializer
Responsible for serializing and deserializing a regular object instance via a series of properties (matched with a constructor).
Obligation<P> - Class in net.corda.contracts.asset
An obligation contract commits the obligor to delivering a specified amount of a fungible asset (for example the class Cash contract) at a specified future point in time. Settlement transactions may split and merge contracts across multiple input and output states. The goal of this design is to handle amounts owed, and these contracts are expected to be netted/merged, with settlement only for any remainder amount.
Obligation() - Constructor for class net.corda.contracts.asset.Obligation
An obligation contract commits the obligor to delivering a specified amount of a fungible asset (for example the class Cash contract) at a specified future point in time. Settlement transactions may split and merge contracts across multiple input and output states. The goal of this design is to handle amounts owed, and these contracts are expected to be netted/merged, with settlement only for any remainder amount.
Obligation.Clauses - Interface in net.corda.contracts.asset
 
Obligation.Commands - Interface in net.corda.contracts.asset
 
Obligation.Lifecycle - Enum in net.corda.contracts.asset
Represents where in its lifecycle a contract state is, which in turn controls the commands that can be applied to the state. Most states will not leave the NORMAL lifecycle. Note that settled (as an end lifecycle) is represented by absence of the state on transaction output.
Obligation.State<P> - Class in net.corda.contracts.asset
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.
Obligation.Terms<P> - Class in net.corda.contracts.asset
Subset of state, containing the elements specified when issuing a new settlement contract.
ObligationKt - Class in net.corda.contracts.asset
 
ObservableContext - Class in net.corda.client.rpc.internal
Holds a context available during Kryo deserialisation of messages that are expected to contain Observables.
ObservableContext(callSiteMap, observableMap, hardReferenceStore) - Constructor for class net.corda.client.rpc.internal.ObservableContext
Holds a context available during Kryo deserialisation of messages that are expected to contain Observables.
ObservableContext - Class in net.corda.node.services.messaging
 
ObservableContext(rpcRequestId, observableMap, clientAddressToObservables, clientAddress, serverControl, sessionAndProducerPool, observationSendExecutor) - Constructor for class net.corda.node.services.messaging.ObservableContext
 
ObservableDelegate(klass, observableProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.ObservableDelegate
 
ObservableFoldKt - Class in net.corda.client.jfx.utils
 
ObservableListDelegate(klass, observableListProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.ObservableListDelegate
 
ObservableListReadOnlyDelegate(klass, observableListReadOnlyProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.ObservableListReadOnlyDelegate
 
ObservableSubscription - Class in net.corda.node.services.messaging
 
ObservableSubscription(subscription) - Constructor for class net.corda.node.services.messaging.ObservableSubscription
 
ObservableUtilitiesKt - Class in net.corda.client.jfx.utils
 
ObservableValueDelegate(klass, observableValueProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.ObservableValueDelegate
 
ObserverDelegate(klass, observerProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.ObserverDelegate
 
obtainLegalIdentity() - Method in class net.corda.node.internal.AbstractNode
 
obtainLegalIdentityKey() - Method in class net.corda.node.internal.AbstractNode
 
of(bytes, offset, size) - Method in class net.corda.core.utilities.ByteSequence.Companion
Construct a class ByteSequence given a ByteArray and optional offset and size, that represents that potentially sub-sequence of bytes. The returned implementation is optimised when the whole ByteArray is the sequence.
of(bytes, offset) - Method in class net.corda.core.utilities.ByteSequence.Companion
Construct a class ByteSequence given a ByteArray and optional offset and size, that represents that potentially sub-sequence of bytes. The returned implementation is optimised when the whole ByteArray is the sequence.
of(bytes) - Method in class net.corda.core.utilities.ByteSequence.Companion
Construct a class ByteSequence given a ByteArray and optional offset and size, that represents that potentially sub-sequence of bytes. The returned implementation is optimised when the whole ByteArray is the sequence.
of(bytes, offset, size) - Static method in class net.corda.core.utilities.ByteSequence
Construct a class ByteSequence given a ByteArray and optional offset and size, that represents that potentially sub-sequence of bytes. The returned implementation is optimised when the whole ByteArray is the sequence.
of(bytes, offset) - Static method in class net.corda.core.utilities.ByteSequence
Construct a class ByteSequence given a ByteArray and optional offset and size, that represents that potentially sub-sequence of bytes. The returned implementation is optimised when the whole ByteArray is the sequence.
of(bytes) - Static method in class net.corda.core.utilities.ByteSequence
Construct a class ByteSequence given a ByteArray and optional offset and size, that represents that potentially sub-sequence of bytes. The returned implementation is optimised when the whole ByteArray is the sequence.
of(element) - Method in class net.corda.core.utilities.NonEmptySet.Companion
Returns a singleton set containing element. This behaves the same as Collections.singleton but returns a class NonEmptySet for the extra type-safety.
of(first, second, rest) - Method in class net.corda.core.utilities.NonEmptySet.Companion
Returns a non-empty set containing the given elements, minus duplicates, in the order each was specified.
of(element) - Static method in class net.corda.core.utilities.NonEmptySet
Returns a singleton set containing element. This behaves the same as Collections.singleton but returns a class NonEmptySet for the extra type-safety.
of(first, second, rest) - Static method in class net.corda.core.utilities.NonEmptySet
Returns a non-empty set containing the given elements, minus duplicates, in the order each was specified.
of(b) - Method in class net.corda.core.utilities.OpaqueBytes.Companion
 
of(b) - Static method in class net.corda.core.utilities.OpaqueBytes
 
on(body) - Method in class net.corda.core.utilities.Try.Companion
Executes the given block of code and returns a class Try.Success capturing the result, or a class Try.Failure if an exception is thrown.
on(body) - Static method in class net.corda.core.utilities.Try
Executes the given block of code and returns a class Try.Success capturing the result, or a class Try.Failure if an exception is thrown.
onCompleted() - Method in class net.corda.node.shell.FlowWatchPrintingSubscriber
 
onError(e) - Method in class net.corda.node.shell.FlowWatchPrintingSubscriber
 
OnLedgerAsset<T,C extends CommandData,S extends FungibleAsset<T>> - Class in net.corda.contracts.asset
An asset transaction may split and merge assets 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.
OnLedgerAsset() - Constructor for class net.corda.contracts.asset.OnLedgerAsset
An asset transaction may split and merge assets 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.
OnLedgerAsset.Companion - Class in net.corda.contracts.asset
 
onNext($receiver, topic, sessionId) - Static method in class net.corda.node.services.messaging.MessagingKt
Returns a ListenableFuture of the next message payload (Message.data) which is received on the given topic and sessionId. The payload is deserialized to an object of type M. Any exceptions thrown will be captured by the future.
onNext(t) - Method in class net.corda.node.shell.FlowWatchPrintingSubscriber
 
opaque($receiver) - Static method in class net.corda.core.utilities.ByteArrays
Deprecated. 
OpaqueBytes - Class in net.corda.core.utilities
A simple class that wraps a byte array and makes the equals/hashCode/toString methods work as you actually expect. In an ideal JVM this would be a value type and be completely overhead free. Project Valhalla is adding such functionality to Java, but it won't arrive for a few years yet!
OpaqueBytes(bytes) - Constructor for class net.corda.core.utilities.OpaqueBytes
A simple class that wraps a byte array and makes the equals/hashCode/toString methods work as you actually expect. In an ideal JVM this would be a value type and be completely overhead free. Project Valhalla is adding such functionality to Java, but it won't arrive for a few years yet!
OpaqueBytes.Companion - Class in net.corda.core.utilities
 
open() - Method in class net.corda.core.contracts.AbstractAttachment
 
open() - Method in interface net.corda.core.contracts.Attachment
 
open() - Method in class net.corda.core.utilities.ByteSequence
Returns a ByteArrayInputStream of the bytes
openAsJAR($this) - Static method in class net.corda.core.contracts.Attachment.DefaultImpls
 
openAsJAR() - Method in interface net.corda.core.contracts.Attachment
 
openAttachment(id) - Method in interface net.corda.core.messaging.CordaRPCOps
Download an attachment JAR by ID
openAttachment(id) - Method in interface net.corda.core.node.services.AttachmentStorage
Returns a handle to a locally stored attachment, or null if it's not known. The handle can be used to open a stream for the data, which will be a zip/jar file.
openAttachment(id) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Download an attachment JAR by ID
openAttachment(id) - Method in class net.corda.node.services.persistence.NodeAttachmentService
Returns a handle to a locally stored attachment, or null if it's not known. The handle can be used to open a stream for the data, which will be a zip/jar file.
ops() - Method in class net.corda.node.shell.InteractiveShellCommand
 
or(criteria) - Method in class net.corda.core.node.services.vault.QueryCriteria
 
OutOfProcessTransactionVerifierService - Class in net.corda.node.services.transactions
 
OutOfProcessTransactionVerifierService(monitoringService) - Constructor for class net.corda.node.services.transactions.OutOfProcessTransactionVerifierService
 
OutOfProcessTransactionVerifierService.Companion - Class in net.corda.node.services.transactions
 
OutOfProcessTransactionVerifierService.VerificationResultForUnknownTransaction - Exception in net.corda.node.services.transactions
 
outputsOfType(clazz) - Method in class net.corda.core.transactions.BaseTransaction
Helper to simplify getting all output states of a particular class, interface, or base class.
outputStates() - Method in class net.corda.core.transactions.TransactionBuilder
 
outRef(index) - Method in class net.corda.core.transactions.BaseTransaction
Returns a class StateAndRef for the given output index.
outRef(state) - Method in class net.corda.core.transactions.BaseTransaction
Returns a class StateAndRef for the requested output state, or throws IllegalArgumentException if not found.
outRefsOfType(clazz) - Method in class net.corda.core.transactions.BaseTransaction
Helper to simplify getting all output class StateAndRef items of a particular state class, interface, or base class.
OverlappingAttachments(path) - Constructor for exception net.corda.core.serialization.AttachmentsClassLoader.OverlappingAttachments
 
OwnableState - Interface in net.corda.core.contracts
A contract state that can have a single owner.
owned by($receiver, owner) - Static method in class net.corda.contracts.asset.CashKt
 
owned by($receiver, owner) - Static method in class net.corda.contracts.asset.ObligationKt
 
owned by($receiver, owner) - Static method in class net.corda.contracts.CommercialPaperKt
 
owned by($receiver, newOwner) - Static method in class net.corda.contracts.CommercialPaperKt
 
ownedBy($receiver, owner) - Static method in class net.corda.contracts.asset.CashKt
 
ownedBy($receiver, owner) - Static method in class net.corda.contracts.asset.ObligationKt
 

P

Page(states, statesMetadata, totalStatesAvailable, stateTypes, otherResults) - Constructor for class net.corda.core.node.services.Vault.Page
Returned in queries VaultService.queryBy and VaultService.trackBy. A Page contains:
PageSpecification - Class in net.corda.core.node.services.vault
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.
PageSpecification(pageNumber, pageSize) - Constructor for 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.
PageSpecification() - Constructor for 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.
parallelStream() - Method in class net.corda.core.utilities.NonEmptySet
 
paramNamesFromConstructor(ctor) - Method in class net.corda.jackson.StringToMethodCallParser
Uses either Kotlin or Java 8 reflection to learn the names of the parameters to a constructor.
paramNamesFromMethod(method) - Method in class net.corda.jackson.StringToMethodCallParser
Uses either Kotlin or Java 8 reflection to learn the names of the parameters to a method.
parse(str) - Method in class net.corda.core.crypto.SecureHash.Companion
 
parse(str) - Static method in class net.corda.core.crypto.SecureHash
 
parse(encoded) - Method in class net.corda.core.node.services.ServiceInfo.Companion
 
parse(id) - Method in class net.corda.core.node.services.ServiceType.Companion
 
parse(criteria, sorting) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parse(target, command) - Method in class net.corda.jackson.StringToMethodCallParser
Parses the given command as a call on the target type. The target should be specified, if it's null then the resulting class StringToMethodCallParser.ParsedMethodCall can't be invoked, just inspected.
parse(args) - Method in class net.corda.node.ArgsParser
 
parse(criteria, sorting) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parseAnd(left, right) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parseAnd(left, right) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parseArguments(methodNameHint, parameters, args) - Method in class net.corda.jackson.StringToMethodCallParser
Parses only the arguments string given the info about parameter names and types.
parseAsHex($receiver) - Static method in class net.corda.core.utilities.ByteArrays
 
parseCriteria(criteria) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parseCriteria(criteria) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parseCriteria(criteria) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parseCriteria(criteria) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parseCriteria(criteria) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parseCriteria(criteria) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parseCriteria(criteria) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parseCriteria(criteria) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parseCriteria(criteria) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parseCriteria(criteria) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parseCurrency(input) - Method in class net.corda.core.contracts.Amount.Companion
Returns an amount that is equal to the given currency amount in text. Examples of what is supported:
parseDateFromString(it) - Method in class net.corda.contracts.BusinessCalendar.Companion
Parses a date of the form YYYY-MM-DD, like 2016-01-10 for 10th Jan.
ParsedMethodCall($outer, target, method) - Constructor for class net.corda.jackson.StringToMethodCallParser.ParsedMethodCall
 
parseNetworkHostAndPort($receiver) - Static method in class net.corda.core.utilities.NetworkHostAndPortKt
Parses a string of the form host:port into a class NetworkHostAndPort. The host part may be a hostname or IP address. If it's an IPv6 address, it must be enclosed in square brackets. Note this does not parse the toString of a resolved java.net.InetSocketAddress, which is of a host/IP:port form.
parseOr(left, right) - Method in interface net.corda.core.node.services.vault.IQueryCriteriaParser
 
parseOr(left, right) - Method in class net.corda.node.services.vault.HibernateQueryCriteriaParser
 
parsePublicKeyBase58(base58String) - Static method in class net.corda.core.crypto.EncodingUtils
 
PartiallyResolvedTransaction - Class in net.corda.client.jfx.model
class PartiallyResolvedTransaction holds a class SignedTransaction that has zero or more inputs resolved. The intent is to prepare clients for cases where an input can only be resolved in the future/cannot be resolved at all (for example because of permissioning)
PartiallyResolvedTransaction(transaction, inputs) - Constructor for class net.corda.client.jfx.model.PartiallyResolvedTransaction
class PartiallyResolvedTransaction holds a class SignedTransaction that has zero or more inputs resolved. The intent is to prepare clients for cases where an input can only be resolved in the future/cannot be resolved at all (for example because of permissioning)
PartiallyResolvedTransaction.Companion - Class in net.corda.client.jfx.model
 
PartiallyResolvedTransaction.InputResolution - Class in net.corda.client.jfx.model
 
PartialMerkleTree - Class in net.corda.core.crypto
Building and verification of Partial Merkle Tree. Partial Merkle Tree is a minimal tree needed to check that a given set of leaves belongs to a full Merkle Tree.
PartialMerkleTree(root) - Constructor for class net.corda.core.crypto.PartialMerkleTree
Building and verification of Partial Merkle Tree. Partial Merkle Tree is a minimal tree needed to check that a given set of leaves belongs to a full Merkle Tree.
PartialMerkleTree.Companion - Class in net.corda.core.crypto
 
PartialMerkleTree.PartialTree - Class in net.corda.core.crypto
The structure is a little different than that of Merkle Tree. Partial Tree might not be a full binary tree. Leaves represent either original Merkle tree leaves or cut subtree node with stored hash. We differentiate between the leaves that are included in a filtered transaction and leaves that just keep hashes needed for calculation. Reason for this approach: during verification it's easier to extract hashes used as a base for this tree.
PartialTree.IncludedLeaf - Class in net.corda.core.crypto
 
PartialTree.Leaf - Class in net.corda.core.crypto
 
PartialTree.Node - Class in net.corda.core.crypto
 
Participant(participant, wellKnown) - Constructor for class net.corda.core.flows.FinalityFlow.Participant
 
partiesFromName(query, exactMatch) - Method in interface net.corda.core.messaging.CordaRPCOps
Returns a list of candidate matches for a given string, with optional fuzzy(ish) matching. Fuzzy matching may get smarter with time e.g. to correct spelling errors, so you should not hard-code indexes into the results but rather show them via a user interface and let the user pick the one they wanted.
partiesFromName(query, exactMatch) - Method in interface net.corda.core.node.services.IdentityService
Returns a list of candidate matches for a given string, with optional fuzzy(ish) matching. Fuzzy matching may get smarter with time e.g. to correct spelling errors, so you should not hard-code indexes into the results but rather show them via a user interface and let the user pick the one they wanted.
partiesFromName(query) - Method in class net.corda.jackson.JacksonSupport.IdentityObjectMapper
 
partiesFromName(query) - Method in class net.corda.jackson.JacksonSupport.NoPartyObjectMapper
 
partiesFromName(query) - Method in interface net.corda.jackson.JacksonSupport.PartyObjectMapper
 
partiesFromName(query) - Method in class net.corda.jackson.JacksonSupport.RpcObjectMapper
 
partiesFromName(query, exactMatch) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Returns a list of candidate matches for a given string, with optional fuzzy(ish) matching. Fuzzy matching may get smarter with time e.g. to correct spelling errors, so you should not hard-code indexes into the results but rather show them via a user interface and let the user pick the one they wanted.
partiesFromName(query, exactMatch) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Returns a list of candidate matches for a given string, with optional fuzzy(ish) matching. Fuzzy matching may get smarter with time e.g. to correct spelling errors, so you should not hard-code indexes into the results but rather show them via a user interface and let the user pick the one they wanted.
Party - Class in net.corda.core.identity
The class Party class represents an entity on the network, which is typically identified by a legal name and public key that it can sign transactions under. As parties may use multiple keys for signing and, for example, have offline backup keys, the "public key" of a party can be represented by a composite construct – a CompositeKey, which combines multiple cryptographic public key primitives into a tree structure.
Party(name, owningKey) - Constructor for class net.corda.core.identity.Party
The class Party class represents an entity on the network, which is typically identified by a legal name and public key that it can sign transactions under. As parties may use multiple keys for signing and, for example, have offline backup keys, the "public key" of a party can be represented by a composite construct – a CompositeKey, which combines multiple cryptographic public key primitives into a tree structure.
Party(certAndKey) - Constructor for class net.corda.core.identity.Party
 
Party(id, name, key) - Constructor for class net.corda.core.schemas.CommonSchemaV1.Party
Party entity (to be replaced by referencing final Identity Schema)
Party(party) - Constructor for class net.corda.core.schemas.CommonSchemaV1.Party
 
party($receiver, nameColumnName, keyColumnName) - Static method in class net.corda.node.utilities.DatabaseSupportKt
 
PartyAndCertificate - Class in net.corda.core.identity
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.
PartyAndCertificate(party, certificate, certPath) - Constructor for 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.
PartyAndCertificate(name, owningKey, certificate, certPath) - Constructor for class net.corda.core.identity.PartyAndCertificate
 
partyAndCertificate($receiver, nameColumnName, keyColumnName, certificateColumnName, pathColumnName) - Static method in class net.corda.node.utilities.DatabaseSupportKt
 
PartyAndCertificateColumns - Class in net.corda.node.utilities
 
PartyAndCertificateColumns(name, owningKey, certificate, certPath) - Constructor for class net.corda.node.utilities.PartyAndCertificateColumns
 
PartyAndReference - Class in net.corda.core.contracts
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.
PartyAndReference(party, reference) - Constructor for 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.
PartyColumns - Class in net.corda.node.utilities
 
PartyColumns(name, owningKey) - Constructor for class net.corda.node.utilities.PartyColumns
 
partyFromAnonymous(anon) - Method in class net.corda.core.flows.FinalityFlow
Helper function which wraps IdentityService.partyFromAnonymous so it can be called as a lambda function.
partyFromAnonymous($this, partyRef) - Static method in class net.corda.core.node.services.IdentityService.DefaultImpls
Resolve the well known identity of a party. If the party passed in is already a well known identity (i.e. a class Party) this returns it as-is.
partyFromAnonymous(party) - Method in interface net.corda.core.node.services.IdentityService
Resolve the well known identity of a party. If the party passed in is already a well known identity (i.e. a class Party) this returns it as-is.
partyFromAnonymous(partyRef) - Method in interface net.corda.core.node.services.IdentityService
Resolve the well known identity of a party. If the party passed in is already a well known identity (i.e. a class Party) this returns it as-is.
partyFromAnonymous(party) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Resolve the well known identity of a party. If the party passed in is already a well known identity (i.e. a class Party) this returns it as-is.
partyFromAnonymous(partyRef) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Resolve the well known identity of a party. If the party passed in is already a well known identity (i.e. a class Party) this returns it as-is.
partyFromKey(key) - Method in interface net.corda.core.messaging.CordaRPCOps
Returns the class Party corresponding to the given key, if found.
partyFromKey(key) - Method in interface net.corda.core.node.services.IdentityService
 
partyFromKey(owningKey) - Method in class net.corda.jackson.JacksonSupport.IdentityObjectMapper
 
partyFromKey(owningKey) - Method in class net.corda.jackson.JacksonSupport.NoPartyObjectMapper
 
partyFromKey(owningKey) - Method in interface net.corda.jackson.JacksonSupport.PartyObjectMapper
 
partyFromKey(owningKey) - Method in class net.corda.jackson.JacksonSupport.RpcObjectMapper
 
partyFromKey(key) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Returns the class Party corresponding to the given key, if found.
partyFromKey(key) - Method in class net.corda.node.services.identity.InMemoryIdentityService
 
partyFromName(name) - Method in interface net.corda.core.messaging.CordaRPCOps
Deprecated. 
partyFromName(name) - Method in interface net.corda.core.node.services.IdentityService
Deprecated. 
partyFromName(partyName) - Method in class net.corda.jackson.JacksonSupport.IdentityObjectMapper
 
partyFromName(partyName) - Method in class net.corda.jackson.JacksonSupport.NoPartyObjectMapper
 
partyFromName(partyName) - Method in interface net.corda.jackson.JacksonSupport.PartyObjectMapper
Deprecated. 
partyFromName(partyName) - Method in class net.corda.jackson.JacksonSupport.RpcObjectMapper
 
partyFromName(name) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Deprecated. 
partyFromName(name) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Deprecated. 
partyFromX500Name(x500Name) - Method in interface net.corda.core.messaging.CordaRPCOps
Returns the class Party with the X.500 principal as it's Party.name
partyFromX500Name(principal) - Method in interface net.corda.core.node.services.IdentityService
 
partyFromX500Name(name) - Method in class net.corda.jackson.JacksonSupport.IdentityObjectMapper
 
partyFromX500Name(name) - Method in class net.corda.jackson.JacksonSupport.NoPartyObjectMapper
 
partyFromX500Name(name) - Method in interface net.corda.jackson.JacksonSupport.PartyObjectMapper
 
partyFromX500Name(name) - Method in class net.corda.jackson.JacksonSupport.RpcObjectMapper
 
partyFromX500Name(x500Name) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Returns the class Party with the X.500 principal as it's Party.name
partyFromX500Name(principal) - Method in class net.corda.node.services.identity.InMemoryIdentityService
 
PartyInfo - Class in net.corda.core.node.services
Holds information about a class Party, which may refer to either a specific node or a service.
PartyInfo.Node - Class in net.corda.core.node.services
 
PartyInfo.Service - Class in net.corda.core.node.services
 
pathForAnonymous(anonymousParty) - Method in interface net.corda.core.node.services.IdentityService
Deprecated. 
pathForAnonymous(anonymousParty) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Get the certificate chain showing an anonymous party is owned by the given party.
PathManager<T extends PathManager<T>> - Class in net.corda.node.services.transactions
An instance of this class is a handle on a temporary path. If necessary, additional handles on the same path can be created using the PathManager.handle method. The path is (recursively) deleted when PathManager.close is called on the last handle, typically at the end of a use expression. The value of eager cleanup of temporary files is that there are cases when shutdown hooks don't run e.g. SIGKILL.
PathManager(path) - Constructor for class net.corda.node.services.transactions.PathManager
An instance of this class is a handle on a temporary path. If necessary, additional handles on the same path can be created using the PathManager.handle method. The path is (recursively) deleted when PathManager.close is called on the last handle, typically at the end of a use expression. The value of eager cleanup of temporary files is that there are cases when shutdown hooks don't run e.g. SIGKILL.
PayCash(amount, recipient, issuerConstraint, anonymous) - Constructor for class net.corda.flows.CashFlowCommand.PayCash
Pay cash to someone else.
PaymentRule - Enum in net.corda.contracts
Whether the payment should be made before the due date, or after it.
PaymentRule() - Constructor for enum net.corda.contracts.PaymentRule
Whether the payment should be made before the due date, or after it.
Peer(party) - Constructor for class net.corda.core.flows.FlowInitiator.Peer
Started when we get new session initiation request.
PEER_ROLE - Static variable in class net.corda.node.services.messaging.NodeLoginModule
 
PersistentCashState(owner, pennies, currency, issuerParty, issuerRef) - Constructor for class net.corda.schemas.CashSchemaV1.PersistentCashState
 
PersistentCommercialPaperState(issuanceParty, issuanceRef, owner, maturity, faceValue, currency, faceValueIssuerParty, faceValueIssuerRef) - Constructor for class net.corda.schemas.CommercialPaperSchemaV1.PersistentCommercialPaperState
 
PersistentKeyManagementService - Class in net.corda.node.services.keys
A persistent re-implementation of class E2ETestKeyManagementService to support node re-start.
PersistentKeyManagementService(identityService, initialKeys) - Constructor for class net.corda.node.services.keys.PersistentKeyManagementService
A persistent re-implementation of class E2ETestKeyManagementService to support node re-start.
PersistentNetworkMapService - Class in net.corda.node.services.network
A network map service backed by a database to survive restarts of the node hosting it.
PersistentNetworkMapService(services, minimumPlatformVersion) - Constructor for class net.corda.node.services.network.PersistentNetworkMapService
A network map service backed by a database to survive restarts of the node hosting it.
PersistentState - Class in net.corda.core.schemas
A super class for all mapped states exported to a schema that ensures the class StateRef appears on the database row. The class StateRef will be set to the correct value by the framework (there's no need to set during mapping generation by the state itself).
PersistentState(stateRef) - Constructor for class net.corda.core.schemas.PersistentState
A super class for all mapped states exported to a schema that ensures the class StateRef appears on the database row. The class StateRef will be set to the correct value by the framework (there's no need to set during mapping generation by the state itself).
PersistentState() - Constructor for class net.corda.core.schemas.PersistentState
A super class for all mapped states exported to a schema that ensures the class StateRef appears on the database row. The class StateRef will be set to the correct value by the framework (there's no need to set during mapping generation by the state itself).
PersistentStateRef - Class in net.corda.core.schemas
Embedded class StateRef representation used in state mapping.
PersistentStateRef(txId, index) - Constructor for class net.corda.core.schemas.PersistentStateRef
Embedded class StateRef representation used in state mapping.
PersistentStateRef() - Constructor for class net.corda.core.schemas.PersistentStateRef
Embedded class StateRef representation used in state mapping.
PersistentStateRef(stateRef) - Constructor for class net.corda.core.schemas.PersistentStateRef
 
PersistentUniquenessProvider - Class in net.corda.node.services.transactions
A RDBMS backed Uniqueness provider
PersistentUniquenessProvider() - Constructor for class net.corda.node.services.transactions.PersistentUniquenessProvider
A RDBMS backed Uniqueness provider
PersistentUniquenessProvider.Companion - Class in net.corda.node.services.transactions
 
persistStateWithSchema(state, stateRef, schema) - Method in class net.corda.node.services.schema.HibernateObserver
 
pickN($receiver, number, list) - Static method in class net.corda.client.mock.GeneratorKt
 
pickOne($receiver, list) - Static method in class net.corda.client.mock.GeneratorKt
 
PluginServiceHub - Interface in net.corda.core.node
A service hub to be used by the class CordaPluginRegistry
PluginServiceHub.DefaultImpls - Class in net.corda.core.node
A service hub to be used by the class CordaPluginRegistry
plus(other) - Method in class net.corda.core.contracts.Amount
A checked addition operator is supported to simplify aggregation of Amounts.
plus(other) - Method in class net.corda.core.contracts.AmountTransfer
Add together two class AmountTransfer objects to produce the single equivalent net flow. The addition only applies to AmountTransfer objects with the same token type. Also the pair of parties must be aligned, although source destination may be swapped in the second item.
plus(rhs) - Method in class net.corda.core.node.services.Vault.Update
Combine two updates into a single update with the combined inputs and outputs of the two updates but net any outputs of the left-hand-side (this) that are consumed by the inputs of the right-hand-side (rhs).
plus(sig) - Method in class net.corda.core.transactions.SignedTransaction
Alias for SignedTransaction.withAdditionalSignature to let you use Kotlin operator overloading.
plus(sigList) - Method in class net.corda.core.transactions.SignedTransaction
Alias for withAdditionalSignatures to let you use Kotlin operator overloading.
plus($receiver, overrides) - Static method in class net.corda.node.services.config.ConfigUtilitiesKt
 
Polynomial - Class in net.corda.contracts.math
Represents a polynomial function of arbitrary degree.
Polynomial(coefficients) - Constructor for class net.corda.contracts.math.Polynomial
Represents a polynomial function of arbitrary degree.
Position(tracker, newStep) - Constructor for class net.corda.core.utilities.Change.Position
 
POUNDS(amount) - Static method in class net.corda.core.contracts.ContractsDSL
 
predicate($receiver, predicate) - Method in class net.corda.core.node.services.vault.Builder
 
predicate($receiver, predicate) - Method in class net.corda.core.node.services.vault.Builder
 
prefixChars(prefixLen) - Method in class net.corda.core.crypto.SecureHash
 
preNetworkRegistration(conf) - Method in class net.corda.node.internal.NodeStartup
 
prepareCall(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareCall(p0, p1, p2) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareCall(p0, p1, p2, p3) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareStatement(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareStatement(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareStatement(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareStatement(p0, p1, p2) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareStatement(p0, p1, p2, p3) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
prepareStatement(p0, p1) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
PrimArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimArraySerializer(type, factory) - Constructor for class net.corda.core.serialization.amqp.PrimArraySerializer
 
PrimArraySerializer.Companion - Class in net.corda.core.serialization.amqp
 
Primary(progressTracker) - Constructor for class net.corda.flows.TwoPartyDealFlow.Primary
Abstracted bilateral deal flow participant that initiates communication/handshake.
Primary() - Constructor for class net.corda.flows.TwoPartyDealFlow.Primary
Abstracted bilateral deal flow participant that initiates communication/handshake.
Primary.Companion - Class in net.corda.flows
 
PrimBooleanArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimBooleanArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.PrimBooleanArraySerializer
 
PrimCharArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimCharArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.PrimCharArraySerializer
 
PrimDoubleArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimDoubleArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.PrimDoubleArraySerializer
 
PrimFloatArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimFloatArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.PrimFloatArraySerializer
 
PrimIntArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimIntArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.PrimIntArraySerializer
 
primitiveType(type) - Method in class net.corda.core.serialization.amqp.SerializerFactory.Companion
 
primitiveTypeName(type) - Method in class net.corda.core.serialization.amqp.SerializerFactory.Companion
 
PrimLongArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimLongArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.PrimLongArraySerializer
 
PrimShortArraySerializer - Class in net.corda.core.serialization.amqp
 
PrimShortArraySerializer(factory) - Constructor for class net.corda.core.serialization.amqp.PrimShortArraySerializer
 
printBasicNodeInfo(description, info) - Method in class net.corda.node.internal.Node.Companion
Used for useful info that we always want to show, even when not logging to the console
printHelp(sink) - Method in class net.corda.node.ArgsParser
 
PrivateKeySerializer - Class in net.corda.core.serialization
 
processUpdatePush(req) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
 
product(other) - Method in class net.corda.client.mock.Generator
 
ProgressTracker - Class in net.corda.core.utilities
A progress tracker helps surface information about the progress of an operation to a user interface or API of some kind. It lets you define a set of steps that represent an operation. A step is represented by an object (typically a singleton).
ProgressTracker(steps) - Constructor for class net.corda.core.utilities.ProgressTracker
A progress tracker helps surface information about the progress of an operation to a user interface or API of some kind. It lets you define a set of steps that represent an operation. A step is represented by an object (typically a singleton).
ProgressTracker.Change - Class in net.corda.core.utilities
 
ProgressTracker.DONE - Class in net.corda.core.utilities
 
ProgressTracker.Step - Class in net.corda.core.utilities
The superclass of all step objects.
ProgressTracker.UNSTARTED - Class in net.corda.core.utilities
 
ProgressTrackingEvent - Class in net.corda.client.jfx.model
 
ProgressTrackingEvent(stateMachineId, message) - Constructor for class net.corda.client.jfx.model.ProgressTrackingEvent
 
ProgressTrackingEvent.Companion - Class in net.corda.client.jfx.model
 
project(screenWidth, screenHeight, topLatitude, bottomLatitude, leftLongitude, rightLongitude) - Method in class net.corda.core.node.WorldCoordinate
Convert to screen coordinates using the Mercator projection. You should have a world map image that you know the precise extents of for this function to work.
PropertySerializer - Class in net.corda.core.serialization.amqp
Base class for serialization of a property of an object.
PropertySerializer.AMQPCharPropertySerializer - Class in net.corda.core.serialization.amqp
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
PropertySerializer.AMQPPrimitivePropertySerializer - Class in net.corda.core.serialization.amqp
A property serializer for most AMQP primitive type (Int, String, etc).
PropertySerializer.Companion - Class in net.corda.core.serialization.amqp
 
PropertySerializer.DescribedTypePropertySerializer - Class in net.corda.core.serialization.amqp
A property serializer for a complex type (another object).
Proposal(stateRef, modification, stx) - Constructor for class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
The class AbstractStateReplacementFlow.Proposal contains the details of proposed state modification. This is the message sent by the class AbstractStateReplacementFlow.Instigator to all participants(class AbstractStateReplacementFlow.Acceptor) during the state replacement process.
Proxy(clazz, proxyClass, factory, withInheritance) - Constructor for class net.corda.core.serialization.amqp.CustomSerializer.Proxy
Additional base features over and above class CustomSerializer.Implements or class CustomSerializer.Is custom serializer for when the serialized form should be the serialized form of a proxy class, and the object can be re-created from that proxy on deserialization.
publicKey($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
 
PublicKeyColumnType - Class in net.corda.node.utilities
ColumnType for marshalling to/from database on behalf of PublicKey.
publicKeyOnCurve(signatureScheme, publicKey) - Method in class net.corda.core.crypto.Crypto
Check if a point's coordinates are on the expected curve to avoid certain types of ECC attacks. Point-at-infinity is not permitted as well.
PublicKeySerializer - Class in net.corda.core.serialization.amqp.custom
A serializer that writes out a public key in X.509 format.
PublicKeySerializer - Class in net.corda.core.serialization
For serialising a public key
pure(value) - Method in class net.corda.client.mock.Generator.Companion
 
put(key, value) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
 
put(commit) - Method in class net.corda.node.services.transactions.DistributedImmutableMap
Stores the given Commands.PutAll.entries if no entry key already exists.
put(key, value) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
 
putAll(from) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
 
PutAll(entries) - Constructor for class net.corda.node.services.transactions.Commands.PutAll
 

Q

Query(withCommandOfType, followInputsOfType) - Constructor for class net.corda.core.contracts.TransactionGraphSearch.Query
 
Query() - Constructor for class net.corda.core.contracts.TransactionGraphSearch.Query
 
QueryableState - Interface in net.corda.core.schemas
A contract state that may be mapped to database schemas configured for this node to support querying for, or filtering of, states.
queryBy($this, contractType) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
queryBy($this, contractType, criteria) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
queryBy($this, contractType, criteria, paging) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
queryBy($this, contractType, criteria, sorting) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
queryBy($this, contractType, criteria, paging, sorting) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
queryBy(contractType) - Method in interface net.corda.core.node.services.VaultQueryService
 
queryBy(contractType, criteria) - Method in interface net.corda.core.node.services.VaultQueryService
 
queryBy(contractType, criteria, paging) - Method in interface net.corda.core.node.services.VaultQueryService
 
queryBy(contractType, criteria, sorting) - Method in interface net.corda.core.node.services.VaultQueryService
 
queryBy(contractType, criteria, paging, sorting) - Method in interface net.corda.core.node.services.VaultQueryService
 
QueryCriteria - Class in net.corda.core.node.services.vault
Indexing assumptions: QueryCriteria assumes underlying schema tables are correctly indexed for performance.
QueryCriteria.CommonQueryCriteria - Class in net.corda.core.node.services.vault
 
QueryCriteria.FungibleAssetQueryCriteria - Class in net.corda.core.node.services.vault
FungibleStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultFungibleState
QueryCriteria.LinearStateQueryCriteria - Class in net.corda.core.node.services.vault
LinearStateQueryCriteria: provides query by attributes defined in VaultSchema.VaultLinearState
QueryCriteria.TimeCondition - Class in net.corda.core.node.services.vault
 
QueryCriteria.TimeInstantType - Enum in net.corda.core.node.services.vault
 
QueryCriteria.VaultCustomQueryCriteria<L extends PersistentState> - Class in net.corda.core.node.services.vault
VaultCustomQueryCriteria: provides query by custom attributes defined in a contracts QueryableState implementation. (see Persistence documentation for more information)
QueryCriteria.VaultQueryCriteria - Class in net.corda.core.node.services.vault
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
QueryCriteriaUtils - Class in net.corda.core.node.services.vault
 
QueryIdentityRequest(identity, replyTo, sessionID) - Constructor for class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
 
QueryIdentityResponse(node) - Constructor for class net.corda.node.services.network.NetworkMapService.QueryIdentityResponse
 

R

RaftNonValidatingNotaryService - Class in net.corda.node.services.transactions
A non-validating notary service operated by a group of mutually trusting parties, uses the Raft algorithm to achieve consensus.
RaftNonValidatingNotaryService(services) - Constructor for class net.corda.node.services.transactions.RaftNonValidatingNotaryService
A non-validating notary service operated by a group of mutually trusting parties, uses the Raft algorithm to achieve consensus.
RaftNonValidatingNotaryService.Companion - Class in net.corda.node.services.transactions
 
RaftUniquenessProvider - Class in net.corda.node.services.transactions
A uniqueness provider that records committed input states in a distributed collection replicated and persisted in a Raft cluster, using the Copycat framework (http://atomix.io/copycat/).
RaftUniquenessProvider(services) - Constructor for class net.corda.node.services.transactions.RaftUniquenessProvider
A uniqueness provider that records committed input states in a distributed collection replicated and persisted in a Raft cluster, using the Copycat framework (http://atomix.io/copycat/).
RaftUniquenessProvider.Companion - Class in net.corda.node.services.transactions
 
RaftUniquenessProviderKt - Class in net.corda.node.services.transactions
 
RaftValidatingNotaryService - Class in net.corda.node.services.transactions
A validating notary service operated by a group of mutually trusting parties, uses the Raft algorithm to achieve consensus.
RaftValidatingNotaryService(services) - Constructor for class net.corda.node.services.transactions.RaftValidatingNotaryService
A validating notary service operated by a group of mutually trusting parties, uses the Raft algorithm to achieve consensus.
RaftValidatingNotaryService.Companion - Class in net.corda.node.services.transactions
 
random63BitValue() - Static method in class net.corda.core.crypto.CryptoUtils
Returns a random positive non-zero long generated using a secure RNG. This function sacrifies a bit of entropy in order to avoid potential bugs where the value is used in a context where negative numbers or zero are not expected.
randomOrNull($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
Returns a random element in the list, or null if empty
randomSHA256() - Method in class net.corda.core.crypto.SecureHash.Companion
 
randomSHA256() - Static method in class net.corda.core.crypto.SecureHash
 
rate(from, to) - Method in interface net.corda.client.jfx.model.ExchangeRate
 
read(kryo, input, type) - Method in class net.corda.client.rpc.internal.RpcClientObservableSerializer
 
read($receiver, options, block) - Static method in class net.corda.core.internal.InternalUtilsKt
 
read(kryo, input, type) - Method in class net.corda.core.serialization.CertPathSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.ClassSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.CompositeKeySerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.ECPublicKeyImplSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.Ed25519PrivateKeySerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.Ed25519PublicKeySerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.ImmutableClassSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.InputStreamSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.KryoAMQPSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.LoggerSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.MetaDataSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.NoReferencesSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.PrivateKeySerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.PublicKeySerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.SerializeAsTokenSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.SerializedBytesSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.SignedTransactionSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.WireTransactionSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.X500NameSerializer
 
read(kryo, input, type) - Method in class net.corda.core.serialization.X509CertificateSerializer
 
read(kryo, input, type) - Method in class net.corda.node.services.messaging.RpcServerObservableSerializer
 
read() - Method in class net.corda.node.services.persistence.NodeAttachmentService.HashCheckingStream
 
read(b, off, len) - Method in class net.corda.node.services.persistence.NodeAttachmentService.HashCheckingStream
 
readAll($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
 
readAllLines($receiver, charset) - Static method in class net.corda.core.internal.InternalUtilsKt
 
readBytesWithLength($receiver) - Static method in class net.corda.core.serialization.KryoKt
 
readLines($receiver, charset, block) - Static method in class net.corda.core.internal.InternalUtilsKt
 
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.AMQPPrimitiveSerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in interface net.corda.core.serialization.amqp.AMQPSerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.ArraySerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.CollectionSerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.custom.PublicKeySerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.custom.X500NameSerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.CustomSerializer.ToString
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.MapSerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.ObjectSerializer
Read the given object from the input. The envelope is provided in case the schema is required.
readObject(obj, schema, input) - Method in class net.corda.core.serialization.amqp.SingletonSerializer
Read the given object from the input. The envelope is provided in case the schema is required.
ReadOnlyBackedObservableMapBase<K,A,B> - Class in net.corda.client.jfx.utils
class ReadOnlyBackedObservableMapBase is a base class implementing all abstract functions required for an ObservableMap using a backing HashMap that subclasses should modify.
ReadOnlyBackedObservableMapBase() - Constructor for class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
class ReadOnlyBackedObservableMapBase is a base class implementing all abstract functions required for an ObservableMap using a backing HashMap that subclasses should modify.
ReadOnlyBackedObservableMapBaseKt - Class in net.corda.client.jfx.utils
 
readProperty(obj, schema, input) - Method in class net.corda.core.serialization.amqp.PropertySerializer.AMQPCharPropertySerializer
 
readProperty(obj, schema, input) - Method in class net.corda.core.serialization.amqp.PropertySerializer.AMQPPrimitivePropertySerializer
 
readProperty(obj, schema, input) - Method in class net.corda.core.serialization.amqp.PropertySerializer.DescribedTypePropertySerializer
 
readProperty(obj, schema, input) - Method in class net.corda.core.serialization.amqp.PropertySerializer
 
receive(receiveType, otherParty) - Method in class net.corda.core.flows.FlowLogic
Suspends until the specified otherParty sends us a message of type receiveType.
receive(receiveType, otherParty, sessionFlow) - Method in interface net.corda.core.internal.FlowStateMachine
 
receive(receiveType, otherParty, sessionFlow) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
 
receiveAndVerifyTx() - Method in class net.corda.core.flows.NotaryFlow.Service
Implement custom logic to receive the transaction to notarise, and perform verification based on validity and privacy requirements.
receiveAndVerifyTx() - Method in class net.corda.node.services.transactions.NonValidatingNotaryFlow
The received transaction is not checked for contract-validity, as that would require fully resolving it into a TransactionForVerification, for which the caller would have to reveal the whole transaction history chain. As a result, the Notary will commit invalid transactions as well, but as it also records the identity of the caller, it is possible to raise a dispute and verify the validity of the transaction and subsequently undo the commit of the input states (the exact mechanism still needs to be worked out).
receiveAndVerifyTx() - Method in class net.corda.node.services.transactions.ValidatingNotaryFlow
The received transaction is checked for contract-validity, which requires fully resolving it into a TransactionForVerification, for which the caller also has to to reveal the whole transaction dependency chain.
ReceivedMessage - Interface in net.corda.node.services.messaging
 
ReceivedSessionMessage<M extends ExistingSessionMessage> - Class in net.corda.node.services.statemachine
 
ReceivedSessionMessage(sender, message) - Constructor for class net.corda.node.services.statemachine.ReceivedSessionMessage
 
ReceiveOnly<T extends SessionMessage> - Class in net.corda.node.services.statemachine
 
ReceiveOnly(session, receiveType, userReceiveType) - Constructor for class net.corda.node.services.statemachine.ReceiveOnly
 
ReceiveRequest<T extends SessionMessage> - Interface in net.corda.node.services.statemachine
 
recordAsAssociation($receiver, toKey, merge) - Static method in class net.corda.client.jfx.utils.ObservableFoldKt
This variant simply associates each event with its key.
recordAuditEvent(eventType, comment, extraAuditData) - Method in class net.corda.core.flows.FlowLogic
Flows can call this method to record application level flow audit events
recordAuditEvent(eventType, comment, extraAuditData) - Method in interface net.corda.core.internal.FlowStateMachine
 
recordAuditEvent(event) - Method in interface net.corda.node.services.api.AuditService
 
recordAuditEvent(event) - Method in class net.corda.node.services.api.DummyAuditService
 
recordAuditEvent(eventType, comment, extraAuditData) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
 
recordInSequence($receiver) - Static method in class net.corda.client.jfx.utils.ObservableFoldKt
recordInSequence records incoming events on the rx.Observable in sequence.
recordTransactions($this, first, remaining) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
 
recordTransactions($this, first, remaining) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
Stores the given class SignedTransactions in the local transaction storage and then sends them to the vault for further processing. This is expected to be run within a database transaction.
recordTransactions(txs) - Method in interface net.corda.core.node.ServiceHub
Stores the given class SignedTransactions in the local transaction storage and then sends them to the vault for further processing. This is expected to be run within a database transaction.
recordTransactions(first, remaining) - Method in interface net.corda.core.node.ServiceHub
Stores the given class SignedTransactions in the local transaction storage and then sends them to the vault for further processing. This is expected to be run within a database transaction.
recordTransactions($this, txs) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
Stores the given class SignedTransactions in the local transaction storage and then sends them to the vault for further processing. This is expected to be run within a database transaction.
recordTransactions($this, first, remaining) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
 
recordTransactions(txs) - Method in interface net.corda.node.services.api.ServiceHubInternal
Stores the given class SignedTransactions in the local transaction storage and then sends them to the vault for further processing. This is expected to be run within a database transaction.
Redeem() - Constructor for class net.corda.contracts.Clauses.Redeem
 
Redeem() - Constructor for class net.corda.contracts.Commands.Redeem
 
Redeem() - Constructor for class net.corda.contracts.Commands.Redeem
 
ref(bytes) - Method in class net.corda.core.identity.AbstractParty
Build a reference to something being stored or issued by a party e.g. in a vault or (more likely) on their normal ledger.
ref(bytes) - Method in class net.corda.core.identity.AbstractParty
Build a reference to something being stored or issued by a party e.g. in a vault or (more likely) on their normal ledger.
ref(bytes) - Method in class net.corda.core.identity.AnonymousParty
Build a reference to something being stored or issued by a party e.g. in a vault or (more likely) on their normal ledger.
ref(bytes) - Method in class net.corda.core.identity.Party
Build a reference to something being stored or issued by a party e.g. in a vault or (more likely) on their normal ledger.
ReflectionDataMissing(methodName, argIndex) - Constructor for exception net.corda.jackson.UnparseableCallException.ReflectionDataMissing
 
register(nodeHostAndPort, username, password, initialiseSerialization) - Method in class net.corda.client.jfx.model.NodeMonitorModel
Register for updates to/from a given vault. TODO provide an unsubscribe mechanism
register(customSerializer) - Method in class net.corda.core.serialization.amqp.SerializerFactory
Register a custom serializer for any type that cannot be serialized or deserialized by the default serializer that expects to find getters and a constructor with a parameter for each property.
register(type) - Method in class net.corda.core.serialization.CordaKryo
 
register(type, id) - Method in class net.corda.core.serialization.CordaKryo
 
register(type, serializer) - Method in class net.corda.core.serialization.CordaKryo
 
register(registration) - Method in class net.corda.core.serialization.CordaKryo
 
register($receiver, type, read, write) - Static method in class net.corda.core.serialization.KryoKt
 
registerAnonymousIdentity(anonymousIdentity, party) - Method in interface net.corda.core.node.services.IdentityService
Deprecated. 
registerAnonymousIdentity(anonymousIdentity, party) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Verify and then store an anonymous identity.
registeredFlows() - Method in interface net.corda.core.messaging.CordaRPCOps
Enumerates the class names of the flows that this node knows about.
registeredFlows() - Method in class net.corda.node.internal.CordaRPCOpsImpl
Enumerates the class names of the flows that this node knows about.
registerFlowInitiator($this, initiatingFlowClass, serviceFlowFactory) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
Deprecated. 
registerFlowInitiator(initiatingFlowClass, serviceFlowFactory) - Method in interface net.corda.core.node.PluginServiceHub
Deprecated. 
registerFlowInitiator($this, initiatingFlowClass, serviceFlowFactory) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
Deprecated. 
registerIdentity(party) - Method in interface net.corda.core.node.services.IdentityService
Verify and then store a well known identity.
registerIdentity(party) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Verify and then store a well known identity.
registerImplicit(type) - Method in class net.corda.core.serialization.CordaClassResolver
 
registerInitiatedFlow(initiatedFlowClass) - Method in class net.corda.node.internal.AbstractNode
Use this method to register your initiated flows in your tests. This is automatically done by the node when it starts up for all class FlowLogic classes it finds which are annotated with interface InitiatedBy.
registerWithContext(context, toBeTokenized) - Method in class net.corda.core.serialization.SingletonSerializationToken
 
registerWithNetworkMap() - Method in class net.corda.node.internal.AbstractNode
Register this node with the network map cache, and load network map from a remote service (and register for updates) if one has been supplied.
registerWithNetworkMap() - Method in class net.corda.node.internal.Node
Insert an initial step in the registration process which will throw an exception if a non-recoverable error is encountered when trying to connect to the network map node.
RegistrationRequest(wireReg, replyTo, sessionID) - Constructor for class net.corda.node.services.network.NetworkMapService.RegistrationRequest
 
RegistrationResponse(error) - Constructor for 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
RegulatorService - Interface in net.corda.node.services.api
Placeholder interface for regulator services.
RegulatorService.Companion - Class in net.corda.node.services.api
 
release(instance) - Method in class net.corda.core.internal.LazyPool
 
release(stickTo, instance) - Method in class net.corda.core.internal.LazyStickyPool
 
releaseSavepoint(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
remove(p) - Method in class net.corda.client.jfx.utils.AggregatedList
 
remove(p) - Method in class net.corda.client.jfx.utils.ChosenList
 
remove(p) - Method in class net.corda.client.jfx.utils.ConcatenatedList
 
remove(p) - Method in class net.corda.client.jfx.utils.FlattenedList
 
remove(p) - Method in class net.corda.client.jfx.utils.MappedList
 
remove(element) - Method in class net.corda.client.jfx.utils.MapValuesList
 
remove(p0, p1) - Method in class net.corda.client.jfx.utils.MapValuesList
 
remove(p) - Method in class net.corda.client.jfx.utils.MapValuesList
 
remove(key) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
 
remove(p) - Method in class net.corda.client.jfx.utils.ReplayedList
 
remove(p) - Method in class net.corda.core.utilities.NonEmptySet
 
remove(key) - Method in class net.corda.node.utilities.AbstractJDBCHashMap
 
remove(element) - Method in class net.corda.node.utilities.AbstractJDBCHashSet
 
removeAll(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
 
removeAll(elements) - Method in class net.corda.client.jfx.utils.MapValuesList
 
removeAll(p) - Method in class net.corda.core.utilities.NonEmptySet
 
removeAt(p) - Method in class net.corda.client.jfx.utils.AggregatedList
 
removeAt(p) - Method in class net.corda.client.jfx.utils.ChosenList
 
removeAt(p) - Method in class net.corda.client.jfx.utils.ConcatenatedList
 
removeAt(p) - Method in class net.corda.client.jfx.utils.FlattenedList
 
removeAt(p) - Method in class net.corda.client.jfx.utils.MappedList
 
removeAt(index) - Method in class net.corda.client.jfx.utils.MapValuesList
 
removeAt(p) - Method in class net.corda.client.jfx.utils.ReplayedList
 
removeCheckpoint(checkpoint) - Method in interface net.corda.node.services.api.CheckpointStorage
Remove existing checkpoint from the store. It is an error to attempt to remove a checkpoint which doesn't exist in the store. Doing so will throw an IllegalArgumentException.
removeCheckpoint(checkpoint) - Method in class net.corda.node.services.persistence.DBCheckpointStorage
Remove existing checkpoint from the store. It is an error to attempt to remove a checkpoint which doesn't exist in the store. Doing so will throw an IllegalArgumentException.
Removed(id, result) - Constructor for class net.corda.core.messaging.StateMachineUpdate.Removed
 
Removed(node) - Constructor for class net.corda.core.node.services.MapChange.Removed
 
Removed(logic, result) - Constructor for class net.corda.node.services.statemachine.Change.Removed
 
removeListener(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
 
removeListener(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
 
removeListener(listener) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
 
removeListener(listener) - Method in class net.corda.client.jfx.utils.ReadOnlyBackedObservableMapBase
 
removeMessageHandler(registration) - Method in interface net.corda.node.services.messaging.MessagingService
Removes a handler given the object returned from addMessageHandler. The callback will no longer be invoked once this method has returned, although executions that are currently in flight will not be interrupted.
removeMessageHandler(registration) - Method in class net.corda.node.services.messaging.NodeMessagingClient
Removes a handler given the object returned from addMessageHandler. The callback will no longer be invoked once this method has returned, although executions that are currently in flight will not be interrupted.
removeNode(node) - Method in interface net.corda.node.services.api.NetworkMapCacheInternal
Removes a node from the local cache.
removeNode(node) - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
Removes a node from the local cache.
renderIfSupported(body) - Method in class net.corda.core.internal.Emoji
 
renderIfSupported(obj) - Method in class net.corda.core.internal.Emoji
 
Rendering(tracker, ofStep) - Constructor for class net.corda.core.utilities.Change.Rendering
 
replaceCommonName($receiver, commonName) - Static method in class net.corda.core.crypto.X509UtilitiesKt
Rebuild the distinguished name, replacing the common name with the given value. If no common name is present, this adds one.
ReplayedList<A> - Class in net.corda.client.jfx.utils
This list type just replays changes propagated from the underlying source list. Used for testing changes and backing a non-backed observable
ReplayedList(sourceList) - Constructor for class net.corda.client.jfx.utils.ReplayedList
This list type just replays changes propagated from the underlying source list. Used for testing changes and backing a non-backed observable
Replica(config, replicaId, tableName, services, timeWindowChecker) - Constructor for class net.corda.node.services.transactions.BFTSMaRt.Replica
Maintains the commit log and executes commit commands received from the class BFTSMaRt.Client.
Replica.Companion - Class in net.corda.node.services.transactions
 
ReplicaResponse.Error - Class in net.corda.node.services.transactions
 
ReplicaResponse.Signature - Class in net.corda.node.services.transactions
 
replicate($receiver, number, generator) - Static method in class net.corda.client.mock.GeneratorKt
 
replicatePoisson($receiver, meanSize, generator) - Static method in class net.corda.client.mock.GeneratorKt
 
Requery - Class in net.corda.core.schemas.requery
 
Requery.PersistentState - Interface in net.corda.core.schemas.requery
A super class for all mapped states exported to a schema that ensures the class StateRef appears on the database row. The class StateRef will be set to the correct value by the framework (there's no need to set during mapping generation by the state itself).
RequeryConfiguration - Class in net.corda.node.services.database
 
RequeryConfiguration(properties, useDefaultLogging) - Constructor for class net.corda.node.services.database.RequeryConfiguration
 
RequeryConfiguration.Companion - Class in net.corda.node.services.database
 
Request(hashes) - Constructor for class net.corda.core.flows.FetchDataFlow.Request
 
Requirements - Class in net.corda.core.contracts
 
requirePartyFromAnonymous(party) - Method in interface net.corda.core.node.services.IdentityService
Resolve the well known identity of a party. Throws an exception if the party cannot be identified. If the party passed in is already a well known identity (i.e. a class Party) this returns it as-is.
requirePartyFromAnonymous(party) - Method in class net.corda.node.services.identity.InMemoryIdentityService
Resolve the well known identity of a party. Throws an exception if the party cannot be identified. If the party passed in is already a well known identity (i.e. a class Party) this returns it as-is.
requirePermission($receiver, permission) - Static method in class net.corda.node.services.messaging.RPCServerStructures
Helper method which checks that the current RPC user is entitled for the given permission. Throws a PermissionException otherwise.
requireSingleCommand($receiver, klass) - Static method in class net.corda.core.contracts.ContractsDSL
Ensures that a transaction has only one command that is of the given type, otherwise throws an exception.
requireState(requiredState) - Method in class net.corda.core.internal.LifeCycle
Assert that the lifecycle in the requiredState.
requireState(errorMessage, predicate) - Method in class net.corda.core.internal.LifeCycle
Assert something about the current state atomically.
requireThat(body) - Static method in class net.corda.core.contracts.ContractsDSL
 
reset() - Method in class net.corda.core.serialization.CordaClassResolver
 
Resolved(stateAndRef) - Constructor for class net.corda.client.jfx.model.InputResolution.Resolved
 
resolveEnclosingObjectFromColumn(column) - Static method in class net.corda.core.node.services.vault.QueryCriteriaUtils
 
resolveEnclosingObjectFromExpression(expression) - Static method in class net.corda.core.node.services.vault.QueryCriteriaUtils
 
ResolveTransactionsFlow - Class in net.corda.core.flows
This flow is used to verify the validity of a transaction by recursively checking the validity of all the dependencies. Once a transaction is checked it's inserted into local storage so it can be relayed and won't be checked again.
ResolveTransactionsFlow(txHashes, otherSide) - Constructor for class net.corda.core.flows.ResolveTransactionsFlow
This flow is used to verify the validity of a transaction by recursively checking the validity of all the dependencies. Once a transaction is checked it's inserted into local storage so it can be relayed and won't be checked again.
ResolveTransactionsFlow(stx, otherSide) - Constructor for class net.corda.core.flows.ResolveTransactionsFlow
Resolve the full history of a transaction and verify it with its dependencies.
ResolveTransactionsFlow(wtx, otherSide) - Constructor for class net.corda.core.flows.ResolveTransactionsFlow
Resolve the full history of a transaction and verify it with its dependencies.
ResolveTransactionsFlow.Companion - Class in net.corda.core.flows
 
ResolveTransactionsFlow.ExcessivelyLargeTransactionGraph - Exception in net.corda.core.flows
 
resolveUniqueContractStateTypes(session) - Method in class net.corda.node.services.vault.HibernateVaultQueryImpl
Maintain a list of contract state interfaces to concrete types stored in the vault for usage in generic queries of type queryBy or queryBy>
restoreThreadLocalTx(context) - Method in class net.corda.node.utilities.DatabaseTransactionManager.Companion
 
RestrictedType - Class in net.corda.core.serialization.amqp
 
RestrictedType(name, label, provides, source, descriptor, choices) - Constructor for class net.corda.core.serialization.amqp.RestrictedType
 
RestrictedType.Companion - Class in net.corda.core.serialization.amqp
 
Result(fromDisk, downloaded) - Constructor for class net.corda.core.flows.FetchDataFlow.Result
 
Result(stx, recipient) - Constructor for 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.
retainAll(p0) - Method in class net.corda.client.jfx.utils.MapValuesList
 
retainAll(elements) - Method in class net.corda.client.jfx.utils.MapValuesList
 
retainAll(p) - Method in class net.corda.core.utilities.NonEmptySet
 
retrieveCertificates(requestId) - Method in class net.corda.node.utilities.registration.HTTPNetworkRegistrationService
Poll Certificate Signing Server for the request and returns a chain of certificates if request has been approved, null otherwise.
retrieveCertificates(requestId) - Method in interface net.corda.node.utilities.registration.NetworkRegistrationService
Poll Certificate Signing Server for the request and returns a chain of certificates if request has been approved, null otherwise.
rollback() - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
rollback(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
rollback() - Method in class net.corda.node.utilities.DatabaseTransaction
 
rollback() - Method in class net.corda.node.utilities.ExposedTransaction
 
RPC(username) - Constructor for class net.corda.core.flows.FlowInitiator.RPC
Started using net.corda.core.messaging.CordaRPCOps.startFlowDynamic.
RPC_ROLE - Static variable in class net.corda.node.services.messaging.NodeLoginModule
 
RPCClient<I extends RPCOps> - Class in net.corda.client.rpc.internal
An RPC client that may be used to create connections to an RPC server.
RPCClient(transport, rpcConfiguration, serializationContext) - Constructor for class net.corda.client.rpc.internal.RPCClient
An RPC client that may be used to create connections to an RPC server.
RPCClient(hostAndPort, sslConfiguration, configuration, serializationContext) - Constructor for class net.corda.client.rpc.internal.RPCClient
 
RPCClient.Companion - Class in net.corda.client.rpc.internal
 
RPCClient.RPCConnection<I extends RPCOps> - Interface in net.corda.client.rpc.internal
Holds a proxy object implementing I that forwards requests to the RPC server.
RPCClientConfiguration - Class in net.corda.client.rpc.internal
This configuration may be used to tweak the internals of the RPC client.
RPCClientConfiguration(minimumServerProtocolVersion, trackRpcCallSites, reapInterval, observationExecutorPoolSize, producerPoolBound, cacheConcurrencyLevel, connectionRetryInterval, connectionRetryIntervalMultiplier, connectionMaxRetryInterval, maxReconnectAttempts, maxFileSize) - Constructor for class net.corda.client.rpc.internal.RPCClientConfiguration
This configuration may be used to tweak the internals of the RPC client.
RPCClientConfiguration.Companion - Class in net.corda.client.rpc.internal
 
rpcClientKryoPool(context) - Method in class net.corda.client.rpc.serialization.KryoClientSerializationScheme
 
rpcClientKryoPool(context) - Method in class net.corda.node.serialization.KryoServerSerializationScheme
 
RpcClientObservableSerializer - Class in net.corda.client.rpc.internal
A Serializer to deserialise Observables once the corresponding Kryo instance has been provided with an class ObservableContext.
RPCClientProxyHandler - Class in net.corda.client.rpc.internal
This class provides a proxy implementation of an RPC interface for RPC clients. It translates API calls to lower-level RPC protocol messages. For this protocol see RPCApi.
RPCClientProxyHandler(rpcConfiguration, rpcUsername, rpcPassword, serverLocator, clientAddress, rpcOpsClass, serializationContext) - Constructor for class net.corda.client.rpc.internal.RPCClientProxyHandler
This class provides a proxy implementation of an RPC interface for RPC clients. It translates API calls to lower-level RPC protocol messages. For this protocol see RPCApi.
RPCClientProxyHandlerKt - Class in net.corda.client.rpc.internal
 
RpcContext - Class in net.corda.node.services.messaging
 
RpcContext(currentUser) - Constructor for class net.corda.node.services.messaging.RpcContext
 
RpcObjectMapper(rpc, factory, fuzzyIdentityMatch) - Constructor for class net.corda.jackson.JacksonSupport.RpcObjectMapper
 
RPCOps - Interface in net.corda.core.messaging
Base interface that all RPC servers must implement. Note: in Corda there's only one RPC interface. This base interface is here in case we split the RPC system out into a separate library one day.
RPCReturnsObservables - Interface in net.corda.core.messaging
If an RPC is tagged with this annotation it may return one or more observables anywhere in its response graph. Calling such a method comes with consequences: it's slower, and consumes server side resources as observations will buffer up on the server until they're consumed by the client.
RPCServer - Class in net.corda.node.services.messaging
The class RPCServer implements the complement of RPCClient. When an RPC request arrives it dispatches to the corresponding function in ops. During serialisation of the reply (and later observations) the server subscribes to each Observable it encounters and captures the client address to associate with these Observables. Later it uses this address to forward observations arriving on the Observables.
RPCServer(ops, rpcServerUsername, rpcServerPassword, serverLocator, userService, nodeLegalName, rpcConfiguration) - Constructor for class net.corda.node.services.messaging.RPCServer
The class RPCServer implements the complement of RPCClient. When an RPC request arrives it dispatches to the corresponding function in ops. During serialisation of the reply (and later observations) the server subscribes to each Observable it encounters and captures the client address to associate with these Observables. Later it uses this address to forward observations arriving on the Observables.
RPCServerConfiguration - Class in net.corda.node.services.messaging
 
RPCServerConfiguration(rpcThreadPoolSize, consumerPoolSize, producerPoolBound, reapInterval) - Constructor for class net.corda.node.services.messaging.RPCServerConfiguration
 
RPCServerConfiguration.Companion - Class in net.corda.node.services.messaging
 
rpcServerKryoPool(context) - Method in class net.corda.client.rpc.serialization.KryoClientSerializationScheme
 
rpcServerKryoPool(context) - Method in class net.corda.node.serialization.KryoServerSerializationScheme
 
RPCServerKt - Class in net.corda.node.services.messaging
 
RpcServerObservableSerializer - Class in net.corda.node.services.messaging
 
RPCServerStructures - Class in net.corda.node.services.messaging
 
RPCUserService - Interface in net.corda.node.services
Service for retrieving User objects representing RPC users who are authorised to use the RPC system. A User contains their login username and password along with a set of permissions for RPC services they are allowed access to. These permissions are represented as Strings to allow RPC implementations to add their own permissioning.
RPCUserServiceImpl - Class in net.corda.node.services
 
RPCUserServiceImpl(users) - Constructor for class net.corda.node.services.RPCUserServiceImpl
 
RPCUserServiceKt - Class in net.corda.node.services
 
RUB - Static variable in class net.corda.core.contracts.ContractsDSL
 
run(withInstance) - Method in class net.corda.core.internal.LazyPool
 
run(stickToOrNull, withInstance) - Method in class net.corda.core.internal.LazyStickyPool
 
run() - Method in class net.corda.node.internal.Node
Starts a blocking event loop for message dispatch.
run() - Method in class net.corda.node.internal.NodeStartup
 
run(serverControl) - Method in class net.corda.node.services.messaging.NodeMessagingClient
Starts the p2p event loop: this method only returns once NodeMessagingClient.stop has been called.
run() - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
 
runFlowByNameFragment(nameFragment, inputData, output) - Static method in class net.corda.node.shell.InteractiveShell
Called from the 'flow' shell command. Takes a name fragment and finds a matching flow, or prints out the list of options if the request is ambiguous. Then parses inputData as constructor arguments using the runFlowFromString method and starts the requested flow using the class ANSIProgressRenderer to draw the progress tracker. Ctrl-C can be used to cancel.
runFlowFromString(invoke, inputData, clazz, om) - Method in class net.corda.node.shell.InteractiveShell
Given a class FlowLogic class and a string in one-line Yaml form, finds an applicable constructor and starts the flow, returning the created flow logic. Useful for lightweight invocation where text is preferable to statically typed, compiled code.
runOnNextMessage($receiver, topic, sessionID, callback) - Static method in class net.corda.node.services.messaging.MessagingKt
Registers a handler for the given topic and session ID that runs the given callback with the message and then removes itself. This is useful for one-shot handlers that aren't supposed to stick around permanently. Note that this callback doesn't take the registration object, unlike the callback to MessagingService.addMessageHandler, as the handler is automatically deregistered before the callback runs.
runOnNextMessage($receiver, topicSession, callback) - Static method in class net.corda.node.services.messaging.MessagingKt
Registers a handler for the given topic and session that runs the given callback with the message and then removes itself. This is useful for one-shot handlers that aren't supposed to stick around permanently. Note that this callback doesn't take the registration object, unlike the callback to MessagingService.addMessageHandler.
runRPCFromString(input, out, context) - Static method in class net.corda.node.shell.InteractiveShell
 
runStateMachinesView(out) - Static method in class net.corda.node.shell.InteractiveShell
 
runWithoutMapService() - Method in interface net.corda.node.services.api.NetworkMapCacheInternal
For testing where the network map cache is manipulated marks the service as immediately ready.
runWithoutMapService() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
For testing where the network map cache is manipulated marks the service as immediately ready.

S

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
ColumnType for marshalling to/from database on behalf of class SecureHash.
SecureHashConverter - Class in net.corda.core.schemas.requery.converters
Convert from a class SecureHash to a String
SecureHashConverter() - Constructor for class net.corda.core.schemas.requery.converters.SecureHashConverter
Convert from a class SecureHash to a String
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
Sends a interface ServiceRequestMessage to target and returns a ListenableFuture of the response.
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
This represents a token in the serialized stream for an instance of a type that implements interface SerializeAsToken.
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
A Kryo serializer for interface SerializeAsToken implementations.
SerializeAsTokenSerializer() - Constructor for class net.corda.core.serialization.SerializeAsTokenSerializer
A Kryo serializer for interface SerializeAsToken implementations.
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
The class SignTransactionFlow should be called in response to the class CollectSignaturesFlow. It automates the signing of a transaction providing the transaction:
SignTransactionFlow(otherParty, progressTracker) - Constructor for class net.corda.core.flows.SignTransactionFlow
The class SignTransactionFlow should be called in response to the class CollectSignaturesFlow. It automates the signing of a transaction providing the transaction:
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
Retrieve softLockStates for a given UUID or return all softLockStates in vault for a given interface ContractState type
softLockedStates(lockId) - Method in class net.corda.node.services.vault.NodeVaultService
Retrieve softLockStates for a given UUID or return all softLockStates in vault for a given interface ContractState type
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
Starts an already constructed flow. Note that you must be on the server thread to call this method. class FlowInitiator defaults to class FlowInitiator.RPC with username "Only For Testing".
startFlow(logic) - 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. class FlowInitiator defaults to class FlowInitiator.RPC with username "Only For Testing".
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
Start the given flow with the given arguments. logicType must be annotated with interface StartableByRPC.
startFlowDynamic(logicType, args) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Start the given flow with the given arguments. logicType must be annotated with interface StartableByRPC.
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
Converts from a class StateRef to a Composite Key defined by a String txnHash and an Int index
StateRefConverter() - Constructor for class net.corda.core.schemas.requery.converters.StateRefConverter
Converts from a class StateRef to a Composite Key defined by a String txnHash and an Int index
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
Return interface ContractStates of a given interface Contract type and Iterable of enum Vault.StateStatus. Optionally may specify whether to include class StateRef that have been marked as soft locked (default is true)
statesForRefs(refs) - Method in interface net.corda.core.node.services.VaultService
Deprecated. 
statesForRefs(refs) - Method in class net.corda.node.services.vault.NodeVaultService
Return unconsumed interface ContractStates for a given set of class StateRefs
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
Returns a class DeclaredField wrapper around the declared (possibly non-public) static field of the receiver Class.
staticField($receiver, name) - Static method in class net.corda.core.internal.InternalUtilsKt
Returns a class DeclaredField wrapper around the declared (possibly non-public) static field of the receiver KClass.
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
Return the sum of an Iterable of BigDecimals.
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.

T

take(n) - Method in class net.corda.core.utilities.ByteSequence
Take the first n bytes of this sequence as a sub-sequence. See subSequence for further semantics.
tee($receiver, teeTo) - Static method in class net.corda.core.internal.InternalUtilsKt
Copy an Observer to multiple other Observers.
Tenor - Class in net.corda.contracts
Placeholder class for the Tenor datatype - which is a standardised duration of time until maturity
Tenor(name) - Constructor for class net.corda.contracts.Tenor
Placeholder class for the Tenor datatype - which is a standardised duration of time until maturity
Tenor.TimeUnit - Enum in net.corda.contracts
 
Terms(acceptableContracts, acceptableIssuedProducts, dueBefore, timeTolerance) - Constructor for class net.corda.contracts.asset.Obligation.Terms
Subset of state, containing the elements specified when issuing a new settlement contract.
Terms(asset, maturityDate) - Constructor for class net.corda.contracts.CommercialPaper.Terms
 
TestClock - Class in net.corda.node.utilities
A Clock that can have the date advanced for use in demos.
TestClock(delegateClock) - Constructor for class net.corda.node.utilities.TestClock
A Clock that can have the date advanced for use in demos.
TestClock() - Constructor for class net.corda.node.utilities.TestClock
A Clock that can have the date advanced for use in demos.
TestMetaCarpenter - Class in net.corda.core.serialization.carpenter
 
TestMetaCarpenter(schemas) - Constructor for class net.corda.core.serialization.carpenter.TestMetaCarpenter
 
then($receiver, block) - Static method in class net.corda.core.Utils
 
thenMatch($receiver, success, failure) - Static method in class net.corda.core.Utils
 
ThreadBox<T> - Class in net.corda.core.internal
A threadbox is a simple utility that makes it harder to forget to take a lock before accessing some shared state. Simply define a private class to hold the data that must be grouped under the same lock, and then pass the only instance to the ThreadBox constructor. You can now use the locked method with a lambda to take the lock in a way that ensures it'll be released if there's an exception.
ThreadBox(content, lock) - Constructor for class net.corda.core.internal.ThreadBox
A threadbox is a simple utility that makes it harder to forget to take a lock before accessing some shared state. Simply define a private class to hold the data that must be grouped under the same lock, and then pass the only instance to the ThreadBox constructor. You can now use the locked method with a lambda to take the lock in a way that ensures it'll be released if there's an exception.
ThrowableProxy(exceptionClass, message, stackTrace, cause, suppressed, additionalProperties) - Constructor for class net.corda.core.serialization.amqp.custom.ThrowableSerializer.ThrowableProxy
 
ThrowableSerializer - Class in net.corda.core.serialization.amqp.custom
 
ThrowableSerializer(factory) - Constructor for class net.corda.core.serialization.amqp.custom.ThrowableSerializer
 
ThrowableSerializer.ThrowableProxy - Class in net.corda.core.serialization.amqp.custom
 
TimeCondition(type, predicate) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
 
TimeInstantType() - Constructor for enum net.corda.core.node.services.vault.QueryCriteria.TimeInstantType
 
times(other) - Method in class net.corda.core.contracts.Amount
The multiplication operator is supported to allow easy calculation for multiples of a primitive Amount. Note this is not a conserving operation, so it may not always be correct modelling of proper token behaviour. N.B. Division is not supported as fractional tokens are not representable by an Amount.
times(other) - Method in class net.corda.core.contracts.Amount
 
times($receiver, multiplicand) - Static method in class net.corda.core.internal.InternalUtilsKt
 
TimeUnit(code) - Constructor for enum net.corda.contracts.Tenor.TimeUnit
 
TimeWindow - Class in net.corda.core.contracts
An interval on the time-line; not a single instantaneous point.
TimeWindow() - Constructor for class net.corda.core.contracts.TimeWindow
An interval on the time-line; not a single instantaneous point.
TimeWindow.Companion - Class in net.corda.core.contracts
 
TimeWindowChecker - Class in net.corda.core.node.services
Checks if the current instant provided by the input clock falls within the provided time-window.
TimeWindowChecker(clock) - Constructor for class net.corda.core.node.services.TimeWindowChecker
Checks if the current instant provided by the input clock falls within the provided time-window.
TimeWindowChecker() - Constructor for class net.corda.core.node.services.TimeWindowChecker
Checks if the current instant provided by the input clock falls within the provided time-window.
toAnonymisedIdentity() - Method in class net.corda.core.identity.PartyAndCertificate
Convert this party and certificate into an anomymised identity. This exists primarily for example cases which want to use well known identities as if they're anonymous identities.
toArray() - Method in class net.corda.client.jfx.utils.MapValuesList
 
toArray(p) - Method in class net.corda.client.jfx.utils.MapValuesList
 
toArray() - Method in class net.corda.core.utilities.NonEmptySet
 
toArray(p) - Method in class net.corda.core.utilities.NonEmptySet
 
toArrayOfType($receiver, type) - Method in class net.corda.core.serialization.amqp.ArraySerializer
 
toArrayOfType($receiver, type) - Method in class net.corda.core.serialization.amqp.CharArraySerializer
 
toArrayOfType($receiver, type) - Method in class net.corda.core.serialization.amqp.PrimCharArraySerializer
 
toASN1Primitive() - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
 
toBase58($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
 
toBase58String($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
 
toBase64($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
 
toCalendar() - Method in class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
 
toDecimal() - Method in class net.corda.core.contracts.Amount
Convert a currency class Amount to a decimal representation. For example, with an amount with a quantity of "1234" GBP, returns "12.34". The precise representation is controlled by the displayTokenSize, which determines the size of a single token and controls the trailing decimal places via it's scale property.
toDecimal() - Method in class net.corda.core.contracts.AmountTransfer
Convert the quantityDelta to a displayable format BigDecimal value. The conversion ratio is the same as for class Amount of the same token type.
toFlowLogic(ref) - Method in class net.corda.node.services.statemachine.FlowLogicRefFactoryImpl
 
toFuture($receiver) - Static method in class net.corda.core.Utils
Returns a ListenableFuture bound to the first item emitted by this Observable. The future will complete with a NoSuchElementException if no items are emitted or any other error thrown by the Observable. If it's cancelled then it will unsubscribe from the observable.
toHex($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
Convert a byte array to a hex (base 16) capitalized encoded string.
toHexString($receiver) - Static method in class net.corda.core.utilities.ByteArrays
 
toInputStreamAndHash($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
toJavaIterator($receiver) - Static method in class net.corda.core.internal.InternalUtilsKt
 
TokenizableAssetInfo - Interface in net.corda.core.contracts
This interface is used by class Amount to determine the conversion ratio from indicative/displayed asset amounts in BigDecimal to fungible tokens represented by Amount objects.
toLedgerTransaction(services, checkSufficientSignatures) - Method in class net.corda.core.transactions.SignedTransaction
Checks the transaction's signatures are valid, optionally calls SignedTransaction.verifyRequiredSignatures to check all required signatures are present, and then calls WireTransaction.toLedgerTransaction with the passed in interface ServiceHub to resolve the dependencies, returning an unverified LedgerTransaction.
toLedgerTransaction(services) - Method in class net.corda.core.transactions.SignedTransaction
Checks the transaction's signatures are valid, optionally calls SignedTransaction.verifyRequiredSignatures to check all required signatures are present, and then calls WireTransaction.toLedgerTransaction with the passed in interface ServiceHub to resolve the dependencies, returning an unverified LedgerTransaction.
toLedgerTransaction(services) - Method in class net.corda.core.transactions.TransactionBuilder
 
toLedgerTransaction(services) - Method in class net.corda.core.transactions.WireTransaction
Looks up identities and attachments from storage to generate a class LedgerTransaction. A transaction is expected to have been fully resolved using the resolution flow by this point.
toLedgerTransaction(resolveIdentity, resolveAttachment, resolveStateRef) - Method in class net.corda.core.transactions.WireTransaction
Looks up identities, attachments and dependent input states using the provided lookup functions in order to construct a class LedgerTransaction. Note that identity lookup failure does not cause an exception to be thrown.
toNonEmptySet($receiver) - Static method in class net.corda.core.utilities.KotlinUtilsKt
 
toObservable($receiver) - Static method in class net.corda.core.Utils
 
TooManyParameters(methodName, command) - Constructor for exception net.corda.jackson.UnparseableCallException.TooManyParameters
 
TopicSession - Class in net.corda.node.services.messaging
An identifier for the endpoint interface MessagingService message handlers listen at.
TopicSession(topic, sessionID) - Constructor for class net.corda.node.services.messaging.TopicSession
An identifier for the endpoint interface MessagingService message handlers listen at.
TopicStringValidator - Class in net.corda.node.services.messaging
A singleton that's useful for validating topic strings
topologicalSort(transactions) - Method in class net.corda.core.flows.ResolveTransactionsFlow.Companion
Topologically sorts the given transactions such that dependencies are listed before dependers.
topologicalSort(transactions) - Static method in class net.corda.core.flows.ResolveTransactionsFlow
Topologically sorts the given transactions such that dependencies are listed before dependers.
toProxy(obj) - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer
Implement these two methods.
toProxy(obj) - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer
Implement these two methods.
toProxy(obj) - Method in class net.corda.core.serialization.amqp.custom.ThrowableSerializer
Implement these two methods.
toProxy(obj) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
Implement these two methods.
toProxy(obj) - Method in class net.corda.core.serialization.amqp.CustomSerializer.ToString
Implement these two methods.
toSHA256Bytes($receiver) - Static method in class net.corda.core.crypto.EncodingUtils
 
toSignedTransaction(checkSufficientSignatures) - Method in class net.corda.core.transactions.TransactionBuilder
Deprecated. 
toStateAndRef($this, stateRef) - Static method in class net.corda.core.node.PluginServiceHub.DefaultImpls
 
toStateAndRef($this, stateRef) - Static method in class net.corda.core.node.ServiceHub.DefaultImpls
Converts the given class StateRef into a class StateAndRef object.
toStateAndRef(stateRef) - Method in interface net.corda.core.node.ServiceHub
Converts the given class StateRef into a class StateAndRef object.
toStateAndRef($this, stateRef) - Static method in class net.corda.node.services.api.ServiceHubInternal.DefaultImpls
 
toString() - Method in class net.corda.client.jfx.model.Diff
 
toString() - Method in class net.corda.client.jfx.model.InputResolution.Resolved
 
toString() - Method in class net.corda.client.jfx.model.InputResolution.Unresolved
 
toString() - Method in class net.corda.client.jfx.model.PartiallyResolvedTransaction
 
toString() - Method in class net.corda.client.jfx.model.ProgressTrackingEvent
 
toString() - Method in class net.corda.client.rpc.CordaRPCClientConfiguration
 
toString() - Method in class net.corda.client.rpc.internal.ObservableContext
 
toString() - Method in class net.corda.client.rpc.internal.RPCClientConfiguration
 
toString() - Method in class net.corda.contracts.asset.Commands.Exit
 
toString() - Method in class net.corda.contracts.asset.Commands.Issue
 
toString() - Method in class net.corda.contracts.asset.Commands.Move
 
toString() - Method in class net.corda.contracts.asset.Cash.State
 
toString() - Method in class net.corda.contracts.asset.Commands.Exit
 
toString() - Method in class net.corda.contracts.asset.Commands.Issue
 
toString() - Method in class net.corda.contracts.asset.Commands.Move
 
toString() - Method in class net.corda.contracts.asset.CommodityContract.State
 
toString() - Method in class net.corda.contracts.asset.Clauses.Net
 
toString() - Method in class net.corda.contracts.asset.Clauses.SetLifecycle
 
toString() - Method in class net.corda.contracts.asset.Commands.Exit
 
toString() - Method in class net.corda.contracts.asset.Commands.Issue
 
toString() - Method in class net.corda.contracts.asset.Commands.Move
 
toString() - Method in class net.corda.contracts.asset.Commands.Net
 
toString() - Method in class net.corda.contracts.asset.Commands.SetLifecycle
 
toString() - Method in class net.corda.contracts.asset.Commands.Settle
 
toString() - Method in class net.corda.contracts.asset.Obligation.State
 
toString() - Method in class net.corda.contracts.asset.Obligation.Terms
 
toString() - Method in class net.corda.contracts.clause.AbstractConserveAmount
 
toString() - Method in class net.corda.contracts.clause.BilateralNetState
 
toString() - Method in class net.corda.contracts.clause.MultilateralNetState
 
toString() - Method in class net.corda.contracts.clause.NoZeroSizedOutputs
 
toString() - Method in class net.corda.contracts.Commands.Issue
 
toString() - Method in class net.corda.contracts.Commands.Move
 
toString() - Method in class net.corda.contracts.CommercialPaper.State
 
toString() - Method in class net.corda.contracts.CommercialPaper.Terms
 
toString() - Method in class net.corda.contracts.CommercialPaperLegacy.State
 
toString() - Method in class net.corda.contracts.Commodity
 
toString() - Method in enum net.corda.contracts.DayCountBasisDay
 
toString() - Method in enum net.corda.contracts.DayCountBasisYear
 
toString() - Method in class net.corda.contracts.Expression
 
toString() - Method in class net.corda.contracts.Fix
 
toString() - Method in class net.corda.contracts.FixOf
 
toString() - Method in class net.corda.contracts.Tenor
 
toString() - Method in class net.corda.core.contracts.AbstractAttachment
 
toString() - Method in class net.corda.core.contracts.Amount
Convert a currency class Amount to a display string representation.
toString() - Method in class net.corda.core.contracts.AmountTransfer
 
toString() - Method in class net.corda.core.contracts.AuthenticatedObject
 
toString() - Method in class net.corda.core.contracts.clauses.AllOf
 
toString() - Method in class net.corda.core.contracts.clauses.AnyOf
 
toString() - Method in class net.corda.core.contracts.clauses.FirstComposition
Deprecated.
 
toString() - Method in class net.corda.core.contracts.clauses.FirstOf
 
toString() - Method in class net.corda.core.contracts.Command
 
toString() - Method in class net.corda.core.contracts.Issued
 
toString() - Method in class net.corda.core.contracts.PartyAndReference
 
toString() - Method in class net.corda.core.contracts.ScheduledActivity
 
toString() - Method in class net.corda.core.contracts.ScheduledStateRef
 
toString() - Method in class net.corda.core.contracts.SourceAndAmount
 
toString() - Method in class net.corda.core.contracts.StateAndRef
 
toString() - Method in class net.corda.core.contracts.StateRef
 
toString() - Method in class net.corda.core.contracts.TransactionState
 
toString() - Method in class net.corda.core.contracts.UniqueIdentifier
 
toString() - Method in class net.corda.core.contracts.UpgradeCommand
 
toString() - Method in class net.corda.core.crypto.CertificateAndKeyPair
 
toString() - Method in class net.corda.core.crypto.composite.CompositeKey.NodeAndWeight
 
toString() - Method in class net.corda.core.crypto.composite.CompositeKey
 
toString() - Method in class net.corda.core.crypto.composite.CompositeSignature.State
 
toString() - Method in class net.corda.core.crypto.composite.CompositeSignaturesWithKeys
 
toString() - Method in class net.corda.core.crypto.MerkleTree.Leaf
 
toString() - Method in class net.corda.core.crypto.MerkleTree.Node
 
toString() - Method in exception net.corda.core.crypto.MerkleTreeException
 
toString() - Method in class net.corda.core.crypto.PartialTree.IncludedLeaf
 
toString() - Method in class net.corda.core.crypto.PartialTree.Leaf
 
toString() - Method in class net.corda.core.crypto.PartialTree.Node
 
toString() - Method in class net.corda.core.crypto.SecureHash
 
toString() - Method in class net.corda.core.crypto.SignatureScheme
 
toString() - Method in class net.corda.core.crypto.testing.DummyPublicKey
Deprecated.
 
toString() - Method in class net.corda.core.crypto.testing.NullPublicKey
 
toString() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.Proposal
 
toString() - Method in class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
 
toString() - Method in class net.corda.core.flows.AppContext
 
toString() - Method in class net.corda.core.flows.BroadcastTransactionFlow.NotifyTxRequest
 
toString() - Method in class net.corda.core.flows.FetchDataFlow.Request
 
toString() - Method in class net.corda.core.flows.FetchDataFlow.Result
 
toString() - Method in class net.corda.core.flows.FinalityFlow.Participant
 
toString() - Method in class net.corda.core.flows.FlowInitiator.Peer
 
toString() - Method in class net.corda.core.flows.FlowInitiator.RPC
 
toString() - Method in class net.corda.core.flows.FlowInitiator.Scheduled
 
toString() - Method in class net.corda.core.flows.NotaryError.Conflict
 
toString() - Method in class net.corda.core.flows.NotaryError.TransactionInvalid
 
toString() - Method in class net.corda.core.flows.StateMachineRunId
 
toString() - Method in class net.corda.core.flows.TransactionParts
 
toString() - Method in class net.corda.core.identity.AnonymousParty
 
toString() - Method in class net.corda.core.identity.AnonymousPartyAndPath
 
toString() - Method in class net.corda.core.identity.Party
 
toString() - Method in class net.corda.core.identity.PartyAndCertificate
 
toString() - Method in class net.corda.core.internal.InputStreamAndHash
 
toString() - Method in class net.corda.core.messaging.DataFeed
 
toString() - Method in class net.corda.core.messaging.FlowHandleImpl
 
toString() - Method in class net.corda.core.messaging.FlowProgressHandleImpl
 
toString() - Method in class net.corda.core.messaging.StateMachineInfo
 
toString() - Method in class net.corda.core.messaging.StateMachineTransactionMapping
 
toString() - Method in class net.corda.core.messaging.StateMachineUpdate.Added
 
toString() - Method in class net.corda.core.messaging.StateMachineUpdate.Removed
 
toString() - Method in class net.corda.core.node.NodeInfo
 
toString() - Method in class net.corda.core.node.ServiceEntry
 
toString() - Method in class net.corda.core.node.services.MapChange.Added
 
toString() - Method in class net.corda.core.node.services.MapChange.Modified
 
toString() - Method in class net.corda.core.node.services.MapChange.Removed
 
toString() - Method in class net.corda.core.node.services.PartyInfo.Node
 
toString() - Method in class net.corda.core.node.services.PartyInfo.Service
 
toString() - Method in class net.corda.core.node.services.ServiceInfo
 
toString() - Method in class net.corda.core.node.services.ServiceType
 
toString() - Method in exception net.corda.core.node.services.StatesNotAvailableException
 
toString() - Method in class net.corda.core.node.services.UniquenessProvider.Conflict
 
toString() - Method in class net.corda.core.node.services.UniquenessProvider.ConsumingTx
 
toString() - Method in class net.corda.core.node.services.vault.ColumnPredicate.AggregateFunction
 
toString() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Between
 
toString() - Method in class net.corda.core.node.services.vault.ColumnPredicate.BinaryComparison
 
toString() - Method in class net.corda.core.node.services.vault.ColumnPredicate.CollectionExpression
 
toString() - Method in class net.corda.core.node.services.vault.ColumnPredicate.EqualityComparison
 
toString() - Method in class net.corda.core.node.services.vault.ColumnPredicate.Likeness
 
toString() - Method in class net.corda.core.node.services.vault.ColumnPredicate.NullExpression
 
toString() - Method in class net.corda.core.node.services.vault.CriteriaExpression.AggregateFunctionExpression
 
toString() - Method in class net.corda.core.node.services.vault.CriteriaExpression.BinaryLogical
 
toString() - Method in class net.corda.core.node.services.vault.CriteriaExpression.ColumnPredicateExpression
 
toString() - Method in class net.corda.core.node.services.vault.CriteriaExpression.Not
 
toString() - Method in class net.corda.core.node.services.Vault.Page
 
toString() - Method in class net.corda.core.node.services.vault.PageSpecification
 
toString() - Method in class net.corda.core.node.services.vault.QueryCriteria.FungibleAssetQueryCriteria
 
toString() - Method in class net.corda.core.node.services.vault.QueryCriteria.LinearStateQueryCriteria
 
toString() - Method in class net.corda.core.node.services.vault.QueryCriteria.TimeCondition
 
toString() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultCustomQueryCriteria
 
toString() - Method in class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
 
toString() - Method in class net.corda.core.node.services.vault.Sort.SortColumn
 
toString() - Method in class net.corda.core.node.services.vault.Sort
 
toString() - Method in class net.corda.core.node.services.vault.SortAttribute.Custom
 
toString() - Method in class net.corda.core.node.services.vault.SortAttribute.Standard
 
toString() - Method in class net.corda.core.node.services.Vault.StateMetadata
 
toString() - Method in class net.corda.core.node.services.Vault.Update
 
toString() - Method in class net.corda.core.node.WorldCoordinate
 
toString() - Method in class net.corda.core.node.WorldMapLocation
 
toString() - Method in class net.corda.core.schemas.MappedSchema
 
toString() - Method in class net.corda.core.schemas.PersistentStateRef
 
toString() - Method in class net.corda.core.serialization.amqp.Choice
 
toString() - Method in class net.corda.core.serialization.amqp.CompositeType
 
toString() - Method in class net.corda.core.serialization.amqp.custom.InstantSerializer.InstantProxy
 
toString() - Method in class net.corda.core.serialization.amqp.custom.StackTraceElementSerializer.StackTraceElementProxy
 
ToString(clazz, withInheritance, maker, unmaker) - Constructor for class net.corda.core.serialization.amqp.CustomSerializer.ToString
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.
toString() - Method in class net.corda.core.serialization.amqp.Descriptor
 
toString() - Method in class net.corda.core.serialization.amqp.DeserializedGenericArrayType
 
toString() - Method in class net.corda.core.serialization.amqp.DeserializedParameterizedType
 
toString() - Method in class net.corda.core.serialization.amqp.Envelope
 
toString() - Method in class net.corda.core.serialization.amqp.Field
 
toString() - Method in class net.corda.core.serialization.amqp.objectAndEnvelope
 
toString() - Method in class net.corda.core.serialization.amqp.RestrictedType
 
toString() - Method in class net.corda.core.serialization.amqp.Schema
 
toString() - Method in class net.corda.core.serialization.amqp.SerializerFactory.AnyType
 
toString() - Method in exception net.corda.core.serialization.AttachmentsClassLoader.OverlappingAttachments
 
toString() - Method in class net.corda.core.serialization.carpenter.CarpenterSchemas
 
toString() - Method in class net.corda.core.transactions.BaseTransaction
 
toString() - Method in class net.corda.core.transactions.LedgerTransaction.InOutGroup
 
toString() - Method in class net.corda.core.transactions.SignedTransaction
 
toString() - Method in class net.corda.core.transactions.WireTransaction
 
toString() - Method in class net.corda.core.utilities.ByteSequence
 
toString() - Method in class net.corda.core.utilities.NetworkHostAndPort
 
toString() - Method in class net.corda.core.utilities.NonEmptySet
 
toString() - Method in class net.corda.core.utilities.Change.Position
 
toString() - Method in class net.corda.core.utilities.Change.Rendering
 
toString() - Method in class net.corda.core.utilities.Change.Structural
 
toString() - Method in class net.corda.core.utilities.Try.Failure
 
toString() - Method in class net.corda.core.utilities.Try.Success
 
toString() - Method in class net.corda.flows.AbstractCashFlow.Result
 
toString() - Method in class net.corda.flows.CashFlowCommand.ExitCash
 
toString() - Method in class net.corda.flows.CashFlowCommand.IssueCash
 
toString() - Method in class net.corda.flows.CashFlowCommand.PayCash
 
toString() - Method in class net.corda.flows.IssuerFlow.IssuanceRequestState
 
toString() - Method in class net.corda.flows.TwoPartyDealFlow.AutoOffer
 
toString() - Method in class net.corda.flows.TwoPartyDealFlow.Handshake
 
toString() - Method in exception net.corda.flows.TwoPartyTradeFlow.AssetMismatchException
 
toString() - Method in class net.corda.flows.TwoPartyTradeFlow.SellerTradeInfo
 
toString() - Method in class net.corda.jackson.JacksonSupport.BusinessCalendarWrapper
 
toString() - Method in class net.corda.node.CmdLineOptions
 
toString() - Method in class net.corda.node.internal.InitiatedFlowFactory.CorDapp
 
toString() - Method in class net.corda.node.internal.InitiatedFlowFactory.Core
 
toString() - Method in class net.corda.node.internal.NetworkMapInfo
 
toString() - Method in class net.corda.node.services.api.Checkpoint
 
toString() - Method in class net.corda.node.services.api.FlowAppAuditEvent
 
toString() - Method in class net.corda.node.services.api.FlowErrorAuditEvent
 
toString() - Method in class net.corda.node.services.api.FlowPermissionAuditEvent
 
toString() - Method in class net.corda.node.services.api.FlowProgressAuditEvent
 
toString() - Method in class net.corda.node.services.api.FlowStartEvent
 
toString() - Method in class net.corda.node.services.api.SchemaService.SchemaOptions
 
toString() - Method in class net.corda.node.services.api.SystemAuditEvent
 
toString() - Method in class net.corda.node.services.config.CertChainPolicyConfig
 
toString() - Method in class net.corda.node.services.config.FullNodeConfiguration
 
toString() - Method in class net.corda.node.services.messaging.CertificateChainCheckPolicy.MustContainOneOf
 
toString() - Method in class net.corda.node.services.messaging.NodeMessagingClient.Handler
 
toString() - Method in class net.corda.node.services.messaging.RpcContext
 
toString() - Method in class net.corda.node.services.messaging.RPCServerConfiguration
 
toString() - Method in class net.corda.node.services.messaging.TopicSession
 
toString() - Method in class net.corda.node.services.network.LastAcknowledgeInfo
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapRequest
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.FetchMapResponse
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityRequest
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.QueryIdentityResponse
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationRequest
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.RegistrationResponse
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeRequest
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.SubscribeResponse
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.Update
 
toString() - Method in class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
 
toString() - Method in class net.corda.node.services.network.NodeRegistration
 
toString() - Method in class net.corda.node.services.network.NodeRegistrationInfo
 
toString() - Method in class net.corda.node.services.statemachine.ErrorSessionEnd
 
toString() - Method in class net.corda.node.services.statemachine.FlowLogicRefImpl
 
toString() - Method in class net.corda.node.services.statemachine.FlowSession
 
toString() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiated
 
toString() - Method in class net.corda.node.services.statemachine.FlowSessionState.Initiating
 
toString() - Method in class net.corda.node.services.statemachine.NormalSessionEnd
 
toString() - Method in class net.corda.node.services.statemachine.ReceivedSessionMessage
 
toString() - Method in class net.corda.node.services.statemachine.ReceiveOnly
 
toString() - Method in class net.corda.node.services.statemachine.SendAndReceive
 
toString() - Method in class net.corda.node.services.statemachine.SendOnly
 
toString() - Method in class net.corda.node.services.statemachine.SessionConfirm
 
toString() - Method in class net.corda.node.services.statemachine.SessionData
 
toString() - Method in class net.corda.node.services.statemachine.SessionInit
 
toString() - Method in class net.corda.node.services.statemachine.SessionReject
 
toString() - Method in class net.corda.node.services.statemachine.Change.Add
 
toString() - Method in class net.corda.node.services.statemachine.Change.Removed
 
toString() - Method in class net.corda.node.services.statemachine.WaitForLedgerCommit
 
toString() - Method in class net.corda.node.services.transactions.ClusterResponse.Error
 
toString() - Method in class net.corda.node.services.transactions.ClusterResponse.Signatures
 
toString() - Method in class net.corda.node.services.transactions.BFTSMaRt.CommitRequest
 
toString() - Method in class net.corda.node.services.transactions.ReplicaResponse.Error
 
toString() - Method in class net.corda.node.services.transactions.ReplicaResponse.Signature
 
toString() - Method in exception net.corda.node.shell.InteractiveShell.NoApplicableConstructor
 
toString() - Method in class net.corda.node.utilities.DatabaseTransactionManager.Boundary
 
toString() - Method in class net.corda.node.utilities.PartyAndCertificateColumns
 
toString() - Method in class net.corda.node.utilities.PartyColumns
 
toString() - Method in class net.corda.node.utilities.StateRefColumns
 
toString() - Method in class net.corda.node.utilities.TxnNoteColumns
 
toString() - Method in class net.corda.node.VersionInfo
 
toStringShort($receiver) - Static method in class net.corda.core.crypto.CryptoUtils
Render a public key to its hash (in Base58) of its serialised form using the DL prefix.
toSupportedPrivateKey(key) - Method in class net.corda.core.crypto.Crypto
Convert a private key to a supported implementation. This can be used to convert a SUN's EC key to an BC key. This method is usually required to retrieve keys from JKS keystores that by default return SUN implementations.
toSupportedPublicKey(key) - Method in class net.corda.core.crypto.Crypto
Convert a public key to a supported implementation. This method is usually required to retrieve a key from an X509CertificateHolder.
toSupportedPublicKey(key) - Method in class net.corda.core.crypto.Crypto
Convert a public key to a supported implementation. This can be used to convert a SUN's EC key to an BC key. This method is usually required to retrieve a key (via its corresponding cert) from JKS keystores that by default return SUN implementations.
toToken(context) - Method in interface net.corda.core.serialization.SerializeAsToken
 
toToken(context) - Method in class net.corda.core.serialization.SingletonSerializeAsToken
 
toToken(context) - Method in class net.corda.node.serialization.NodeClock
 
toToken(context) - Method in class net.corda.node.utilities.TestClock
 
toWire(keyManager, publicKey) - Method in class net.corda.node.services.network.NodeRegistration
Build a node registration in wire format.
toWireTransaction() - Method in class net.corda.core.transactions.TransactionBuilder
 
trace($receiver, msg) - Static method in class net.corda.core.utilities.KotlinUtilsKt
Log a TRACE level message produced by evaluating the given lamdba, but only if TRACE logging is enabled.
track() - Method in class net.corda.core.flows.FlowLogic
Returns a pair of the current progress step, as a string, and an observable of stringified changes to the progressTracker.
track() - Method in interface net.corda.core.node.services.NetworkMapCache
Atomically get the current party nodes and a stream of updates. Note that the Observable buffers updates until the first subscriber is registered so as to avoid racing with early updates.
track() - Method in interface net.corda.core.node.services.TransactionStorage
Returns all currently stored transactions and further fresh ones.
track() - Method in interface net.corda.core.node.services.VaultService
Deprecated. 
track() - Method in interface net.corda.node.services.api.StateMachineRecordedTransactionMappingStorage
 
track() - Method in class net.corda.node.services.network.InMemoryNetworkMapCache
Atomically get the current party nodes and a stream of updates. Note that the Observable buffers updates until the first subscriber is registered so as to avoid racing with early updates.
track() - Method in class net.corda.node.services.persistence.DBTransactionMappingStorage
 
track() - Method in class net.corda.node.services.persistence.DBTransactionStorage
Returns all currently stored transactions and further fresh ones.
track() - Method in class net.corda.node.services.persistence.InMemoryStateMachineRecordedTransactionMappingStorage
 
track() - Method in class net.corda.node.services.statemachine.StateMachineManager
Atomic get snapshot + subscribe. This is needed so we don't miss updates between subscriptions to changes and calls to allStateMachines
track() - Method in class net.corda.node.services.vault.NodeVaultService
Atomically get the current vault and a stream of updates. Note that the Observable buffers updates until the first subscriber is registered so as to avoid racing with early updates.
trackBy($this, contractType) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
trackBy($this, contractType, criteria) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
trackBy($this, contractType, criteria, paging) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
trackBy($this, contractType, criteria, sorting) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
trackBy($this, contractType, criteria, paging, sorting) - Static method in class net.corda.core.node.services.VaultQueryService.DefaultImpls
 
trackBy(contractType) - Method in interface net.corda.core.node.services.VaultQueryService
 
trackBy(contractType, criteria) - Method in interface net.corda.core.node.services.VaultQueryService
 
trackBy(contractType, criteria, paging) - Method in interface net.corda.core.node.services.VaultQueryService
 
trackBy(contractType, criteria, sorting) - Method in interface net.corda.core.node.services.VaultQueryService
 
trackBy(contractType, criteria, paging, sorting) - Method in interface net.corda.core.node.services.VaultQueryService
 
TrackedDelegate<M> - Class in net.corda.client.jfx.model
 
TrackedDelegate.EventSinkDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.EventStreamDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.ObjectPropertyDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.ObservableDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.ObservableListDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.ObservableListReadOnlyDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.ObservableValueDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.ObserverDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.SubjectDelegate<M,T> - Class in net.corda.client.jfx.model
 
TrackedDelegate.WritableValueDelegate<M,T> - Class in net.corda.client.jfx.model
 
tracker() - Method in class net.corda.core.flows.Acceptor.Companion
 
tracker() - Method in class net.corda.core.flows.Instigator.Companion
 
tracker() - Method in class net.corda.core.flows.CollectSignaturesFlow.Companion
 
tracker() - Method in class net.corda.core.flows.FinalityFlow.Companion
 
tracker() - Method in class net.corda.core.flows.Client.Companion
 
tracker() - Method in class net.corda.core.flows.SignTransactionFlow.Companion
 
tracker() - Method in class net.corda.core.flows.TransactionKeyFlow.Companion
 
tracker() - Method in class net.corda.flows.AbstractCashFlow.Companion
 
tracker() - Method in class net.corda.flows.CashExitFlow.Companion
 
tracker() - Method in class net.corda.flows.Issuer.Companion
 
tracker() - Method in class net.corda.flows.Primary.Companion
 
tracker() - Method in class net.corda.flows.Secondary.Companion
 
tracker() - Method in class net.corda.flows.Seller.Companion
 
transaction(statement) - Method in class net.corda.node.utilities.CordaPersistence
 
TransactionBuilder - Class in net.corda.core.transactions
A TransactionBuilder is a transaction class that's mutable (unlike the others which are all immutable). It is intended to be passed around contracts that may edit it by adding new states/commands. Then once the states and commands are right, this class can be used as a holding bucket to gather signatures from multiple parties.
TransactionBuilder(type, notary, lockId, inputs, attachments, outputs, commands, signers, window) - Constructor for class net.corda.core.transactions.TransactionBuilder
A TransactionBuilder is a transaction class that's mutable (unlike the others which are all immutable). It is intended to be passed around contracts that may edit it by adding new states/commands. Then once the states and commands are right, this class can be used as a holding bucket to gather signatures from multiple parties.
TransactionBuilder() - Constructor for class net.corda.core.transactions.TransactionBuilder
A TransactionBuilder is a transaction class that's mutable (unlike the others which are all immutable). It is intended to be passed around contracts that may edit it by adding new states/commands. Then once the states and commands are right, this class can be used as a holding bucket to gather signatures from multiple parties.
TransactionBuilder(type, notary) - Constructor for class net.corda.core.transactions.TransactionBuilder
 
TransactionDataModel - Class in net.corda.client.jfx.model
This model provides an observable list of transactions and what state machines/flows recorded them
TransactionDataModel() - Constructor for class net.corda.client.jfx.model.TransactionDataModel
This model provides an observable list of transactions and what state machines/flows recorded them
TransactionGraphSearch - Class in net.corda.core.contracts
Given a map of transaction id to class SignedTransaction, performs a breadth first search of the dependency graph from the starting point down in order to find transactions that match the given query criteria.
TransactionGraphSearch(transactions, startPoints) - Constructor for class net.corda.core.contracts.TransactionGraphSearch
Given a map of transaction id to class SignedTransaction, performs a breadth first search of the dependency graph from the starting point down in order to find transactions that match the given query criteria.
TransactionGraphSearch.Query - Class in net.corda.core.contracts
 
TransactionInvalid(cause) - Constructor for class net.corda.core.flows.NotaryError.TransactionInvalid
 
TransactionKeyFlow - Class in net.corda.core.flows
Very basic flow which exchanges transaction key and certificate paths between two parties in a transaction. This is intended for use as a subflow of another flow.
TransactionKeyFlow(otherSide, revocationEnabled, progressTracker) - Constructor for class net.corda.core.flows.TransactionKeyFlow
Very basic flow which exchanges transaction key and certificate paths between two parties in a transaction. This is intended for use as a subflow of another flow.
TransactionKeyFlow(otherSide) - Constructor for class net.corda.core.flows.TransactionKeyFlow
 
TransactionKeyFlow.Companion - Class in net.corda.core.flows
 
TransactionKeyHandler - Class in net.corda.node.services
 
TransactionKeyHandler(otherSide, revocationEnabled) - Constructor for class net.corda.node.services.TransactionKeyHandler
 
TransactionKeyHandler(otherSide) - Constructor for class net.corda.node.services.TransactionKeyHandler
 
TransactionKeyHandler.Companion - Class in net.corda.node.services
 
TransactionMissingEncumbranceException(txId, missing, inOut) - Constructor for exception net.corda.core.contracts.TransactionVerificationException.TransactionMissingEncumbranceException
 
TransactionParts - Class in net.corda.core.flows
The minimum amount of information needed to notarise a transaction. Note that this does not include any sensitive transaction details.
TransactionParts(id, inputs, timestamp) - Constructor for 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.
TransactionResolutionException - Exception in net.corda.core.contracts
 
TransactionResolutionException(hash) - Constructor for exception net.corda.core.contracts.TransactionResolutionException
 
TransactionSignature - Class in net.corda.core.crypto
A wrapper around a digital signature accompanied with metadata, see MetaData.Full and class DigitalSignature. The signature protocol works as follows: s = sign(MetaData.hashBytes).
TransactionSignature(signatureData, metaData) - Constructor for class net.corda.core.crypto.TransactionSignature
A wrapper around a digital signature accompanied with metadata, see MetaData.Full and class DigitalSignature. The signature protocol works as follows: s = sign(MetaData.hashBytes).
TransactionState<T extends ContractState> - Class in net.corda.core.contracts
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.
TransactionState(data, notary, encumbrance) - Constructor for 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.
TransactionState(data, notary) - Constructor for 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.
TransactionStorage - Interface in net.corda.core.node.services
Thread-safe storage of transactions.
TransactionType - Class in net.corda.core.contracts
Defines transaction build & validation logic for a specific transaction type
TransactionType.General - Class in net.corda.core.contracts
A general transaction type where transaction validity is determined by custom contract code
TransactionType.NotaryChange - Class in net.corda.core.contracts
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.
TransactionVerificationException - Exception in net.corda.core.contracts
 
TransactionVerificationException.ContractRejection - Exception in net.corda.core.contracts
 
TransactionVerificationException.Direction - Enum in net.corda.core.contracts
 
TransactionVerificationException.DuplicateInputStates - Exception in net.corda.core.contracts
 
TransactionVerificationException.InvalidNotaryChange - Exception in net.corda.core.contracts
 
TransactionVerificationException.MoreThanOneNotary - Exception in net.corda.core.contracts
 
TransactionVerificationException.NotaryChangeInWrongTransactionType - Exception in net.corda.core.contracts
 
TransactionVerificationException.SignersMissing - Exception in net.corda.core.contracts
 
TransactionVerificationException.TransactionMissingEncumbranceException - Exception in net.corda.core.contracts
 
TransactionVerifierService - Interface in net.corda.core.node.services
Provides verification service. The implementation may be a simple in-memory verify() call or perhaps an IPC/RPC.
transient(initializer) - Static method in class net.corda.core.utilities.KotlinUtilsKt
A simple wrapper that enables the use of Kotlin's val x by transient { ... } syntax. Such a property will not be serialized, and if it's missing (or the first time it's accessed), the initializer will be used to set it up.
TransientProperty<T> - Class in net.corda.core.utilities
Deprecated. 
TransientProperty(initialiser) - Constructor for class net.corda.core.utilities.TransientProperty
Deprecated.
 
transition(from, to) - Method in class net.corda.core.internal.LifeCycle
Transition the state from from to to.
TraversableTransaction - Interface in net.corda.core.transactions
Implemented by class WireTransaction and class FilteredLeaves. A TraversableTransaction allows you to iterate over the flattened components of the underlying transaction structure, taking into account that some may be missing in the case of this representing a "torn" transaction. Please see the user guide section "Transaction tear-offs" to learn more about this feature.
TraversableTransaction.DefaultImpls - Class in net.corda.core.transactions
Implemented by class WireTransaction and class FilteredLeaves. A TraversableTransaction allows you to iterate over the flattened components of the underlying transaction structure, taking into account that some may be missing in the case of this representing a "torn" transaction. Please see the user guide section "Transaction tear-offs" to learn more about this feature.
TrustedAuthorityNotaryService - Class in net.corda.core.node.services
A base notary service implementation that provides functionality for cases where a signature by a single member of the cluster is sufficient for transaction notarisation. For example, a single-node or a Raft notary.
TrustedAuthorityNotaryService() - Constructor for class net.corda.core.node.services.TrustedAuthorityNotaryService
A base notary service implementation that provides functionality for cases where a signature by a single member of the cluster is sufficient for transaction notarisation. For example, a single-node or a Raft notary.
Try<A> - Class in net.corda.core.utilities
Representation of an operation that has either succeeded with a result (represented by class Try.Success) or failed with an exception (represented by class Try.Failure).
Try.Companion - Class in net.corda.core.utilities
 
Try.Failure - Class in net.corda.core.utilities
 
Try.Success<A> - Class in net.corda.core.utilities
 
tryDetectPublicIP() - Method in class net.corda.node.utilities.AddressUtils
Returns the first public IP address found on any of the network interfaces, or null if none found.
TwoPartyDealFlow - Class in net.corda.flows
Classes for manipulating a two party deal or agreement.
TwoPartyDealFlow.Acceptor - Class in net.corda.flows
One side of the flow for inserting a pre-agreed deal.
TwoPartyDealFlow.AutoOffer - Class in net.corda.flows
 
TwoPartyDealFlow.Handshake<T> - Class in net.corda.flows
 
TwoPartyDealFlow.Instigator - Class in net.corda.flows
One side of the flow for inserting a pre-agreed deal.
TwoPartyDealFlow.Primary - Class in net.corda.flows
Abstracted bilateral deal flow participant that initiates communication/handshake.
TwoPartyDealFlow.Secondary<U> - Class in net.corda.flows
Abstracted bilateral deal flow participant that is recipient of initial communication.
TwoPartyTradeFlow - Class in net.corda.flows
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:
TwoPartyTradeFlow.AssetMismatchException - Exception in net.corda.flows
 
TwoPartyTradeFlow.Buyer - Class in net.corda.flows
 
TwoPartyTradeFlow.Seller - Class in net.corda.flows
 
TwoPartyTradeFlow.SellerTradeInfo - Class in net.corda.flows
 
TwoPartyTradeFlow.UnacceptablePriceException - Exception in net.corda.flows
 
txnNote($receiver, txIdColumnName, txnNoteColumnName) - Static method in class net.corda.node.utilities.DatabaseSupportKt
 
TxnNoteColumns - Class in net.corda.node.utilities
 
TxnNoteColumns(txId, note) - Constructor for class net.corda.node.utilities.TxnNoteColumns
 
typeAsString() - Method in class net.corda.core.serialization.amqp.Field
 
TypeNotation - Class in net.corda.core.serialization.amqp
 
TypeNotation.Companion - Class in net.corda.core.serialization.amqp
 
TypeOnlyCommandData - Class in net.corda.core.contracts
Commands that inherit from this are intended to have no data items: it's only their presence that matters.
TypeOnlyCommandData() - Constructor for class net.corda.core.contracts.TypeOnlyCommandData
Commands that inherit from this are intended to have no data items: it's only their presence that matters.

U

UnacceptablePriceException(givenPrice) - Constructor for exception net.corda.flows.TwoPartyTradeFlow.UnacceptablePriceException
 
UncarpentableException - Exception in net.corda.core.serialization.carpenter
 
UncarpentableException(name, field, type) - Constructor for exception net.corda.core.serialization.carpenter.UncarpentableException
 
unconsumedStatesForSpending(amount, onlyFromIssuerParties, notary, lockId, withIssuerRefs) - Method in interface net.corda.core.node.services.VaultService
TODO: this function should be private to the vault, but currently Cash Exit functionality is implemented in a separate module (finance) and requires access to it.
unconsumedStatesForSpending(amount, onlyFromIssuerParties, notary, lockId, withIssuerRefs) - Method in class net.corda.node.services.vault.NodeVaultService
TODO: this function should be private to the vault, but currently Cash Exit functionality is implemented in a separate module (finance) and requires access to it.
UnexpectedFlowEndException - Exception in net.corda.core.flows
Thrown when a flow session ends unexpectedly due to a type mismatch (the other side sent an object of a type that we were not expecting), or the other side had an internal error, or the other side terminated when we were waiting for a response.
UnexpectedFlowEndException(message, cause) - Constructor for exception net.corda.core.flows.UnexpectedFlowEndException
Thrown when a flow session ends unexpectedly due to a type mismatch (the other side sent an object of a type that we were not expecting), or the other side had an internal error, or the other side terminated when we were waiting for a response.
UnexpectedFlowEndException(msg) - Constructor for exception net.corda.core.flows.UnexpectedFlowEndException
 
unique($receiver) - Static method in class net.corda.client.jfx.utils.ObservableUtilitiesKt
 
UniqueIdentifier - Class in net.corda.core.contracts
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.
UniqueIdentifier(externalId, id) - Constructor for 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.
UniqueIdentifier() - Constructor for 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.
UniqueIdentifier.Companion - Class in net.corda.core.contracts
 
UniquenessException - Exception in net.corda.core.node.services
 
UniquenessException(error) - Constructor for exception net.corda.core.node.services.UniquenessException
 
UniquenessProvider - Interface in net.corda.core.node.services
A service that records input states of the given transaction and provides conflict information if any of the inputs have already been used in another transaction.
UniquenessProvider.Conflict - Class in net.corda.core.node.services
Specifies the consuming transaction for every conflicting state
UniquenessProvider.ConsumingTx - Class in net.corda.core.node.services
Specifies the transaction id, the position of the consumed state in the inputs, and the caller identity requesting the commit.
UnknownAnonymousPartyException(msg) - Constructor for exception net.corda.core.node.services.IdentityService.UnknownAnonymousPartyException
 
UnknownCalendar(name) - Constructor for exception net.corda.contracts.BusinessCalendar.UnknownCalendar
 
UnknownMethod(methodName) - Constructor for exception net.corda.jackson.UnparseableCallException.UnknownMethod
 
UnparseableCallException(command, cause) - Constructor for exception net.corda.jackson.StringToMethodCallParser.UnparseableCallException
 
UnparseableCallException.FailedParse - Exception in net.corda.jackson
 
UnparseableCallException.MissingParameter - Exception in net.corda.jackson
 
UnparseableCallException.ReflectionDataMissing - Exception in net.corda.jackson
 
UnparseableCallException.TooManyParameters - Exception in net.corda.jackson
 
UnparseableCallException.UnknownMethod - Exception in net.corda.jackson
 
unregisterNetworkHandlers() - Method in class net.corda.node.services.network.AbstractNetworkMapService
 
Unresolved(stateRef) - Constructor for class net.corda.client.jfx.model.InputResolution.Unresolved
 
unscheduleStateActivity(ref) - Method in interface net.corda.node.services.api.SchedulerService
Unschedule all activity for a TX output, probably because it was consumed.
unscheduleStateActivity(ref) - Method in class net.corda.node.services.events.NodeSchedulerService
Unschedule all activity for a TX output, probably because it was consumed.
unsetName - Static variable in class net.corda.core.serialization.carpenter.Field
 
until($receiver, endExclusive) - Static method in class net.corda.core.internal.InternalUtilsKt
 
untilOnly(untilTime) - Method in class net.corda.core.contracts.TimeWindow.Companion
Creates a class TimeWindow with null fromTime, i.e. the time interval (∞, untilTime). midpoint will return null.
untilOnly(untilTime) - Static method in class net.corda.core.contracts.TimeWindow
Creates a class TimeWindow with null fromTime, i.e. the time interval (∞, untilTime). midpoint will return null.
UntrustworthyData<T> - Class in net.corda.core.utilities
A small utility to approximate taint tracking: if a method gives you back one of these, it means the data came from a remote source that may be incentivised to pass us junk that violates basic assumptions and thus must be checked first. The wrapper helps you to avoid forgetting this vital step. Things you might want to check are:
UntrustworthyData(fromUntrustedWorld) - Constructor for class net.corda.core.utilities.UntrustworthyData
A small utility to approximate taint tracking: if a method gives you back one of these, it means the data came from a remote source that may be incentivised to pass us junk that violates basic assumptions and thus must be checked first. The wrapper helps you to avoid forgetting this vital step. Things you might want to check are:
UntrustworthyData.Validator<T,R> - Interface in net.corda.core.utilities
 
UntrustworthyDataKt - Class in net.corda.core.utilities
 
unwrap(validator) - Method in class net.corda.core.utilities.UntrustworthyData
 
unwrap($receiver, validator) - Static method in class net.corda.core.utilities.UntrustworthyDataKt
 
unwrap(unwrapType) - Method in class net.corda.node.services.database.HibernateConfiguration.NodeDatabaseConnectionProvider
 
unwrap(p0) - Method in class net.corda.node.services.database.KotlinConfigurationTransactionWrapper.CordaConnection
 
Update(consumed, produced, flowId) - Constructor for class net.corda.core.node.services.Vault.Update
Represents an update observed by the vault that will be notified to observers. Include the class StateRefs of transaction outputs that were consumed (inputs) and the interface ContractStates produced (outputs) to/by the transaction or transactions observed and the vault.
Update(wireReg, mapVersion, replyTo) - Constructor for class net.corda.node.services.network.NetworkMapService.Update
 
UpdateAcknowledge(mapVersion, replyTo) - Constructor for class net.corda.node.services.network.NetworkMapService.UpdateAcknowledge
 
updateDate(date) - Method in class net.corda.node.utilities.TestClock
 
upgrade(state) - Method in interface net.corda.core.contracts.UpgradedContract
Upgrade contract's state object to a new state object.
UpgradeCommand - Class in net.corda.core.contracts
Indicates that this transaction replaces the inputs contract state to another contract state
UpgradeCommand(upgradedContractClass) - Constructor for class net.corda.core.contracts.UpgradeCommand
Indicates that this transaction replaces the inputs contract state to another contract state
UpgradedContract<OldState extends ContractState,NewState extends ContractState> - Interface in net.corda.core.contracts
Interface which can upgrade state objects issued by a contract to a new state object issued by a different contract.
UpgradeTx(stx, participants, myKey) - Constructor for class net.corda.core.flows.AbstractStateReplacementFlow.UpgradeTx
The assembled transaction for upgrading a contract.
upload(file) - Method in interface net.corda.node.services.api.FileUploader
Accepts the data in the given input stream, and returns some sort of useful return message that will be sent back to the user in the response.
upload(file) - Method in class net.corda.node.services.persistence.NodeAttachmentService
Accepts the data in the given input stream, and returns some sort of useful return message that will be sent back to the user in the response.
uploadAttachment(jar) - Method in interface net.corda.core.messaging.CordaRPCOps
Uploads a jar to the node, returns it's hash.
uploadAttachment(jar) - Method in class net.corda.node.internal.CordaRPCOpsImpl
Uploads a jar to the node, returns it's hash.
uploadFile(dataType, name, file) - Method in interface net.corda.core.messaging.CordaRPCOps
Deprecated. 
uploadFile(dataType, name, file) - Method in class net.corda.node.internal.CordaRPCOpsImpl
 
USD - Static variable in class net.corda.core.contracts.ContractsDSL
 
use(username, password, block) - Method in class net.corda.client.rpc.CordaRPCClient
 
UseCase() - Constructor for enum net.corda.core.serialization.SerializationContext.UseCase
The use case that we are serializing for, since it influences the implementations chosen.
useClassLoader($receiver, cl, body) - Static method in class net.corda.core.serialization.KryoKt
 
using($receiver, expr) - Method in class net.corda.core.contracts.Requirements
Throws IllegalArgumentException if the given expression evaluates to false.
Utils - Class in net.corda.core
 
UtilsKt - Class in net.corda.client.rpc
 
uuidString($receiver, name) - Static method in class net.corda.node.utilities.DatabaseSupportKt
 
UUIDStringColumnType - Class in net.corda.node.utilities
ColumnType for marshalling to/from database on behalf of UUID, always using a string representation.

V

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 StateRefs of transaction outputs that were consumed (inputs) and the interface ContractStates 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: provides query by attributes defined in VaultSchema.VaultStates
VaultQueryCriteria(status, contractStateTypes, stateRefs, notaryName, includeSoftlockedStates) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
VaultQueryCriteria(status, contractStateTypes, stateRefs, notaryName) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
VaultQueryCriteria(status, contractStateTypes, stateRefs) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
VaultQueryCriteria(status, contractStateTypes) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
VaultQueryCriteria(status) - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
VaultQueryCriteria() - Constructor for class net.corda.core.node.services.vault.QueryCriteria.VaultQueryCriteria
VaultQueryCriteria: provides query by attributes defined in VaultSchema.VaultStates
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
Converter which persists a enum Vault.StateStatus enum using its enum ordinal representation
VaultStateStatusConverter() - Constructor for class net.corda.core.schemas.requery.converters.VaultStateStatusConverter
Converter which persists a enum Vault.StateStatus enum using its enum ordinal representation
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
Checks the transaction's signatures are valid, optionally calls SignedTransaction.verifyRequiredSignatures to check all required signatures are present, calls WireTransaction.toLedgerTransaction with the passed in interface ServiceHub to resolve the dependencies and return an unverified LedgerTransaction, then verifies the LedgerTransaction.
verify(services) - Method in class net.corda.core.transactions.SignedTransaction
Checks the transaction's signatures are valid, optionally calls SignedTransaction.verifyRequiredSignatures to check all required signatures are present, calls WireTransaction.toLedgerTransaction with the passed in interface ServiceHub to resolve the dependencies and return an unverified LedgerTransaction, then verifies the LedgerTransaction.
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
 

W

waitAndRun() - Method in class net.corda.node.utilities.AffinityExecutor.Gate
 
waitForLedgerCommit(hash) - Method in class net.corda.core.flows.FlowLogic
Suspends the flow until the transaction with the specified ID is received, successfully verified and sent to the vault for processing. Note that this call suspends until the transaction is considered valid by the local node, but that doesn't imply the vault will consider it relevant.
waitForLedgerCommit(hash, sessionFlow) - Method in interface net.corda.core.internal.FlowStateMachine
 
waitForLedgerCommit(hash, sessionFlow) - Method in class net.corda.node.services.statemachine.FlowStateMachineImpl
 
WaitForLedgerCommit - Class in net.corda.node.services.statemachine
 
WaitForLedgerCommit(hash, fiber) - Constructor for class net.corda.node.services.statemachine.WaitForLedgerCommit
 
WaitingRequest - Interface in net.corda.node.services.statemachine
 
waitUntilRegisteredWithNetworkMap() - Method in interface net.corda.core.messaging.CordaRPCOps
Returns a ListenableFuture which completes when the node has registered wih the network map service. It can also complete with an exception if it is unable to.
waitUntilRegisteredWithNetworkMap() - Method in class net.corda.node.internal.CordaRPCOpsImpl
Returns a ListenableFuture which completes when the node has registered wih the network map service. It can also complete with an exception if it is unable to.
waitUntilReplicaWillNotPrintStackTrace(contextReplicaId) - Method in class net.corda.node.services.transactions.BFTSMaRtConfig
 
whenConsumed($this, ref) - Static method in class net.corda.core.node.services.VaultService.DefaultImpls
Provide a Future for when a class StateRef is consumed, which can be very useful in building tests.
whenConsumed(ref) - Method in interface net.corda.core.node.services.VaultService
Provide a Future for when a class StateRef is consumed, which can be very useful in building tests.
WireNodeRegistration - Class in net.corda.node.services.network
A node registration and its signature as a pair.
WireNodeRegistration(raw, sig) - Constructor for class net.corda.node.services.network.WireNodeRegistration
A node registration and its signature as a pair.
WireTransaction - Class in net.corda.core.transactions
A transaction ready for serialisation, without any signatures attached. A WireTransaction is usually wrapped by a class SignedTransaction that carries the signatures over this payload. The identity of the transaction is the Merkle tree root of its components (see class MerkleTree).
WireTransaction(inputs, attachments, outputs, commands, notary, signers, type, timeWindow) - Constructor for class net.corda.core.transactions.WireTransaction
A transaction ready for serialisation, without any signatures attached. A WireTransaction is usually wrapped by a class SignedTransaction that carries the signatures over this payload. The identity of the transaction is the Merkle tree root of its components (see class MerkleTree).
WireTransactionSerializer - Class in net.corda.core.serialization
A serialisation engine that knows how to deserialise code inside a sandbox
with deposit($receiver, deposit) - Static method in class net.corda.contracts.asset.CashKt
 
with notary($receiver, notary) - Static method in class net.corda.contracts.CommercialPaperKt
 
with notary($receiver, newNotary) - Static method in class net.corda.core.contracts.StructuresKt
withAdditionalSignature(sig) - Method in class net.corda.core.transactions.SignedTransaction
Returns the same transaction but with an additional (unchecked) signature.
withAdditionalSignatures(sigList) - Method in class net.corda.core.transactions.SignedTransaction
Returns the same transaction but with an additional (unchecked) signatures.
withClassLoader(classLoader) - Method in interface net.corda.core.serialization.SerializationContext
Helper method to return a new context based on this context with the deserialization class loader changed.
withDeposit($receiver, deposit) - Static method in class net.corda.contracts.asset.CashKt
 
withDescribed($receiver, descriptor, block) - Static method in class net.corda.core.serialization.amqp.SerializationHelperKt
Extension helper for writing described objects.
withFaceValue(newFaceValue) - Method in class net.corda.contracts.CommercialPaper.State
 
withFaceValue(newFaceValue) - Method in class net.corda.contracts.CommercialPaperLegacy.State
 
withItems(items) - Method in class net.corda.core.transactions.TransactionBuilder
A more convenient way to add items to this transaction that calls the add* methods for you based on type
WithKey(by, bits) - Constructor for class net.corda.core.crypto.DigitalSignature.WithKey
A digital signature that identifies who the public key is owned by.
withList($receiver, block) - Static method in class net.corda.core.serialization.amqp.SerializationHelperKt
Extension helper for writing lists.
withMaturityDate(newMaturityDate) - Method in class net.corda.contracts.CommercialPaper.State
 
withMaturityDate(newMaturityDate) - Method in class net.corda.contracts.CommercialPaperLegacy.State
 
withNewOwner(newOwner) - Method in class net.corda.contracts.asset.Cash.State
Copies the underlying data structure, replacing the owner field with this new value and leaving the rest alone
withNewOwner(newOwner) - Method in class net.corda.contracts.asset.CommodityContract.State
Copies the underlying data structure, replacing the owner field with this new value and leaving the rest alone
withNewOwner(newOwner) - Method in class net.corda.contracts.asset.Obligation.State
Copies the underlying data structure, replacing the owner field with this new value and leaving the rest alone
withNewOwner(newOwner) - Method in class net.corda.contracts.CommercialPaper.State
Copies the underlying data structure, replacing the owner field with this new value and leaving the rest alone
withNewOwner(newOwner) - Method in class net.corda.contracts.CommercialPaperLegacy.State
Copies the underlying data structure, replacing the owner field with this new value and leaving the rest alone
withNewOwner(newOwner) - Method in interface net.corda.core.contracts.OwnableState
Copies the underlying data structure, replacing the owner field with this new value and leaving the rest alone
withNotary($receiver, newNotary) - Static method in class net.corda.core.contracts.StructuresKt
 
withoutIssuer($receiver) - Static method in class net.corda.core.contracts.StructuresKt
Strips the issuer and returns an class Amount of the raw token directly. This is useful when you are mixing code that cares about specific issuers with code that will accept any, or which is imposing issuer constraints via some other mechanism and the additional type safety is not wanted.
withoutOwner() - Method in class net.corda.contracts.CommercialPaperLegacy.State
 
withoutReferences($receiver, block) - Static method in class net.corda.core.serialization.KryoKt
 
withoutReferences() - Method in interface net.corda.core.serialization.SerializationContext
Helper method to return a new context based on this context with object references disabled.
withOwner(newOwner) - Method in class net.corda.contracts.CommercialPaper.State
 
withOwner(newOwner) - Method in class net.corda.contracts.CommercialPaperLegacy.State
 
withProperty(property, value) - Method in interface net.corda.core.serialization.SerializationContext
Helper method to return a new context based on this context with the property added.
withTokenContext($receiver, serializationContext) - Static method in class net.corda.core.serialization.SerializationTokenKt
 
withTolerance(instant, tolerance) - Method in class net.corda.core.contracts.TimeWindow.Companion
Creates a class TimeWindow which is centered around instant with the given tolerance on both sides, i.e the time interval [instant - tolerance, instant + tolerance). midpoint will return instant.
withTolerance(instant, tolerance) - Static method in class net.corda.core.contracts.TimeWindow
Creates a class TimeWindow which is centered around instant with the given tolerance on both sides, i.e the time interval [instant - tolerance, instant + tolerance). midpoint will return instant.
withWhitelisted(clazz) - Method in interface net.corda.core.serialization.SerializationContext
Helper method to return a new context based on this context with the given class specifically whitelisted.
withZone(zone) - Method in class net.corda.node.serialization.NodeClock
 
withZone(zone) - Method in class net.corda.node.utilities.TestClock
 
WorldCoordinate - Class in net.corda.core.node
A latitude/longitude pair.
WorldCoordinate(latitude, longitude) - Constructor for class net.corda.core.node.WorldCoordinate
A latitude/longitude pair.
WorldMapLocation - Class in net.corda.core.node
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.
WorldMapLocation(coordinate, description, countryCode) - Constructor for 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.
WrappedObservableValue(observableValue) - Constructor for class net.corda.client.jfx.utils.FlattenedList.WrappedObservableValue
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.
wrapWithDatabaseTransaction($receiver, db) - Static method in class net.corda.node.utilities.CordaPersistenceKt
Wrap delivery of observations in a database transaction. Multiple subscribers will receive the observations inside the same database transaction. This also lazily subscribes to the source rx.Observable to preserve any buffering that might be in place.
WritableTransactionStorage - Interface in net.corda.node.services.api
Thread-safe storage of transactions.
WritableValueDelegate(klass, writableValueProperty) - Constructor for class net.corda.client.jfx.model.TrackedDelegate.WritableValueDelegate
 
write(kryo, output, observable) - Method in class net.corda.client.rpc.internal.RpcClientObservableSerializer
 
write($receiver, createDirs, options, block) - Static method in class net.corda.core.internal.InternalUtilsKt
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.CertPathSerializer
 
write(kryo, output, clazz) - Method in class net.corda.core.serialization.ClassSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.CompositeKeySerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.ECPublicKeyImplSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.Ed25519PrivateKeySerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.Ed25519PublicKeySerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.ImmutableClassSerializer
 
write(kryo, output, stream) - Method in class net.corda.core.serialization.InputStreamSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.KryoAMQPSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.LoggerSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.MetaDataSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.NoReferencesSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.PrivateKeySerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.PublicKeySerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.SerializeAsTokenSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.SerializedBytesSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.SignedTransactionSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.WireTransactionSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.X500NameSerializer
 
write(kryo, output, obj) - Method in class net.corda.core.serialization.X509CertificateSerializer
 
write(kryo, output, observable) - Method in class net.corda.node.services.messaging.RpcServerObservableSerializer
 
writeBytesWithLength($receiver, byteArray) - Static method in class net.corda.core.serialization.KryoKt
 
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.AMQPPrimitiveSerializer
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in interface net.corda.core.serialization.amqp.AMQPSerializer
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.ArraySerializer
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.CollectionSerializer
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Implements
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Is
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.MapSerializer
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.ObjectSerializer
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.PropertySerializer.AMQPCharPropertySerializer
 
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.PropertySerializer.AMQPPrimitivePropertySerializer
 
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.PropertySerializer.DescribedTypePropertySerializer
 
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.PropertySerializer
 
writeClassInfo(output) - Method in class net.corda.core.serialization.amqp.SingletonSerializer
Add anything required to the AMQP schema via SerializationOutput.writeTypeNotations and any dependent serializers via SerializationOutput.requireSerializer. e.g. for the elements of an array.
writeDescribedObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.custom.PublicKeySerializer
 
writeDescribedObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.custom.X500NameSerializer
 
writeDescribedObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.CustomSerializer.Proxy
 
writeDescribedObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.CustomSerializer.SubClass
 
writeDescribedObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.CustomSerializer.ToString
 
writeDescribedObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.CustomSerializer
 
writeLines($receiver, lines, charset, options) - Static method in class net.corda.core.internal.InternalUtilsKt
 
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.AMQPPrimitiveSerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in interface net.corda.core.serialization.amqp.AMQPSerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.ArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.CollectionSerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.CustomSerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.MapSerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.ObjectSerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.PrimBooleanArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.PrimCharArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.PrimDoubleArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.PrimFloatArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.PrimIntArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.PrimLongArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.PrimShortArraySerializer
Write the given object, with declared type, to the output.
writeObject(obj, data, type, output) - Method in class net.corda.core.serialization.amqp.SingletonSerializer
Write the given object, with declared type, to the output.
WriteOnceProperty<T> - Class in net.corda.core.internal
A write-once property to be used as delegate for Kotlin var properties. The expectation is that this is initialised prior to the spawning of any threads that may access it and so there's no need for it to be volatile.
WriteOnceProperty() - Constructor for class net.corda.core.internal.WriteOnceProperty
A write-once property to be used as delegate for Kotlin var properties. The expectation is that this is initialised prior to the spawning of any threads that may access it and so there's no need for it to be volatile.
writeProperty(obj, data, output) - Method in class net.corda.core.serialization.amqp.PropertySerializer.AMQPCharPropertySerializer
 
writeProperty(obj, data, output) - Method in class net.corda.core.serialization.amqp.PropertySerializer.AMQPPrimitivePropertySerializer
 
writeProperty(obj, data, output) - Method in class net.corda.core.serialization.amqp.PropertySerializer.DescribedTypePropertySerializer
 
writeProperty(obj, data, output) - Method in class net.corda.core.serialization.amqp.PropertySerializer
 
writeSchema(schema, data) - Method in class net.corda.core.serialization.amqp.SerializationOutput
 

X

X500NameSerializer - Class in net.corda.core.serialization.amqp.custom
Custom serializer for X500 names that utilizes their ASN.1 encoding on the wire.
X500NameSerializer - Class in net.corda.core.serialization
For serialising an X500Name without touching Sun internal classes.
X509CertificateColumnType - Class in net.corda.node.utilities
ColumnType for marshalling to/from database on behalf of X509CertificateHolder.
X509CertificateSerializer - Class in net.corda.core.serialization
For serialising an X509CertificateHolder in an X.500 standard format.
X509Utilities - Class in net.corda.core.crypto
 
X509UtilitiesKt - Class in net.corda.core.crypto
 

Z

zero(token) - Method in class net.corda.core.contracts.Amount.Companion
For a particular token returns a zero sized Amount
zero(token) - Static method in class net.corda.core.contracts.Amount
For a particular token returns a zero sized Amount
zero(token, source, destination) - Method in class net.corda.core.contracts.AmountTransfer.Companion
Helper to make a zero size AmountTransfer
zero(token, source, destination) - Static method in class net.corda.core.contracts.AmountTransfer
Helper to make a zero size AmountTransfer

_

_queryBy(criteria, paging, sorting, contractType) - Method in interface net.corda.core.node.services.VaultQueryService
Generic vault query function which takes a class QueryCriteria object to define filters, optional class PageSpecification and optional class Sort modification criteria (default unsorted), and returns a class Vault.Page object containing the following:
_queryBy(criteria, paging, sorting, contractType) - Method in class net.corda.node.services.vault.HibernateVaultQueryImpl
Generic vault query function which takes a class QueryCriteria object to define filters, optional class PageSpecification and optional class Sort modification criteria (default unsorted), and returns a class Vault.Page object containing the following:
_trackBy(criteria, paging, sorting, contractType) - Method in interface net.corda.core.node.services.VaultQueryService
Generic vault query function which takes a class QueryCriteria object to define filters, optional class PageSpecification and optional class Sort modification criteria (default unsorted), and returns a Vault.PageAndUpdates object containing
_trackBy(criteria, paging, sorting, contractType) - Method in class net.corda.node.services.vault.HibernateVaultQueryImpl
Generic vault query function which takes a class QueryCriteria object to define filters, optional class PageSpecification and optional class Sort modification criteria (default unsorted), and returns a Vault.PageAndUpdates object containing
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 
Skip navigation links