Module Contents
alltypes
Module Contents
class ANSIProgressObserver
object ANSIProgressRenderer
interface APIServer
Module Contents
abstract fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
abstract fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
abstract fun fetchFlowsRequiringAttention(query: StatesQuery): Map<StateRef, FlowRequiringAttention>
abstract fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
abstract fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
abstract fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
abstract fun info(): NodeInfo
abstract fun invokeFlowSync(type: FlowRef, args: Map<String, Any?>): Any?
abstract fun provideFlowResponse(flow: FlowInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
abstract fun queryStates(query: StatesQuery): List<StateRef>
abstract fun serverTime(): LocalDateTime
abstract fun status(): <ERROR CLASS>
class APIServerImpl : APIServer
Module Contents
APIServerImpl(node: AbstractNode)
fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
fun fetchFlowsRequiringAttention(query: StatesQuery): Map<StateRef, FlowRequiringAttention>
fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
fun info(): NodeInfo
fun invokeFlowSync(type: FlowRef, args: Map<String, Any?>): Any?
val node: AbstractNode
fun provideFlowResponse(flow: FlowInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
fun queryStates(query: StatesQuery): List<StateRef>
fun serverTime(): LocalDateTime
fun status(): <ERROR CLASS>
abstract class AbstractConserveAmount<S : FungibleAsset<T>, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
Module Contents
AbstractConserveAmount()
fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<T>>, assetStates: List<StateAndRef<S>>, deriveState: (TransactionState<S>, Amount<Issued<T>>, CompositeKey) -> TransactionState<S>, generateMoveCommand: () -> CommandData, generateExitCommand: (Amount<Issued<T>>) -> CommandData): CompositeKey
open fun toString(): String
open fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Issued<T>?): Set<C>
abstract class AbstractIssue<in S : ContractState, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
abstract class AbstractJDBCHashMap<K : Any, V : Any, out T : JDBCHashedTable> : MutableMap<K, V>, AbstractMap<K, V>
Module Contents
AbstractJDBCHashMap(table: T, loadOnInit: Boolean = false, maxBuckets: Int = 256)
protected abstract fun addKeyToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
protected abstract fun addValueToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
open fun clear(): Unit
open fun containsKey(key: K): Boolean
open fun containsValue(value: V): Boolean
open val entries: MutableSet<MutableEntry<K, V>>
open fun get(key: K): V?
open fun isEmpty(): Boolean
protected abstract fun keyFromRow(row: <ERROR CLASS>): K
open val keys: MutableSet<K>
val loadOnInit: Boolean
protected val log: <ERROR CLASS>
val maxBuckets: Int
open fun put(key: K, value: V): V?
open fun remove(key: K): V?
open val size: Int
val table: T
protected abstract fun valueFromRow(row: <ERROR CLASS>): V
open val values: MutableCollection<V>
abstract class AbstractJDBCHashSet<K : Any, out T : JDBCHashedTable> : MutableSet<K>, AbstractSet<K>
abstract class AbstractNetworkMapService : NetworkMapService, AbstractNodeService
abstract class AbstractNode : SingletonSerializeAsToken
abstract class AbstractNodeService : SingletonSerializeAsToken
abstract class AbstractStateReplacementFlow<T>
interface AcceptsFileUpload
enum class AccrualAdjustment
object Ack : DeserializeAsKotlinObjectDef
enum class AddOrRemove
interface AffinityExecutor : Executor
class AggregatedList<A, E : Any, K : Any> : TransformationList<A, E>
class AllComposition<S : ContractState, C : CommandData, K : Any> : CompositeClause<S, C, K>
Module Contents
AllComposition(firstClause: Clause<S, C, K>, vararg remainingClauses: Clause<S, C, K>)
val clauses: ArrayList<Clause<S, C, K>>
fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<Clause<S, C, K>>
fun toString(): String
fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
interface AllPossibleRecipients : MessageRecipients
data class Amount<T> : Comparable<Amount<T>>
object AmountBindings
class AmountGenerator<T>
class AnyComposition<in S : ContractState, C : CommandData, in K : Any> : CompositeClause<S, C, K>
Module Contents
AnyComposition(vararg rawClauses: Clause<S, C, K>)
val clauses: List<Clause<S, C, K>>
fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<Clause<S, C, K>>
fun toString(): String
fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
class ApiUtils
data class AppContext
abstract class ArtemisMessagingComponent : SingletonSerializeAsToken
class ArtemisMessagingServer : ArtemisMessagingComponent
class AssociatedList<K, out A, B> : ReadOnlyBackedObservableMapBase<K, B, Unit>
interface Attachment : NamedByHash
class AttachmentDownloadServlet
interface AttachmentStorage
class AttachmentsClassLoader : SecureClassLoader
data class AuthenticatedObject<out T : Any>
abstract class BaseTransaction : NamedByHash
data class BilateralNetState<P> : NetState<P>
interface BilateralNettableState<N : BilateralNettableState<N>>
class BroadcastTransactionFlow : FlowLogic<Unit>
open class BusinessCalendar
Module Contents
val TEST_CALENDAR_DATA: <ERROR CLASS>
class UnknownCalendar : Exception
open fun applyRollConvention(testDate: LocalDate, dateRollConvention: DateRollConvention): LocalDate
val calendars: <ERROR CLASS>
fun createGenericSchedule(startDate: LocalDate, period: Frequency, calendar: BusinessCalendar = getInstance(), dateRollConvention: DateRollConvention = DateRollConvention.Following, noOfAdditionalPeriods: Int = Integer.MAX_VALUE, endDate: LocalDate? = null, periodOffset: Int? = null): List<LocalDate>
open fun equals(other: Any?): Boolean
fun getInstance(vararg calname: String): BusinessCalendar
fun getOffsetDate(startDate: LocalDate, period: Frequency, steps: Int = 1): LocalDate
open fun hashCode(): Int
val holidayDates: List<LocalDate>
open fun isWorkingDay(date: LocalDate): Boolean
fun moveBusinessDays(date: LocalDate, direction: DateRollDirection, i: Int): LocalDate
fun parseDateFromString(it: String): LocalDate
class Cash : OnLedgerAsset<Currency, Commands, State>
Module Contents
Cash()
interface Clauses
interface Commands : Commands
data class State : FungibleAsset<Currency>, QueryableState
val conserveClause: AbstractConserveAmount<State, Commands, Currency>
fun deriveState(txState: TransactionState<State>, amount: Amount<Issued<Currency>>, owner: CompositeKey): TransactionState<State>
fun extractCommands(commands: Collection<AuthenticatedObject<CommandData>>): List<AuthenticatedObject<Commands>>
fun generateExitCommand(amount: Amount<Issued<Currency>>): Exit
fun generateIssue(tx: TransactionBuilder, tokenDef: Issued<Currency>, pennies: Long, owner: CompositeKey, notary: Party): Unit
fun generateIssue(tx: TransactionBuilder, amount: Amount<Issued<Currency>>, owner: CompositeKey, notary: Party): Unit
fun generateIssueCommand(): Issue
fun generateMoveCommand(): Move
val legalContractReference: SecureHash
fun verify(tx: TransactionForContract): Unit
class CashBalanceAsMetricsObserver
sealed class CashCommand
class CashFlow : FlowLogic<CashFlowResult>
sealed class CashFlowResult
object CashSchema
object CashSchemaV1 : MappedSchema
class CertificateSigner
interface CertificateSigningService
class Checkpoint
interface CheckpointStorage
class ChosenList<E> : ObservableListBase<E>
object CityDatabase
abstract class Clause<in S : ContractState, C : CommandData, in K : Any>
data class ClientRPCRequestMessage
data class Command
interface CommandData
class CommandDataGenerator
class CommandGenerator
class CommercialPaper : Contract
class CommercialPaperLegacy : Contract
object CommercialPaperSchema
object CommercialPaperSchemaV1 : MappedSchema
data class Commodity
class CommodityContract : OnLedgerAsset<Commodity, Commands, State>
Module Contents
CommodityContract()
interface Clauses
interface Commands : Commands
data class State : FungibleAsset<Commodity>
val conserveClause: AbstractConserveAmount<State, Commands, Commodity>
fun deriveState(txState: TransactionState<State>, amount: Amount<Issued<Commodity>>, owner: CompositeKey): TransactionState<State>
fun extractCommands(commands: Collection<AuthenticatedObject<CommandData>>): List<AuthenticatedObject<Commands>>
fun generateExitCommand(amount: Amount<Issued<Commodity>>): Exit
fun generateIssue(tx: TransactionBuilder, tokenDef: Issued<Commodity>, pennies: Long, owner: CompositeKey, notary: Party): Unit
fun generateIssue(tx: TransactionBuilder, amount: Amount<Issued<Commodity>>, owner: CompositeKey, notary: Party): Unit
fun generateIssueCommand(): Issue
fun generateMoveCommand(): Move
val legalContractReference: SecureHash
fun verify(tx: TransactionForContract): Unit
abstract class CompositeClause<in S : ContractState, C : CommandData, in K : Any> : Clause<S, C, K>
sealed class CompositeKey
object CompositeKeyColumnType
class CompositeKeyGenerator
class ConcatenatedList<A> : TransformationList<A, ObservableList<A>>
class Config
object ConfigHelper
class ConfigurationException : Exception
interface Contract
data class ContractClassRef : ContractDefRef
interface ContractDefRef
data class ContractLedgerRef : ContractDefRef
interface ContractState
class ContractStateGenerator
class ContractStateModel
abstract class CordaPluginRegistry
class CordaRPCClient : Closeable, ArtemisMessagingComponent
class CordaRPCClientImpl
interface CordaRPCOps : RPCOps
class CordaRPCOpsImpl : CordaRPCOps
class CubicSplineInterpolator : Interpolator
class CurrencyGenerator
class DBCheckpointStorage : CheckpointStorage
class DBTransactionMappingStorage : StateMachineRecordedTransactionMappingStorage
class DBTransactionStorage : TransactionStorage
class DataUploadServlet
object DataVending
enum class DateRollConvention
enum class DateRollDirection
enum class DayCountBasisDay
enum class DayCountBasisYear
interface DealState : LinearState
interface DeserializeAsKotlinObjectDef
data class Diff<out T : ContractState>
open class DigitalSignature : OpaqueBytes
class DistributedImmutableMap<K : Any, V : Any>
open class DriverDSL : DriverDSLInternalInterface
Module Contents
DriverDSL(portAllocation: PortAllocation, debugPortAllocation: PortAllocation, driverDirectory: Path, useTestClock: Boolean, isDebug: Boolean)
class State
val debugPortAllocation: PortAllocation
val driverDirectory: Path
val isDebug: Boolean
val name: Array<String>
fun <A> pickA(array: Array<A>): A
val portAllocation: PortAllocation
fun registerProcess(process: Process): Unit
open fun shutdown(): Unit
open fun start(): Unit
open fun startNode(providedName: String?, advertisedServices: Set<ServiceInfo>, rpcUsers: List<User>, customOverrides: Map<String, Any?>): Future<NodeInfoAndConfig>
open fun startNotaryCluster(notaryName: String, clusterSize: Int, type: ServiceType): Unit
val useTestClock: Boolean
open fun waitForAllNodesToFinish(): Unit
interface DriverDSLExposedInterface
interface DriverDSLInternalInterface : DriverDSLExposedInterface
class DummyContract : Contract
class DummyPublicKey : PublicKey, Comparable<PublicKey>
data class DummyState : ContractState
class DurationGenerator
class E2ETestKeyManagementService : SingletonSerializeAsToken, KeyManagementService
object Ed25519PrivateKeySerializer
object Ed25519PublicKeySerializer
object Emoji
data class ErrorOr<out A>
class EventGenerator
interface ExchangeRate
class ExchangeRateModel
class ExitGenerator
data class Expression
object ExpressionDeserializer
object ExpressionSerializer
class FetchAttachmentsFlow : FetchDataFlow<Attachment, ByteArray>
abstract class FetchDataFlow<T : NamedByHash, in W : Any> : FlowLogic<Result<T>>
class FetchTransactionsFlow : FetchDataFlow<SignedTransaction, SignedTransaction>
class FiberBox<out T>
class FilterFuns
class FilterOn<S : ContractState, C : CommandData, K : Any> : Clause<ContractState, C, K>
Module Contents
FilterOn(clause: Clause<S, C, K>, filterStates: (List<ContractState>) -> List<S>)
val clause: Clause<S, C, K>
val filterStates: (List<ContractState>) -> List<S>
fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
val requiredCommands: Set<Class<out CommandData>>
fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
class FilteredLeaves
class FilteredTransaction
class FinalityFlow : FlowLogic<Unit>
class FirstComposition<S : ContractState, C : CommandData, K : Any> : CompositeClause<S, C, K>
Module Contents
FirstComposition(firstClause: Clause<S, C, K>, vararg remainingClauses: Clause<S, C, K>)
val clauses: ArrayList<Clause<S, C, K>>
val firstClause: Clause<S, C, K>
val logger: <ERROR CLASS>
fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<Clause<S, C, K>>
fun toString(): String
fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
data class Fix : CommandData
data class FixOf
interface FixableDealState : DealState
class FlattenedList<A> : TransformationList<A, ObservableValue<out A>>
data class FlowClassRef : FlowRef
data class FlowHandle<A>
interface FlowIORequest
data class FlowInstanceRef
abstract class FlowLogic<out T>
data class FlowLogicRef
class FlowLogicRefFactory : SingletonSerializeAsToken
interface FlowRef
data class FlowRequiringAttention
class FlowSessionException : Exception
interface FlowStateMachine<R>
class FlowStateMachineImpl<R> : FlowStateMachine<R>
data class FlowStatus
enum class Frequency
class FullNodeConfiguration : NodeConfiguration
interface FungibleAsset<T> : OwnableState
data class GatheredTransactionData
class GatheredTransactionDataModel
class Generator<out A : Any>
Module Contents
Generator(generate: (SplittableRandom) -> ErrorOr<A>)
fun <B : Any> bind(function: (A) -> Generator<B>): Generator<B>
fun <A : Any> choice(generators: List<Generator<A>>): Generator<A>
fun <B : Any, R : Any> combine(other1: Generator<B>, function: (A, B) -> R): Generator<R>
fun <B : Any, C : Any, R : Any> combine(other1: Generator<B>, other2: Generator<C>, function: (A, B, C) -> R): Generator<R>
fun <B : Any, C : Any, D : Any, R : Any> combine(other1: Generator<B>, other2: Generator<C>, other3: Generator<D>, function: (A, B, C, D) -> R): Generator<R>
fun <B : Any, C : Any, D : Any, E : Any, R : Any> combine(other1: Generator<B>, other2: Generator<C>, other3: Generator<D>, other4: Generator<E>, function: (A, B, C, D, E) -> R): Generator<R>
fun <A : Any> fail(error: Exception): Generator<A>
fun <A : Any> frequency(generators: List<<ERROR CLASS><Double, Generator<A>>>): Generator<A>
val generate: (SplittableRandom) -> ErrorOr<A>
fun <A : Any> impure(valueClosure: () -> A): Generator<A>
fun <B : Any> map(function: (A) -> B): Generator<B>
fun <B : Any> product(other: Generator<(A) -> B>): Generator<B>
fun <A : Any> pure(value: A): Generator<A>
fun <A : Any> sequence(generators: List<Generator<A>>): Generator<List<A>>
fun <A : Any> success(generate: (SplittableRandom) -> A): Generator<A>
abstract class GroupClauseVerifier<S : ContractState, C : CommandData, K : Any> : Clause<ContractState, C, Unit>
Module Contents
GroupClauseVerifier(clause: Clause<S, C, K>)
val clause: Clause<S, C, K>
open fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
abstract fun groupStates(tx: TransactionForContract): List<InOutGroup<S, K>>
open fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
class HTTPCertificateSigningService : CertificateSigningService
class HibernateObserver
interface IdentityService
class IllegalFlowLogicException : IllegalArgumentException
class ImmutableClassSerializer<T : Any>
class InMemoryIdentityService : SingletonSerializeAsToken, IdentityService
open class InMemoryNetworkMapCache : SingletonSerializeAsToken, NetworkMapCache
class InMemoryNetworkMapService : AbstractNetworkMapService
class InMemoryStateMachineRecordedTransactionMappingStorage : StateMachineRecordedTransactionMappingStorage
class InMemoryUniquenessProvider : UniquenessProvider
class InputStateRefResolveFailed : Exception
object InstantColumnType
class InstantGenerator
class InsufficientBalanceException : Exception
interface Interpolator
interface InterpolatorFactory
interface IssuanceDefinition
interface IssueCommand : CommandData
class IssueGenerator
data class Issued<out P>
class IssuedGenerator<T>
class JDBCHashMap<K : Any, V : Any> : AbstractJDBCHashMap<K, V, BlobMapTable>
class JDBCHashSet<K : Any> : AbstractJDBCHashSet<K, BlobSetTable>
open class JDBCHashedTable
object JsonSupport
interface KeyManagementService
object KotlinObjectSerializer
data class LastAcknowledgeInfo
class LedgerTransaction : BaseTransaction
class LeftOuterJoinedMap<K : Any, A, B, C> : ReadOnlyBackedObservableMapBase<K, C, SimpleObjectProperty<B?>>
class LinearInterpolator : Interpolator
interface LinearState : ContractState
object LocalDateColumnType
object LocalDateTimeColumnType
object LogHelper
class MapValuesList<K, A, C> : ObservableList<C>
class MappedList<A, B> : TransformationList<B, A>
abstract class MappedSchema
data class MarshalledObservation
sealed class MerkleTree
class MerkleTreeException : Exception
interface Message
interface MessageHandlerRegistration
interface MessageRecipientGroup : MessageRecipients
interface MessageRecipients
interface MessagingService
interface MessagingServiceBuilder<out T : MessagingServiceInternal>
interface MessagingServiceInternal : MessagingService
class MissingAttachmentsException : Exception
object Models
class MonitoringService : SingletonSerializeAsToken
interface MoveCommand : CommandData
class MoveGenerator
data class MultilateralNetState<P> : NetState<P>
interface MultilateralNettableState<out T : Any>
abstract class MutableClock : Clock
interface NamedByHash
open class NetClause<C : CommandData, P> : Clause<ContractState, C, Unit>
interface NetCommand : CommandData
interface NetState<P>
enum class NetType
interface NettableState<N : BilateralNettableState<N>, T : Any> : BilateralNettableState<N>, MultilateralNettableState<T>
sealed class NetworkCacheError : Exception
class NetworkIdentityModel
interface NetworkMapCache
interface NetworkMapService
class NoReferencesSerializer<T>
open class NoZeroSizedOutputs<in S : FungibleAsset<T>, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
class Node : AbstractNode
class NodeAttachmentService : AttachmentStorage, AcceptsFileUpload
class NodeClock : Clock, SerializeAsToken
interface NodeConfiguration : NodeSSLConfiguration
data class NodeInfo
data class NodeInfoAndConfig
sealed class NodeMapError : Exception
class NodeMessagingClient : ArtemisMessagingComponent, MessagingServiceInternal
Module Contents
NodeMessagingClient(config: NodeConfiguration, serverHostPort: <ERROR CLASS>, myIdentity: CompositeKey?, executor: AffinityExecutor, database: <ERROR CLASS>, networkMapRegistrationFuture: <ERROR CLASS><Unit>)
data class Handler : MessageHandlerRegistration
val SESSION_ID_PROPERTY: String
val TOPIC_PROPERTY: String
fun addMessageHandler(topic: String, sessionID: Long, callback: (Message, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
fun addMessageHandler(topicSession: TopicSession, callback: (Message, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
val config: NodeConfiguration
fun createMessage(topicSession: TopicSession, data: ByteArray, uuid: UUID): Message
val database: <ERROR CLASS>
var dispatcher: RPCDispatcher?
val executor: AffinityExecutor
val log: <ERROR CLASS>
fun makeNetworkMapAddress(hostAndPort: <ERROR CLASS>): SingleMessageRecipient
val myAddress: SingleMessageRecipient
val myIdentity: CompositeKey?
val networkMapRegistrationFuture: <ERROR CLASS><Unit>
fun removeMessageHandler(registration: MessageHandlerRegistration): Unit
fun run(): Unit
fun send(message: Message, target: MessageRecipients): Unit
val serverHostPort: <ERROR CLASS>
fun start(rpcOps: RPCOps, userService: RPCUserService): Unit
fun stop(): Unit
class NodeMonitorModel
class NodeRegistration
data class NodeRegistrationInfo
interface NodeSSLConfiguration
class NodeSchedulerService : SchedulerService, SingletonSerializeAsToken
class NodeSchemaService : SchemaService, SingletonSerializeAsToken
class NodeVaultService : SingletonSerializeAsToken, VaultService
class NonEmptySet<T> : MutableSet<T>
object NonEmptySetSerializer
object NotaryChange
object NotaryChangeFlow : AbstractStateReplacementFlow<Party>
sealed class NotaryError
class NotaryException : Exception
object NotaryFlow
abstract class NotaryService : SingletonSerializeAsToken
object NullPublicKey : PublicKey, Comparable<PublicKey>
object NullSignature : WithKey
class Obligation<P> : Contract
Module Contents
Obligation()
interface Clauses
Module Contents
class ConserveAmount<P> : AbstractConserveAmount<State<P>, Commands, Terms<P>>
class Group<P> : GroupClauseVerifier<State<P>, Commands, Issued<Terms<P>>>
class Issue<P> : AbstractIssue<State<P>, Commands, Terms<P>>
class Net<C : CommandData, P> : NetClause<C, P>
class SetLifecycle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
class Settle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
class VerifyLifecycle<S : ContractState, C : CommandData, T : Any, P> : Clause<S, C, T>
interface Commands : Commands
enum class Lifecycle
data class State<P> : FungibleAsset<Terms<P>>, NettableState<State<P>, MultilateralNetState<P>>
data class Terms<P>
fun generateCloseOutNetting(tx: TransactionBuilder, signer: CompositeKey, vararg states: State<P>): Unit
fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<Terms<P>>>, assetStates: List<StateAndRef<State<P>>>): CompositeKey
fun generateIssue(tx: TransactionBuilder, obligor: Party, issuanceDef: Terms<P>, pennies: Long, beneficiary: CompositeKey, notary: Party): Unit
fun generatePaymentNetting(tx: TransactionBuilder, issued: Issued<Terms<P>>, notary: Party, vararg states: State<P>): Unit
fun generateSetLifecycle(tx: TransactionBuilder, statesAndRefs: List<StateAndRef<State<P>>>, lifecycle: Lifecycle, notary: Party): Unit
fun generateSettle(tx: TransactionBuilder, statesAndRefs: Iterable<StateAndRef<State<P>>>, assetStatesAndRefs: Iterable<StateAndRef<FungibleAsset<P>>>, moveCommand: MoveCommand, notary: Party): Unit
val legalContractReference: SecureHash
fun verify(tx: TransactionForContract): Unit
abstract class OnLedgerAsset<T : Any, C : CommandData, S : FungibleAsset<T>> : Contract
open class OpaqueBytes
class OptionalConfig<out T>
object OrderedSerializer
interface OwnableState : ContractState
object ParamsSpec
class PartialMerkleTree
data class PartiallyResolvedTransaction
data class Party
data class PartyAndReference
class PartyAndReferenceGenerator
data class PartyColumns
class PartyGenerator
enum class PaymentRule
class PermissionException : RuntimeException
class PersistentKeyManagementService : SingletonSerializeAsToken, KeyManagementService
class PersistentNetworkMapService : AbstractNetworkMapService
open class PersistentState
data class PersistentStateRef : Serializable
class PersistentUniquenessProvider : UniquenessProvider, SingletonSerializeAsToken
data class PhysicalLocation
interface PluginServiceHub : ServiceHub
class Polynomial
sealed class PortAllocation
class PrivateKeyGenerator
class ProgressTracker
data class ProgressTrackingEvent
object PublicKeyColumnType
class PublicKeyGenerator
interface QueryableState : ContractState
abstract class RPCDispatcher
open class RPCException : RuntimeException
interface RPCOps
@Target([AnnotationTarget.FUNCTION]) annotation class RPCReturnsObservables
@Target([AnnotationTarget.FUNCTION]) annotation class RPCSinceVersion
interface RPCUserService
class RPCUserServiceImpl : RPCUserService
class RaftUniquenessProvider : UniquenessProvider, SingletonSerializeAsToken
class RaftValidatingNotaryService : NotaryService
open class ReadOnlyBackedObservableMapBase<K, A, B> : ObservableMap<K, A>
interface ReadOnlyTransactionStorage
data class ReceiveOnly<T : SessionMessage> : ReceiveRequest<T>
interface ReceiveRequest<T : SessionMessage> : FlowIORequest
object ReferencesAwareJavaSerializer
interface RegulatorService
class ReplayedList<A> : TransformationList<A, A>
object Requirements
class ResolveTransactionsFlow : FlowLogic<List<LedgerTransaction>>
class ResponseFilter
abstract class RetryableException : Exception
interface SchedulableState : ContractState
interface Scheduled
data class ScheduledActivity : Scheduled
class ScheduledActivityObserver
data class ScheduledStateRef : Scheduled
interface SchedulerService
interface SchemaService
sealed class SecureHash : OpaqueBytes
object SecureHashColumnType
class SecureHashGenerator
data class SendAndReceive<T : SessionMessage> : SendRequest, ReceiveRequest<T>
data class SendOnly : SendRequest
interface SendRequest : FlowIORequest
interface SerializationToken
interface SerializeAsToken
class SerializeAsTokenContext
class SerializeAsTokenSerializer<T : SerializeAsToken>
class SerializedBytes<T : Any> : OpaqueBytes
object SerializedBytesSerializer
data class ServiceEntry
interface ServiceHub
abstract class ServiceHubInternal : PluginServiceHub
object ServiceIdentityGenerator
data class ServiceInfo
interface ServiceRequestMessage
sealed class ServiceType
open class SignedData<T : Any>
data class SignedTransaction : NamedByHash
class SignedTransactionGenerator
class SimpleNotaryService : NotaryService
interface SingleMessageRecipient : MessageRecipients
data class SingletonSerializationToken : SerializationToken
abstract class SingletonSerializeAsToken : SerializeAsToken
class SplineFunction
class StackSnapshot : Throwable
data class StateAndRef<out T : ContractState>
data class StateMachineData
data class StateMachineInfo
class StateMachineManager
interface StateMachineRecordedTransactionMappingStorage
data class StateMachineRunId
sealed class StateMachineStatus
data class StateMachineTransactionMapping
sealed class StateMachineUpdate
data class StateRef
data class StateRefColumns
class StateRefGenerator
class StateReplacementException : Exception
class StateReplacementRefused
interface StatesQuery
interface StorageService
open class StorageServiceImpl : SingletonSerializeAsToken, TxWritableStorageService
class StrandLocalTransactionManager
data class Tenor
class TestClock : MutableClock, SerializeAsToken
class ThreadBox<out T>
data class TimeWindow
data class Timestamp
class TimestampChecker
class TimestampGenerator
data class TopicSession
object TopicStringValidator
sealed class TrackedDelegate<M : Any>
Module Contents
class EventSinkDelegate<M : Any, T> : TrackedDelegate<M>
class EventStreamDelegate<M : Any, T> : TrackedDelegate<M>
class ObjectPropertyDelegate<M : Any, T> : TrackedDelegate<M>
class ObservableDelegate<M : Any, T> : TrackedDelegate<M>
class ObservableListDelegate<M : Any, T> : TrackedDelegate<M>
class ObservableListReadOnlyDelegate<M : Any, out T> : TrackedDelegate<M>
class ObservableValueDelegate<M : Any, T> : TrackedDelegate<M>
class ObserverDelegate<M : Any, T> : TrackedDelegate<M>
class SubjectDelegate<M : Any, T> : TrackedDelegate<M>
class WritableValueDelegate<M : Any, T> : TrackedDelegate<M>
val klass: KClass<M>
data class TransactionBuildStep
open class TransactionBuilder
Module Contents
TransactionBuilder(type: TransactionType = TransactionType.General(), notary: Party? = null, inputs: MutableList<StateRef> = arrayListOf(), attachments: MutableList<SecureHash> = arrayListOf(), outputs: MutableList<TransactionState<ContractState>> = arrayListOf(), commands: MutableList<Command> = arrayListOf(), signers: MutableSet<CompositeKey> = mutableSetOf(), timestamp: Timestamp? = null)
fun addAttachment(attachmentId: SecureHash): Unit
fun addCommand(arg: Command): Unit
fun addCommand(data: CommandData, vararg keys: CompositeKey): <ERROR CLASS>
fun addCommand(data: CommandData, keys: List<CompositeKey>): Unit
open fun addInputState(stateAndRef: StateAndRef<*>): Unit
fun addOutputState(state: TransactionState<*>): Int
fun addOutputState(state: ContractState, notary: Party): Int
fun addOutputState(state: ContractState): Int
fun addSignatureUnchecked(sig: WithKey): TransactionBuilder
fun attachments(): List<SecureHash>
protected val attachments: MutableList<SecureHash>
fun checkAndAddSignature(sig: WithKey): Unit
fun checkSignature(sig: WithKey): Unit
fun commands(): List<Command>
protected val commands: MutableList<Command>
fun copy(): TransactionBuilder
protected val currentSigs: <ERROR CLASS>
fun inputStates(): List<StateRef>
protected val inputs: MutableList<StateRef>
var notary: Party?
fun outputStates(): List<TransactionState<*>>
protected val outputs: MutableList<TransactionState<ContractState>>
fun setTime(time: Instant, timeTolerance: Duration): Unit
fun setTime(newTimestamp: Timestamp): Unit
fun signWith(key: KeyPair): TransactionBuilder
protected val signers: MutableSet<CompositeKey>
val time: Timestamp?
protected var timestamp: Timestamp?
fun toSignedTransaction(checkSufficientSignatures: Boolean = true): SignedTransaction
fun toWireTransaction(): WireTransaction
protected val type: TransactionType
fun withItems(vararg items: Any): TransactionBuilder
class TransactionConflictException : Exception
sealed class TransactionCreateStatus
data class TransactionForContract
Module Contents
TransactionForContract(inputs: List<ContractState>, outputs: List<ContractState>, attachments: List<Attachment>, commands: List<AuthenticatedObject<CommandData>>, origHash: SecureHash, inputNotary: Party? = null, timestamp: Timestamp? = null)
data class InOutGroup<out T : ContractState, out K : Any>
val attachments: List<Attachment>
val commands: List<AuthenticatedObject<CommandData>>
fun equals(other: Any?): Boolean
fun <T : ContractState, K : Any> groupStates(ofType: Class<T>, selector: (T) -> K): List<InOutGroup<T, K>>
inline fun <reified T : ContractState, K : Any> groupStates(selector: (T) -> K): List<InOutGroup<T, K>>
fun <T : ContractState, K : Any> groupStatesInternal(inGroups: Map<K, List<T>>, outGroups: Map<K, List<T>>): List<InOutGroup<T, K>>
fun hashCode(): Int
val inputNotary: Party?
val inputs: List<ContractState>
val origHash: SecureHash
val outputs: List<ContractState>
val timestamp: Timestamp?
class TransactionGraphSearch : Callable<List<WireTransaction>>
class TransactionResolutionException : Exception
data class TransactionState<out T : ContractState>
class TransactionStateGenerator<T : ContractState>
interface TransactionStorage : ReadOnlyTransactionStorage
sealed class TransactionType
sealed class TransactionVerificationException : Exception
class TransientProperty<out T>
object TwoPartyDealFlow
object TwoPartyTradeFlow
interface TxWritableStorageService : StorageService
data class TxnNoteColumns
abstract class TypeOnlyCommandData : CommandData
object UUIDStringColumnType
data class UniqueIdentifier : Comparable<UniqueIdentifier>
class UniquenessException : Exception
interface UniquenessProvider
class UntrustworthyData<out T>
data class User
class ValidatingNotaryFlow : Service
class ValidatingNotaryService : NotaryService
class Vault
interface VaultService
Module Contents
abstract fun addNoteToTransaction(txnId: SecureHash, noteText: String): Unit
open val cashBalances: Map<Currency, Amount<Currency>>
abstract val currentVault: Vault
abstract fun generateSpend(tx: TransactionBuilder, amount: Amount<Currency>, to: CompositeKey, onlyFromParties: Set<Party>? = null): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
abstract fun getTransactionNotes(txnId: SecureHash): Iterable<String>
abstract val linearHeads: Map<UniqueIdentifier, StateAndRef<LinearState>>
open fun <T : LinearState> linearHeadsOfType_(stateType: Class<T>): Map<UniqueIdentifier, StateAndRef<T>>
open fun notify(tx: WireTransaction): Vault
abstract fun notifyAll(txns: Iterable<WireTransaction>): Vault
open fun statesForRefs(refs: List<StateRef>): Map<StateRef, TransactionState<*>?>
abstract fun track(): <ERROR CLASS><Vault, <ERROR CLASS><Update>>
abstract val updates: <ERROR CLASS><Update>
open fun whenConsumed(ref: StateRef): <ERROR CLASS><Update>
class WhitelistTrustManager : X509ExtendedTrustManager
Module Contents
WhitelistTrustManager(originalProvider: X509ExtendedTrustManager)
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String): Unit
val checker: HostnameChecker
fun getAcceptedIssuers(): Array<out X509Certificate>
val originalProvider: X509ExtendedTrustManager
object WhitelistTrustManagerProvider : Provider
class WhitelistTrustManagerSpi : TrustManagerFactorySpi
class WireNodeRegistration : SignedData<NodeRegistration>
class WireTransaction : BaseTransaction
object WireTransactionSerializer
class WiredTransactionGenerator
data class WorldCoordinate
object X509Utilities
Module Contents
data class CACertAndKey
val CORDA_CLIENT_CA: String
val CORDA_CLIENT_CA_PRIVATE_KEY: String
val CORDA_INTERMEDIATE_CA: String
val CORDA_INTERMEDIATE_CA_PRIVATE_KEY: String
val CORDA_ROOT_CA: String
val CORDA_ROOT_CA_PRIVATE_KEY: String
val ECDSA_CURVE: String
val KEYSTORE_TYPE: String
val KEY_GENERATION_ALGORITHM: String
val SIGNATURE_ALGORITHM: String
fun KeyStore.addOrReplaceCertificate(alias: String, cert: Certificate): Unit
fun KeyStore.addOrReplaceKey(alias: String, key: Key, password: CharArray, chain: Array<Certificate>): Unit
fun createCAKeyStoreAndTrustStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, trustStoreFilePath: Path, trustStorePassword: String): KeyStore
fun createCertificateSigningRequest(myLegalName: String, nearestCity: String, email: String, keyPair: KeyPair): <ERROR CLASS>
fun createIntermediateCert(domain: String, certificateAuthority: CACertAndKey): CACertAndKey
fun createKeystoreForSSL(: Path, : String, : String, : KeyStore, : String): KeyStore
fun createSelfSignedCACert(myLegalName: String): CACertAndKey
fun createServerCert(subject: <ERROR CLASS>, publicKey: PublicKey, certificateAuthority: CACertAndKey, subjectAlternativeNameDomains: List<String>, subjectAlternativeNameIps: List<String>): X509Certificate
fun generateECDSAKeyPairForSSL(): KeyPair
fun getDevX509Name(domain: String): <ERROR CLASS>
fun getX509Name(myLegalName: String, nearestCity: String, email: String): <ERROR CLASS>
fun loadCertificateAndKey(keyStore: KeyStore, keyPassword: String, alias: String): CACertAndKey
fun loadCertificateFromKeyStore(keyStoreFilePath: Path, storePassword: String, alias: String): X509Certificate
fun loadCertificateFromPEMFile(filename: Path): X509Certificate
fun loadKeyPairFromKeyStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, alias: String): KeyPair
fun loadKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun loadKeyStore(input: InputStream, storePassword: String): KeyStore
fun loadOrCreateKeyPairFromKeyStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, alias: String, keyGenerator: () -> CACertAndKey): KeyPair
fun loadOrCreateKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun saveCertificateAsPEMFile(x509Certificate: X509Certificate, filename: Path): Unit
fun saveKeyStore(keyStore: KeyStore, keyStoreFilePath: Path, storePassword: String): Unit
java.io.InputStream
java.nio.file.Path
java.security.KeyPair
java.security.PrivateKey
java.security.PublicKey
java.time.Clock
Module Contents
fun Clock.awaitWithDeadline(deadline: Instant, future: Future<*> = GuavaSettableFuture.create<Any>()): Boolean
java.time.LocalDate
java.time.temporal.Temporal
java.util.Currency
java.util.concurrent.Future
javafx.beans.value.ObservableValue
javafx.collections.ObservableList
Module Contents
fun <K, A, B> ObservableList<out A>.associateBy(toKey: (A) -> K, assemble: (K, A) -> B): ObservableMap<K, B>
fun <K, A> ObservableList<out A>.associateBy(toKey: (A) -> K): ObservableMap<K, A>
fun <K : Any, A : Any, B> ObservableList<out A>.associateByAggregation(toKey: (A) -> K, assemble: (K, A) -> B): ObservableMap<K, ObservableList<B>>
fun <K : Any, A : Any> ObservableList<out A>.associateByAggregation(toKey: (A) -> K): ObservableMap<K, ObservableList<A>>
fun <A> ObservableList<ObservableList<A>>.concatenate(): ObservableList<A>
fun <A> ObservableList<out A>.filter(predicate: ObservableValue<(A) -> Boolean>): ObservableList<A>
fun <A> ObservableList<out A?>.filterNotNull(): ObservableList<A>
fun <A> ObservableList<A>.first(): ObservableValue<A?>
fun <A> ObservableList<A>.firstOrDefault(default: ObservableValue<A?>, predicate: (A) -> Boolean): ObservableValue<A?>
fun <A> ObservableList<A>.firstOrNullObservable(predicate: (A) -> Boolean): ObservableValue<A?>
fun <A> ObservableList<out ObservableValue<out A>>.flatten(): ObservableList<A>
fun <A, B> ObservableList<out A>.foldObservable(initial: B, folderFunction: (B, A) -> B): ObservableValue<B>
fun <A> ObservableList<A>.getValueAt(index: Int): ObservableValue<A?>
fun <A> ObservableList<A>.last(): ObservableValue<A?>
fun <A : Any, B : Any, C, K : Any> ObservableList<A>.leftOuterJoin(rightTable: ObservableList<B>, leftToJoinKey: (A) -> K, rightToJoinKey: (B) -> K, assemble: (A, ObservableList<B>) -> C): ObservableList<C>
fun <A : Any, B : Any, K : Any> ObservableList<A>.leftOuterJoin(rightTable: ObservableList<B>, leftToJoinKey: (A) -> K, rightToJoinKey: (B) -> K): ObservableMap<K, <ERROR CLASS><ObservableList<A>, ObservableList<B>>>
fun <A, B> ObservableList<out A>.map(cached: Boolean = true, function: (A) -> B): ObservableList<B>
fun <T : Any> ObservableList<T>.unique(): ObservableList<T>
javafx.collections.ObservableMap
Module Contents
fun <A, K> ObservableMap<K, A>.createMapChange(key: K, removedValue: A?, addedValue: A?): Change<K, A>
fun <K, V> ObservableMap<K, V>.getObservableEntries(): ObservableList<Entry<K, V>>
fun <K, V> ObservableMap<K, V>.getObservableValue(key: K): ObservableValue<V?>
fun <K, V> ObservableMap<K, V>.getObservableValues(): ObservableList<V>
kotlin.ByteArray
kotlin.ByteArray
kotlin.Double
kotlin.Double
kotlin.Function1
kotlin.Function2
kotlin.Function3
kotlin.Function4
Module Contents
fun <A, B, C, D, R> (A, B, C, D) -> R.lift(arg0: ObservableValue<A>, arg1: ObservableValue<B>, arg2: ObservableValue<C>, arg3: ObservableValue<D>): ObservableValue<R>
kotlin.Int
kotlin.Int
kotlin.Long
kotlin.String
kotlin.String
kotlin.Throwable
kotlin.collections.Collection
kotlin.collections.Collection
kotlin.collections.Iterable
kotlin.collections.Iterable
kotlin.collections.Iterable
kotlin.collections.Iterable
kotlin.collections.Iterable
kotlin.collections.List
package net.corda.client
package net.corda.client.fxutils
Module Contents
class AggregatedList<A, E : Any, K : Any> : TransformationList<A, E>
object AmountBindings
class AssociatedList<K, out A, B> : ReadOnlyBackedObservableMapBase<K, B, Unit>
class ChosenList<E> : ObservableListBase<E>
class ConcatenatedList<A> : TransformationList<A, ObservableList<A>>
class FlattenedList<A> : TransformationList<A, ObservableValue<out A>>
class LeftOuterJoinedMap<K : Any, A, B, C> : ReadOnlyBackedObservableMapBase<K, C, SimpleObjectProperty<B?>>
class MapValuesList<K, A, C> : ObservableList<C>
class MappedList<A, B> : TransformationList<B, A>
open class ReadOnlyBackedObservableMapBase<K, A, B> : ObservableMap<K, A>
class ReplayedList<A> : TransformationList<A, A>
fun <A, B, C> <ERROR CLASS><A>.foldToObservableList(initialAccumulator: C, folderFun: (A, C, ObservableList<B>) -> C): ObservableList<B>
fun <A, B, K, C> <ERROR CLASS><A>.foldToObservableMap(initialAccumulator: C, folderFun: (A, C, ObservableMap<K, B>) -> C): ObservableMap<K, out B>
fun <A, B> <ERROR CLASS><A>.foldToObservableValue(initial: B, folderFun: (A, B) -> B): ObservableValue<B>
javafx.beans.value.ObservableValue
javafx.collections.ObservableList
Module Contents
fun <K, A, B> ObservableList<out A>.associateBy(toKey: (A) -> K, assemble: (K, A) -> B): ObservableMap<K, B>
fun <K, A> ObservableList<out A>.associateBy(toKey: (A) -> K): ObservableMap<K, A>
fun <K : Any, A : Any, B> ObservableList<out A>.associateByAggregation(toKey: (A) -> K, assemble: (K, A) -> B): ObservableMap<K, ObservableList<B>>
fun <K : Any, A : Any> ObservableList<out A>.associateByAggregation(toKey: (A) -> K): ObservableMap<K, ObservableList<A>>
fun <A> ObservableList<ObservableList<A>>.concatenate(): ObservableList<A>
fun <A> ObservableList<out A>.filter(predicate: ObservableValue<(A) -> Boolean>): ObservableList<A>
fun <A> ObservableList<out A?>.filterNotNull(): ObservableList<A>
fun <A> ObservableList<A>.first(): ObservableValue<A?>
fun <A> ObservableList<A>.firstOrDefault(default: ObservableValue<A?>, predicate: (A) -> Boolean): ObservableValue<A?>
fun <A> ObservableList<A>.firstOrNullObservable(predicate: (A) -> Boolean): ObservableValue<A?>
fun <A> ObservableList<out ObservableValue<out A>>.flatten(): ObservableList<A>
fun <A, B> ObservableList<out A>.foldObservable(initial: B, folderFunction: (B, A) -> B): ObservableValue<B>
fun <A> ObservableList<A>.getValueAt(index: Int): ObservableValue<A?>
fun <A> ObservableList<A>.last(): ObservableValue<A?>
fun <A : Any, B : Any, C, K : Any> ObservableList<A>.leftOuterJoin(rightTable: ObservableList<B>, leftToJoinKey: (A) -> K, rightToJoinKey: (B) -> K, assemble: (A, ObservableList<B>) -> C): ObservableList<C>
fun <A : Any, B : Any, K : Any> ObservableList<A>.leftOuterJoin(rightTable: ObservableList<B>, leftToJoinKey: (A) -> K, rightToJoinKey: (B) -> K): ObservableMap<K, <ERROR CLASS><ObservableList<A>, ObservableList<B>>>
fun <A, B> ObservableList<out A>.map(cached: Boolean = true, function: (A) -> B): ObservableList<B>
fun <T : Any> ObservableList<T>.unique(): ObservableList<T>
javafx.collections.ObservableMap
Module Contents
fun <A, K> ObservableMap<K, A>.createMapChange(key: K, removedValue: A?, addedValue: A?): Change<K, A>
fun <K, V> ObservableMap<K, V>.getObservableEntries(): ObservableList<Entry<K, V>>
fun <K, V> ObservableMap<K, V>.getObservableValue(key: K): ObservableValue<V?>
fun <K, V> ObservableMap<K, V>.getObservableValues(): ObservableList<V>
kotlin.Function1
kotlin.Function2
kotlin.Function3
kotlin.Function4
Module Contents
fun <A, B, C, D, R> (A, B, C, D) -> R.lift(arg0: ObservableValue<A>, arg1: ObservableValue<B>, arg2: ObservableValue<C>, arg3: ObservableValue<D>): ObservableValue<R>
kotlin.collections.Collection
fun <A> A.lift(): ObservableValue<A>
fun <A, K> <ERROR CLASS><A>.recordAsAssociation(toKey: (A) -> K, merge: (K, A, A) -> A = { _key, _oldValue, newValue -> newValue }): ObservableMap<K, out A>
fun <A> <ERROR CLASS><A>.recordInSequence(): ObservableList<A>
package net.corda.client.impl
package net.corda.client.mock
Module Contents
class EventGenerator
class Generator<out A : Any>
Module Contents
Generator(generate: (SplittableRandom) -> ErrorOr<A>)
fun <B : Any> bind(function: (A) -> Generator<B>): Generator<B>
fun <A : Any> choice(generators: List<Generator<A>>): Generator<A>
fun <B : Any, R : Any> combine(other1: Generator<B>, function: (A, B) -> R): Generator<R>
fun <B : Any, C : Any, R : Any> combine(other1: Generator<B>, other2: Generator<C>, function: (A, B, C) -> R): Generator<R>
fun <B : Any, C : Any, D : Any, R : Any> combine(other1: Generator<B>, other2: Generator<C>, other3: Generator<D>, function: (A, B, C, D) -> R): Generator<R>
fun <B : Any, C : Any, D : Any, E : Any, R : Any> combine(other1: Generator<B>, other2: Generator<C>, other3: Generator<D>, other4: Generator<E>, function: (A, B, C, D, E) -> R): Generator<R>
fun <A : Any> fail(error: Exception): Generator<A>
fun <A : Any> frequency(generators: List<<ERROR CLASS><Double, Generator<A>>>): Generator<A>
val generate: (SplittableRandom) -> ErrorOr<A>
fun <A : Any> impure(valueClosure: () -> A): Generator<A>
fun <B : Any> map(function: (A) -> B): Generator<B>
fun <B : Any> product(other: Generator<(A) -> B>): Generator<B>
fun <A : Any> pure(value: A): Generator<A>
fun <A : Any> sequence(generators: List<Generator<A>>): Generator<List<A>>
fun <A : Any> success(generate: (SplittableRandom) -> A): Generator<A>
fun Generator.Companion.bytes(size: Int): Generator<ByteArray>
fun Generator.Companion.double(): Generator<Double>
fun Generator.Companion.doubleRange(from: Double, to: Double): Generator<Double>
fun <A : Any> Generator.Companion.frequency(vararg generators: <ERROR CLASS><Double, Generator<A>>): <ERROR CLASS>
fun <T : Any> generateAmount(min: Long, max: Long, tokenGenerator: Generator<T>): Generator<Amount<T>>
fun generateCurrency(): Generator<Currency>
fun generateCurrencyAmount(min: Long, max: Long): Generator<Amount<Currency>>
fun generateIssueRef(size: Int): Generator<OpaqueBytes>
fun <A : Any> Generator<A>.generateOrFail(random: SplittableRandom, numberOfTries: Int = 1): A
fun Generator.Companion.int(): Generator<Int>
fun Generator.Companion.intRange(range: IntRange): Generator<Int>
fun Generator.Companion.intRange(from: Int, to: Int): Generator<Int>
fun Generator.Companion.longRange(range: LongRange): Generator<Long>
fun Generator.Companion.longRange(from: Long, to: Long): Generator<Long>
fun <A : Any> Generator.Companion.pickN(number: Int, list: List<A>): Generator<List<A>>
fun <A : Any> Generator.Companion.pickOne(list: List<A>): Generator<A>
fun <A : Any> Generator.Companion.replicate(number: Int, generator: Generator<A>): Generator<List<A>>
fun <A : Any> Generator.Companion.replicatePoisson(meanSize: Double, generator: Generator<A>): Generator<List<A>>
fun <A> Generator.Companion.sampleBernoulli(maxRatio: Double = 1.0, vararg collection: A): <ERROR CLASS>
fun <A> Generator.Companion.sampleBernoulli(collection: Collection<A>, maxRatio: Double = 1.0): Generator<List<A>>
package net.corda.client.model
Module Contents
class ContractStateModel
data class Diff<out T : ContractState>
interface ExchangeRate
class ExchangeRateModel
data class FlowStatus
data class GatheredTransactionData
class GatheredTransactionDataModel
object Models
class NetworkIdentityModel
class NodeMonitorModel
data class PartiallyResolvedTransaction
data class ProgressTrackingEvent
data class StateMachineData
sealed class StateMachineStatus
sealed class TrackedDelegate<M : Any>
Module Contents
class EventSinkDelegate<M : Any, T> : TrackedDelegate<M>
class EventStreamDelegate<M : Any, T> : TrackedDelegate<M>
class ObjectPropertyDelegate<M : Any, T> : TrackedDelegate<M>
class ObservableDelegate<M : Any, T> : TrackedDelegate<M>
class ObservableListDelegate<M : Any, T> : TrackedDelegate<M>
class ObservableListReadOnlyDelegate<M : Any, out T> : TrackedDelegate<M>
class ObservableValueDelegate<M : Any, T> : TrackedDelegate<M>
class ObserverDelegate<M : Any, T> : TrackedDelegate<M>
class SubjectDelegate<M : Any, T> : TrackedDelegate<M>
class WritableValueDelegate<M : Any, T> : TrackedDelegate<M>
val klass: KClass<M>
sealed class TransactionCreateStatus
inline fun <reified M : Any, T> eventSink(noinline sinkProperty: (M) -> <ERROR CLASS><T>): <ERROR CLASS>
inline fun <reified M : Any, T> eventStream(noinline streamProperty: (M) -> <ERROR CLASS><T>): <ERROR CLASS>
fun ExchangeRate.exchangeAmount(amount: Amount<Currency>, to: Currency): Amount<Currency>
fun ExchangeRate.exchangeDouble(amount: Amount<Currency>, to: Currency): Double
inline fun <reified M : Any, T> objectProperty(noinline objectProperty: (M) -> ObjectProperty<T>): ObjectPropertyDelegate<M, T>
inline fun <reified M : Any, T> observable(noinline observableProperty: (M) -> <ERROR CLASS><T>): <ERROR CLASS>
inline fun <reified M : Any, T> observableList(noinline observableListProperty: (M) -> ObservableList<T>): ObservableListDelegate<M, T>
inline fun <reified M : Any, T> observableListReadOnly(noinline observableListProperty: (M) -> ObservableList<out T>): ObservableListReadOnlyDelegate<M, T>
inline fun <reified M : Any, T> observableValue(noinline observableValueProperty: (M) -> ObservableValue<T>): ObservableValueDelegate<M, T>
inline fun <reified M : Any, T> observer(noinline observerProperty: (M) -> <ERROR CLASS><T>): <ERROR CLASS>
inline fun <reified M : Any, T> subject(noinline subjectProperty: (M) -> <ERROR CLASS><T, T>): <ERROR CLASS>
inline fun <reified M : Any, T> writableValue(noinline writableValueProperty: (M) -> WritableValue<T>): WritableValueDelegate<M, T>
package net.corda.contracts
package net.corda.contracts.asset
Module Contents
val Amount<Currency>.CASH: State
val CASH_PROGRAM_ID: Cash
val COMMODITY_PROGRAM_ID: CommodityContract
class Cash : OnLedgerAsset<Currency, Commands, State>
Module Contents
Cash()
interface Clauses
interface Commands : Commands
data class State : FungibleAsset<Currency>, QueryableState
val conserveClause: AbstractConserveAmount<State, Commands, Currency>
fun deriveState(txState: TransactionState<State>, amount: Amount<Issued<Currency>>, owner: CompositeKey): TransactionState<State>
fun extractCommands(commands: Collection<AuthenticatedObject<CommandData>>): List<AuthenticatedObject<Commands>>
fun generateExitCommand(amount: Amount<Issued<Currency>>): Exit
fun generateIssue(tx: TransactionBuilder, tokenDef: Issued<Currency>, pennies: Long, owner: CompositeKey, notary: Party): Unit
fun generateIssue(tx: TransactionBuilder, amount: Amount<Issued<Currency>>, owner: CompositeKey, notary: Party): Unit
fun generateIssueCommand(): Issue
fun generateMoveCommand(): Move
val legalContractReference: SecureHash
fun verify(tx: TransactionForContract): Unit
class CommodityContract : OnLedgerAsset<Commodity, Commands, State>
Module Contents
CommodityContract()
interface Clauses
interface Commands : Commands
data class State : FungibleAsset<Commodity>
val conserveClause: AbstractConserveAmount<State, Commands, Commodity>
fun deriveState(txState: TransactionState<State>, amount: Amount<Issued<Commodity>>, owner: CompositeKey): TransactionState<State>
fun extractCommands(commands: Collection<AuthenticatedObject<CommandData>>): List<AuthenticatedObject<Commands>>
fun generateExitCommand(amount: Amount<Issued<Commodity>>): Exit
fun generateIssue(tx: TransactionBuilder, tokenDef: Issued<Commodity>, pennies: Long, owner: CompositeKey, notary: Party): Unit
fun generateIssue(tx: TransactionBuilder, amount: Amount<Issued<Commodity>>, owner: CompositeKey, notary: Party): Unit
fun generateIssueCommand(): Issue
fun generateMoveCommand(): Move
val legalContractReference: SecureHash
fun verify(tx: TransactionForContract): Unit
val DUMMY_CASH_ISSUER: <ERROR CLASS>
val DUMMY_CASH_ISSUER_KEY: <ERROR CLASS>
val DUMMY_OBLIGATION_ISSUER: <ERROR CLASS>
val DUMMY_OBLIGATION_ISSUER_KEY: <ERROR CLASS>
val Amount<Issued<Currency>>.OBLIGATION: State<Currency>
val Issued<Currency>.OBLIGATION_DEF: Terms<Currency>
val OBLIGATION_PROGRAM_ID: Obligation<Currency>
class Obligation<P> : Contract
Module Contents
Obligation()
interface Clauses
Module Contents
class ConserveAmount<P> : AbstractConserveAmount<State<P>, Commands, Terms<P>>
class Group<P> : GroupClauseVerifier<State<P>, Commands, Issued<Terms<P>>>
class Issue<P> : AbstractIssue<State<P>, Commands, Terms<P>>
class Net<C : CommandData, P> : NetClause<C, P>
class SetLifecycle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
class Settle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
class VerifyLifecycle<S : ContractState, C : CommandData, T : Any, P> : Clause<S, C, T>
interface Commands : Commands
enum class Lifecycle
data class State<P> : FungibleAsset<Terms<P>>, NettableState<State<P>, MultilateralNetState<P>>
data class Terms<P>
fun generateCloseOutNetting(tx: TransactionBuilder, signer: CompositeKey, vararg states: State<P>): Unit
fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<Terms<P>>>, assetStates: List<StateAndRef<State<P>>>): CompositeKey
fun generateIssue(tx: TransactionBuilder, obligor: Party, issuanceDef: Terms<P>, pennies: Long, beneficiary: CompositeKey, notary: Party): Unit
fun generatePaymentNetting(tx: TransactionBuilder, issued: Issued<Terms<P>>, notary: Party, vararg states: State<P>): Unit
fun generateSetLifecycle(tx: TransactionBuilder, statesAndRefs: List<StateAndRef<State<P>>>, lifecycle: Lifecycle, notary: Party): Unit
fun generateSettle(tx: TransactionBuilder, statesAndRefs: Iterable<StateAndRef<State<P>>>, assetStatesAndRefs: Iterable<StateAndRef<FungibleAsset<P>>>, moveCommand: MoveCommand, notary: Party): Unit
val legalContractReference: SecureHash
fun verify(tx: TransactionForContract): Unit
abstract class OnLedgerAsset<T : Any, C : CommandData, S : FungibleAsset<T>> : Contract
val Amount<Issued<Currency>>.STATE: State
infix fun <T> State<T>.at(dueBefore: Instant): State<T>
infix fun <T> State<T>.between(parties: <ERROR CLASS><Party, CompositeKey>): State<T>
fun <P> extractAmountsDue(: Terms<P>, : Iterable<State<P>>): Map<<ERROR CLASS><CompositeKey, CompositeKey>, Amount<Terms<P>>>
infix fun State.issued by(party: Party): State
infix fun State.issued by(deposit: PartyAndReference): State
infix fun <T> State<T>.issued by(party: Party): State<T>
fun State.issuedBy(party: Party): State
fun State.issuedBy(deposit: PartyAndReference): State
fun <T> State<T>.issuedBy(party: Party): State<T>
kotlin.collections.Iterable
fun <P> netAmountsDue(balances: Map<<ERROR CLASS><CompositeKey, CompositeKey>, Amount<P>>): Map<<ERROR CLASS><CompositeKey, CompositeKey>, Amount<P>>
infix fun State.owned by(owner: CompositeKey): State
infix fun <T> State<T>.owned by(owner: CompositeKey): State<T>
fun State.ownedBy(owner: CompositeKey): State
fun <T> State<T>.ownedBy(owner: CompositeKey): State<T>
fun <P> sumAmountsDue(balances: Map<<ERROR CLASS><CompositeKey, CompositeKey>, Amount<P>>): Map<CompositeKey, Long>
infix fun State.with deposit(deposit: PartyAndReference): State
fun State.withDeposit(deposit: PartyAndReference): State
package net.corda.contracts.clause
Module Contents
abstract class AbstractConserveAmount<S : FungibleAsset<T>, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
Module Contents
AbstractConserveAmount()
fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<T>>, assetStates: List<StateAndRef<S>>, deriveState: (TransactionState<S>, Amount<Issued<T>>, CompositeKey) -> TransactionState<S>, generateMoveCommand: () -> CommandData, generateExitCommand: (Amount<Issued<T>>) -> CommandData): CompositeKey
open fun toString(): String
open fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Issued<T>?): Set<C>
abstract class AbstractIssue<in S : ContractState, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
data class BilateralNetState<P> : NetState<P>
data class MultilateralNetState<P> : NetState<P>
open class NetClause<C : CommandData, P> : Clause<ContractState, C, Unit>
interface NetState<P>
open class NoZeroSizedOutputs<in S : FungibleAsset<T>, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
package net.corda.contracts.testing
package net.corda.core
package net.corda.core.contracts
Module Contents
enum class AccrualAdjustment
data class Amount<T> : Comparable<Amount<T>>
interface Attachment : NamedByHash
data class AuthenticatedObject<out T : Any>
interface BilateralNettableState<N : BilateralNettableState<N>>
open class BusinessCalendar
Module Contents
val TEST_CALENDAR_DATA: <ERROR CLASS>
class UnknownCalendar : Exception
open fun applyRollConvention(testDate: LocalDate, dateRollConvention: DateRollConvention): LocalDate
val calendars: <ERROR CLASS>
fun createGenericSchedule(startDate: LocalDate, period: Frequency, calendar: BusinessCalendar = getInstance(), dateRollConvention: DateRollConvention = DateRollConvention.Following, noOfAdditionalPeriods: Int = Integer.MAX_VALUE, endDate: LocalDate? = null, periodOffset: Int? = null): List<LocalDate>
open fun equals(other: Any?): Boolean
fun getInstance(vararg calname: String): BusinessCalendar
fun getOffsetDate(startDate: LocalDate, period: Frequency, steps: Int = 1): LocalDate
open fun hashCode(): Int
val holidayDates: List<LocalDate>
open fun isWorkingDay(date: LocalDate): Boolean
fun moveBusinessDays(date: LocalDate, direction: DateRollDirection, i: Int): LocalDate
fun parseDateFromString(it: String): LocalDate
val CHF: Currency
data class Command
interface CommandData
data class Commodity
interface Contract
interface ContractState
fun DOLLARS(amount: Int): Amount<Currency>
fun DOLLARS(amount: Double): Amount<Currency>
val DUMMY_PROGRAM_ID: DummyContract
enum class DateRollConvention
enum class DateRollDirection
enum class DayCountBasisDay
enum class DayCountBasisYear
interface DealState : LinearState
class DummyContract : Contract
data class DummyState : ContractState
val EUR: Currency
data class Expression
object ExpressionDeserializer
object ExpressionSerializer
val FCOJ: Commodity
fun FCOJ(amount: Int): Amount<Commodity>
data class Fix : CommandData
data class FixOf
interface FixableDealState : DealState
enum class Frequency
interface FungibleAsset<T> : OwnableState
val GBP: Currency
class InsufficientBalanceException : Exception
interface IssuanceDefinition
interface IssueCommand : CommandData
data class Issued<out P>
interface LinearState : ContractState
interface MoveCommand : CommandData
interface MultilateralNettableState<out T : Any>
interface NamedByHash
interface NetCommand : CommandData
enum class NetType
interface NettableState<N : BilateralNettableState<N>, T : Any> : BilateralNettableState<N>, MultilateralNettableState<T>
interface OwnableState : ContractState
fun POUNDS(amount: Int): Amount<Currency>
data class PartyAndReference
enum class PaymentRule
object Requirements
fun SWISS_FRANCS(amount: Int): Amount<Currency>
interface SchedulableState : ContractState
interface Scheduled
data class ScheduledActivity : Scheduled
data class ScheduledStateRef : Scheduled
data class StateAndRef<out T : ContractState>
data class StateRef
data class Tenor
data class Timestamp
class TransactionConflictException : Exception
data class TransactionForContract
Module Contents
TransactionForContract(inputs: List<ContractState>, outputs: List<ContractState>, attachments: List<Attachment>, commands: List<AuthenticatedObject<CommandData>>, origHash: SecureHash, inputNotary: Party? = null, timestamp: Timestamp? = null)
data class InOutGroup<out T : ContractState, out K : Any>
val attachments: List<Attachment>
val commands: List<AuthenticatedObject<CommandData>>
fun equals(other: Any?): Boolean
fun <T : ContractState, K : Any> groupStates(ofType: Class<T>, selector: (T) -> K): List<InOutGroup<T, K>>
inline fun <reified T : ContractState, K : Any> groupStates(selector: (T) -> K): List<InOutGroup<T, K>>
fun <T : ContractState, K : Any> groupStatesInternal(inGroups: Map<K, List<T>>, outGroups: Map<K, List<T>>): List<InOutGroup<T, K>>
fun hashCode(): Int
val inputNotary: Party?
val inputs: List<ContractState>
val origHash: SecureHash
val outputs: List<ContractState>
val timestamp: Timestamp?
class TransactionGraphSearch : Callable<List<WireTransaction>>
class TransactionResolutionException : Exception
data class TransactionState<out T : ContractState>
sealed class TransactionType
sealed class TransactionVerificationException : Exception
abstract class TypeOnlyCommandData : CommandData
val USD: Currency
data class UniqueIdentifier : Comparable<UniqueIdentifier>
fun calculateDaysBetween(startDate: LocalDate, endDate: LocalDate, dcbYear: DayCountBasisYear, dcbDay: DayCountBasisDay): Int
fun commodity(code: String): Commodity
fun currency(code: String): Currency
fun ContractState.hash(): SecureHash
infix fun Commodity.issued by(deposit: PartyAndReference): Issued<Commodity>
infix fun Amount<Currency>.issued by(deposit: PartyAndReference): Amount<Issued<Currency>>
infix fun Commodity.issuedBy(deposit: PartyAndReference): Issued<Commodity>
infix fun Amount<Currency>.issuedBy(deposit: PartyAndReference): Amount<Issued<Currency>>
java.time.LocalDate
java.util.Currency
kotlin.Double
kotlin.Int
kotlin.collections.Collection
kotlin.collections.Iterable
inline fun <R> requireThat(body: Requirements.() -> R): R
inline fun <reified T : MoveCommand> verifyMoveCommand(inputs: List<OwnableState>, tx: TransactionForContract): MoveCommand
inline fun <reified T : MoveCommand> verifyMoveCommand(inputs: List<OwnableState>, commands: List<AuthenticatedObject<CommandData>>): MoveCommand
infix fun <T : ContractState> T.with notary(newNotary: Party): TransactionState<T>
infix fun <T : ContractState> T.withNotary(newNotary: Party): TransactionState<T>
fun <T> Amount<Issued<T>>.withoutIssuer(): Amount<T>
package net.corda.core.contracts.clauses
Module Contents
class AllComposition<S : ContractState, C : CommandData, K : Any> : CompositeClause<S, C, K>
Module Contents
AllComposition(firstClause: Clause<S, C, K>, vararg remainingClauses: Clause<S, C, K>)
val clauses: ArrayList<Clause<S, C, K>>
fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<Clause<S, C, K>>
fun toString(): String
fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
class AnyComposition<in S : ContractState, C : CommandData, in K : Any> : CompositeClause<S, C, K>
Module Contents
AnyComposition(vararg rawClauses: Clause<S, C, K>)
val clauses: List<Clause<S, C, K>>
fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<Clause<S, C, K>>
fun toString(): String
fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
abstract class Clause<in S : ContractState, C : CommandData, in K : Any>
abstract class CompositeClause<in S : ContractState, C : CommandData, in K : Any> : Clause<S, C, K>
class FilterOn<S : ContractState, C : CommandData, K : Any> : Clause<ContractState, C, K>
Module Contents
FilterOn(clause: Clause<S, C, K>, filterStates: (List<ContractState>) -> List<S>)
val clause: Clause<S, C, K>
val filterStates: (List<ContractState>) -> List<S>
fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
val requiredCommands: Set<Class<out CommandData>>
fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
class FirstComposition<S : ContractState, C : CommandData, K : Any> : CompositeClause<S, C, K>
Module Contents
FirstComposition(firstClause: Clause<S, C, K>, vararg remainingClauses: Clause<S, C, K>)
val clauses: ArrayList<Clause<S, C, K>>
val firstClause: Clause<S, C, K>
val logger: <ERROR CLASS>
fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<Clause<S, C, K>>
fun toString(): String
fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
abstract class GroupClauseVerifier<S : ContractState, C : CommandData, K : Any> : Clause<ContractState, C, Unit>
Module Contents
GroupClauseVerifier(clause: Clause<S, C, K>)
val clause: Clause<S, C, K>
open fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
abstract fun groupStates(tx: TransactionForContract): List<InOutGroup<S, K>>
open fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
fun <C : CommandData> Clause<*, C, *>.matches(commands: List<AuthenticatedObject<C>>): Boolean
fun <C : CommandData> verifyClause(tx: TransactionForContract, clause: Clause<ContractState, C, Unit>, commands: List<AuthenticatedObject<C>>): Unit
package net.corda.core.crypto
Module Contents
sealed class CompositeKey
open class DigitalSignature : OpaqueBytes
class DummyPublicKey : PublicKey, Comparable<PublicKey>
class MerkleTreeException : Exception
val NullCompositeKey: CompositeKey
object NullPublicKey : PublicKey, Comparable<PublicKey>
object NullSignature : WithKey
class PartialMerkleTree
data class Party
sealed class SecureHash : OpaqueBytes
open class SignedData<T : Any>
class WhitelistTrustManager : X509ExtendedTrustManager
Module Contents
WhitelistTrustManager(originalProvider: X509ExtendedTrustManager)
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String): Unit
val checker: HostnameChecker
fun getAcceptedIssuers(): Array<out X509Certificate>
val originalProvider: X509ExtendedTrustManager
object WhitelistTrustManagerProvider : Provider
class WhitelistTrustManagerSpi : TrustManagerFactorySpi
object X509Utilities
Module Contents
data class CACertAndKey
val CORDA_CLIENT_CA: String
val CORDA_CLIENT_CA_PRIVATE_KEY: String
val CORDA_INTERMEDIATE_CA: String
val CORDA_INTERMEDIATE_CA_PRIVATE_KEY: String
val CORDA_ROOT_CA: String
val CORDA_ROOT_CA_PRIVATE_KEY: String
val ECDSA_CURVE: String
val KEYSTORE_TYPE: String
val KEY_GENERATION_ALGORITHM: String
val SIGNATURE_ALGORITHM: String
fun KeyStore.addOrReplaceCertificate(alias: String, cert: Certificate): Unit
fun KeyStore.addOrReplaceKey(alias: String, key: Key, password: CharArray, chain: Array<Certificate>): Unit
fun createCAKeyStoreAndTrustStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, trustStoreFilePath: Path, trustStorePassword: String): KeyStore
fun createCertificateSigningRequest(myLegalName: String, nearestCity: String, email: String, keyPair: KeyPair): <ERROR CLASS>
fun createIntermediateCert(domain: String, certificateAuthority: CACertAndKey): CACertAndKey
fun createKeystoreForSSL(: Path, : String, : String, : KeyStore, : String): KeyStore
fun createSelfSignedCACert(myLegalName: String): CACertAndKey
fun createServerCert(subject: <ERROR CLASS>, publicKey: PublicKey, certificateAuthority: CACertAndKey, subjectAlternativeNameDomains: List<String>, subjectAlternativeNameIps: List<String>): X509Certificate
fun generateECDSAKeyPairForSSL(): KeyPair
fun getDevX509Name(domain: String): <ERROR CLASS>
fun getX509Name(myLegalName: String, nearestCity: String, email: String): <ERROR CLASS>
fun loadCertificateAndKey(keyStore: KeyStore, keyPassword: String, alias: String): CACertAndKey
fun loadCertificateFromKeyStore(keyStoreFilePath: Path, storePassword: String, alias: String): X509Certificate
fun loadCertificateFromPEMFile(filename: Path): X509Certificate
fun loadKeyPairFromKeyStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, alias: String): KeyPair
fun loadKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun loadKeyStore(input: InputStream, storePassword: String): KeyStore
fun loadOrCreateKeyPairFromKeyStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, alias: String, keyGenerator: () -> CACertAndKey): KeyPair
fun loadOrCreateKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun saveCertificateAsPEMFile(x509Certificate: X509Certificate, filename: Path): Unit
fun saveKeyStore(keyStore: KeyStore, keyStoreFilePath: Path, storePassword: String): Unit
val ed25519Curve: <ERROR CLASS>
fun entropyToKeyPair(entropy: BigInteger): KeyPair
fun generateKeyPair(): KeyPair
java.security.KeyPair
java.security.PrivateKey
java.security.PublicKey
kotlin.ByteArray
kotlin.collections.Iterable
fun newSecureRandom(): SecureRandom
fun parsePublicKeyBase58(base58String: String): <ERROR CLASS>
fun registerWhitelistTrustManager(): Unit
fun OpaqueBytes.sha256(): SHA256
package net.corda.core.flows
package net.corda.core.math
package net.corda.core.messaging
Module Contents
object Ack : DeserializeAsKotlinObjectDef
interface AllPossibleRecipients : MessageRecipients
interface Message
interface MessageHandlerRegistration
interface MessageRecipientGroup : MessageRecipients
interface MessageRecipients
interface MessagingService
interface SingleMessageRecipient : MessageRecipients
data class TopicSession
object TopicStringValidator
fun MessagingService.createMessage(topic: String, sessionID: Long = DEFAULT_SESSION_ID, data: ByteArray): Message
fun <M : Any> MessagingService.onNext(topic: String, sessionId: Long): <ERROR CLASS><M>
fun MessagingService.runOnNextMessage(topic: String, sessionID: Long, callback: (Message) -> Unit): Unit
inline fun MessagingService.runOnNextMessage(topicSession: TopicSession, crossinline callback: (Message) -> Unit): Unit
fun MessagingService.send(topic: String, sessionID: Long, payload: Any, to: MessageRecipients, uuid: UUID = UUID.randomUUID()): Unit
fun MessagingService.send(topicSession: TopicSession, payload: Any, to: MessageRecipients, uuid: UUID = UUID.randomUUID()): Unit
package net.corda.core.node
package net.corda.core.node.services
Module Contents
interface AttachmentStorage
val DEFAULT_SESSION_ID: Long
interface IdentityService
interface KeyManagementService
sealed class NetworkCacheError : Exception
interface NetworkMapCache
interface ReadOnlyTransactionStorage
interface SchedulerService
data class ServiceInfo
sealed class ServiceType
interface StateMachineRecordedTransactionMappingStorage
data class StateMachineTransactionMapping
interface StorageService
class TimestampChecker
interface TransactionStorage : ReadOnlyTransactionStorage
interface TxWritableStorageService : StorageService
class UniquenessException : Exception
interface UniquenessProvider
class Vault
interface VaultService
Module Contents
abstract fun addNoteToTransaction(txnId: SecureHash, noteText: String): Unit
open val cashBalances: Map<Currency, Amount<Currency>>
abstract val currentVault: Vault
abstract fun generateSpend(tx: TransactionBuilder, amount: Amount<Currency>, to: CompositeKey, onlyFromParties: Set<Party>? = null): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
abstract fun getTransactionNotes(txnId: SecureHash): Iterable<String>
abstract val linearHeads: Map<UniqueIdentifier, StateAndRef<LinearState>>
open fun <T : LinearState> linearHeadsOfType_(stateType: Class<T>): Map<UniqueIdentifier, StateAndRef<T>>
open fun notify(tx: WireTransaction): Vault
abstract fun notifyAll(txns: Iterable<WireTransaction>): Vault
open fun statesForRefs(refs: List<StateRef>): Map<StateRef, TransactionState<*>?>
abstract fun track(): <ERROR CLASS><Vault, <ERROR CLASS><Update>>
abstract val updates: <ERROR CLASS><Update>
open fun whenConsumed(ref: StateRef): <ERROR CLASS><Update>
inline fun <reified T : DealState> VaultService.dealsWith(party: Party): <ERROR CLASS>
kotlin.collections.Iterable
inline fun <reified T : LinearState> VaultService.linearHeadsOfType(): <ERROR CLASS>
package net.corda.core.schemas
package net.corda.core.serialization
package net.corda.core.testing
package net.corda.core.transactions
Module Contents
abstract class BaseTransaction : NamedByHash
class FilterFuns
class FilteredLeaves
class FilteredTransaction
class LedgerTransaction : BaseTransaction
sealed class MerkleTree
data class SignedTransaction : NamedByHash
open class TransactionBuilder
Module Contents
TransactionBuilder(type: TransactionType = TransactionType.General(), notary: Party? = null, inputs: MutableList<StateRef> = arrayListOf(), attachments: MutableList<SecureHash> = arrayListOf(), outputs: MutableList<TransactionState<ContractState>> = arrayListOf(), commands: MutableList<Command> = arrayListOf(), signers: MutableSet<CompositeKey> = mutableSetOf(), timestamp: Timestamp? = null)
fun addAttachment(attachmentId: SecureHash): Unit
fun addCommand(arg: Command): Unit
fun addCommand(data: CommandData, vararg keys: CompositeKey): <ERROR CLASS>
fun addCommand(data: CommandData, keys: List<CompositeKey>): Unit
open fun addInputState(stateAndRef: StateAndRef<*>): Unit
fun addOutputState(state: TransactionState<*>): Int
fun addOutputState(state: ContractState, notary: Party): Int
fun addOutputState(state: ContractState): Int
fun addSignatureUnchecked(sig: WithKey): TransactionBuilder
fun attachments(): List<SecureHash>
protected val attachments: MutableList<SecureHash>
fun checkAndAddSignature(sig: WithKey): Unit
fun checkSignature(sig: WithKey): Unit
fun commands(): List<Command>
protected val commands: MutableList<Command>
fun copy(): TransactionBuilder
protected val currentSigs: <ERROR CLASS>
fun inputStates(): List<StateRef>
protected val inputs: MutableList<StateRef>
var notary: Party?
fun outputStates(): List<TransactionState<*>>
protected val outputs: MutableList<TransactionState<ContractState>>
fun setTime(time: Instant, timeTolerance: Duration): Unit
fun setTime(newTimestamp: Timestamp): Unit
fun signWith(key: KeyPair): TransactionBuilder
protected val signers: MutableSet<CompositeKey>
val time: Timestamp?
protected var timestamp: Timestamp?
fun toSignedTransaction(checkSufficientSignatures: Boolean = true): SignedTransaction
fun toWireTransaction(): WireTransaction
protected val type: TransactionType
fun withItems(vararg items: Any): TransactionBuilder
class WireTransaction : BaseTransaction
fun WireTransaction.buildFilteredTransaction(filterFuns: FilterFuns): FilteredTransaction
fun WireTransaction.calculateLeavesHashes(): List<SecureHash>
fun SecureHash.hashConcat(other: SecureHash): <ERROR CLASS>
fun <T : Any> serializedHash(x: T): SecureHash
package net.corda.core.utilities
package net.corda.flows
package net.corda.node
package net.corda.node.api
Module Contents
interface APIServer
Module Contents
abstract fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
abstract fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
abstract fun fetchFlowsRequiringAttention(query: StatesQuery): Map<StateRef, FlowRequiringAttention>
abstract fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
abstract fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
abstract fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
abstract fun info(): NodeInfo
abstract fun invokeFlowSync(type: FlowRef, args: Map<String, Any?>): Any?
abstract fun provideFlowResponse(flow: FlowInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
abstract fun queryStates(query: StatesQuery): List<StateRef>
abstract fun serverTime(): LocalDateTime
abstract fun status(): <ERROR CLASS>
data class ContractClassRef : ContractDefRef
interface ContractDefRef
data class ContractLedgerRef : ContractDefRef
data class FlowClassRef : FlowRef
data class FlowInstanceRef
interface FlowRef
data class FlowRequiringAttention
interface StatesQuery
data class TransactionBuildStep
package net.corda.node.driver
Module Contents
open class DriverDSL : DriverDSLInternalInterface
Module Contents
DriverDSL(portAllocation: PortAllocation, debugPortAllocation: PortAllocation, driverDirectory: Path, useTestClock: Boolean, isDebug: Boolean)
class State
val debugPortAllocation: PortAllocation
val driverDirectory: Path
val isDebug: Boolean
val name: Array<String>
fun <A> pickA(array: Array<A>): A
val portAllocation: PortAllocation
fun registerProcess(process: Process): Unit
open fun shutdown(): Unit
open fun start(): Unit
open fun startNode(providedName: String?, advertisedServices: Set<ServiceInfo>, rpcUsers: List<User>, customOverrides: Map<String, Any?>): Future<NodeInfoAndConfig>
open fun startNotaryCluster(notaryName: String, clusterSize: Int, type: ServiceType): Unit
val useTestClock: Boolean
open fun waitForAllNodesToFinish(): Unit
interface DriverDSLExposedInterface
interface DriverDSLInternalInterface : DriverDSLExposedInterface
data class NodeInfoAndConfig
sealed class PortAllocation
fun addressMustBeBound(hostAndPort: <ERROR CLASS>): Unit
fun addressMustNotBeBound(hostAndPort: <ERROR CLASS>): Unit
fun <A> driver(driverDirectory: Path = Paths.get("build", getTimestampAsDirectoryName()), portAllocation: PortAllocation = PortAllocation.Incremental(10000), debugPortAllocation: PortAllocation = PortAllocation.Incremental(5005), useTestClock: Boolean = false, isDebug: Boolean = false, dsl: DriverDSLExposedInterface.() -> A): A
fun <DI : DriverDSLExposedInterface, D : DriverDSLInternalInterface, A> genericDriver(driverDsl: D, coerce: (D) -> DI, dsl: DI.() -> A): A
fun <A> poll(pollName: String, pollIntervalMs: Long = 500, warnCount: Int = 120, f: () -> A?): A
fun writeConfig(path: Path, filename: String, config: <ERROR CLASS>): Unit
package net.corda.node.internal
Module Contents
class APIServerImpl : APIServer
Module Contents
APIServerImpl(node: AbstractNode)
fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
fun fetchFlowsRequiringAttention(query: StatesQuery): Map<StateRef, FlowRequiringAttention>
fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
fun info(): NodeInfo
fun invokeFlowSync(type: FlowRef, args: Map<String, Any?>): Any?
val node: AbstractNode
fun provideFlowResponse(flow: FlowInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
fun queryStates(query: StatesQuery): List<StateRef>
fun serverTime(): LocalDateTime
fun status(): <ERROR CLASS>
abstract class AbstractNode : SingletonSerializeAsToken
class ConfigurationException : Exception
class CordaRPCOpsImpl : CordaRPCOps
class Node : AbstractNode
package net.corda.node.serialization
package net.corda.node.services
package net.corda.node.services.api
package net.corda.node.services.config
package net.corda.node.services.events
package net.corda.node.services.identity
package net.corda.node.services.keys
package net.corda.node.services.messaging
Module Contents
abstract class ArtemisMessagingComponent : SingletonSerializeAsToken
class ArtemisMessagingServer : ArtemisMessagingComponent
val CURRENT_RPC_USER: ThreadLocal<User>
data class ClientRPCRequestMessage
interface CordaRPCOps : RPCOps
data class FlowHandle<A>
data class MarshalledObservation
class NodeMessagingClient : ArtemisMessagingComponent, MessagingServiceInternal
Module Contents
NodeMessagingClient(config: NodeConfiguration, serverHostPort: <ERROR CLASS>, myIdentity: CompositeKey?, executor: AffinityExecutor, database: <ERROR CLASS>, networkMapRegistrationFuture: <ERROR CLASS><Unit>)
data class Handler : MessageHandlerRegistration
val SESSION_ID_PROPERTY: String
val TOPIC_PROPERTY: String
fun addMessageHandler(topic: String, sessionID: Long, callback: (Message, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
fun addMessageHandler(topicSession: TopicSession, callback: (Message, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
val config: NodeConfiguration
fun createMessage(topicSession: TopicSession, data: ByteArray, uuid: UUID): Message
val database: <ERROR CLASS>
var dispatcher: RPCDispatcher?
val executor: AffinityExecutor
val log: <ERROR CLASS>
fun makeNetworkMapAddress(hostAndPort: <ERROR CLASS>): SingleMessageRecipient
val myAddress: SingleMessageRecipient
val myIdentity: CompositeKey?
val networkMapRegistrationFuture: <ERROR CLASS><Unit>
fun removeMessageHandler(registration: MessageHandlerRegistration): Unit
fun run(): Unit
fun send(message: Message, target: MessageRecipients): Unit
val serverHostPort: <ERROR CLASS>
fun start(rpcOps: RPCOps, userService: RPCUserService): Unit
fun stop(): Unit
class PermissionException : RuntimeException
abstract class RPCDispatcher
open class RPCException : RuntimeException
interface RPCOps
@Target([AnnotationTarget.FUNCTION]) annotation class RPCReturnsObservables
@Target([AnnotationTarget.FUNCTION]) annotation class RPCSinceVersion
data class StateMachineInfo
sealed class StateMachineUpdate
fun createRPCKryo(observableSerializer: <ERROR CLASS><<ERROR CLASS><Any>>? = null): <ERROR CLASS>
fun requirePermission(permission: String): Unit
val rpcLog: <ERROR CLASS>
inline fun <T : Any, reified R : FlowLogic<T>> CordaRPCOps.startFlow(flowConstructor: () -> R): <ERROR CLASS>
inline fun <T : Any, A, reified R : FlowLogic<T>> CordaRPCOps.startFlow(flowConstructor: (A) -> R, arg0: A): <ERROR CLASS>
inline fun <T : Any, A, B, reified R : FlowLogic<T>> CordaRPCOps.startFlow(flowConstructor: (A, B) -> R, arg0: A, arg1: B): <ERROR CLASS>
inline fun <T : Any, A, B, C, reified R : FlowLogic<T>> CordaRPCOps.startFlow(flowConstructor: (A, B, C) -> R, arg0: A, arg1: B, arg2: C): <ERROR CLASS>
inline fun <T : Any, A, B, C, D, reified R : FlowLogic<T>> CordaRPCOps.startFlow(flowConstructor: (A, B, C, D) -> R, arg0: A, arg1: B, arg2: C, arg3: D): <ERROR CLASS>
package net.corda.node.services.network
package net.corda.node.services.persistence
package net.corda.node.services.schema
package net.corda.node.services.statemachine
package net.corda.node.services.transactions
package net.corda.node.services.vault
package net.corda.node.servlets
package net.corda.node.utilities
Module Contents
class ANSIProgressObserver
object ANSIProgressRenderer
abstract class AbstractJDBCHashMap<K : Any, V : Any, out T : JDBCHashedTable> : MutableMap<K, V>, AbstractMap<K, V>
Module Contents
AbstractJDBCHashMap(table: T, loadOnInit: Boolean = false, maxBuckets: Int = 256)
protected abstract fun addKeyToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
protected abstract fun addValueToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
open fun clear(): Unit
open fun containsKey(key: K): Boolean
open fun containsValue(value: V): Boolean
open val entries: MutableSet<MutableEntry<K, V>>
open fun get(key: K): V?
open fun isEmpty(): Boolean
protected abstract fun keyFromRow(row: <ERROR CLASS>): K
open val keys: MutableSet<K>
val loadOnInit: Boolean
protected val log: <ERROR CLASS>
val maxBuckets: Int
open fun put(key: K, value: V): V?
open fun remove(key: K): V?
open val size: Int
val table: T
protected abstract fun valueFromRow(row: <ERROR CLASS>): V
open val values: MutableCollection<V>
abstract class AbstractJDBCHashSet<K : Any, out T : JDBCHashedTable> : MutableSet<K>, AbstractSet<K>
enum class AddOrRemove
interface AffinityExecutor : Executor
object CompositeKeyColumnType
class FiberBox<out T>
object InstantColumnType
class JDBCHashMap<K : Any, V : Any> : AbstractJDBCHashMap<K, V, BlobMapTable>
class JDBCHashSet<K : Any> : AbstractJDBCHashSet<K, BlobSetTable>
open class JDBCHashedTable
object JsonSupport
object LocalDateColumnType
object LocalDateTimeColumnType
abstract class MutableClock : Clock
const val NODE_DATABASE_PREFIX: String
data class PartyColumns
object PublicKeyColumnType
object SecureHashColumnType
object ServiceIdentityGenerator
data class StateRefColumns
class StrandLocalTransactionManager
class TestClock : MutableClock, SerializeAsToken
data class TxnNoteColumns
object UUIDStringColumnType
fun <T : Any> bytesFromBlob(blob: Blob): SerializedBytes<T>
fun bytesToBlob(value: SerializedBytes<*>, finalizables: MutableList<() -> Unit>): Blob
fun <ERROR CLASS>.compositeKey(name: String): <ERROR CLASS>
fun configureDatabase(props: Properties): <ERROR CLASS><Closeable, <ERROR CLASS>>
fun createDatabaseTransaction(db: <ERROR CLASS>): <ERROR CLASS>
fun <T> databaseTransaction(db: <ERROR CLASS>, statement: <ERROR CLASS>.() -> T): T
fun <T : Any> deserializeFromBlob(blob: Blob): T
fun <ERROR CLASS>.instant(name: String): <ERROR CLASS>
fun <T> isolatedTransaction(database: <ERROR CLASS>, block: <ERROR CLASS>.() -> T): T
java.time.Clock
Module Contents
fun Clock.awaitWithDeadline(deadline: Instant, future: Future<*> = GuavaSettableFuture.create<Any>()): Boolean
fun <ERROR CLASS>.localDate(name: String): <ERROR CLASS>
fun <ERROR CLASS>.localDateTime(name: String): <ERROR CLASS>
fun main(args: Array<String>): Unit
fun <ERROR CLASS>.party(nameColumnName: String, keyColumnName: String): <ERROR CLASS>
fun <ERROR CLASS>.publicKey(name: String): <ERROR CLASS>
fun <ERROR CLASS>.secureHash(name: String): <ERROR CLASS>
fun serializeToBlob(value: Any, finalizables: MutableList<() -> Unit>): Blob
fun <ERROR CLASS>.stateRef(txIdColumnName: String, indexColumnName: String): <ERROR CLASS>
fun <ERROR CLASS>.txnNote(txIdColumnName: String, txnNoteColumnName: String): <ERROR CLASS>
fun <ERROR CLASS>.uuidString(name: String): <ERROR CLASS>
package net.corda.node.utilities.certsigning
package net.corda.schemas