Module Contents alltypes
      Module Contents class ANSIProgressObserver
        Module Contents ANSIProgressObserver(smm: StateMachineManager)
        val smm: StateMachineManager
      object ANSIProgressRenderer
        Module Contents var progressTracker: ProgressTracker?
      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>>
        Module Contents AbstractIssue(sum: List<S>.() -> Amount<Issued<T>>, sumOrZero: List<S>.(Issued<T>) -> Amount<Issued<T>>)
        val sum: List<S>.() -> Amount<Issued<T>>
        val sumOrZero: List<S>.(Issued<T>) -> Amount<Issued<T>>
        open fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Issued<T>?): Set<C>
      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 = DEFAULT_MAX_BUCKETS)
        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>
        Module Contents AbstractJDBCHashSet(table: T, loadOnInit: Boolean = false, maxBuckets: Int = DEFAULT_MAX_BUCKETS)
        open fun add(element: K): Boolean
        protected abstract fun addElementToInsert(insert: <ERROR CLASS>, entry: K, finalizables: MutableList<() -> Unit>): Unit
        open fun clear(): Unit
        open fun contains(element: K): Boolean
        protected abstract fun elementFromRow(row: <ERROR CLASS>): K
        protected val innerMap: AbstractJDBCHashMap<K, Unit, T>
        open fun isEmpty(): Boolean
        open fun iterator(): MutableIterator<K>
        open fun remove(element: K): Boolean
        open val size: Int
        protected val table: T
      abstract class AbstractNetworkMapService : NetworkMapService, AbstractNodeService
        Module Contents AbstractNetworkMapService(services: ServiceHubInternal)
        protected val _mapVersion: AtomicInteger
        fun getUnacknowledgedCount(subscriber: SingleMessageRecipient, mapVersion: Int): Int?
        val mapVersion: Int
        val maxSizeRegistrationRequestBytes: Int
        val maxUnacknowledgedUpdates: Int
        open val nodes: List<NodeInfo>
        fun notifySubscribers(wireReg: WireNodeRegistration, mapVersion: Int): Unit
        fun processAcknowledge(req: UpdateAcknowledge): Unit
        fun processFetchAllRequest(req: FetchMapRequest): FetchMapResponse
        fun processQueryRequest(req: QueryIdentityRequest): QueryIdentityResponse
        fun processRegistrationChangeRequest(req: RegistrationRequest): RegistrationResponse
        fun processSubscriptionRequest(req: SubscribeRequest): SubscribeResponse
        protected abstract val registeredNodes: MutableMap<Party, NodeRegistrationInfo>
        protected fun setup(): Unit
        protected abstract val subscribers: ThreadBox<MutableMap<SingleMessageRecipient, LastAcknowledgeInfo>>
        fun unregisterNetworkHandlers(): Unit
      abstract class AbstractNode : SingletonSerializeAsToken
        Module Contents AbstractNode(configuration: NodeConfiguration, networkMapService: SingleMessageRecipient?, advertisedServices: Set<ServiceInfo>, platformClock: Clock)
        class DatabaseConfigurationException : Exception
          Module Contents DatabaseConfigurationException(msg: String)
        val PRIVATE_KEY_FILE_NAME: String
        val PUBLIC_IDENTITY_FILE_NAME: String
        protected val _servicesThatAcceptUploads: ArrayList<AcceptsFileUpload>
        protected open fun acceptableLiveFiberCountOnStop(): Int
        val advertisedServices: Set<ServiceInfo>
        lateinit var api: APIServer
        lateinit var checkpointStorage: CheckpointStorage
        open val configuration: NodeConfiguration
        protected open fun constructStorageService(attachments: NodeAttachmentService, transactionStorage: TransactionStorage, stateMachineRecordedTransactionMappingStorage: StateMachineRecordedTransactionMappingStorage): StorageServiceImpl
        protected fun createNodeDir(): Unit
        val customServices: ArrayList<Any>
        lateinit var database: <ERROR CLASS>
        protected var dbCloser: Runnable?
        val defaultFlowWhiteList: Map<Class<out FlowLogic<*>>, Set<Class<*>>>
        open fun findMyLocation(): PhysicalLocation?
        inline fun <reified T : Any> findService(): <ERROR CLASS>
        lateinit var flowLogicFactory: FlowLogicRefFactory
        protected open fun generateKeyPair(): KeyPair
        lateinit var identity: IdentityService
        var inNodeNetworkMapService: NetworkMapService?
        var inNodeNotaryService: NotaryService?
        lateinit var info: NodeInfo
        protected open fun initialiseDatabasePersistence(insideTransaction: () -> Unit): Unit
        protected open fun initialiseStorageService(dir: Path): <ERROR CLASS><TxWritableStorageService, CheckpointStorage>
        var isPreviousCheckpointsPresent: Boolean
        lateinit var keyManagement: KeyManagementService
        protected abstract val log: <ERROR CLASS>
        protected fun makeAttachmentStorage(dir: Path): NodeAttachmentService
        protected open fun makeIdentityService(): IdentityService
        protected open fun makeKeyManagementService(): KeyManagementService
        protected abstract fun makeMessagingService(): MessagingServiceInternal
        protected open fun makeNetworkMapService(): Unit
        protected open fun makeNotaryService(type: ServiceType): NotaryService
        protected open fun makeSchemaService(): SchemaService
        protected fun makeServiceEntries(): List<ServiceEntry>
        protected abstract fun makeUniquenessProvider(type: ServiceType): UniquenessProvider
        protected open fun makeVaultService(): VaultService
        lateinit var net: MessagingServiceInternal
        lateinit var netMapCache: NetworkMapCache
        val networkMapRegistrationFuture: <ERROR CLASS><Unit>
        var networkMapSeq: Long
        val networkMapService: SingleMessageRecipient?
        protected open fun noNetworkMapConfigured(): <ERROR CLASS><Unit>
        protected fun obtainLegalIdentity(): Party
        protected fun obtainLegalIdentityKey(): KeyPair
        protected val partyKeys: <ERROR CLASS>
        val platformClock: Clock
        open val pluginRegistries: List<CordaPluginRegistry>
        protected val runOnStop: ArrayList<Runnable>
        lateinit var scheduler: NodeSchedulerService
        lateinit var schemas: SchemaService
        protected abstract val serverThread: AffinityExecutor
        val services: ServiceHubInternal
        val servicesThatAcceptUploads: List<AcceptsFileUpload>
        open fun setup(): AbstractNode
        lateinit var smm: StateMachineManager
        open fun start(): AbstractNode
        protected abstract fun startMessagingService(rpcOps: RPCOps): Unit
        var started: Boolean
        open fun stop(): Unit
        lateinit var storage: TxWritableStorageService
        var uniquenessProvider: UniquenessProvider?
        lateinit var vault: VaultService
      abstract class AbstractNodeService : SingletonSerializeAsToken
        Module Contents AbstractNodeService(services: ServiceHubInternal)
        protected inline fun <reified Q : ServiceRequestMessage, reified R : Any> addMessageHandler(topic: String, crossinline handler: (Q) -> R, crossinline exceptionConsumer: (Message, Exception) -> Unit): MessageHandlerRegistration
        protected inline fun <reified Q : ServiceRequestMessage, reified R : Any> addMessageHandler(topic: String, crossinline handler: (Q) -> R): MessageHandlerRegistration
        val net: MessagingServiceInternal
        val services: ServiceHubInternal
      abstract class AbstractStateReplacementFlow<T>
        Module Contents AbstractStateReplacementFlow()
        abstract class Acceptor<T> : FlowLogic<Unit>
          Module Contents Acceptor(otherSide: Party, progressTracker: ProgressTracker = tracker())
          object APPROVING : Step
          object REJECTING : Step
          object VERIFYING : Step
          open fun call(): Unit
          val otherSide: Party
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
          protected abstract fun verifyProposal(maybeProposal: UntrustworthyData<Proposal<T>>): Proposal<T>
        abstract class Instigator<out S : ContractState, T> : FlowLogic<StateAndRef<S>>
          Module Contents Instigator(originalState: StateAndRef<S>, modification: T, progressTracker: ProgressTracker = tracker())
          object NOTARY : Step
          object SIGNING : Step
          protected abstract fun assembleProposal(stateRef: StateRef, modification: T, stx: SignedTransaction): Proposal<T>
          protected abstract fun assembleTx(): <ERROR CLASS><SignedTransaction, List<CompositeKey>>
          open fun call(): StateAndRef<S>
          val modification: T
          val originalState: StateAndRef<S>
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
        interface Proposal<out T>
          Module Contents abstract val modification: T
          abstract val stateRef: StateRef
          abstract val stx: SignedTransaction
        data class Result
          Module Contents val error: StateReplacementRefused?
          fun noError(sig: WithKey): Result
          val sig: WithKey?
          fun withError(error: StateReplacementRefused): Result
      interface AcceptsFileUpload
        Module Contents abstract val acceptableFileExtensions: List<String>
        abstract val dataTypePrefix: String
        abstract fun upload(data: InputStream): String
      enum class AccrualAdjustment
        Module Contents Adjusted
        Unadjusted
      object Ack : DeserializeAsKotlinObjectDef
      enum class AddOrRemove
        Module Contents ADD
        REMOVE
      interface AffinityExecutor : Executor
        Module Contents class Gate : AffinityExecutor
          Module Contents Gate(alwaysQueue: Boolean = false)
          fun execute(command: Runnable): Unit
          fun flush(): Unit
          val isOnThread: Boolean
          val taskQueueSize: Int
          fun waitAndRun(): Unit
        open class ServiceAffinityExecutor : AffinityExecutor, ThreadPoolExecutor
          Module Contents ServiceAffinityExecutor(threadName: String, numThreads: Int)
          protected open fun afterExecute(r: Runnable, t: Throwable?): Unit
          open fun flush(): Unit
          open val isOnThread: Boolean
          val logger: <ERROR CLASS>
        open fun checkOnThread(): Unit
        open fun executeASAP(runnable: () -> Unit): Unit
        open fun <T> fetchFrom(fetcher: () -> T): T
        abstract fun flush(): Unit
        abstract val isOnThread: Boolean
      class AggregatedList<A, E : Any, K : Any> : TransformationList<A, E>
        Module Contents AggregatedList(list: ObservableList<out E>, toKey: (E) -> K, assemble: (K, ObservableList<E>) -> A)
        val assemble: (K, ObservableList<E>) -> A
        fun get(index: Int): A?
        fun getSourceIndex(index: Int): Int
        val size: Int
        protected fun sourceChanged(c: Change<out E>): Unit
        val toKey: (E) -> K
      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>>
        Module Contents Amount(amount: BigDecimal, currency: T)
        Amount(quantity: Long, token: T)
        fun compareTo(other: Amount<T>): Int
        operator fun div(other: Long): Amount<T>
        operator fun div(other: Int): Amount<T>
        operator fun minus(other: Amount<T>): Amount<T>
        operator fun plus(other: Amount<T>): Amount<T>
        val quantity: Long
        operator fun times(other: Long): Amount<T>
        operator fun times(other: Int): Amount<T>
        fun toString(): String
        val token: T
      object AmountBindings
        Module Contents fun exchange(currency: ObservableValue<Currency>, exchangeRate: ObservableValue<ExchangeRate>): ObservableValue<<ERROR CLASS><Currency, (Amount<Currency>) -> Long>>
        fun <T> sum(amounts: ObservableList<Amount<T>>, token: T): <ERROR CLASS>
        fun sumAmountExchange(amounts: ObservableList<Amount<Currency>>, currency: ObservableValue<Currency>, exchangeRate: ObservableValue<ExchangeRate>): ObservableValue<Amount<Currency>>
      class AmountGenerator<T>
        Module Contents AmountGenerator(tokenGenerator: <ERROR CLASS><T>)
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Amount<T>
        val tokenGenerator: <ERROR CLASS><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
        Module Contents ApiUtils(rpc: CordaRPCOps)
        val rpc: CordaRPCOps
        fun withParty(partyKeyStr: String, notFound: (String) -> <ERROR CLASS> = defaultNotFound, found: (Party) -> <ERROR CLASS>): <ERROR CLASS>
      data class AppContext
        Module Contents AppContext(attachments: List<SecureHash>)
        val attachments: List<SecureHash>
        val classLoader: ClassLoader
      abstract class ArtemisMessagingComponent : SingletonSerializeAsToken
        Module Contents ArtemisMessagingComponent()
        interface ArtemisAddress : MessageRecipients
          Module Contents abstract val queueName: <ERROR CLASS>
        interface ArtemisPeerAddress : ArtemisAddress, SingleMessageRecipient
          Module Contents abstract val hostAndPort: <ERROR CLASS>
        const val CLIENTS_PREFIX: String
        protected enum class ConnectionDirection
          Module Contents INBOUND
          OUTBOUND
        const val INTERNAL_PREFIX: String
        val NETWORK_MAP_ADDRESS: String
        const val NODE_USER: String
        const val NOTIFICATIONS_ADDRESS: String
        data class NetworkMapAddress : SingleMessageRecipient, ArtemisPeerAddress
          Module Contents NetworkMapAddress(hostAndPort: <ERROR CLASS>)
          val hostAndPort: <ERROR CLASS>
          val queueName: <ERROR CLASS>
        data class NodeAddress : ArtemisPeerAddress
          Module Contents NodeAddress(queueName: <ERROR CLASS>, hostAndPort: <ERROR CLASS>)
          fun asPeer(peerIdentity: CompositeKey, hostAndPort: <ERROR CLASS>): NodeAddress
          fun asService(serviceIdentity: CompositeKey, hostAndPort: <ERROR CLASS>): NodeAddress
          val hostAndPort: <ERROR CLASS>
          val queueName: <ERROR CLASS>
          fun toString(): String
        const val P2P_QUEUE: String
        const val PEERS_PREFIX: String
        const val PEER_USER: String
        const val RPC_QUEUE_REMOVALS_QUEUE: String
        const val RPC_REQUESTS_QUEUE: String
        const val SERVICES_PREFIX: String
        data class ServiceAddress : ArtemisAddress, MessageRecipientGroup
          Module Contents ServiceAddress(identity: CompositeKey)
          val identity: CompositeKey
          val queueName: <ERROR CLASS>
        fun checkStorePasswords(): Unit
        abstract val config: NodeSSLConfiguration
        protected fun Path.expectedOnDefaultFileSystem(): Unit
        protected fun tcpTransport(direction: ConnectionDirection, host: String, port: Int): <ERROR CLASS>
        fun toHostAndPort(target: MessageRecipients): <ERROR CLASS>
      class ArtemisMessagingServer : ArtemisMessagingComponent
        Module Contents ArtemisMessagingServer(config: NodeConfiguration, myHostPort: <ERROR CLASS>, networkMapCache: NetworkMapCache, userService: RPCUserService)
        class NodeLoginModule : LoginModule
          Module Contents NodeLoginModule()
          const val NODE_ROLE: String
          const val PEER_ROLE: String
          const val RPC_ROLE: String
          fun abort(): Boolean
          fun commit(): Boolean
          fun initialize(subject: Subject, callbackHandler: CallbackHandler, sharedState: Map<String, *>, options: Map<String, *>): Unit
          fun login(): Boolean
          fun logout(): Boolean
        val config: NodeConfiguration
        fun deployBridgeIfAbsent(queueName: <ERROR CLASS>, hostAndPort: <ERROR CLASS>): Unit
        val myHostPort: <ERROR CLASS>
        val networkMapCache: NetworkMapCache
        fun start(): Unit
        fun stop(): Unit
        val userService: RPCUserService
      class AssociatedList<K, out A, B> : ReadOnlyBackedObservableMapBase<K, B, Unit>
        Module Contents AssociatedList(sourceList: ObservableList<out A>, toKey: (A) -> K, assemble: (K, A) -> B)
        val sourceList: ObservableList<out A>
      interface Attachment : NamedByHash
        Module Contents open fun extractFile(path: String, outputTo: OutputStream): Unit
        abstract fun open(): InputStream
        open fun openAsJAR(): JarInputStream
      class AttachmentDownloadServlet
        Module Contents AttachmentDownloadServlet()
        fun doGet(req: <ERROR CLASS>, resp: <ERROR CLASS>): Unit
      interface AttachmentStorage
        Module Contents abstract fun importAttachment(jar: InputStream): SecureHash
        abstract fun openAttachment(id: SecureHash): Attachment?
      class AttachmentsClassLoader : SecureClassLoader
        Module Contents AttachmentsClassLoader(attachments: List<Attachment>, parent: ClassLoader = ClassLoader.getSystemClassLoader())
        class OverlappingAttachments : Exception
          Module Contents OverlappingAttachments(path: String)
          val path: String
          fun toString(): String
        protected fun findClass(name: String): Class<*>
        protected fun findResource(name: String): URL?
        fun getResourceAsStream(name: String): InputStream?
      data class AuthenticatedObject<out T : Any>
        Module Contents AuthenticatedObject(signers: List<CompositeKey>, signingParties: List<Party>, value: T)
        val signers: List<CompositeKey>
        val signingParties: List<Party>
        val value: T
      abstract class BaseTransaction : NamedByHash
        Module Contents BaseTransaction(inputs: List<*>, outputs: List<TransactionState<ContractState>>, notary: Party?, mustSign: List<CompositeKey>, type: TransactionType, timestamp: Timestamp?)
        protected fun checkInvariants(): Unit
        open fun equals(other: Any?): Boolean
        open fun hashCode(): Int
        open val inputs: List<*>
        val mustSign: List<CompositeKey>
        val notary: Party?
        val outputs: List<TransactionState<ContractState>>
        val timestamp: Timestamp?
        val type: TransactionType
      data class BilateralNetState<P> : NetState<P>
        Module Contents BilateralNetState(partyKeys: Set<CompositeKey>, template: Terms<P>)
        val partyKeys: Set<CompositeKey>
        val template: Terms<P>
      interface BilateralNettableState<N : BilateralNettableState<N>>
        Module Contents abstract val bilateralNetState: Any
        abstract fun net(other: N): N
      class BroadcastTransactionFlow : FlowLogic<Unit>
        Module Contents BroadcastTransactionFlow(notarisedTransaction: SignedTransaction, participants: Set<Party>)
        data class NotifyTxRequest
          Module Contents NotifyTxRequest(tx: SignedTransaction)
          val tx: SignedTransaction
        fun call(): Unit
        val notarisedTransaction: SignedTransaction
        val participants: Set<Party>
      open class BusinessCalendar
        Module Contents val TEST_CALENDAR_DATA: <ERROR CLASS>
        class UnknownCalendar : Exception
          Module Contents UnknownCalendar(name: String)
        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
          Module Contents class ConserveAmount : AbstractConserveAmount<State, Commands, Currency>
            Module Contents ConserveAmount()
          class Group : GroupClauseVerifier<State, Commands, Issued<Currency>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State, Issued<Currency>>>
          class Issue : AbstractIssue<State, Commands, Currency>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
        interface Commands : Commands
          Module Contents data class Exit : Commands, Exit<Currency>
            Module Contents Exit(amount: Amount<Issued<Currency>>)
            val amount: Amount<Issued<Currency>>
          data class Issue : Issue, Commands
            Module Contents Issue(nonce: Long = newSecureRandom().nextLong())
            val nonce: Long
          data class Move : Move, Commands
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
        data class State : FungibleAsset<Currency>, QueryableState
          Module Contents State(deposit: PartyAndReference, amount: Amount<Currency>, owner: CompositeKey)
          State(amount: Amount<Issued<Currency>>, owner: CompositeKey, encumbrance: Int? = null)
          val amount: Amount<Issued<Currency>>
          val contract: Cash
          val encumbrance: Int?
          val exitKeys: <ERROR CLASS>
          fun generateMappedObject(schema: MappedSchema): PersistentState
          fun move(newAmount: Amount<Issued<Currency>>, newOwner: CompositeKey): FungibleAsset<Currency>
          val owner: CompositeKey
          val participants: <ERROR CLASS>
          fun supportedSchemas(): Iterable<MappedSchema>
          fun toString(): String
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        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
        Module Contents CashBalanceAsMetricsObserver(serviceHubInternal: ServiceHubInternal, database: <ERROR CLASS>)
        val database: <ERROR CLASS>
        val serviceHubInternal: ServiceHubInternal
      sealed class CashCommand
        Module Contents class ExitCash : CashCommand
          Module Contents ExitCash(amount: Amount<Currency>, issueRef: OpaqueBytes)
          val amount: Amount<Currency>
          val issueRef: OpaqueBytes
        class IssueCash : CashCommand
          Module Contents IssueCash(amount: Amount<Currency>, issueRef: OpaqueBytes, recipient: Party, notary: Party)
          val amount: Amount<Currency>
          val issueRef: OpaqueBytes
          val notary: Party
          val recipient: Party
        class PayCash : CashCommand
          Module Contents PayCash(amount: Amount<Issued<Currency>>, recipient: Party)
          val amount: Amount<Issued<Currency>>
          val recipient: Party
      class CashFlow : FlowLogic<CashFlowResult>
        Module Contents CashFlow(command: CashCommand)
        CashFlow(command: CashCommand, progressTracker: ProgressTracker)
        object EXITING : Step
        object ISSUING : Step
        object PAYING : Step
        fun call(): CashFlowResult
        val command: CashCommand
        val progressTracker: ProgressTracker
        fun tracker(): ProgressTracker
      sealed class CashFlowResult
        Module Contents class Failed : CashFlowResult
          Module Contents Failed(message: String?)
          val message: String?
          fun toString(): String
        class Success : CashFlowResult
          Module Contents Success(id: StateMachineRunId, transaction: SignedTransaction?, message: String?)
          val id: StateMachineRunId
          val message: String?
          fun toString(): String
          val transaction: SignedTransaction?
      object CashSchema
      object CashSchemaV1 : MappedSchema
        Module Contents class PersistentCashState : PersistentState
          Module Contents PersistentCashState(encumbrance: Int?, owner: String, pennies: Long, currency: String, issuerParty: String, issuerRef: ByteArray)
          var currency: String
          var encumbrance: Int?
          var issuerParty: String
          var issuerRef: ByteArray
          var owner: String
          var pennies: Long
      class CertificateSigner
        Module Contents CertificateSigner(config: NodeConfiguration, certService: CertificateSigningService)
        fun buildKeyStore(): Unit
        val certService: CertificateSigningService
        val config: NodeConfiguration
        val log: <ERROR CLASS>
        val pollInterval: Duration
      interface CertificateSigningService
        Module Contents abstract fun retrieveCertificates(requestId: String): Array<Certificate>?
        abstract fun submitRequest(request: <ERROR CLASS>): String
      class CertificateStream
        Module Contents CertificateStream(input: InputStream)
        val input: InputStream
        fun nextCertificate(): X509Certificate
      class Checkpoint
        Module Contents Checkpoint(serializedFiber: SerializedBytes<FlowStateMachineImpl<*>>)
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        val id: SecureHash
        val serializedFiber: SerializedBytes<FlowStateMachineImpl<*>>
        fun toString(): String
      interface CheckpointStorage
        Module Contents abstract fun addCheckpoint(checkpoint: Checkpoint): Unit
        abstract fun forEach(block: (Checkpoint) -> Boolean): Unit
        abstract fun removeCheckpoint(checkpoint: Checkpoint): Unit
      class ChosenList<E> : ObservableListBase<E>
        Module Contents ChosenList(chosenListObservable: ObservableValue<out ObservableList<out E>>)
        fun get(index: Int): E
        val size: Int
      object CityDatabase
        Module Contents operator fun get(name: String): PhysicalLocation?
      object ClassSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Class<*>>): Class<*>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, clazz: Class<*>): Unit
      abstract class Clause<in S : ContractState, C : CommandData, in K : Any>
        Module Contents Clause()
        open fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
        val log: <ERROR CLASS>
        open val requiredCommands: Set<Class<out CommandData>>
        abstract fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
      data class ClientRPCRequestMessage
        Module Contents ClientRPCRequestMessage(args: SerializedBytes<Array<Any>>, replyToAddress: String, observationsToAddress: String?, methodName: String, user: User)
        const val METHOD_NAME: String
        const val OBSERVATIONS_TO: String
        const val REPLY_TO: String
        val args: SerializedBytes<Array<Any>>
        val methodName: String
        val observationsToAddress: String?
        val replyToAddress: String
        val user: User
      data class Command
        Module Contents Command(data: CommandData, key: CompositeKey)
        Command(value: CommandData, signers: List<CompositeKey>)
        val signers: List<CompositeKey>
        fun toString(): String
        val value: CommandData
      interface CommandData
      class CommandDataGenerator
        Module Contents CommandDataGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): CommandData
      class CommandGenerator
        Module Contents CommandGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Command
      class CommercialPaper : Contract
        Module Contents CommercialPaper()
        interface Clauses
          Module Contents class Group : GroupClauseVerifier<State, Commands, Issued<Terms>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State, Issued<Terms>>>
          class Issue : AbstractIssue<State, Commands, Terms>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State>, outputs: List<State>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms>?): Set<Commands>
          class Move : Clause<State, Commands, Issued<Terms>>
            Module Contents Move()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State>, outputs: List<State>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms>?): Set<Commands>
          class Redeem : Clause<State, Commands, Issued<Terms>>
            Module Contents Redeem()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State>, outputs: List<State>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms>?): Set<Commands>
        interface Commands : CommandData
          Module Contents data class Issue : IssueCommand, Commands
            Module Contents Issue(nonce: Long = random63BitValue())
            val nonce: Long
          data class Move : Move, Commands
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
          class Redeem : TypeOnlyCommandData, Commands
            Module Contents Redeem()
        data class State : OwnableState, QueryableState
          Module Contents State(issuance: PartyAndReference, owner: CompositeKey, faceValue: Amount<Issued<Currency>>, maturityDate: Instant)
          val contract: CommercialPaper
          val faceValue: Amount<Issued<Currency>>
          fun generateMappedObject(schema: MappedSchema): PersistentState
          val issuance: PartyAndReference
          val maturityDate: Instant
          val owner: CompositeKey
          val participants: List<CompositeKey>
          fun supportedSchemas(): Iterable<MappedSchema>
          fun toString(): String
          val token: Issued<Terms>
          fun withFaceValue(newFaceValue: Amount<Issued<Currency>>): <ERROR CLASS>
          fun withIssuance(newIssuance: PartyAndReference): <ERROR CLASS>
          fun withMaturityDate(newMaturityDate: Instant): <ERROR CLASS>
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
          fun withOwner(newOwner: CompositeKey): <ERROR CLASS>
        data class Terms
          Module Contents Terms(asset: Issued<Currency>, maturityDate: Instant)
          val asset: Issued<Currency>
          val maturityDate: Instant
        fun generateIssue(issuance: PartyAndReference, faceValue: Amount<Issued<Currency>>, maturityDate: Instant, notary: Party): TransactionBuilder
        fun generateMove(tx: TransactionBuilder, paper: StateAndRef<State>, newOwner: CompositeKey): Unit
        fun generateRedeem(tx: TransactionBuilder, paper: StateAndRef<State>, vault: VaultService): Unit
        val legalContractReference: SecureHash
        fun verify(tx: TransactionForContract): Unit
      class CommercialPaperLegacy : Contract
        Module Contents CommercialPaperLegacy()
        interface Commands : CommandData
          Module Contents class Issue : TypeOnlyCommandData, Commands
            Module Contents Issue()
          class Move : TypeOnlyCommandData, Commands
            Module Contents Move()
          class Redeem : TypeOnlyCommandData, Commands
            Module Contents Redeem()
        data class State : OwnableState
          Module Contents State(issuance: PartyAndReference, owner: CompositeKey, faceValue: Amount<Issued<Currency>>, maturityDate: Instant)
          val contract: CommercialPaperLegacy
          val faceValue: Amount<Issued<Currency>>
          val issuance: PartyAndReference
          val maturityDate: Instant
          val owner: CompositeKey
          val participants: <ERROR CLASS>
          fun toString(): String
          fun withFaceValue(newFaceValue: Amount<Issued<Currency>>): <ERROR CLASS>
          fun withIssuance(newIssuance: PartyAndReference): <ERROR CLASS>
          fun withMaturityDate(newMaturityDate: Instant): <ERROR CLASS>
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
          fun withOwner(newOwner: CompositeKey): <ERROR CLASS>
          fun withoutOwner(): State
        fun generateIssue(issuance: PartyAndReference, faceValue: Amount<Issued<Currency>>, maturityDate: Instant, notary: Party): TransactionBuilder
        fun generateMove(tx: TransactionBuilder, paper: StateAndRef<State>, newOwner: CompositeKey): Unit
        fun generateRedeem(tx: TransactionBuilder, paper: StateAndRef<State>, vault: VaultService): Unit
        val legalContractReference: SecureHash
        fun verify(tx: TransactionForContract): Unit
      object CommercialPaperSchema
      object CommercialPaperSchemaV1 : MappedSchema
        Module Contents class PersistentCommericalPaperState : PersistentState
          Module Contents PersistentCommericalPaperState(issuanceParty: String, issuanceRef: ByteArray, owner: String, maturity: Instant, faceValue: Long, currency: String, faceValueIssuerParty: String, faceValueIssuerRef: ByteArray)
          var currency: String
          var faceValue: Long
          var faceValueIssuerParty: String
          var faceValueIssuerRef: ByteArray
          var issuanceParty: String
          var issuanceRef: ByteArray
          var maturity: Instant
          var owner: String
      data class Commodity
        Module Contents Commodity(commodityCode: String, displayName: String, defaultFractionDigits: Int = 0)
        val commodityCode: String
        val defaultFractionDigits: Int
        val displayName: String
        fun getInstance(commodityCode: String): Commodity?
      class CommodityContract : OnLedgerAsset<Commodity, Commands, State>
        Module Contents CommodityContract()
        interface Clauses
          Module Contents class ConserveAmount : AbstractConserveAmount<State, Commands, Commodity>
            Module Contents ConserveAmount()
          class Group : GroupClauseVerifier<State, Commands, Issued<Commodity>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State, Issued<Commodity>>>
          class Issue : AbstractIssue<State, Commands, Commodity>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
        interface Commands : Commands
          Module Contents data class Exit : Commands, Exit<Commodity>
            Module Contents Exit(amount: Amount<Issued<Commodity>>)
            val amount: Amount<Issued<Commodity>>
          data class Issue : Issue, Commands
            Module Contents Issue(nonce: Long = newSecureRandom().nextLong())
            val nonce: Long
          data class Move : Move, Commands
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
        data class State : FungibleAsset<Commodity>
          Module Contents State(deposit: PartyAndReference, amount: Amount<Commodity>, owner: CompositeKey)
          State(amount: Amount<Issued<Commodity>>, owner: CompositeKey)
          val amount: Amount<Issued<Commodity>>
          val contract: CommodityContract
          val exitKeys: MutableSet<CompositeKey>
          fun move(newAmount: Amount<Issued<Commodity>>, newOwner: CompositeKey): FungibleAsset<Commodity>
          val owner: CompositeKey
          val participants: <ERROR CLASS>
          fun toString(): String
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        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>
        Module Contents CompositeClause()
        abstract val clauses: List<Clause<S, C, K>>
        open fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
        abstract fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<Clause<S, C, K>>
      sealed class CompositeKey
        Module Contents class Builder
          Module Contents Builder()
          fun addKey(key: CompositeKey, weight: Int = 1): Builder
          fun addKeys(vararg keys: CompositeKey): Builder
          fun addKeys(keys: List<CompositeKey>): Builder
          fun build(threshold: Int? = null): Node
        class Leaf : CompositeKey
          Module Contents Leaf(publicKey: PublicKey)
          fun equals(other: Any?): Boolean
          fun hashCode(): Int
          fun isFulfilledBy(keys: Iterable<PublicKey>): <ERROR CLASS>
          val keys: Set<PublicKey>
          val publicKey: PublicKey
          fun toString(): String
        class Node : CompositeKey
          Module Contents Node(threshold: Int, children: List<CompositeKey>, weights: List<Int>)
          val children: List<CompositeKey>
          fun equals(other: Any?): Boolean
          fun hashCode(): Int
          fun isFulfilledBy(keys: Iterable<PublicKey>): Boolean
          val keys: Set<PublicKey>
          val threshold: Int
          fun toString(): String
          val weights: List<Int>
        fun containsAny(otherKeys: Iterable<PublicKey>): <ERROR CLASS>
        abstract fun isFulfilledBy(keys: Iterable<PublicKey>): Boolean
        fun isFulfilledBy(key: PublicKey): <ERROR CLASS>
        abstract val keys: Set<PublicKey>
        fun parseFromBase58(encoded: String): <ERROR CLASS>
        val singleKey: PublicKey
        fun toBase58String(): String
      object CompositeKeyColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      class CompositeKeyGenerator
        Module Contents CompositeKeyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): CompositeKey
      object CompositeKeyLeafSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Leaf>): Leaf
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: Leaf): Unit
      object CompositeKeyNodeSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Node>): Node
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: Node): Unit
      class ConcatenatedList<A> : TransformationList<A, ObservableList<A>>
        Module Contents ConcatenatedList(sourceList: ObservableList<ObservableList<A>>)
        fun get(index: Int): A
        fun getSourceIndex(index: Int): Int
        val size: Int
        protected fun sourceChanged(change: Change<out ObservableList<A>>): Unit
      class Config
        Module Contents Config(services: ServiceHub)
        val defaultObjectMapper: <ERROR CLASS>
        fun getContext(type: Class<*>): <ERROR CLASS>
        val services: ServiceHub
      object ConfigHelper
        Module Contents fun loadConfig(baseDirectoryPath: Path, configFileOverride: Path? = null, allowMissingConfig: Boolean = false, configOverrides: Map<String, Any?> = emptyMap()): <ERROR CLASS>
        val log: <ERROR CLASS>
      class ConfigurationException : Exception
        Module Contents ConfigurationException(message: String)
      interface Contract
        Module Contents abstract val legalContractReference: SecureHash
        abstract fun verify(tx: TransactionForContract): Unit
      data class ContractClassRef : ContractDefRef
        Module Contents ContractClassRef(className: String)
        val className: String
      interface ContractDefRef
      data class ContractLedgerRef : ContractDefRef
        Module Contents ContractLedgerRef(hash: SecureHash)
        val hash: SecureHash
      interface ContractState
        Module Contents abstract val contract: Contract
        open val encumbrance: Int?
        abstract val participants: List<CompositeKey>
      class ContractStateGenerator
        Module Contents ContractStateGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): ContractState
      class ContractStateModel
        Module Contents ContractStateModel()
        val cash: ObservableList<Amount<Issued<Currency>>>
        val cashStates: ObservableList<StateAndRef<State>>
      abstract class CordaPluginRegistry
        Module Contents CordaPluginRegistry(webApis: List<Function<CordaRPCOps, out Any>> = emptyList(), staticServeDirs: Map<String, String> = emptyMap(), requiredFlows: Map<String, Set<String>> = emptyMap(), servicePlugins: List<Function<PluginServiceHub, out Any>> = emptyList())
        open fun registerRPCKryoTypes(kryo: <ERROR CLASS>): Boolean
        open val requiredFlows: Map<String, Set<String>>
        open val servicePlugins: List<Function<PluginServiceHub, out Any>>
        open val staticServeDirs: Map<String, String>
        open val webApis: List<Function<CordaRPCOps, out Any>>
      class CordaRPCClient : Closeable, ArtemisMessagingComponent
        Module Contents CordaRPCClient(host: <ERROR CLASS>, config: NodeSSLConfiguration)
        fun close(): Unit
        val config: NodeSSLConfiguration
        val host: <ERROR CLASS>
        fun proxy(timeout: Duration? = null, minVersion: Int = 0): CordaRPCOps
        fun start(username: String, password: String): Unit
      class CordaRPCClientImpl
        Module Contents CordaRPCClientImpl(session: <ERROR CLASS>, sessionLock: ReentrantLock, username: String)
        fun <T : RPCOps> proxyFor(rpcInterface: Class<T>, timeout: Duration? = null, minVersion: Int = 0): T
      interface CordaRPCOps : RPCOps
        Module Contents abstract fun addVaultTransactionNote(txnId: SecureHash, txnNote: String): Unit
        abstract fun attachmentExists(id: SecureHash): Boolean
        abstract fun currentNodeTime(): Instant
        abstract fun getVaultTransactionNotes(txnId: SecureHash): Iterable<String>
        @RPCReturnsObservables abstract fun networkMapUpdates(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
        abstract fun nodeIdentity(): NodeInfo
        abstract fun partyFromKey(key: CompositeKey): Party?
        abstract fun partyFromName(name: String): Party?
        @RPCReturnsObservables abstract fun <T : Any> startFlowDynamic(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowHandle<T>
        @RPCReturnsObservables abstract fun stateMachineRecordedTransactionMapping(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
        @RPCReturnsObservables abstract fun stateMachinesAndUpdates(): <ERROR CLASS><List<StateMachineInfo>, <ERROR CLASS><StateMachineUpdate>>
        abstract fun uploadAttachment(jar: InputStream): SecureHash
        @RPCReturnsObservables abstract fun vaultAndUpdates(): <ERROR CLASS><List<StateAndRef<ContractState>>, <ERROR CLASS><Update>>
        @RPCReturnsObservables abstract fun verifiedTransactions(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
      class CordaRPCOpsImpl : CordaRPCOps
        Module Contents CordaRPCOpsImpl(services: ServiceHub, smm: StateMachineManager, database: <ERROR CLASS>)
        fun addVaultTransactionNote(txnId: SecureHash, txnNote: String): Unit
        fun attachmentExists(id: SecureHash): Boolean
        fun currentNodeTime(): Instant
        val database: <ERROR CLASS>
        fun getVaultTransactionNotes(txnId: SecureHash): Iterable<String>
        fun networkMapUpdates(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
        fun nodeIdentity(): NodeInfo
        fun partyFromKey(key: CompositeKey): Party?
        fun partyFromName(name: String): Party?
        val protocolVersion: Int
        val services: ServiceHub
        val smm: StateMachineManager
        fun <T : Any> startFlowDynamic(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowHandle<T>
        fun stateMachineRecordedTransactionMapping(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
        fun stateMachinesAndUpdates(): <ERROR CLASS><List<StateMachineInfo>, <ERROR CLASS><StateMachineUpdate>>
        fun uploadAttachment(jar: InputStream): SecureHash
        fun vaultAndUpdates(): <ERROR CLASS><List<StateAndRef<ContractState>>, <ERROR CLASS><Update>>
        fun verifiedTransactions(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
      class CubicSplineInterpolator : Interpolator
        Module Contents CubicSplineInterpolator(xs: DoubleArray, ys: DoubleArray)
        fun create(xs: DoubleArray, ys: DoubleArray): CubicSplineInterpolator
        fun interpolate(x: Double): Double
      class CurrencyGenerator
        Module Contents CurrencyGenerator()
        val currencies: <ERROR CLASS>
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Currency
      class DBCheckpointStorage : CheckpointStorage
        Module Contents DBCheckpointStorage()
        fun addCheckpoint(checkpoint: Checkpoint): Unit
        fun forEach(block: (Checkpoint) -> Boolean): Unit
        fun removeCheckpoint(checkpoint: Checkpoint): Unit
      class DBTransactionMappingStorage : StateMachineRecordedTransactionMappingStorage
        Module Contents DBTransactionMappingStorage()
        fun addMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash): Unit
        fun track(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
      class DBTransactionStorage : TransactionStorage
        Module Contents DBTransactionStorage()
        fun addTransaction(transaction: SignedTransaction): Boolean
        fun getTransaction(id: SecureHash): SignedTransaction?
        fun track(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
        val transactions: Iterable<SignedTransaction>
        val updates: <ERROR CLASS><SignedTransaction>
        val updatesPublisher: <ERROR CLASS>
      class DataUploadServlet
        Module Contents DataUploadServlet()
        fun doPost(req: <ERROR CLASS>, resp: <ERROR CLASS>): Unit
      object DataVending
        Module Contents class Plugin : CordaPluginRegistry
          Module Contents Plugin()
          val servicePlugins: <ERROR CLASS>
        class Service : SingletonSerializeAsToken
          Module Contents Service(services: PluginServiceHub)
          class NotifyTransactionHandler : FlowLogic<Unit>
            Module Contents NotifyTransactionHandler(otherParty: Party)
            fun call(): Unit
            val otherParty: Party
          val logger: <ERROR CLASS>
      enum class DateRollConvention
        Module Contents Actual
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        Following
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        ModifiedFollowing
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        ModifiedPrevious
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        Previous
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        abstract fun direction(): DateRollDirection
        abstract val isModified: Boolean
      enum class DateRollDirection
        Module Contents BACKWARD
        FORWARD
        val value: Long
      enum class DayCountBasisDay
        Module Contents D30
        D30E
        D30F
        D30G
        D30N
        D30P
        D30Z
        DActual
        DActualJ
        DBus_SaoPaulo
        fun toString(): String
      enum class DayCountBasisYear
        Module Contents Y252
        Y360
        Y365
        Y365B
        Y365F
        Y365L
        Y365Q
        Y366
        YActual
        YActualA
        YICMA
        YISMA
        fun toString(): String
      interface DealState : LinearState
        Module Contents abstract fun generateAgreement(notary: Party): TransactionBuilder
        abstract val parties: List<Party>
        abstract val ref: String
      interface DeserializeAsKotlinObjectDef
      data class Diff<out T : ContractState>
        Module Contents Diff(added: Collection<StateAndRef<T>>, removed: Collection<StateAndRef<T>>)
        val added: Collection<StateAndRef<T>>
        val removed: Collection<StateAndRef<T>>
      open class DigitalSignature : OpaqueBytes
        Module Contents DigitalSignature(bits: ByteArray)
        class LegallyIdentifiable : WithKey
          Module Contents LegallyIdentifiable(signer: Party, bits: ByteArray)
          val signer: Party
        open class WithKey : DigitalSignature
          Module Contents WithKey(by: PublicKey, bits: ByteArray)
          val by: PublicKey
          fun verifyWithECDSA(content: ByteArray): Unit
          fun verifyWithECDSA(content: OpaqueBytes): Unit
      class DistributedImmutableMap<K : Any, V : Any>
        Module Contents DistributedImmutableMap(db: <ERROR CLASS>, tableName: String)
        object Commands
          Module Contents class Get<out K, V>
            Module Contents Get(key: K)
            val key: K
          class PutAll<K, V>
            Module Contents PutAll(entries: Map<K, V>)
            fun compaction(): <ERROR CLASS>
            val entries: Map<K, V>
          class Size
            Module Contents Size()
        val db: <ERROR CLASS>
        fun get(commit: <ERROR CLASS><Get<K, V>>): V?
        fun install(reader: <ERROR CLASS>): Unit
        fun put(commit: <ERROR CLASS><PutAll<K, V>>): Map<K, V>
        fun size(commit: <ERROR CLASS><Size>): Int
        fun snapshot(writer: <ERROR CLASS>): Unit
      abstract class DriverBasedTest
        Module Contents DriverBasedTest()
        protected sealed class RunTestToken
        protected fun DriverDSLExposedInterface.runTest(): RunTestToken
        protected abstract fun setup(): RunTestToken
        fun start(): Unit
        fun stop(): Unit
      open class DriverDSL : DriverDSLInternalInterface
        Module Contents DriverDSL(portAllocation: PortAllocation, debugPortAllocation: PortAllocation, driverDirectory: Path, useTestClock: Boolean, isDebug: Boolean)
        class State
          Module Contents State()
          val clients: LinkedList<NodeMessagingClient>
          val registeredProcesses: LinkedList<<ERROR CLASS><Process>>
        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: <ERROR CLASS><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?>): <ERROR CLASS><NodeHandle>
        open fun startNotaryCluster(notaryName: String, clusterSize: Int, type: ServiceType, rpcUsers: List<User>): <ERROR CLASS><<ERROR CLASS><Party, List<NodeHandle>>>
        val useTestClock: Boolean
        open fun waitForAllNodesToFinish(): Unit
      interface DriverDSLExposedInterface
        Module Contents abstract fun startNode(providedName: String? = null, advertisedServices: Set<ServiceInfo> = emptySet(), rpcUsers: List<User> = emptyList(), customOverrides: Map<String, Any?> = emptyMap()): <ERROR CLASS><NodeHandle>
        abstract fun startNotaryCluster(notaryName: String, clusterSize: Int = 3, type: ServiceType = RaftValidatingNotaryService.type, rpcUsers: List<User> = emptyList()): Future<<ERROR CLASS><Party, List<NodeHandle>>>
        abstract fun waitForAllNodesToFinish(): Unit
      interface DriverDSLInternalInterface : DriverDSLExposedInterface
        Module Contents abstract fun shutdown(): Unit
        abstract fun start(): Unit
      data class DummyContract : Contract
        Module Contents DummyContract(legalContractReference: SecureHash = SecureHash.sha256(""))
        interface Commands : CommandData
          Module Contents class Create : TypeOnlyCommandData, Commands
            Module Contents Create()
          class Move : TypeOnlyCommandData, Commands
            Module Contents Move()
        data class MultiOwnerState : ContractState, State
          Module Contents MultiOwnerState(magicNumber: Int = 0, owners: List<CompositeKey>)
          val contract: DummyContract
          val magicNumber: Int
          val owners: List<CompositeKey>
          val participants: List<CompositeKey>
        data class SingleOwnerState : OwnableState, State
          Module Contents SingleOwnerState(magicNumber: Int = 0, owner: CompositeKey)
          val contract: DummyContract
          val magicNumber: Int
          val owner: CompositeKey
          val participants: List<CompositeKey>
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        interface State : ContractState
          Module Contents abstract val magicNumber: Int
        fun generateInitial(owner: PartyAndReference, magicNumber: Int, notary: Party): TransactionBuilder
        val legalContractReference: SecureHash
        fun move(prior: StateAndRef<SingleOwnerState>, newOwner: CompositeKey): <ERROR CLASS>
        fun move(priors: List<StateAndRef<SingleOwnerState>>, newOwner: CompositeKey): TransactionBuilder
        fun verify(tx: TransactionForContract): Unit
      class DummyPublicKey : PublicKey, Comparable<PublicKey>
        Module Contents DummyPublicKey(s: String)
        fun compareTo(other: PublicKey): Int
        fun equals(other: Any?): Boolean
        fun getAlgorithm(): String
        fun getEncoded(): <ERROR CLASS>
        fun getFormat(): String
        fun hashCode(): Int
        val s: String
        fun toString(): String
      data class DummyState : ContractState
        Module Contents DummyState(magicNumber: Int = 0)
        val contract: DummyContract
        val magicNumber: Int
        val participants: List<CompositeKey>
      class DurationGenerator
        Module Contents DurationGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Duration
      class E2ETestKeyManagementService : SingletonSerializeAsToken, KeyManagementService
        Module Contents E2ETestKeyManagementService(initialKeys: Set<KeyPair>)
        fun freshKey(): KeyPair
        val keys: Map<PublicKey, PrivateKey>
      object Ed25519PrivateKeySerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<<ERROR CLASS>>): <ERROR CLASS>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: <ERROR CLASS>): Unit
      object Ed25519PublicKeySerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<<ERROR CLASS>>): <ERROR CLASS>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: <ERROR CLASS>): Unit
      object Emoji
        Module Contents const val CODE_BAG_OF_CASH: String
        const val CODE_COOL_GUY: String
        const val CODE_DIAMOND: String
        const val CODE_GREEN_TICK: String
        const val CODE_LEFT_ARROW: String
        const val CODE_NEWSPAPER: String
        const val CODE_PAPERCLIP: String
        const val CODE_RIGHT_ARROW: String
        const val CODE_SANTA_CLAUS: String
        val bagOfCash: String
        val coolGuy: String
        val diamond: String
        val emojiMode: ThreadLocal<Any>
        val hasEmojiTerminal: <ERROR CLASS>
        val leftArrow: String
        val newspaper: String
        val paperclip: String
        inline fun <T> renderIfSupported(body: () -> T): T
        fun renderIfSupported(obj: Any): String
        val rightArrow: String
        val santaClaus: String
      data class ErrorOr<out A>
        Module Contents ErrorOr(value: A)
        fun <B : Any> bind(function: (A) -> ErrorOr<B>): ErrorOr<B>
        inline fun <T : Any> catch(body: () -> T): ErrorOr<T>
        fun <B, C> combine(other: ErrorOr<B>, function: (A, B) -> C): ErrorOr<C>
        val error: Throwable?
        fun getOrThrow(): A
        fun <B> map(function: (A) -> B): <ERROR CLASS>
        fun <T> match(onValue: (A) -> T, onError: (Throwable) -> T): T
        fun of(t: Throwable): ErrorOr<Nothing>
        val value: A?
      class EventGenerator
        Module Contents EventGenerator(parties: List<Party>, notary: Party, currencies: List<Currency> = listOf(USD, GBP, CHF), issuers: List<Party> = parties)
        val amountGenerator: Generator<Amount<Currency>>
        val amountIssuedGenerator: Generator<Amount<Issued<Currency>>>
        val bankOfCordaExitGenerator: <ERROR CLASS>
        val bankOfCordaIssueGenerator: <ERROR CLASS>
        val cashStateGenerator: <ERROR CLASS>
        val clientCommandGenerator: <ERROR CLASS>
        val consumedGenerator: Generator<Set<StateRef>>
        val currencies: List<Currency>
        val currencyGenerator: Generator<Currency>
        val exitCashGenerator: Generator<ExitCash>
        val issueCashGenerator: Generator<IssueCash>
        val issueRefGenerator: Generator<OpaqueBytes>
        val issuedGenerator: Generator<Issued<Currency>>
        val issuerGenerator: Generator<PartyAndReference>
        val issuers: List<Party>
        val moveCashGenerator: Generator<PayCash>
        val notary: Party
        val parties: List<Party>
        val partyGenerator: Generator<Party>
        val producedGenerator: Generator<Set<StateAndRef<ContractState>>>
        val publicKeyGenerator: <ERROR CLASS>
      interface ExchangeRate
        Module Contents abstract fun rate(from: Currency, to: Currency): Double
      class ExchangeRateModel
        Module Contents ExchangeRateModel()
        val exchangeRate: ObservableValue<ExchangeRate>
      class ExitGenerator
        Module Contents ExitGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Exit
      data class Expression
        Module Contents Expression(expr: String)
        val expr: String
      object ExpressionDeserializer
        Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): Expression
      object ExpressionSerializer
        Module Contents fun serialize(expr: Expression, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
      class FetchAttachmentsFlow : FetchDataFlow<Attachment, ByteArray>
        Module Contents FetchAttachmentsFlow(requests: Set<SecureHash>, otherSide: Party)
        protected fun convert(wire: ByteArray): Attachment
        protected fun load(txid: SecureHash): Attachment?
        protected fun maybeWriteToDisk(downloaded: List<Attachment>): Unit
      abstract class FetchDataFlow<T : NamedByHash, in W : Any> : FlowLogic<Result<T>>
        Module Contents FetchDataFlow(requests: Set<SecureHash>, otherSide: Party)
        open class BadAnswer : Exception
          Module Contents BadAnswer()
        class DownloadedVsRequestedDataMismatch : BadAnswer
          Module Contents DownloadedVsRequestedDataMismatch(requested: SecureHash, got: SecureHash)
          val got: SecureHash
          val requested: SecureHash
        class HashNotFound : BadAnswer
          Module Contents HashNotFound(requested: SecureHash)
          val requested: SecureHash
        data class Request
          Module Contents Request(hashes: List<SecureHash>)
          val hashes: List<SecureHash>
        data class Result<out T : NamedByHash>
          Module Contents Result(fromDisk: List<T>, downloaded: List<T>)
          val downloaded: List<T>
          val fromDisk: List<T>
        open fun call(): Result<T>
        protected open fun convert(wire: W): T
        protected abstract fun load(txid: SecureHash): T?
        protected open fun maybeWriteToDisk(downloaded: List<T>): Unit
        protected val otherSide: Party
        protected val requests: Set<SecureHash>
      class FetchTransactionsFlow : FetchDataFlow<SignedTransaction, SignedTransaction>
        Module Contents FetchTransactionsFlow(requests: Set<SecureHash>, otherSide: Party)
        protected fun load(txid: SecureHash): SignedTransaction?
      class FiberBox<out T>
        Module Contents FiberBox(content: T, lock: Lock = ReentrantLock())
        fun <R> read(body: T.() -> R): R
        fun <R> readWithDeadline(clock: Clock, deadline: Instant, body: T.() -> R): R
        fun <R> write(body: T.() -> R): R
      class FilterFuns
        Module Contents FilterFuns(filterInputs: (StateRef) -> Boolean = { false }, filterOutputs: (TransactionState<ContractState>) -> Boolean = { false }, filterAttachments: (SecureHash) -> Boolean = { false }, filterCommands: (Command) -> Boolean = { false })
        val filterAttachments: (SecureHash) -> Boolean
        val filterCommands: (Command) -> Boolean
        val filterInputs: (StateRef) -> Boolean
        val filterOutputs: (TransactionState<ContractState>) -> Boolean
        fun <T : Any> genericFilter(elem: T): Boolean
      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
        Module Contents FilteredLeaves(inputs: List<StateRef>, outputs: List<TransactionState<ContractState>>, attachments: List<SecureHash>, commands: List<Command>)
        val attachments: List<SecureHash>
        val commands: List<Command>
        fun getFilteredHashes(): List<SecureHash>
        val inputs: List<StateRef>
        val outputs: List<TransactionState<ContractState>>
      class FilteredTransaction
        Module Contents FilteredTransaction(filteredLeaves: FilteredLeaves, partialMerkleTree: PartialMerkleTree)
        fun buildMerkleTransaction(wtx: WireTransaction, filterFuns: FilterFuns): FilteredTransaction
        val filteredLeaves: FilteredLeaves
        val partialMerkleTree: PartialMerkleTree
        fun verify(merkleRootHash: SecureHash): Boolean
      class FinalityFlow : FlowLogic<Unit>
        Module Contents FinalityFlow(transaction: SignedTransaction, participants: Set<Party>)
        FinalityFlow(transaction: SignedTransaction, participants: Set<Party>, progressTracker: ProgressTracker)
        object BROADCASTING : Step
        object NOTARISING : Step
        fun call(): Unit
        val participants: Set<Party>
        val progressTracker: ProgressTracker
        fun tracker(): ProgressTracker
        val transaction: SignedTransaction
      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
        Module Contents Fix(of: FixOf, value: BigDecimal)
        val of: FixOf
        val value: BigDecimal
      data class FixOf
        Module Contents FixOf(name: String, forDay: LocalDate, ofTenor: Tenor)
        val forDay: LocalDate
        val name: String
        val ofTenor: Tenor
      interface FixableDealState : DealState
        Module Contents abstract fun generateFix(ptx: TransactionBuilder, oldState: StateAndRef<*>, fix: Fix): Unit
        abstract fun nextFixingOf(): FixOf?
        abstract val oracleType: ServiceType
      class FlattenedList<A> : TransformationList<A, ObservableValue<out A>>
        Module Contents FlattenedList(sourceList: ObservableList<out ObservableValue<out A>>)
        class WrappedObservableValue<A>
          Module Contents WrappedObservableValue(observableValue: ObservableValue<A>)
          val observableValue: ObservableValue<A>
        fun get(index: Int): A
        fun getSourceIndex(index: Int): Int
        val indexMap: HashMap<WrappedObservableValue<out A>, <ERROR CLASS><Int, ChangeListener<A>>>
        val size: Int
        protected fun sourceChanged(c: Change<out ObservableValue<out A>>): Unit
        val sourceList: ObservableList<out ObservableValue<out A>>
      data class FlowClassRef : FlowRef
        Module Contents FlowClassRef(className: String)
        val className: String
      data class FlowHandle<A>
        Module Contents FlowHandle(id: StateMachineRunId, progress: <ERROR CLASS><String>, returnValue: <ERROR CLASS><A>)
        val id: StateMachineRunId
        val progress: <ERROR CLASS><String>
        val returnValue: <ERROR CLASS><A>
      interface FlowIORequest
        Module Contents abstract val session: FlowSession
        abstract val stackTraceInCaseOfProblems: StackSnapshot
      data class FlowInstanceRef
        Module Contents FlowInstanceRef(flowInstance: SecureHash, flowClass: FlowClassRef, flowStepId: String)
        val flowClass: FlowClassRef
        val flowInstance: SecureHash
        val flowStepId: String
      abstract class FlowLogic<out T>
        Module Contents FlowLogic()
        abstract fun call(): T
        lateinit var fsm: FlowStateMachine<*>
        open fun getCounterpartyMarker(party: Party): Class<*>
        val logger: <ERROR CLASS>
        open val progressTracker: ProgressTracker?
        inline fun <reified T : Any> receive(otherParty: Party): UntrustworthyData<T>
        fun <T : Any> receive(receiveType: Class<T>, otherParty: Party): UntrustworthyData<T>
        fun send(otherParty: Party, payload: Any): Unit
        inline fun <reified T : Any> sendAndReceive(otherParty: Party, payload: Any): UntrustworthyData<T>
        fun <T : Any> sendAndReceive(receiveType: Class<T>, otherParty: Party, payload: Any): UntrustworthyData<T>
        val serviceHub: ServiceHub
        fun <R> subFlow(subLogic: FlowLogic<R>, shareParentSessions: Boolean = false): R
        fun track(): <ERROR CLASS><String, <ERROR CLASS><String>>?
      data class FlowLogicRef
        Module Contents val appContext: AppContext
        val args: Map<String, Any?>
        val flowLogicClassName: String
      class FlowLogicRefFactory : SingletonSerializeAsToken
        Module Contents FlowLogicRefFactory()
        FlowLogicRefFactory(flowWhitelist: Map<String, Set<String>>)
        fun create(type: Class<out FlowLogic<*>>, vararg args: Any?): FlowLogicRef
        fun createKotlin(flowLogicClassName: String, args: Map<String, Any?>, attachments: List<SecureHash> = emptyList()): FlowLogicRef
        fun createKotlin(type: Class<out FlowLogic<*>>, args: Map<String, Any?>): FlowLogicRef
        fun toFlowLogic(ref: FlowLogicRef): FlowLogic<*>
      interface FlowRef
      data class FlowRequiringAttention
        Module Contents FlowRequiringAttention(ref: FlowInstanceRef, prompt: String, choiceIdsToMessages: Map<SecureHash, String>, dueBy: Instant)
        val choiceIdsToMessages: Map<SecureHash, String>
        val dueBy: Instant
        val prompt: String
        val ref: FlowInstanceRef
      class FlowSessionException : Exception
        Module Contents FlowSessionException(message: String)
      interface FlowStateMachine<R>
        Module Contents abstract val id: StateMachineRunId
        abstract val logger: <ERROR CLASS>
        abstract fun <T : Any> receive(otherParty: Party, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        abstract val resultFuture: <ERROR CLASS><R>
        abstract fun send(otherParty: Party, payload: Any, sessionFlow: FlowLogic<*>): Unit
        abstract fun <T : Any> sendAndReceive(otherParty: Party, payload: Any, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        abstract val serviceHub: ServiceHub
      class FlowStateMachineImpl<R> : FlowStateMachine<R>
        Module Contents FlowStateMachineImpl(id: StateMachineRunId, logic: FlowLogic<R>, scheduler: FiberScheduler)
        fun currentStateMachine(): FlowStateMachineImpl<*>?
        val id: StateMachineRunId
        val logger: <ERROR CLASS>
        val logic: FlowLogic<R>
        fun <T : Any> receive(otherParty: Party, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        val resultFuture: <ERROR CLASS><R>
        fun run(): R
        fun send(otherParty: Party, payload: Any, sessionFlow: FlowLogic<*>): Unit
        fun <T : Any> sendAndReceive(otherParty: Party, payload: Any, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        lateinit var serviceHub: ServiceHubInternal
      data class FlowStatus
        Module Contents FlowStatus(status: String)
        val status: String
      enum class Frequency
        Module Contents Annual
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        BiWeekly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Daily
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Monthly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Quarterly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        SemiAnnual
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Weekly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        val annualCompoundCount: Int
        abstract fun offset(d: LocalDate, n: Long = 1): LocalDate
      class FullNodeConfiguration : NodeConfiguration
        Module Contents FullNodeConfiguration(config: <ERROR CLASS>)
        val artemisAddress: <ERROR CLASS>
        val basedir: Path
        val config: <ERROR CLASS>
        fun createNode(): Node
        val dataSourceProperties: Properties
        val devMode: Boolean
        val emailAddress: String
        val exportJMXto: String
        val extraAdvertisedServiceIds: String
        val keyStorePassword: String
        val messagingServerAddress: <ERROR CLASS>?
        val myLegalName: String
        val nearestCity: String
        val networkMapAddress: <ERROR CLASS>?
        val notaryClusterAddresses: List<<ERROR CLASS>>
        val notaryNodeAddress: <ERROR CLASS>?
        val rpcUsers: List<User>
        val trustStorePassword: String
        val useHTTPS: Boolean
        val useTestClock: Boolean
        val webAddress: <ERROR CLASS>
      interface FungibleAsset<T> : OwnableState
        Module Contents interface Commands : CommandData
          Module Contents interface Exit<T> : Commands
            Module Contents abstract val amount: Amount<Issued<T>>
          interface Issue : IssueCommand, Commands
          interface Move : MoveCommand, Commands
        abstract val amount: Amount<Issued<T>>
        abstract val exitKeys: Collection<CompositeKey>
        abstract fun move(newAmount: Amount<Issued<T>>, newOwner: CompositeKey): FungibleAsset<T>
        abstract val owner: CompositeKey
      data class GatheredTransactionData
        Module Contents GatheredTransactionData(transaction: PartiallyResolvedTransaction, stateMachines: ObservableList<out StateMachineData>)
        val stateMachines: ObservableList<out StateMachineData>
        val transaction: PartiallyResolvedTransaction
      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
        Module Contents HTTPCertificateSigningService(server: URL)
        val clientVersion: String
        fun retrieveCertificates(requestId: String): Array<Certificate>?
        val server: URL
        fun submitRequest(request: <ERROR CLASS>): String
      class HibernateObserver
        Module Contents HibernateObserver(services: ServiceHubInternal)
        class NodeDatabaseConnectionProvider
          Module Contents NodeDatabaseConnectionProvider()
          fun closeConnection(conn: Connection): Unit
          fun getConnection(): Connection
          fun isUnwrappableAs(unwrapType: Class<*>?): Boolean
          fun supportsAggressiveRelease(): Boolean
          fun <T> unwrap(unwrapType: Class<T>): T
        val logger: <ERROR CLASS>
        val schemaService: SchemaService
        val sessionFactories: ConcurrentHashMap<MappedSchema, <ERROR CLASS>>
      interface IdentityService
        Module Contents abstract fun getAllIdentities(): Iterable<Party>
        abstract fun partyFromKey(key: CompositeKey): Party?
        abstract fun partyFromName(name: String): Party?
        abstract fun registerIdentity(party: Party): Unit
      class IllegalFlowLogicException : IllegalArgumentException
        Module Contents IllegalFlowLogicException(type: Class<*>, msg: String)
      class ImmutableClassSerializer<T : Any>
        Module Contents ImmutableClassSerializer(klass: KClass<T>)
        val constructor: <ERROR CLASS>
        val klass: KClass<T>
        val props: <ERROR CLASS>
        val propsByName: <ERROR CLASS>
        fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<T>): T
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: T): Unit
      class InMemoryIdentityService : SingletonSerializeAsToken, IdentityService
        Module Contents InMemoryIdentityService()
        fun getAllIdentities(): Iterable<Party>
        fun partyFromKey(key: CompositeKey): Party?
        fun partyFromName(name: String): Party?
        fun registerIdentity(party: Party): Unit
      open class InMemoryNetworkMapCache : SingletonSerializeAsToken, NetworkMapCache
        Module Contents InMemoryNetworkMapCache()
        open fun addMapService(net: MessagingService, networkMapAddress: SingleMessageRecipient, subscribe: Boolean, ifChangedSinceVer: Int?): <ERROR CLASS><Unit>
        open fun addNode(node: NodeInfo): Unit
        open val changed: <ERROR CLASS><MapChange>
        open fun deregisterForUpdates(net: MessagingService, service: NodeInfo): <ERROR CLASS><Unit>
        open fun getPartyInfo(party: Party): PartyInfo?
        val logger: <ERROR CLASS>
        open val mapServiceRegistered: <ERROR CLASS><Unit>
        open val networkMapNodes: List<NodeInfo>
        open val partyNodes: List<NodeInfo>
        fun processUpdatePush(req: Update): Unit
        protected var registeredNodes: MutableMap<Party, NodeInfo>
        open fun removeNode(node: NodeInfo): Unit
        open fun runWithoutMapService(): Unit
        open fun track(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
      class InMemoryNetworkMapService : AbstractNetworkMapService
        Module Contents InMemoryNetworkMapService(services: ServiceHubInternal)
        protected val registeredNodes: MutableMap<Party, NodeRegistrationInfo>
        protected val subscribers: <ERROR CLASS>
      class InMemoryStateMachineRecordedTransactionMappingStorage : StateMachineRecordedTransactionMappingStorage
        Module Contents InMemoryStateMachineRecordedTransactionMappingStorage()
        fun addMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash): Unit
        fun track(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
      class InMemoryUniquenessProvider : UniquenessProvider
        Module Contents InMemoryUniquenessProvider()
        fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      class InputStateRefResolveFailed : Exception
        Module Contents InputStateRefResolveFailed(stateRefs: List<StateRef>)
      object InputStreamSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<InputStream>): InputStream
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, stream: InputStream): Unit
      object InstantColumnType
        Module Contents fun nonNullValueToString(value: Any): String
        fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      class InstantGenerator
        Module Contents InstantGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Instant
      class InsufficientBalanceException : Exception
        Module Contents InsufficientBalanceException(amountMissing: Amount<*>)
        val amountMissing: Amount<*>
        fun toString(): String
      interface Interpolator
        Module Contents abstract fun interpolate(x: Double): Double
      interface InterpolatorFactory
        Module Contents abstract fun create(xs: DoubleArray, ys: DoubleArray): Interpolator
      interface IssuanceDefinition
      interface IssueCommand : CommandData
        Module Contents abstract val nonce: Long
      class IssueGenerator
        Module Contents IssueGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Issue
      data class Issued<out P>
        Module Contents Issued(issuer: PartyAndReference, product: P)
        val issuer: PartyAndReference
        val product: P
        fun toString(): String
      class IssuedGenerator<T>
        Module Contents IssuedGenerator(productGenerator: <ERROR CLASS><T>)
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Issued<T>
        val productGenerator: <ERROR CLASS><T>
      object IssuerFlow
        Module Contents data class IssuanceRequestState
          Module Contents IssuanceRequestState(amount: Amount<Currency>, issueToParty: Party, issuerPartyRef: OpaqueBytes)
          val amount: Amount<Currency>
          val issueToParty: Party
          val issuerPartyRef: OpaqueBytes
        class IssuanceRequester : FlowLogic<SignedTransaction>
          Module Contents IssuanceRequester(amount: Amount<Currency>, issueToParty: Party, issueToPartyRef: OpaqueBytes, issuerBankParty: Party)
          val amount: Amount<Currency>
          fun call(): SignedTransaction
          val issueToParty: Party
          val issueToPartyRef: OpaqueBytes
          val issuerBankParty: Party
        class Issuer : FlowLogic<SignedTransaction>
          Module Contents Issuer(otherParty: Party)
          object AWAITING_REQUEST : Step
          object ISSUING : Step
          object SENDING_CONFIRM : Step
          class Service
            Module Contents Service(services: PluginServiceHub)
          object TRANSFERRING : Step
          fun call(): SignedTransaction
          val otherParty: Party
          val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
      class JDBCHashMap<K : Any, V : Any> : AbstractJDBCHashMap<K, V, BlobMapTable>
        Module Contents JDBCHashMap(tableName: String, loadOnInit: Boolean = false, maxBuckets: Int = DEFAULT_MAX_BUCKETS)
        class BlobMapTable : JDBCHashedTable
          Module Contents BlobMapTable(tableName: String)
          val key: <ERROR CLASS>
          val value: <ERROR CLASS>
        protected fun addKeyToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
        protected fun addValueToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
        protected fun keyFromRow(row: <ERROR CLASS>): K
        protected fun valueFromRow(row: <ERROR CLASS>): V
      class JDBCHashSet<K : Any> : AbstractJDBCHashSet<K, BlobSetTable>
        Module Contents JDBCHashSet(tableName: String, loadOnInit: Boolean = false, maxBuckets: Int = DEFAULT_MAX_BUCKETS)
        class BlobSetTable : JDBCHashedTable
          Module Contents BlobSetTable(tableName: String)
          val key: <ERROR CLASS>
        protected fun addElementToInsert(insert: <ERROR CLASS>, entry: K, finalizables: MutableList<() -> Unit>): Unit
        protected fun elementFromRow(row: <ERROR CLASS>): K
      open class JDBCHashedTable
        Module Contents JDBCHashedTable(tableName: String)
        val keyHash: <ERROR CLASS>
        val seqNo: <ERROR CLASS>
      object JsonSupport
        Module Contents object CalendarDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): BusinessCalendar
        object CompositeKeyDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): CompositeKey
        object CompositeKeySerializer
          Module Contents fun serialize(obj: CompositeKey, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        object LocalDateDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): LocalDate
        object LocalDateKeyDeserializer
          Module Contents fun deserializeKey(text: String, p1: <ERROR CLASS>): Any?
        object NodeInfoDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): NodeInfo
        object NodeInfoSerializer
          Module Contents fun serialize(value: NodeInfo, gen: <ERROR CLASS>, serializers: <ERROR CLASS>): Unit
        object PartyDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): Party
        object PartySerializer
          Module Contents fun serialize(obj: Party, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        object PublicKeyDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): <ERROR CLASS>
        object PublicKeySerializer
          Module Contents fun serialize(obj: <ERROR CLASS>, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        class SecureHashDeserializer<T : SecureHash>
          Module Contents SecureHashDeserializer()
          fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): T
        object SecureHashSerializer
          Module Contents fun serialize(obj: SecureHash, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        class ServiceHubObjectMapper
          Module Contents ServiceHubObjectMapper(identities: IdentityService)
          val identities: IdentityService
        object ToStringSerializer
          Module Contents fun serialize(obj: Any, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        fun createDefaultMapper(identities: IdentityService): <ERROR CLASS>
      interface KeyManagementService
        Module Contents abstract fun freshKey(): KeyPair
        abstract val keys: Map<PublicKey, PrivateKey>
        open fun toKeyPair(publicKey: PublicKey): KeyPair
        open fun toKeyPair(publicKeys: Iterable<PublicKey>): <ERROR CLASS>
        open fun toPrivate(publicKey: PublicKey): PrivateKey
      object KotlinObjectSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<DeserializeAsKotlinObjectDef>): DeserializeAsKotlinObjectDef
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: DeserializeAsKotlinObjectDef): Unit
      data class LastAcknowledgeInfo
        Module Contents LastAcknowledgeInfo(mapVersion: Int)
        val mapVersion: Int
      class LedgerTransaction : BaseTransaction
        Module Contents LedgerTransaction(inputs: List<StateAndRef<*>>, outputs: List<TransactionState<ContractState>>, commands: List<AuthenticatedObject<CommandData>>, attachments: List<Attachment>, id: SecureHash, notary: Party?, signers: List<CompositeKey>, timestamp: Timestamp?, type: TransactionType)
        val attachments: List<Attachment>
        val commands: List<AuthenticatedObject<CommandData>>
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        val id: SecureHash
        val inputs: List<StateAndRef<*>>
        fun <T : ContractState> outRef(index: Int): StateAndRef<T>
        fun toTransactionForContract(): TransactionForContract
        fun verify(): Unit
      class LeftOuterJoinedMap<K : Any, A, B, C> : ReadOnlyBackedObservableMapBase<K, C, SimpleObjectProperty<B?>>
        Module Contents LeftOuterJoinedMap(leftTable: ObservableMap<K, out A>, rightTable: ObservableMap<K, out B>, assemble: (K, A, ObservableValue<B?>) -> C)
        val leftTable: ObservableMap<K, out A>
        val rightTable: ObservableMap<K, out B>
      class LinearInterpolator : Interpolator
        Module Contents LinearInterpolator(xs: DoubleArray, ys: DoubleArray)
        fun create(xs: DoubleArray, ys: DoubleArray): LinearInterpolator
        fun interpolate(x: Double): Double
      interface LinearState : ContractState
        Module Contents class ClauseVerifier<S : LinearState, C : CommandData> : Clause<S, C, Unit>
          Module Contents ClauseVerifier()
          fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
        abstract fun isRelevant(ourKeys: Set<PublicKey>): Boolean
        abstract val linearId: UniqueIdentifier
      object LocalDateColumnType
        Module Contents fun nonNullValueToString(value: Any): String
        fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      object LocalDateTimeColumnType
        Module Contents fun nonNullValueToString(value: Any): String
        fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      object LogHelper
        Module Contents fun reset(vararg names: String): Unit
        fun reset(vararg classes: KClass<*>): <ERROR CLASS>
        fun setLevel(vararg loggerNames: String): Unit
        fun setLevel(vararg classes: KClass<*>): <ERROR CLASS>
      class MapValuesList<K, A, C> : ObservableList<C>
        Module Contents fun <K, A, C> create(sourceMap: ObservableMap<K, A>, assemble: (Entry<K, A>) -> C): MapValuesList<K, A, C>
        val sourceMap: ObservableMap<K, A>
      class MappedList<A, B> : TransformationList<B, A>
        Module Contents MappedList(list: ObservableList<A>, function: (A) -> B)
        val function: (A) -> B
        fun get(index: Int): B
        fun getSourceIndex(index: Int): Int
        val size: Int
        protected fun sourceChanged(change: Change<out A>): Unit
      abstract class MappedSchema
        Module Contents MappedSchema(schemaFamily: Class<*>, version: Int, mappedTypes: Iterable<Class<*>>)
        val mappedTypes: Iterable<Class<*>>
        val name: String
        open fun toString(): String
        val version: Int
      data class MarshalledObservation
        Module Contents MarshalledObservation(forHandle: Int, what: <ERROR CLASS><out <ERROR CLASS>>)
        val forHandle: Int
        val what: <ERROR CLASS><out <ERROR CLASS>>
      sealed class MerkleTree
        Module Contents class DuplicatedLeaf : MerkleTree
          Module Contents DuplicatedLeaf(value: SecureHash)
          val value: SecureHash
        class Leaf : MerkleTree
          Module Contents Leaf(value: SecureHash)
          val value: SecureHash
        class Node : MerkleTree
          Module Contents Node(value: SecureHash, left: MerkleTree, right: MerkleTree)
          val left: MerkleTree
          val right: MerkleTree
          val value: SecureHash
        fun getMerkleTree(allLeavesHashes: List<SecureHash>): MerkleTree
        val hash: SecureHash
        fun hashNodes(right: MerkleTree): MerkleTree
      class MerkleTreeException : Exception
        Module Contents MerkleTreeException(reason: String)
        val reason: String
        fun toString(): String
      interface Message
        Module Contents abstract val data: ByteArray
        abstract val debugTimestamp: Instant
        abstract val topicSession: TopicSession
        abstract val uniqueMessageId: UUID
      interface MessageHandlerRegistration
      interface MessageRecipientGroup : MessageRecipients
      interface MessageRecipients
      interface MessagingService
        Module Contents abstract fun addMessageHandler(topic: String = "", sessionID: Long = DEFAULT_SESSION_ID, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        abstract fun addMessageHandler(topicSession: TopicSession, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        abstract fun createMessage(topicSession: TopicSession, data: ByteArray, uuid: UUID = UUID.randomUUID()): Message
        abstract fun getAddressOfParty(partyInfo: PartyInfo): MessageRecipients
        abstract val myAddress: SingleMessageRecipient
        abstract fun removeMessageHandler(registration: MessageHandlerRegistration): Unit
        abstract fun send(message: Message, target: MessageRecipients): Unit
      interface MessagingServiceBuilder<out T : MessagingServiceInternal>
        Module Contents abstract fun start(): <ERROR CLASS><out T>
      interface MessagingServiceInternal : MessagingService
        Module Contents abstract fun stop(): Unit
      class MissingAttachmentsException : Exception
        Module Contents MissingAttachmentsException(ids: List<SecureHash>)
        val ids: List<SecureHash>
      object Models
        Module Contents fun <M : Any> get(klass: KClass<M>, origin: KClass<*>): M
        inline fun <reified M : Any> get(origin: KClass<*>): M
        fun <M : Any> initModel(klass: KClass<M>): <ERROR CLASS>
      class MonitoringService : SingletonSerializeAsToken
        Module Contents MonitoringService(metrics: <ERROR CLASS>)
        val metrics: <ERROR CLASS>
      interface MoveCommand : CommandData
        Module Contents abstract val contractHash: SecureHash?
      class MoveGenerator
        Module Contents MoveGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Move
      data class MultilateralNetState<P> : NetState<P>
        Module Contents MultilateralNetState(template: Terms<P>)
        val template: Terms<P>
      interface MultilateralNettableState<out T : Any>
        Module Contents abstract val multilateralNetState: T
      abstract class MutableClock : Clock
        Module Contents MutableClock()
        val mutationCount: Long
        val mutations: <ERROR CLASS><Long>
        protected fun notifyMutationObservers(): Unit
      interface NamedByHash
        Module Contents abstract val id: SecureHash
      open class NetClause<C : CommandData, P> : Clause<ContractState, C, Unit>
        Module Contents NetClause()
        open val requiredCommands: Set<Class<out CommandData>>
        open fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
        fun verifyNetCommand(inputs: List<State<P>>, outputs: List<State<P>>, command: AuthenticatedObject<NetCommand>, netState: NetState<P>): Unit
      interface NetCommand : CommandData
        Module Contents abstract val type: NetType
      interface NetState<P>
        Module Contents abstract val template: Terms<P>
      enum class NetType
        Module Contents CLOSE_OUT
        PAYMENT
      interface NettableState<N : BilateralNettableState<N>, T : Any> : BilateralNettableState<N>, MultilateralNettableState<T>
      sealed class NetworkCacheError : Exception
        Module Contents class DeregistrationFailed : NetworkCacheError
          Module Contents DeregistrationFailed()
      class NetworkIdentityModel
        Module Contents NetworkIdentityModel()
        fun lookup(compositeKey: CompositeKey): ObservableValue<NodeInfo?>
        fun lookup(publicKey: PublicKey): ObservableValue<NodeInfo?>
        val myIdentity: ObservableValue<NodeInfo?>
        val networkIdentities: ObservableList<NodeInfo>
        val notaries: ObservableList<NodeInfo>
        val parties: ObservableList<NodeInfo>
      interface NetworkMapCache
        Module Contents sealed class MapChange
          Module Contents class Added : MapChange
            Module Contents Added(node: NodeInfo)
          class Modified : MapChange
            Module Contents Modified(node: NodeInfo, previousNode: NodeInfo)
            val previousNode: NodeInfo
          class Removed : MapChange
            Module Contents Removed(node: NodeInfo)
          val node: NodeInfo
        abstract fun addMapService(net: MessagingService, networkMapAddress: SingleMessageRecipient, subscribe: Boolean, ifChangedSinceVer: Int? = null): <ERROR CLASS><Unit>
        abstract fun addNode(node: NodeInfo): Unit
        abstract val changed: <ERROR CLASS><MapChange>
        abstract fun deregisterForUpdates(net: MessagingService, service: NodeInfo): <ERROR CLASS><Unit>
        open fun getAnyNotary(type: ServiceType? = null): Party?
        open fun getNodeByLegalIdentityKey(compositeKey: CompositeKey): NodeInfo?
        open fun getNodeByLegalName(name: String): NodeInfo?
        open fun getNodesByAdvertisedServiceIdentityKey(compositeKey: CompositeKey): List<NodeInfo>
        open fun getNodesWithService(serviceType: ServiceType): List<NodeInfo>
        open fun getNotary(name: String): Party?
        abstract fun getPartyInfo(party: Party): PartyInfo?
        open fun getRecommended(type: ServiceType, contract: Contract, vararg party: Party): NodeInfo?
        open fun isNotary(party: Party): Boolean
        abstract val mapServiceRegistered: <ERROR CLASS><Unit>
        abstract val networkMapNodes: List<NodeInfo>
        open val notaryNodes: List<NodeInfo>
        abstract val partyNodes: List<NodeInfo>
        open val regulatorNodes: List<NodeInfo>
        abstract fun removeNode(node: NodeInfo): Unit
        abstract fun runWithoutMapService(): Unit
        abstract fun track(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
      interface NetworkMapService
        Module Contents val DEFAULT_EXPIRATION_PERIOD: Period
        val FETCH_FLOW_TOPIC: String
        class FetchMapRequest : ServiceRequestMessage
          Module Contents FetchMapRequest(subscribe: Boolean, ifChangedSinceVersion: Int?, replyTo: SingleMessageRecipient, sessionID: Long = random63BitValue())
          val ifChangedSinceVersion: Int?
          val replyTo: SingleMessageRecipient
          val sessionID: Long
          val subscribe: Boolean
        data class FetchMapResponse
          Module Contents FetchMapResponse(nodes: Collection<NodeRegistration>?, version: Int)
          val nodes: Collection<NodeRegistration>?
          val version: Int
        val PUSH_ACK_FLOW_TOPIC: String
        val PUSH_FLOW_TOPIC: String
        val QUERY_FLOW_TOPIC: String
        class QueryIdentityRequest : ServiceRequestMessage
          Module Contents QueryIdentityRequest(identity: Party, replyTo: SingleMessageRecipient, sessionID: Long)
          val identity: Party
          val replyTo: SingleMessageRecipient
          val sessionID: Long
        data class QueryIdentityResponse
          Module Contents QueryIdentityResponse(node: NodeInfo?)
          val node: NodeInfo?
        val REGISTER_FLOW_TOPIC: String
        class RegistrationRequest : ServiceRequestMessage
          Module Contents RegistrationRequest(wireReg: WireNodeRegistration, replyTo: SingleMessageRecipient, sessionID: Long = random63BitValue())
          val replyTo: SingleMessageRecipient
          val sessionID: Long
          val wireReg: WireNodeRegistration
        data class RegistrationResponse
          Module Contents RegistrationResponse(success: Boolean)
          val success: Boolean
        val SUBSCRIPTION_FLOW_TOPIC: String
        class SubscribeRequest : ServiceRequestMessage
          Module Contents SubscribeRequest(subscribe: Boolean, replyTo: SingleMessageRecipient, sessionID: Long = random63BitValue())
          val replyTo: SingleMessageRecipient
          val sessionID: Long
          val subscribe: Boolean
        data class SubscribeResponse
          Module Contents SubscribeResponse(confirmed: Boolean)
          val confirmed: Boolean
        data class Update
          Module Contents Update(wireReg: WireNodeRegistration, mapVersion: Int, replyTo: MessageRecipients)
          val mapVersion: Int
          val replyTo: MessageRecipients
          val wireReg: WireNodeRegistration
        data class UpdateAcknowledge
          Module Contents UpdateAcknowledge(mapVersion: Int, replyTo: MessageRecipients)
          val mapVersion: Int
          val replyTo: MessageRecipients
        val logger: <ERROR CLASS>
        abstract val nodes: List<NodeInfo>
        val type: ServiceType
      class NoReferencesSerializer<T>
        Module Contents NoReferencesSerializer(baseSerializer: <ERROR CLASS><T>)
        val baseSerializer: <ERROR CLASS><T>
        fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<T>): T
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: T): Unit
      open class NoZeroSizedOutputs<in S : FungibleAsset<T>, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
        Module Contents NoZeroSizedOutputs()
        open fun toString(): String
        open fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Issued<T>?): Set<C>
      class Node : AbstractNode
        Module Contents Node(configuration: FullNodeConfiguration, networkMapAddress: SingleMessageRecipient?, advertisedServices: Set<ServiceInfo>, clock: Clock = NodeClock())
        val configuration: FullNodeConfiguration
        protected fun initialiseDatabasePersistence(insideTransaction: () -> Unit): Unit
        protected val log: <ERROR CLASS>
        protected fun makeMessagingService(): MessagingServiceInternal
        protected fun makeUniquenessProvider(type: ServiceType): UniquenessProvider
        var messageBroker: ArtemisMessagingServer?
        fun run(): Unit
        protected val serverThread: ServiceAffinityExecutor
        fun setup(): Node
        fun start(): Node
        protected fun startMessagingService(rpcOps: RPCOps): Unit
        fun stop(): Unit
        lateinit var webServer: <ERROR CLASS>
      class NodeAttachmentService : AttachmentStorage, AcceptsFileUpload
        Module Contents NodeAttachmentService(storePath: Path, metrics: <ERROR CLASS>)
        class OnDiskHashMismatch : Exception
          Module Contents OnDiskHashMismatch(file: Path, actual: SecureHash)
          val actual: SecureHash
          val file: Path
          fun toString(): String
        val acceptableFileExtensions: <ERROR CLASS>
        var automaticallyExtractAttachments: Boolean
        var checkAttachmentsOnLoad: Boolean
        val dataTypePrefix: String
        fun importAttachment(jar: InputStream): SecureHash
        fun openAttachment(id: SecureHash): Attachment?
        val storePath: Path
        fun upload(data: InputStream): <ERROR CLASS>
      class NodeClock : Clock, SerializeAsToken
        Module Contents NodeClock(delegateClock: Clock = Clock.systemUTC())
        fun getZone(): ZoneId
        fun instant(): Instant
        fun toToken(context: SerializeAsTokenContext): SerializationToken
        fun withZone(zone: ZoneId): Clock
      interface NodeConfiguration : NodeSSLConfiguration
        Module Contents abstract val basedir: Path
        open val certificatesPath: Path
        open val dataSourceProperties: Properties
        abstract val devMode: Boolean
        abstract val emailAddress: String
        abstract val exportJMXto: String
        abstract val myLegalName: String
        abstract val nearestCity: String
      data class NodeHandle
        Module Contents NodeHandle(nodeInfo: NodeInfo, config: <ERROR CLASS>, process: Process)
        val config: <ERROR CLASS>
        val nodeInfo: NodeInfo
        val process: Process
      data class NodeInfo
        Module Contents NodeInfo(address: SingleMessageRecipient, legalIdentity: Party, advertisedServices: List<ServiceEntry> = emptyList(), physicalLocation: PhysicalLocation? = null)
        val address: SingleMessageRecipient
        var advertisedServices: List<ServiceEntry>
        val legalIdentity: Party
        val notaryIdentity: Party
        val physicalLocation: PhysicalLocation?
        fun serviceIdentities(type: ServiceType): List<Party>
      sealed class NodeMapError : Exception
        Module Contents class InvalidSignature : NodeMapError
          Module Contents InvalidSignature()
        class InvalidSubscriber : NodeMapError
          Module Contents InvalidSubscriber()
        class UnknownChangeType : NodeMapError
          Module Contents UnknownChangeType()
      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
          Module Contents Handler(topicSession: TopicSession, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit)
          val callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit
          val topicSession: TopicSession
        const val SESSION_ID_PROPERTY: String
        const val TOPIC_PROPERTY: String
        fun addMessageHandler(topic: String, sessionID: Long, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        fun addMessageHandler(topicSession: TopicSession, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        val config: NodeConfiguration
        fun createMessage(topicSession: TopicSession, data: ByteArray, uuid: UUID): Message
        val database: <ERROR CLASS>
        val executor: AffinityExecutor
        fun getAddressOfParty(partyInfo: PartyInfo): MessageRecipients
        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
        Module Contents NodeMonitorModel()
        val networkMap: <ERROR CLASS><MapChange>
        val progressTracking: <ERROR CLASS><ProgressTrackingEvent>
        val proxyObservable: SimpleObjectProperty<CordaRPCOps?>
        fun register(nodeHostAndPort: <ERROR CLASS>, sslConfig: NodeSSLConfiguration, username: String, password: String): Unit
        val stateMachineTransactionMapping: <ERROR CLASS><StateMachineTransactionMapping>
        val stateMachineUpdates: <ERROR CLASS><StateMachineUpdate>
        val transactions: <ERROR CLASS><SignedTransaction>
        val vaultUpdates: <ERROR CLASS><Update>
      class NodeRegistration
        Module Contents NodeRegistration(node: NodeInfo, serial: Long, type: AddOrRemove, expires: Instant)
        var expires: Instant
        val node: NodeInfo
        val serial: Long
        fun toString(): String
        fun toWire(privateKey: PrivateKey): WireNodeRegistration
        val type: AddOrRemove
      data class NodeRegistrationInfo
        Module Contents NodeRegistrationInfo(reg: NodeRegistration, mapVersion: Int)
        val mapVersion: Int
        val reg: NodeRegistration
      interface NodeSSLConfiguration
        Module Contents abstract val certificatesPath: Path
        abstract val keyStorePassword: String
        open val keyStorePath: Path
        abstract val trustStorePassword: String
        open val trustStorePath: Path
      class NodeSchedulerService : SchedulerService, SingletonSerializeAsToken
        Module Contents NodeSchedulerService(database: <ERROR CLASS>, services: ServiceHubInternal, flowLogicRefFactory: FlowLogicRefFactory, schedulerTimerExecutor: Executor = Executors.newSingleThreadExecutor())
        class RunScheduled : FlowLogic<Unit>
          Module Contents RunScheduled(scheduledState: ScheduledStateRef, scheduler: NodeSchedulerService)
          object RUNNING : Step
          fun call(): Unit
          val progressTracker: ProgressTracker
          val scheduledState: ScheduledStateRef
          val scheduler: NodeSchedulerService
          fun tracker(): ProgressTracker
        fun scheduleStateActivity(action: ScheduledStateRef): Unit
        fun start(): Unit
        val unfinishedSchedules: <ERROR CLASS>
        fun unscheduleStateActivity(ref: StateRef): Unit
      class NodeSchemaService : SchemaService, SingletonSerializeAsToken
        Module Contents NodeSchemaService()
        fun generateMappedObject(state: QueryableState, schema: MappedSchema): PersistentState
        val schemaOptions: Map<MappedSchema, SchemaOptions>
        fun selectSchemas(state: QueryableState): Iterable<MappedSchema>
      class NodeVaultService : SingletonSerializeAsToken, VaultService
        Module Contents NodeVaultService(services: ServiceHub)
        fun addNoteToTransaction(txnId: SecureHash, noteText: String): Unit
        val cashBalances: Map<Currency, Amount<Currency>>
        val currentVault: Vault
        fun generateSpend(tx: TransactionBuilder, amount: Amount<Currency>, to: CompositeKey, onlyFromParties: Set<Party>?): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
        fun getTransactionNotes(txnId: SecureHash): Iterable<String>
        val linearHeads: Map<UniqueIdentifier, StateAndRef<LinearState>>
        val log: <ERROR CLASS>
        fun notifyAll(txns: Iterable<WireTransaction>): Unit
        val rawUpdates: <ERROR CLASS><Update>
        fun track(): <ERROR CLASS><Vault, <ERROR CLASS><Update>>
        val updates: <ERROR CLASS><Update>
      class NonEmptySet<T> : MutableSet<T>
        Module Contents NonEmptySet(initial: T)
        inner class Iterator<out T, T> : MutableIterator<T>
          Module Contents Iterator(iterator: MutableIterator<T>)
          fun hasNext(): Boolean
          val iterator: MutableIterator<T>
          fun next(): T
          fun remove(): Unit
        fun add(element: T): Boolean
        fun addAll(elements: Collection<T>): Boolean
        fun clear(): Nothing
        fun contains(element: T): Boolean
        fun containsAll(elements: Collection<T>): Boolean
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        fun isEmpty(): Boolean
        fun iterator(): MutableIterator<T>
        fun remove(element: T): Boolean
        fun removeAll(elements: Collection<T>): Boolean
        fun retainAll(elements: Collection<T>): Boolean
        val size: Int
        fun toString(): String
      object NonEmptySetSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<NonEmptySet<Any>>): NonEmptySet<Any>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: NonEmptySet<Any>): Unit
      object NotaryChange
        Module Contents class Plugin : CordaPluginRegistry
          Module Contents Plugin()
          val servicePlugins: <ERROR CLASS>
        class Service : SingletonSerializeAsToken
          Module Contents Service(services: PluginServiceHub)
      object NotaryChangeFlow : AbstractStateReplacementFlow<Party>
        Module Contents class Acceptor : Acceptor<Party>
          Module Contents Acceptor(otherSide: Party, progressTracker: ProgressTracker = tracker())
          val progressTracker: ProgressTracker
          protected fun verifyProposal(maybeProposal: UntrustworthyData<Proposal<Party>>): Proposal<Party>
        class Instigator<T : ContractState> : Instigator<T, Party>
          Module Contents Instigator(originalState: StateAndRef<T>, newNotary: Party, progressTracker: ProgressTracker = tracker())
          protected fun assembleProposal(stateRef: StateRef, modification: Party, stx: SignedTransaction): Proposal<Party>
          protected fun assembleTx(): <ERROR CLASS><SignedTransaction, List<CompositeKey>>
        data class Proposal : Proposal<Party>
          Module Contents Proposal(stateRef: StateRef, modification: Party, stx: SignedTransaction)
          val modification: Party
          val stateRef: StateRef
          val stx: SignedTransaction
      sealed class NotaryError
        Module Contents class Conflict : NotaryError
          Module Contents Conflict(tx: WireTransaction, conflict: SignedData<Conflict>)
          val conflict: SignedData<Conflict>
          fun toString(): String
          val tx: WireTransaction
        class SignaturesMissing : NotaryError
          Module Contents SignaturesMissing(missingSigners: Set<CompositeKey>)
          val missingSigners: Set<CompositeKey>
          fun toString(): String
        class TimestampInvalid : NotaryError
          Module Contents TimestampInvalid()
        class TransactionInvalid : NotaryError
          Module Contents TransactionInvalid()
      class NotaryException : Exception
        Module Contents NotaryException(error: NotaryError)
        val error: NotaryError
        fun toString(): String
      object NotaryFlow
        Module Contents class Client : FlowLogic<WithKey>
          Module Contents Client(stx: SignedTransaction)
          Client(stx: SignedTransaction, progressTracker: ProgressTracker)
          object REQUESTING : Step
          object VALIDATING : Step
          open fun call(): WithKey
          lateinit var notaryParty: Party
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
        sealed class Result
          Module Contents class Error : Result
            Module Contents Error(error: NotaryError)
            val error: NotaryError
          class Success : Result
            Module Contents Success(sig: WithKey)
            val sig: WithKey
        class Service : FlowLogic<Unit>
          Module Contents Service(otherSide: Party, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
          open fun beforeCommit(stx: SignedTransaction): Unit
          open fun call(): Unit
          val otherSide: Party
          val timestampChecker: TimestampChecker
          val uniquenessProvider: UniquenessProvider
        data class SignRequest
          Module Contents SignRequest(tx: SignedTransaction)
          val tx: SignedTransaction
      abstract class NotaryService : SingletonSerializeAsToken
        Module Contents NotaryService(services: ServiceHubInternal)
        abstract fun createFlow(otherParty: Party): Service
      object NullPublicKey : PublicKey, Comparable<PublicKey>
        Module Contents fun compareTo(other: PublicKey): Int
        fun getAlgorithm(): String
        fun getEncoded(): ByteArray
        fun getFormat(): String
        fun toString(): String
      object NullSignature : WithKey
      class Obligation<P> : Contract
        Module Contents Obligation()
        interface Clauses
          Module Contents class ConserveAmount<P> : AbstractConserveAmount<State<P>, Commands, Terms<P>>
            Module Contents ConserveAmount()
          class Group<P> : GroupClauseVerifier<State<P>, Commands, Issued<Terms<P>>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State<P>, Issued<Terms<P>>>>
          class Issue<P> : AbstractIssue<State<P>, Commands, Terms<P>>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
          class Net<C : CommandData, P> : NetClause<C, P>
            Module Contents Net()
            val lifecycleClause: VerifyLifecycle<ContractState, C, Unit, P>
            fun toString(): String
            fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
          class SetLifecycle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
            Module Contents SetLifecycle()
            val requiredCommands: Set<Class<out CommandData>>
            fun toString(): String
            fun verify(tx: TransactionForContract, inputs: List<State<P>>, outputs: List<State<P>>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms<P>>?): Set<Commands>
          class Settle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
            Module Contents Settle()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State<P>>, outputs: List<State<P>>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms<P>>?): Set<Commands>
          class VerifyLifecycle<S : ContractState, C : CommandData, T : Any, P> : Clause<S, C, T>
            Module Contents VerifyLifecycle()
            fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: T?): Set<C>
        interface Commands : Commands
          Module Contents data class Exit<P> : Commands, Exit<Terms<P>>
            Module Contents Exit(amount: Amount<Issued<Terms<P>>>)
            val amount: Amount<Issued<Terms<P>>>
          data class Issue : Issue, Commands
            Module Contents Issue(nonce: Long = random63BitValue())
            val nonce: Long
          data class Move : Commands, Move
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
          data class Net : NetCommand, Commands
            Module Contents Net(type: NetType)
            val type: NetType
          data class SetLifecycle : Commands
            Module Contents SetLifecycle(lifecycle: Lifecycle)
            val inverse: Lifecycle
            val lifecycle: Lifecycle
          data class Settle<P> : Commands
            Module Contents Settle(amount: Amount<Issued<Terms<P>>>)
            val amount: Amount<Issued<Terms<P>>>
        enum class Lifecycle
          Module Contents DEFAULTED
          NORMAL
        data class State<P> : FungibleAsset<Terms<P>>, NettableState<State<P>, MultilateralNetState<P>>
          Module Contents State(lifecycle: Lifecycle = Lifecycle.NORMAL, obligor: Party, template: Terms<P>, quantity: Long, beneficiary: CompositeKey)
          val amount: Amount<Issued<Terms<P>>>
          val beneficiary: CompositeKey
          val bilateralNetState: BilateralNetState<P>
          val contract: Obligation<Currency>
          val dueBefore: Instant
          val exitKeys: Collection<CompositeKey>
          var lifecycle: Lifecycle
          fun move(newAmount: Amount<Issued<Terms<P>>>, newOwner: CompositeKey): State<P>
          val multilateralNetState: MultilateralNetState<P>
          fun net(other: State<P>): State<P>
          val obligor: Party
          val owner: CompositeKey
          val participants: List<CompositeKey>
          val quantity: Long
          val template: Terms<P>
          fun toString(): String
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        data class Terms<P>
          Module Contents Terms(acceptableContracts: NonEmptySet<SecureHash>, acceptableIssuedProducts: NonEmptySet<Issued<P>>, dueBefore: Instant, timeTolerance: Duration = Duration.ofSeconds(30))
          val acceptableContracts: NonEmptySet<SecureHash>
          val acceptableIssuedProducts: NonEmptySet<Issued<P>>
          val dueBefore: Instant
          val product: P
          val timeTolerance: Duration
        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
        Module Contents OnLedgerAsset()
        abstract val conserveClause: AbstractConserveAmount<S, C, T>
        abstract fun deriveState(txState: TransactionState<S>, amount: Amount<Issued<T>>, owner: CompositeKey): TransactionState<S>
        abstract fun extractCommands(commands: Collection<AuthenticatedObject<CommandData>>): Collection<AuthenticatedObject<C>>
        fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<T>>, assetStates: List<StateAndRef<S>>): CompositeKey
        abstract fun generateExitCommand(amount: Amount<Issued<T>>): Exit<T>
        abstract fun generateIssueCommand(): Issue
        abstract fun generateMoveCommand(): Move
      open class OpaqueBytes
        Module Contents OpaqueBytes(bytes: ByteArray)
        val bytes: ByteArray
        open fun equals(other: Any?): Boolean
        open fun hashCode(): Int
        fun of(vararg b: Byte): OpaqueBytes
        fun open(): ByteArrayInputStream
        val size: Int
        open fun toString(): String
      class OptionalConfig<out T>
        Module Contents OptionalConfig(conf: <ERROR CLASS>, lambda: () -> T)
        val conf: <ERROR CLASS>
        operator fun getValue(receiver: Any, metadata: KProperty<*>): T
        val lambda: () -> T
      object OrderedSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<HashMap<Any, Any>>): HashMap<Any, Any>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: HashMap<Any, Any>): Unit
      interface OwnableState : ContractState
        Module Contents abstract val owner: CompositeKey
        abstract fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS><CommandData, OwnableState>
      object ParamsSpec
        Module Contents val baseDirectoryArg: <ERROR CLASS>
        val configFileArg: <ERROR CLASS>
        val parser: <ERROR CLASS>
      class PartialMerkleTree
        Module Contents PartialMerkleTree(root: PartialTree)
        sealed class PartialTree
          Module Contents class IncludedLeaf : PartialTree
            Module Contents IncludedLeaf(hash: SecureHash)
            val hash: SecureHash
          class Leaf : PartialTree
            Module Contents Leaf(hash: SecureHash)
            val hash: SecureHash
          class Node : PartialTree
            Module Contents Node(left: PartialTree, right: PartialTree)
            val left: PartialTree
            val right: PartialTree
        fun build(merkleRoot: MerkleTree, includeHashes: List<SecureHash>): PartialMerkleTree
        val root: PartialTree
        fun verify(merkleRootHash: SecureHash, hashesToCheck: List<SecureHash>): Boolean
      data class PartiallyResolvedTransaction
        Module Contents PartiallyResolvedTransaction(transaction: SignedTransaction, inputs: List<ObservableValue<InputResolution>>)
        sealed class InputResolution
          Module Contents class Resolved : InputResolution
            Module Contents Resolved(stateAndRef: StateAndRef<ContractState>)
            val stateAndRef: StateAndRef<ContractState>
          class Unresolved : InputResolution
            Module Contents Unresolved(stateRef: StateRef)
          val stateRef: StateRef
        fun fromSignedTransaction(transaction: SignedTransaction, transactions: ObservableMap<SecureHash, SignedTransaction>): PartiallyResolvedTransaction
        val id: SecureHash
        val inputs: List<ObservableValue<InputResolution>>
        val transaction: SignedTransaction
      data class Party
        Module Contents Party(name: String, owningKey: PublicKey)
        Party(name: String, owningKey: CompositeKey)
        val name: String
        val owningKey: CompositeKey
        fun ref(bytes: OpaqueBytes): PartyAndReference
        fun ref(vararg bytes: Byte): PartyAndReference
        fun toString(): String
      data class PartyAndReference
        Module Contents PartyAndReference(party: Party, reference: OpaqueBytes)
        val party: Party
        val reference: OpaqueBytes
        fun toString(): String
      class PartyAndReferenceGenerator
        Module Contents PartyAndReferenceGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): PartyAndReference
      data class PartyColumns
        Module Contents PartyColumns(name: <ERROR CLASS><String>, owningKey: <ERROR CLASS><CompositeKey>)
        val name: <ERROR CLASS><String>
        val owningKey: <ERROR CLASS><CompositeKey>
      class PartyGenerator
        Module Contents PartyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Party
      sealed class PartyInfo
        Module Contents class Node : PartyInfo
          Module Contents Node(node: NodeInfo)
          val node: NodeInfo
          val party: Party
        class Service : PartyInfo
          Module Contents Service(service: ServiceEntry)
          val party: Party
          val service: ServiceEntry
        abstract val party: Party
      enum class PaymentRule
        Module Contents InAdvance
        InArrears
      class PermissionException : RuntimeException
        Module Contents PermissionException(msg: String)
      class PersistentKeyManagementService : SingletonSerializeAsToken, KeyManagementService
        Module Contents PersistentKeyManagementService(initialKeys: Set<KeyPair>)
        fun freshKey(): KeyPair
        val keys: Map<PublicKey, PrivateKey>
      class PersistentNetworkMapService : AbstractNetworkMapService
        Module Contents PersistentNetworkMapService(services: ServiceHubInternal)
        protected val registeredNodes: MutableMap<Party, NodeRegistrationInfo>
        protected val subscribers: ThreadBox<JDBCHashMap<SingleMessageRecipient, LastAcknowledgeInfo>>
      open class PersistentState
        Module Contents PersistentState(stateRef: PersistentStateRef? = null)
        var stateRef: PersistentStateRef?
      data class PersistentStateRef : Serializable
        Module Contents PersistentStateRef(stateRef: StateRef)
        PersistentStateRef()
        PersistentStateRef(txId: String?, index: Int?)
        var index: Int?
        var txId: String?
      class PersistentUniquenessProvider : UniquenessProvider, SingletonSerializeAsToken
        Module Contents PersistentUniquenessProvider()
        fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      data class PhysicalLocation
        Module Contents PhysicalLocation(coordinate: WorldCoordinate, description: String)
        val coordinate: WorldCoordinate
        val description: String
      interface PluginServiceHub : ServiceHub
        Module Contents abstract fun getFlowFactory(markerClass: Class<*>): (Party) -> FlowLogic<*>
        abstract fun registerFlowInitiator(markerClass: KClass<*>, flowFactory: (Party) -> FlowLogic<*>): Unit
      class Polynomial
        Module Contents Polynomial(coefficients: DoubleArray)
        fun getValue(x: Double): <ERROR CLASS>
      sealed class PortAllocation
        Module Contents class Incremental : PortAllocation
          Module Contents Incremental(startingPort: Int)
          fun nextPort(): Int
          val portCounter: AtomicInteger
        class RandomFree : PortAllocation
          Module Contents RandomFree()
          fun nextPort(): Int
        fun nextHostAndPort(): <ERROR CLASS>
        abstract fun nextPort(): Int
      class PrivateKeyGenerator
        Module Contents PrivateKeyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): PrivateKey
      class ProgressTracker
        Module Contents ProgressTracker(vararg steps: Step)
        sealed class Change
          Module Contents class Position : Change
            Module Contents Position(tracker: ProgressTracker, newStep: Step)
            val newStep: Step
            fun toString(): String
            val tracker: ProgressTracker
          class Rendering : Change
            Module Contents Rendering(tracker: ProgressTracker, ofStep: Step)
            val ofStep: Step
            fun toString(): String
            val tracker: ProgressTracker
          class Structural : Change
            Module Contents Structural(tracker: ProgressTracker, parent: Step)
            val parent: Step
            fun toString(): String
            val tracker: ProgressTracker
        object DONE : Step
          Module Contents fun equals(other: Any?): Boolean
        inner class RelabelableStep : Step
          Module Contents RelabelableStep(currentLabel: String)
          open val changes: <ERROR CLASS>
          var currentLabel: String
          open val label: String
        class Step
          Module Contents Step(label: String)
          open val changes: <ERROR CLASS><Change>
          open fun childProgressTracker(): ProgressTracker?
          open val label: String
        object UNSTARTED : Step
          Module Contents fun equals(other: Any?): Boolean
        val allSteps: List<<ERROR CLASS><Int, Step>>
        val changes: <ERROR CLASS><Change>
        var currentStep: Step
        val currentStepRecursive: Step
        fun getChildProgressTracker(step: Step): ProgressTracker?
        fun nextStep(): Step
        var parent: ProgressTracker?
        fun setChildProgressTracker(step: Step, childProgressTracker: ProgressTracker): Unit
        var stepIndex: Int
        val steps: Array<Step>
        val topLevelTracker: ProgressTracker
      data class ProgressTrackingEvent
        Module Contents ProgressTrackingEvent(stateMachineId: StateMachineRunId, message: String)
        fun createStreamFromStateMachineInfo(stateMachine: StateMachineInfo): <ERROR CLASS><ProgressTrackingEvent>?
        val message: String
        val stateMachineId: StateMachineRunId
      object PublicKeyColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      class PublicKeyGenerator
        Module Contents PublicKeyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): PublicKey
      interface QueryableState : ContractState
        Module Contents abstract fun generateMappedObject(schema: MappedSchema): PersistentState
        abstract fun supportedSchemas(): Iterable<MappedSchema>
      abstract class RPCDispatcher
        Module Contents RPCDispatcher(ops: RPCOps, userService: RPCUserService, nodeLegalName: String)
        fun dispatch(msg: ClientRPCRequestMessage): Unit
        protected open fun getUser(message: <ERROR CLASS>): User
        val nodeLegalName: String
        val ops: RPCOps
        abstract fun send(data: SerializedBytes<*>, toAddress: String): Unit
        fun start(rpcConsumer: <ERROR CLASS>, rpcNotificationConsumer: <ERROR CLASS>?, onExecutor: AffinityExecutor): Unit
        val userService: RPCUserService
      open class RPCException : RuntimeException
        Module Contents RPCException(msg: String)
        RPCException(msg: String, cause: Throwable?)
        class DeadlineExceeded : RPCException
          Module Contents DeadlineExceeded(rpcName: String)
      interface RPCOps
        Module Contents abstract val protocolVersion: Int
      @Target([AnnotationTarget.FUNCTION]) annotation class RPCReturnsObservables
        Module Contents RPCReturnsObservables()
      @Target([AnnotationTarget.FUNCTION]) annotation class RPCSinceVersion
        Module Contents RPCSinceVersion(version: Int)
        val version: Int
      interface RPCUserService
        Module Contents abstract fun getUser(username: String): User?
        abstract val users: List<User>
      class RPCUserServiceImpl : RPCUserService
        Module Contents RPCUserServiceImpl(config: FullNodeConfiguration)
        fun getUser(username: String): User?
        val users: List<User>
      class RaftUniquenessProvider : UniquenessProvider, SingletonSerializeAsToken
        Module Contents RaftUniquenessProvider(storagePath: Path, myAddress: <ERROR CLASS>, clusterAddresses: List<<ERROR CLASS>>, db: <ERROR CLASS>, config: NodeSSLConfiguration)
        fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      class RaftValidatingNotaryService : NotaryService
        Module Contents RaftValidatingNotaryService(services: ServiceHubInternal, timestampChecker: TimestampChecker, uniquenessProvider: RaftUniquenessProvider)
        fun createFlow(otherParty: Party): ValidatingNotaryFlow
        val timestampChecker: TimestampChecker
        val type: ServiceType
        val uniquenessProvider: RaftUniquenessProvider
      open class ReadOnlyBackedObservableMapBase<K, A, B> : ObservableMap<K, A>
        Module Contents ReadOnlyBackedObservableMapBase()
        open fun addListener(listener: InvalidationListener): Unit
        open fun addListener(listener: MapChangeListener<in K, in A>?): Unit
        protected val backingMap: HashMap<K, <ERROR CLASS><A, B>>
        open fun clear(): Unit
        open fun containsKey(key: K): Boolean
        open fun containsValue(value: A): <ERROR CLASS>
        open val entries: MutableSet<MutableEntry<K, A>>
        protected fun fireChange(change: Change<out K, out A>): Unit
        open fun get(key: K): <ERROR CLASS>
        open fun isEmpty(): Boolean
        open val keys: MutableSet<K>
        open fun put(key: K, value: A): A
        open fun putAll(from: Map<out K, A>): Unit
        open fun remove(key: K): A
        open fun removeListener(listener: InvalidationListener?): Unit
        open fun removeListener(listener: MapChangeListener<in K, in A>?): Unit
        open val size: Int
        open val values: MutableCollection<A>
      interface ReadOnlyTransactionStorage
        Module Contents abstract fun getTransaction(id: SecureHash): SignedTransaction?
        abstract fun track(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
        abstract val updates: <ERROR CLASS><SignedTransaction>
      data class ReceiveOnly<T : SessionMessage> : ReceiveRequest<T>
        Module Contents ReceiveOnly(session: FlowSession, receiveType: Class<T>)
        val receiveType: Class<T>
        val session: FlowSession
        val stackTraceInCaseOfProblems: StackSnapshot
      interface ReceiveRequest<T : SessionMessage> : FlowIORequest
        Module Contents abstract val receiveType: Class<T>
      interface ReceivedMessage : Message
        Module Contents abstract val peer: <ERROR CLASS>
      object ReferencesAwareJavaSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Any>): Any
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: Any): Unit
      interface RegulatorService
        Module Contents val type: ServiceType
      class ReplayedList<A> : TransformationList<A, A>
        Module Contents ReplayedList(sourceList: ObservableList<A>)
        fun get(index: Int): A
        fun getSourceIndex(index: Int): Int
        val replayedList: ArrayList<A>
        val size: Int
        protected fun sourceChanged(c: Change<out A>): Unit
      object Requirements
        Module Contents inline infix fun String.by(expr: Boolean): Unit
      class ResolveTransactionsFlow : FlowLogic<List<LedgerTransaction>>
        Module Contents ResolveTransactionsFlow(stx: SignedTransaction, otherSide: Party)
        ResolveTransactionsFlow(wtx: WireTransaction, otherSide: Party)
        ResolveTransactionsFlow(txHashes: Set<SecureHash>, otherSide: Party)
        class ExcessivelyLargeTransactionGraph : Exception
          Module Contents ExcessivelyLargeTransactionGraph()
        fun call(): List<LedgerTransaction>
        var transactionCountLimit: Int
      class ResponseFilter
        Module Contents ResponseFilter()
        fun filter(requestContext: <ERROR CLASS>, responseContext: <ERROR CLASS>): Unit
      abstract class RetryableException : Exception
        Module Contents RetryableException(message: String)
      interface SchedulableState : ContractState
        Module Contents abstract fun nextScheduledActivity(thisStateRef: StateRef, flowLogicRefFactory: FlowLogicRefFactory): ScheduledActivity?
      interface Scheduled
        Module Contents abstract val scheduledAt: Instant
      data class ScheduledActivity : Scheduled
        Module Contents ScheduledActivity(logicRef: FlowLogicRef, scheduledAt: Instant)
        val logicRef: FlowLogicRef
        val scheduledAt: Instant
      class ScheduledActivityObserver
        Module Contents ScheduledActivityObserver(services: ServiceHubInternal)
        val services: ServiceHubInternal
      data class ScheduledStateRef : Scheduled
        Module Contents ScheduledStateRef(ref: StateRef, scheduledAt: Instant)
        val ref: StateRef
        val scheduledAt: Instant
      interface SchedulerService
        Module Contents abstract fun scheduleStateActivity(action: ScheduledStateRef): Unit
        abstract fun unscheduleStateActivity(ref: StateRef): Unit
      interface SchemaService
        Module Contents data class SchemaOptions
          Module Contents SchemaOptions(databaseSchema: String?, tablePrefix: String?)
          val databaseSchema: String?
          val tablePrefix: String?
        abstract fun generateMappedObject(state: QueryableState, schema: MappedSchema): PersistentState
        abstract val schemaOptions: Map<MappedSchema, SchemaOptions>
        abstract fun selectSchemas(state: QueryableState): Iterable<MappedSchema>
      sealed class SecureHash : OpaqueBytes
        Module Contents class SHA256 : SecureHash
          Module Contents SHA256(bytes: ByteArray)
        fun parse(str: String): <ERROR CLASS>
        fun prefixChars(prefixLen: Int = 6): <ERROR CLASS>
        fun randomSHA256(): SHA256
        fun sha256(bytes: ByteArray): SHA256
        fun sha256(str: String): <ERROR CLASS>
        fun sha256Twice(bytes: ByteArray): SHA256
        open fun toString(): <ERROR CLASS>
      object SecureHashColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      class SecureHashGenerator
        Module Contents SecureHashGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): SecureHash
      data class SendAndReceive<T : SessionMessage> : SendRequest, ReceiveRequest<T>
        Module Contents SendAndReceive(session: FlowSession, message: SessionMessage, receiveType: Class<T>)
        val message: SessionMessage
        val receiveType: Class<T>
        val session: FlowSession
        val stackTraceInCaseOfProblems: StackSnapshot
      data class SendOnly : SendRequest
        Module Contents SendOnly(session: FlowSession, message: SessionMessage)
        val message: SessionMessage
        val session: FlowSession
        val stackTraceInCaseOfProblems: StackSnapshot
      interface SendRequest : FlowIORequest
        Module Contents abstract val message: SessionMessage
      interface SerializationToken
        Module Contents abstract fun fromToken(context: SerializeAsTokenContext): Any
      interface SerializeAsToken
        Module Contents abstract fun toToken(context: SerializeAsTokenContext): SerializationToken
      class SerializeAsTokenContext
        Module Contents SerializeAsTokenContext(toBeTokenized: Any, kryo: <ERROR CLASS> = createKryo())
      class SerializeAsTokenSerializer<T : SerializeAsToken>
        Module Contents SerializeAsTokenSerializer()
        fun clearContext(kryo: <ERROR CLASS>): Unit
        fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<T>): T
        fun setContext(kryo: <ERROR CLASS>, context: SerializeAsTokenContext): Unit
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: T): Unit
      class SerializedBytes<T : Any> : OpaqueBytes
        Module Contents SerializedBytes(bytes: ByteArray)
        val hash: SecureHash
        fun writeToFile(path: Path): Path
      object SerializedBytesSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<SerializedBytes<Any>>): SerializedBytes<Any>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: SerializedBytes<Any>): Unit
      data class ServiceEntry
        Module Contents ServiceEntry(info: ServiceInfo, identity: Party)
        val identity: Party
        val info: ServiceInfo
      interface ServiceHub
        Module Contents abstract val clock: Clock
        abstract val identityService: IdentityService
        abstract fun <T : Any> invokeFlowAsync(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowStateMachine<T>
        abstract val keyManagementService: KeyManagementService
        open val legalIdentityKey: KeyPair
        open fun loadState(stateRef: StateRef): TransactionState<*>
        abstract val myInfo: NodeInfo
        abstract val networkMapCache: NetworkMapCache
        abstract val networkService: MessagingService
        open val notaryIdentityKey: KeyPair
        abstract fun recordTransactions(txs: Iterable<SignedTransaction>): Unit
        abstract val schedulerService: SchedulerService
        abstract val storageService: StorageService
        open fun <T : ContractState> toStateAndRef(ref: StateRef): StateAndRef<T>
        abstract val vaultService: VaultService
      abstract class ServiceHubInternal : PluginServiceHub
        Module Contents ServiceHubInternal()
        abstract val flowLogicRefFactory: FlowLogicRefFactory
        open fun <T : Any> invokeFlowAsync(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowStateMachine<T>
        abstract val monitoringService: MonitoringService
        abstract val networkService: MessagingServiceInternal
        abstract val schemaService: SchemaService
        abstract fun <T> startFlow(logic: FlowLogic<T>): FlowStateMachine<T>
      object ServiceIdentityGenerator
        Module Contents fun generateToDisk(dirs: List<Path>, serviceId: String, serviceName: String, threshold: Int = 1): Unit
      data class ServiceInfo
        Module Contents ServiceInfo(type: ServiceType, name: String? = null)
        val name: String?
        fun parse(encoded: String): ServiceInfo
        fun toString(): String
        val type: ServiceType
      interface ServiceRequestMessage
        Module Contents abstract val replyTo: SingleMessageRecipient
        abstract val sessionID: Long
      sealed class ServiceType
        Module Contents val corda: ServiceType
        open operator fun equals(other: Any?): Boolean
        fun getServiceType(namespace: String, typeId: String): ServiceType
        fun getSubType(subTypeId: String): ServiceType
        open fun hashCode(): Int
        val id: String
        fun isNotary(): Boolean
        fun isSubTypeOf(superType: ServiceType): Boolean
        val notary: ServiceType
        fun parse(id: String): ServiceType
        val regulator: ServiceType
        open fun toString(): String
      open class SignedData<T : Any>
        Module Contents SignedData(raw: SerializedBytes<T>, sig: WithKey)
        val raw: SerializedBytes<T>
        val sig: WithKey
        fun verified(): T
        protected open fun verifyData(data: T): Unit
      data class SignedTransaction : NamedByHash
        Module Contents SignedTransaction(txBits: SerializedBytes<WireTransaction>, sigs: List<WithKey>, id: SecureHash)
        class SignaturesMissingException : NamedByHash, SignatureException
          Module Contents SignaturesMissingException(missing: Set<CompositeKey>, descriptions: List<String>, id: SecureHash)
          val descriptions: List<String>
          val id: SecureHash
          val missing: Set<CompositeKey>
          fun toString(): String
        fun checkSignaturesAreValid(): Unit
        val id: SecureHash
        operator fun plus(sig: WithKey): SignedTransaction
        operator fun plus(sigList: Collection<WithKey>): SignedTransaction
        val sigs: List<WithKey>
        fun toLedgerTransaction(services: ServiceHub): LedgerTransaction
        val tx: WireTransaction
        val txBits: SerializedBytes<WireTransaction>
        fun verifySignatures(vararg allowedToBeMissing: CompositeKey): WireTransaction
        fun withAdditionalSignature(sig: WithKey): SignedTransaction
        fun withAdditionalSignatures(sigList: Iterable<WithKey>): SignedTransaction
      class SignedTransactionGenerator
        Module Contents SignedTransactionGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): SignedTransaction
      class SimpleNotaryService : NotaryService
        Module Contents SimpleNotaryService(services: ServiceHubInternal, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
        fun createFlow(otherParty: Party): Service
        val timestampChecker: TimestampChecker
        val type: ServiceType
        val uniquenessProvider: UniquenessProvider
      interface SingleMessageRecipient : MessageRecipients
      data class SingletonSerializationToken : SerializationToken
        Module Contents SingletonSerializationToken(toBeTokenized: SerializeAsToken)
        fun fromToken(context: SerializeAsTokenContext): Any
        fun registerWithContext(token: SingletonSerializationToken, toBeTokenized: SerializeAsToken, context: SerializeAsTokenContext): SerializationToken
      abstract class SingletonSerializeAsToken : SerializeAsToken
        Module Contents SingletonSerializeAsToken()
        open fun toToken(context: SerializeAsTokenContext): SerializationToken
      class SplineFunction
        Module Contents SplineFunction(segmentMap: TreeMap<Double, Polynomial>)
        fun getValue(x: Double): Double
      class StackSnapshot : Throwable
        Module Contents StackSnapshot()
      data class StateAndRef<out T : ContractState>
        Module Contents StateAndRef(state: TransactionState<T>, ref: StateRef)
        val ref: StateRef
        val state: TransactionState<T>
      data class StateMachineData
        Module Contents StateMachineData(id: StateMachineRunId, flowStatus: ObservableValue<FlowStatus?>, stateMachineStatus: ObservableValue<StateMachineStatus>)
        val flowStatus: ObservableValue<FlowStatus?>
        val id: StateMachineRunId
        val stateMachineStatus: ObservableValue<StateMachineStatus>
      data class StateMachineInfo
        Module Contents StateMachineInfo(id: StateMachineRunId, flowLogicClassName: String, progressTrackerStepAndUpdates: <ERROR CLASS><String, <ERROR CLASS><String>>?)
        val flowLogicClassName: String
        val id: StateMachineRunId
        val progressTrackerStepAndUpdates: <ERROR CLASS><String, <ERROR CLASS><String>>?
      class StateMachineManager
        Module Contents StateMachineManager(serviceHub: ServiceHubInternal, tokenizableServices: List<Any>, checkpointStorage: CheckpointStorage, executor: AffinityExecutor, database: <ERROR CLASS>)
        data class Change
          Module Contents Change(logic: FlowLogic<*>, addOrRemove: AddOrRemove, id: StateMachineRunId)
          val addOrRemove: AddOrRemove
          val id: StateMachineRunId
          val logic: FlowLogic<*>
        interface ExistingSessionMessage : SessionMessage
          Module Contents abstract val recipientSessionId: Long
        inner class FiberScheduler
          Module Contents FiberScheduler()
        data class FlowSession
          Module Contents FlowSession(flow: FlowLogic<*>, ourSessionId: Long, state: FlowSessionState, waitingForResponse: Boolean = false)
          val flow: FlowLogic<*>
          val ourSessionId: Long
          val psm: FlowStateMachineImpl<*>
          val receivedMessages: ConcurrentLinkedQueue<ReceivedSessionMessage<ExistingSessionMessage>>
          var state: FlowSessionState
          var waitingForResponse: Boolean
        sealed class FlowSessionState
          Module Contents class Initiated : FlowSessionState
            Module Contents Initiated(peerParty: Party, peerSessionId: Long)
            val peerParty: Party
            val peerSessionId: Long
            val sendToParty: Party
          class Initiating : FlowSessionState
            Module Contents Initiating(otherParty: Party)
            val otherParty: Party
            val sendToParty: Party
          abstract val sendToParty: Party
        data class ReceivedSessionMessage<out M : SessionMessage>
          Module Contents ReceivedSessionMessage(sendingParty: Party, message: M)
          val message: M
          val sendingParty: Party
        data class SessionConfirm : SessionInitResponse
          Module Contents SessionConfirm(initiatorSessionId: Long, initiatedSessionId: Long)
          val initiatedSessionId: Long
          val initiatorSessionId: Long
          val recipientSessionId: Long
        data class SessionData : ExistingSessionMessage
          Module Contents SessionData(recipientSessionId: Long, payload: Any)
          val payload: Any
          val recipientSessionId: Long
          fun toString(): String
        data class SessionEnd : ExistingSessionMessage
          Module Contents SessionEnd(recipientSessionId: Long)
          val recipientSessionId: Long
        data class SessionInit : SessionMessage
          Module Contents SessionInit(initiatorSessionId: Long, flowName: String, firstPayload: Any?)
          val firstPayload: Any?
          val flowName: String
          val initiatorSessionId: Long
        interface SessionInitResponse : ExistingSessionMessage
        interface SessionMessage
        data class SessionReject : SessionInitResponse
          Module Contents SessionReject(initiatorSessionId: Long, errorMessage: String)
          val errorMessage: String
          val initiatorSessionId: Long
          val recipientSessionId: Long
        fun <T> add(logic: FlowLogic<T>): FlowStateMachine<T>
        val allStateMachines: List<FlowLogic<*>>
        val changes: <ERROR CLASS><Change>
        val checkpointStorage: CheckpointStorage
        val database: <ERROR CLASS>
        val executor: AffinityExecutor
        fun <P : FlowLogic<T>, T> findStateMachines(flowClass: Class<P>): List<<ERROR CLASS><P, <ERROR CLASS><T>>>
        val scheduler: FiberScheduler
        val serviceHub: ServiceHubInternal
        fun start(): Unit
        fun stop(allowedUnsuspendedFiberCount: Int = 0): Unit
        fun track(): <ERROR CLASS><List<FlowStateMachineImpl<*>>, <ERROR CLASS><Change>>
        val unfinishedFibers: <ERROR CLASS>
      interface StateMachineRecordedTransactionMappingStorage
        Module Contents abstract fun addMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash): Unit
        abstract fun track(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
      data class StateMachineRunId
        Module Contents fun createRandom(): StateMachineRunId
        fun toString(): String
        val uuid: UUID
        fun wrap(uuid: UUID): StateMachineRunId
      sealed class StateMachineStatus
        Module Contents class Added : StateMachineStatus
          Module Contents Added(stateMachineName: String)
        class Removed : StateMachineStatus
          Module Contents Removed(stateMachineName: String)
        val stateMachineName: String
        open fun toString(): String
      data class StateMachineTransactionMapping
        Module Contents StateMachineTransactionMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash)
        val stateMachineRunId: StateMachineRunId
        val transactionId: SecureHash
      sealed class StateMachineUpdate
        Module Contents class Added : StateMachineUpdate
          Module Contents Added(stateMachineInfo: StateMachineInfo)
          val stateMachineInfo: StateMachineInfo
          fun toString(): String
        class Removed : StateMachineUpdate
          Module Contents Removed(id: StateMachineRunId)
          fun toString(): String
        val id: StateMachineRunId
      data class StateRef
        Module Contents StateRef(txhash: SecureHash, index: Int)
        val index: Int
        fun toString(): String
        val txhash: SecureHash
      data class StateRefColumns
        Module Contents StateRefColumns(txId: <ERROR CLASS><SecureHash>, index: <ERROR CLASS><Int>)
        val index: <ERROR CLASS><Int>
        val txId: <ERROR CLASS><SecureHash>
      class StateRefGenerator
        Module Contents StateRefGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): StateRef
      class StateReplacementException : Exception
        Module Contents StateReplacementException(error: StateReplacementRefused)
        val error: StateReplacementRefused
      class StateReplacementRefused
        Module Contents StateReplacementRefused(identity: Party, state: StateRef, detail: String?)
        val detail: String?
        val identity: Party
        val state: StateRef
        fun toString(): String
      interface StatesQuery
        Module Contents interface Criteria
          Module Contents object AllDeals : Criteria
          data class Deal : Criteria
            Module Contents Deal(ref: String)
            val ref: String
        data class Selection : StatesQuery
          Module Contents Selection(criteria: Criteria)
          val criteria: Criteria
        fun select(criteria: Criteria): Selection
      interface StorageService
        Module Contents abstract val attachments: AttachmentStorage
        abstract val stateMachineRecordedTransactionMapping: StateMachineRecordedTransactionMappingStorage
        abstract val validatedTransactions: ReadOnlyTransactionStorage
      open class StorageServiceImpl : SingletonSerializeAsToken, TxWritableStorageService
        Module Contents StorageServiceImpl(attachments: AttachmentStorage, validatedTransactions: TransactionStorage, stateMachineRecordedTransactionMapping: StateMachineRecordedTransactionMappingStorage)
        open val attachments: AttachmentStorage
        open val stateMachineRecordedTransactionMapping: StateMachineRecordedTransactionMappingStorage
        open val validatedTransactions: TransactionStorage
      class StrandLocalTransactionManager
        Module Contents StrandLocalTransactionManager(initWithDatabase: <ERROR CLASS>)
        data class Boundary
          Module Contents Boundary(txId: UUID)
          val txId: UUID
        fun currentOrNull(): <ERROR CLASS>?
        var database: <ERROR CLASS>
        val manager: StrandLocalTransactionManager
        fun newTransaction(isolation: Int): <ERROR CLASS>
        fun restoreThreadLocalTx(context: <ERROR CLASS><<ERROR CLASS>?, <ERROR CLASS>?>): Unit
        fun setThreadLocalTx(tx: <ERROR CLASS>?): <ERROR CLASS><<ERROR CLASS>?, <ERROR CLASS>?>
        val transactionBoundaries: <ERROR CLASS><Boundary>
        val transactionId: UUID
      data class Tenor
        Module Contents Tenor(name: String)
        enum class TimeUnit
          Module Contents Day
          Month
          Week
          Year
          val code: String
        fun daysToMaturity(startDate: LocalDate, calendar: BusinessCalendar): Int
        val name: String
        fun toString(): String
      class TestClock : MutableClock, SerializeAsToken
        Module Contents TestClock(delegateClock: Clock = Clock.systemUTC())
        fun getZone(): ZoneId
        fun instant(): Instant
        fun toToken(context: SerializeAsTokenContext): SerializationToken
        fun updateDate(date: LocalDate): Boolean
        fun withZone(zone: ZoneId): Clock
      class ThreadBox<out T>
        Module Contents ThreadBox(content: T, lock: ReentrantLock = ReentrantLock())
        inline fun <R> alreadyLocked(body: T.() -> R): R
        fun checkNotLocked(): <ERROR CLASS>
        val content: T
        val lock: ReentrantLock
        inline fun <R> locked(body: T.() -> R): R
      data class TimeWindow
        Module Contents TimeWindow(start: Instant, duration: Duration)
        val duration: Duration
        val end: Instant
        val start: Instant
      data class Timestamp
        Module Contents Timestamp(time: Instant, tolerance: Duration)
        Timestamp(after: Instant?, before: Instant?)
        val after: Instant?
        val before: Instant?
        val midpoint: Instant
      class TimestampChecker
        Module Contents TimestampChecker(clock: Clock = Clock.systemUTC(), tolerance: Duration = 30.seconds)
        val clock: Clock
        fun isValid(timestampCommand: Timestamp): Boolean
        val tolerance: Duration
      class TimestampGenerator
        Module Contents TimestampGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Timestamp
      data class TopicSession
        Module Contents TopicSession(topic: String, sessionID: Long = DEFAULT_SESSION_ID)
        fun isBlank(): Boolean
        val sessionID: Long
        fun toString(): String
        val topic: String
      object TopicStringValidator
        Module Contents fun check(tag: String): <ERROR CLASS>
      sealed class TrackedDelegate<M : Any>
        Module Contents class EventSinkDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents EventSinkDelegate(klass: KClass<M>, eventSinkProperty: (M) -> <ERROR CLASS><T>)
          val eventSinkProperty: (M) -> <ERROR CLASS><T>
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
        class EventStreamDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents EventStreamDelegate(klass: KClass<M>, eventStreamProperty: (M) -> <ERROR CLASS><T>)
          val eventStreamProperty: (M) -> <ERROR CLASS><T>
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
        class ObjectPropertyDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObjectPropertyDelegate(klass: KClass<M>, objectPropertyProperty: (M) -> ObjectProperty<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObjectProperty<T>
          val objectPropertyProperty: (M) -> ObjectProperty<T>
        class ObservableDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObservableDelegate(klass: KClass<M>, observableProperty: (M) -> <ERROR CLASS><T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
          val observableProperty: (M) -> <ERROR CLASS><T>
        class ObservableListDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObservableListDelegate(klass: KClass<M>, observableListProperty: (M) -> ObservableList<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObservableList<T>
          val observableListProperty: (M) -> ObservableList<T>
        class ObservableListReadOnlyDelegate<M : Any, out T> : TrackedDelegate<M>
          Module Contents ObservableListReadOnlyDelegate(klass: KClass<M>, observableListReadOnlyProperty: (M) -> ObservableList<out T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObservableList<out T>
          val observableListReadOnlyProperty: (M) -> ObservableList<out T>
        class ObservableValueDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObservableValueDelegate(klass: KClass<M>, observableValueProperty: (M) -> ObservableValue<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObservableValue<T>
          val observableValueProperty: (M) -> ObservableValue<T>
        class ObserverDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObserverDelegate(klass: KClass<M>, observerProperty: (M) -> <ERROR CLASS><T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
          val observerProperty: (M) -> <ERROR CLASS><T>
        class SubjectDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents SubjectDelegate(klass: KClass<M>, subjectProperty: (M) -> <ERROR CLASS><T, T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T, T>
          val subjectProperty: (M) -> <ERROR CLASS><T, T>
        class WritableValueDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents WritableValueDelegate(klass: KClass<M>, writableValueProperty: (M) -> WritableValue<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): WritableValue<T>
          val writableValueProperty: (M) -> WritableValue<T>
        val klass: KClass<M>
      data class TransactionBuildStep
        Module Contents TransactionBuildStep(generateMethodName: String, args: Map<String, Any?>)
        val args: Map<String, Any?>
        val generateMethodName: String
      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
        Module Contents TransactionConflictException(conflictRef: StateRef, tx1: LedgerTransaction, tx2: LedgerTransaction)
        val conflictRef: StateRef
        val tx1: LedgerTransaction
        val tx2: LedgerTransaction
      sealed class TransactionCreateStatus
        Module Contents class Failed : TransactionCreateStatus
          Module Contents Failed(message: String?)
        class Started : TransactionCreateStatus
          Module Contents Started(message: String?)
        val message: String?
        open fun toString(): String
      class TransactionDataModel
        Module Contents TransactionDataModel()
        val partiallyResolvedTransactions: <ERROR CLASS>
      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>
          Module Contents InOutGroup(inputs: List<T>, outputs: List<T>, groupingKey: K)
          val groupingKey: K
          val inputs: List<T>
          val outputs: List<T>
        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>>
        Module Contents TransactionGraphSearch(transactions: ReadOnlyTransactionStorage, startPoints: List<WireTransaction>)
        class Query
          Module Contents Query(withCommandOfType: Class<out CommandData>? = null, followInputsOfType: Class<out ContractState>? = null)
          val followInputsOfType: Class<out ContractState>?
          val withCommandOfType: Class<out CommandData>?
        fun call(): List<WireTransaction>
        var query: Query
        val startPoints: List<WireTransaction>
        val transactions: ReadOnlyTransactionStorage
      class TransactionResolutionException : Exception
        Module Contents TransactionResolutionException(hash: SecureHash)
        val hash: SecureHash
        fun toString(): String
      data class TransactionState<out T : ContractState>
        Module Contents TransactionState(data: T, notary: Party)
        val data: T
        val notary: Party
        fun withNotary(newNotary: Party): TransactionState<T>
      class TransactionStateGenerator<T : ContractState>
        Module Contents TransactionStateGenerator(stateGenerator: <ERROR CLASS><T>)
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): TransactionState<T>
        val stateGenerator: <ERROR CLASS><T>
      interface TransactionStorage : ReadOnlyTransactionStorage
        Module Contents abstract fun addTransaction(transaction: SignedTransaction): Boolean
      sealed class TransactionType
        Module Contents class General : TransactionType
          Module Contents General()
          class Builder : TransactionBuilder
            Module Contents Builder(notary: Party?)
          fun getRequiredSigners(tx: LedgerTransaction): <ERROR CLASS>
          fun verifyTransaction(tx: LedgerTransaction): Unit
        class NotaryChange : TransactionType
          Module Contents NotaryChange()
          class Builder : TransactionBuilder
            Module Contents Builder(notary: Party)
            fun addInputState(stateAndRef: StateAndRef<*>): Unit
          fun getRequiredSigners(tx: LedgerTransaction): <ERROR CLASS>
          fun verifyTransaction(tx: LedgerTransaction): Unit
        open fun equals(other: Any?): Boolean
        abstract fun getRequiredSigners(tx: LedgerTransaction): Set<CompositeKey>
        open fun hashCode(): <ERROR CLASS>
        fun verify(tx: LedgerTransaction): Unit
        fun verifySigners(tx: LedgerTransaction): Set<CompositeKey>
        abstract fun verifyTransaction(tx: LedgerTransaction): Unit
      sealed class TransactionVerificationException : Exception
        Module Contents class ContractRejection : TransactionVerificationException
          Module Contents ContractRejection(tx: LedgerTransaction, contract: Contract, cause: Throwable?)
          val contract: Contract
        enum class Direction
          Module Contents INPUT
          OUTPUT
        class InvalidNotaryChange : TransactionVerificationException
          Module Contents InvalidNotaryChange(tx: LedgerTransaction)
        class MoreThanOneNotary : TransactionVerificationException
          Module Contents MoreThanOneNotary(tx: LedgerTransaction)
        class NotaryChangeInWrongTransactionType : TransactionVerificationException
          Module Contents NotaryChangeInWrongTransactionType(tx: LedgerTransaction, outputNotary: Party)
          val outputNotary: Party
          fun toString(): String
        class SignersMissing : TransactionVerificationException
          Module Contents SignersMissing(tx: LedgerTransaction, missing: List<CompositeKey>)
          val missing: List<CompositeKey>
          fun toString(): String
        class TransactionMissingEncumbranceException : TransactionVerificationException
          Module Contents TransactionMissingEncumbranceException(tx: LedgerTransaction, missing: Int, inOut: Direction)
          val inOut: Direction
          val message: String?
          val missing: Int
        val tx: LedgerTransaction
      class TransientProperty<out T>
        Module Contents TransientProperty(initializer: () -> T)
        operator fun getValue(thisRef: Any?, property: KProperty<*>): T
      object TwoPartyDealFlow
        Module Contents class Acceptor : Secondary<AutoOffer>
          Module Contents Acceptor(otherParty: Party, progressTracker: ProgressTracker = Secondary.tracker())
          protected open fun assembleSharedTX(handshake: Handshake<AutoOffer>): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
          open val otherParty: Party
          open val progressTracker: ProgressTracker
          protected open fun validateHandshake(handshake: Handshake<AutoOffer>): Handshake<AutoOffer>
        data class AutoOffer
          Module Contents AutoOffer(notary: Party, dealBeingOffered: DealState)
          val dealBeingOffered: DealState
          val notary: Party
        class DealMismatchException : Exception
          Module Contents DealMismatchException(expectedDeal: ContractState, actualDeal: ContractState)
          val actualDeal: ContractState
          val expectedDeal: ContractState
          fun toString(): String
        class DealRefMismatchException : Exception
          Module Contents DealRefMismatchException(expectedDeal: StateRef, actualDeal: StateRef)
          val actualDeal: StateRef
          val expectedDeal: StateRef
          fun toString(): String
        data class Handshake<out T>
          Module Contents Handshake(payload: T, publicKey: CompositeKey)
          val payload: T
          val publicKey: CompositeKey
        class Instigator : Primary
          Module Contents Instigator(otherParty: Party, payload: AutoOffer, myKeyPair: KeyPair, progressTracker: ProgressTracker = Primary.tracker())
          open val myKeyPair: KeyPair
          open val notaryNode: NodeInfo
          open val otherParty: Party
          open val payload: AutoOffer
          open val progressTracker: ProgressTracker
        interface MarkerForBogusRegulatorFlow
        abstract class Primary : FlowLogic<SignedTransaction>
          Module Contents Primary(progressTracker: ProgressTracker = Primary.tracker())
          object AWAITING_PROPOSAL : Step
          object COPYING_TO_REGULATOR : Step
          object NOTARY : Step
          object RECORDING : Step
          object SENDING_SIGS : Step
          object SIGNING : Step
          object VERIFYING : Step
          open fun call(): SignedTransaction
          open fun computeOurSignature(partialTX: SignedTransaction): WithKey
          open fun getCounterpartyMarker(party: Party): Class<*>
          fun getPartialTransaction(): UntrustworthyData<SignedTransaction>
          abstract val myKeyPair: KeyPair
          abstract val notaryNode: NodeInfo
          abstract val otherParty: Party
          abstract val payload: Any
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
          fun verifyPartialTransaction(untrustedPartialTX: UntrustworthyData<SignedTransaction>): SignedTransaction
        abstract class Secondary<U> : FlowLogic<SignedTransaction>
          Module Contents Secondary(progressTracker: ProgressTracker = Secondary.tracker())
          object RECEIVING : Step
          object RECORDING : Step
          object SIGNING : Step
          object SWAPPING_SIGNATURES : Step
          object VERIFYING : Step
          protected abstract fun assembleSharedTX(handshake: Handshake<U>): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
          open fun call(): SignedTransaction
          abstract val otherParty: Party
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
          protected abstract fun validateHandshake(handshake: Handshake<U>): Handshake<U>
        class SignaturesFromPrimary
          Module Contents SignaturesFromPrimary(sellerSig: WithKey, notarySig: WithKey)
          val notarySig: WithKey
          val sellerSig: WithKey
      object TwoPartyTradeFlow
        Module Contents class AssetMismatchException : Exception
          Module Contents AssetMismatchException(expectedTypeName: String, typeName: String)
          val expectedTypeName: String
          fun toString(): String
          val typeName: String
        class Buyer : FlowLogic<SignedTransaction>
          Module Contents Buyer(otherParty: Party, notary: Party, acceptablePrice: Amount<Currency>, typeToBuy: Class<out OwnableState>)
          object RECEIVING : Step
          object SIGNING : Step
          object SWAPPING_SIGNATURES : Step
          object VERIFYING : Step
          val acceptablePrice: Amount<Currency>
          open fun call(): SignedTransaction
          val notary: Party
          val otherParty: Party
          open val progressTracker: ProgressTracker
          val typeToBuy: Class<out OwnableState>
        class Seller : FlowLogic<SignedTransaction>
          Module Contents Seller(otherParty: Party, notaryNode: NodeInfo, assetToSell: StateAndRef<OwnableState>, price: Amount<Currency>, myKeyPair: KeyPair, progressTracker: ProgressTracker = Seller.tracker())
          object AWAITING_PROPOSAL : Step
          object NOTARY : Step
          object SENDING_SIGS : Step
          object SIGNING : Step
          object VERIFYING : Step
          val assetToSell: StateAndRef<OwnableState>
          open fun calculateOurSignature(partialTX: SignedTransaction): WithKey
          open fun call(): SignedTransaction
          val myKeyPair: KeyPair
          val notaryNode: NodeInfo
          val otherParty: Party
          val price: Amount<Currency>
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
        data class SellerTradeInfo
          Module Contents SellerTradeInfo(assetForSale: StateAndRef<OwnableState>, price: Amount<Currency>, sellerOwnerKey: CompositeKey)
          val assetForSale: StateAndRef<OwnableState>
          val price: Amount<Currency>
          val sellerOwnerKey: CompositeKey
        data class SignaturesFromSeller
          Module Contents SignaturesFromSeller(sellerSig: WithKey, notarySig: WithKey)
          val notarySig: WithKey
          val sellerSig: WithKey
        class UnacceptablePriceException : Exception
          Module Contents UnacceptablePriceException(givenPrice: Amount<Currency>)
          val givenPrice: Amount<Currency>
      interface TxWritableStorageService : StorageService
        Module Contents abstract val validatedTransactions: TransactionStorage
      data class TxnNoteColumns
        Module Contents TxnNoteColumns(txId: <ERROR CLASS><SecureHash>, note: <ERROR CLASS><String>)
        val note: <ERROR CLASS><String>
        val txId: <ERROR CLASS><SecureHash>
      abstract class TypeOnlyCommandData : CommandData
        Module Contents TypeOnlyCommandData()
        open fun equals(other: Any?): Boolean
        open fun hashCode(): <ERROR CLASS>
      object UUIDStringColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      data class UniqueIdentifier : Comparable<UniqueIdentifier>
        Module Contents UniqueIdentifier(externalId: String? = null, id: UUID = UUID.randomUUID())
        fun compareTo(other: UniqueIdentifier): Int
        fun equals(other: Any?): Boolean
        val externalId: String?
        fun fromString(name: String): UniqueIdentifier
        fun hashCode(): Int
        val id: UUID
        fun toString(): String
      class UniquenessException : Exception
        Module Contents UniquenessException(error: Conflict)
        val error: Conflict
      interface UniquenessProvider
        Module Contents data class Conflict
          Module Contents Conflict(stateHistory: Map<StateRef, ConsumingTx>)
          val stateHistory: Map<StateRef, ConsumingTx>
        data class ConsumingTx
          Module Contents ConsumingTx(id: SecureHash, inputIndex: Int, requestingParty: Party)
          val id: SecureHash
          val inputIndex: Int
          val requestingParty: Party
        abstract fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      class UntrustworthyData<out T>
        Module Contents UntrustworthyData(fromUntrustedWorld: T)
        val data: T
        inline fun <R> unwrap(validator: (T) -> R): R
        inline fun <R> validate(validator: (T) -> R): R
      data class User
        Module Contents User(username: String, password: String, permissions: Set<String>)
        val password: String
        val permissions: Set<String>
        fun toString(): String
        val username: String
      class ValidatingNotaryFlow : Service
        Module Contents ValidatingNotaryFlow(otherSide: Party, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
        fun beforeCommit(stx: SignedTransaction): Unit
      class ValidatingNotaryService : NotaryService
        Module Contents ValidatingNotaryService(services: ServiceHubInternal, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
        fun createFlow(otherParty: Party): ValidatingNotaryFlow
        val timestampChecker: TimestampChecker
        val type: ServiceType
        val uniquenessProvider: UniquenessProvider
      class Vault
        Module Contents Vault(states: List<StateAndRef<ContractState>>)
        val NoUpdate: Update
        data class Update
          Module Contents Update(consumed: Set<StateAndRef<ContractState>>, produced: Set<StateAndRef<ContractState>>)
          val consumed: Set<StateAndRef<ContractState>>
          inline fun <reified T : ContractState> containsType(): Boolean
          operator fun plus(rhs: Update): Update
          val produced: Set<StateAndRef<ContractState>>
          fun toString(): String
        val states: List<StateAndRef<ContractState>>
        inline fun <reified T : ContractState> statesOfType(): List<StateAndRef<T>>
      interface VaultService
        Module Contents abstract fun addNoteToTransaction(txnId: SecureHash, noteText: String): Unit
        abstract 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): Unit
        abstract fun notifyAll(txns: Iterable<WireTransaction>): Unit
        abstract val rawUpdates: <ERROR CLASS><Update>
        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
        Module Contents fun addWhitelistEntries(serverNames: List<String>): Unit
        fun addWhitelistEntry(serverName: String): Unit
        val originalTrustProviderAlgorithm: String
        fun register(): Unit
        val whitelist: Set<String>
      class WhitelistTrustManagerSpi : TrustManagerFactorySpi
        Module Contents WhitelistTrustManagerSpi()
        protected fun engineGetTrustManagers(): Array<out TrustManager>
        protected fun engineInit(keyStore: KeyStore?): Unit
        protected fun engineInit(managerFactoryParameters: ManagerFactoryParameters?): Unit
        val originalProvider: TrustManagerFactory
      class WireNodeRegistration : SignedData<NodeRegistration>
        Module Contents WireNodeRegistration(raw: SerializedBytes<NodeRegistration>, sig: WithKey)
        protected fun verifyData(data: NodeRegistration): Unit
      class WireTransaction : BaseTransaction
        Module Contents WireTransaction(inputs: List<StateRef>, attachments: List<SecureHash>, outputs: List<TransactionState<ContractState>>, commands: List<Command>, notary: Party?, signers: List<CompositeKey>, type: TransactionType, timestamp: Timestamp?)
        val allLeavesHashes: List<SecureHash>
        val attachments: List<SecureHash>
        var cachedTree: MerkleTree?
        val commands: List<Command>
        fun deserialize(data: SerializedBytes<WireTransaction>, kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): WireTransaction
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        val id: SecureHash
        val inputs: List<StateRef>
        val merkleTree: MerkleTree
        fun <T : ContractState> outRef(index: Int): StateAndRef<T>
        fun <T : ContractState> outRef(state: ContractState): StateAndRef<T>
        val serialized: SerializedBytes<WireTransaction>
        fun toLedgerTransaction(services: ServiceHub): LedgerTransaction
        fun toString(): String
      object WireTransactionSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<WireTransaction>): WireTransaction
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: WireTransaction): Unit
      class WiredTransactionGenerator
        Module Contents WiredTransactionGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): WireTransaction
      data class WorldCoordinate
        Module Contents WorldCoordinate(latitude: Double, longitude: Double)
        val latitude: Double
        val longitude: Double
        fun project(screenWidth: Double, screenHeight: Double, topLatitude: Double, bottomLatitude: Double, leftLongitude: Double, rightLongitude: Double): <ERROR CLASS><Double, Double>
      object X509Utilities
        Module Contents data class CACertAndKey
          Module Contents CACertAndKey(certificate: X509Certificate, keyPair: KeyPair)
          val certificate: X509Certificate
          val keyPair: KeyPair
        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(keyStoreFilePath: Path, storePassword: String, keyPassword: String, caKeyStore: KeyStore, caKeyPassword: String, commonName: 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(commonName: 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
        Module Contents fun InputStream.copyTo(target: Path, vararg options: CopyOption): Long
      java.nio.file.Path
        Module Contents fun Path.createDirectories(vararg attrs: FileAttribute<*>): Path
        fun Path.createDirectory(vararg attrs: FileAttribute<*>): Path
        fun Path.deleteIfExists(): Boolean
        operator fun Path.div(other: String): Path
        fun Path.exists(vararg options: LinkOption): Boolean
        fun Path.isDirectory(vararg options: LinkOption): Boolean
        fun Path.isRegularFile(vararg options: LinkOption): Boolean
        inline fun <R> Path.list(block: (Stream<Path>) -> R): R
        fun Path.moveTo(target: Path, vararg options: CopyOption): Path
        inline fun <R> Path.read(vararg options: OpenOption, block: (InputStream) -> R): R
        fun Path.readAll(): ByteArray
        inline fun <R> Path.readLines(charset: Charset = UTF_8, block: (Stream<String>) -> R): R
        val Path.size: Long
        inline fun Path.write(createDirs: Boolean = false, vararg options: OpenOption = emptyArray(), block: (OutputStream) -> Unit): Unit
        fun Path.writeLines(lines: Iterable<CharSequence>, charset: Charset = UTF_8, vararg options: OpenOption): Path
      java.security.KeyPair
        Module Contents operator fun KeyPair.component1(): PrivateKey
        operator fun KeyPair.component2(): PublicKey
        fun KeyPair.signWithECDSA(bytesToSign: ByteArray): WithKey
        fun KeyPair.signWithECDSA(bytesToSign: OpaqueBytes): WithKey
        fun KeyPair.signWithECDSA(bytesToSign: OpaqueBytes, party: Party): LegallyIdentifiable
        fun KeyPair.signWithECDSA(bytesToSign: ByteArray, party: Party): LegallyIdentifiable
      java.security.PrivateKey
        Module Contents fun PrivateKey.signWithECDSA(bytes: ByteArray): DigitalSignature
        fun PrivateKey.signWithECDSA(bytesToSign: ByteArray, publicKey: PublicKey): WithKey
      java.security.PublicKey
        Module Contents val PublicKey.composite: CompositeKey
        fun PublicKey.toBase58String(): <ERROR CLASS>
        fun PublicKey.toStringShort(): String
        fun PublicKey.verifyWithECDSA(content: ByteArray, signature: DigitalSignature): Unit
      java.time.Clock
        Module Contents fun Clock.awaitWithDeadline(deadline: Instant, future: Future<*> = GuavaSettableFuture.create<Any>()): Boolean
      java.time.LocalDate
        Module Contents fun LocalDate.isWorkingDay(accordingToCalendar: BusinessCalendar): Boolean
      java.time.temporal.Temporal
        Module Contents infix fun Temporal.until(endExclusive: Temporal): Duration
      java.util.Currency
        Module Contents infix fun Currency.issued by(deposit: PartyAndReference): Issued<Currency>
        infix fun Currency.issuedBy(deposit: PartyAndReference): Issued<Currency>
      java.util.concurrent.Future
        Module Contents fun <T> Future<T>.getOrThrow(timeout: Duration? = null): T
      javafx.beans.value.ObservableValue
        Module Contents fun <A, B> ObservableValue<out A>.bind(function: (A) -> ObservableValue<B>): ObservableValue<B>
        fun <A, B> ObservableValue<out A>.bindOut(function: (A) -> ObservableValue<out B>): ObservableValue<out B>
        fun ObservableValue<*>.isNotNull(): BooleanBinding
        fun <A, B> ObservableValue<out A>.map(function: (A) -> B): ObservableValue<B>
      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
        Module Contents fun ByteArray.sha256(): SHA256
      kotlin.ByteArray
        Module Contents fun <T : Any> ByteArray.deserialize(kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): T
        fun ByteArray.opaque(): OpaqueBytes
        fun ByteArray.toHexString(): <ERROR CLASS>
      kotlin.Double
        Module Contents val Double.DOLLARS: Amount<Currency>
      kotlin.Double
        Module Contents val Double.bd: BigDecimal
      kotlin.Function1
        Module Contents fun <A, R> (A) -> R.lift(arg0: ObservableValue<A>): ObservableValue<R>
      kotlin.Function2
        Module Contents fun <A, B, R> (A, B) -> R.lift(arg0: ObservableValue<A>, arg1: ObservableValue<B>): ObservableValue<R>
      kotlin.Function3
        Module Contents fun <A, B, C, R> (A, B, C) -> R.lift(arg0: ObservableValue<A>, arg1: ObservableValue<B>, arg2: ObservableValue<C>): ObservableValue<R>
      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
        Module Contents val Int.DOLLARS: Amount<Currency>
        val Int.FCOJ: Amount<Commodity>
        val Int.POUNDS: Amount<Currency>
        val Int.SWISS_FRANCS: Amount<Currency>
      kotlin.Int
        Module Contents val Int.bd: BigDecimal
        infix fun Int.checkedAdd(b: Int): Int
        val Int.days: Duration
        val Int.hours: Duration
        val Int.millis: Duration
        val Int.minutes: Duration
        val Int.seconds: Duration
      kotlin.Long
        Module Contents val Long.bd: BigDecimal
        infix fun Long.checkedAdd(b: Long): Long
      kotlin.String
        Module Contents fun String.parseAsHex(): <ERROR CLASS>
      kotlin.String
        Module Contents fun String.abbreviate(maxWidth: Int): String
        val String.bd: BigDecimal
      kotlin.Throwable
        Module Contents val Throwable.rootCause: Throwable
      kotlin.collections.Collection
        Module Contents inline fun <reified T : CommandData> Collection<AuthenticatedObject<CommandData>>.requireSingleCommand(): <ERROR CLASS>
        fun <C : CommandData> Collection<AuthenticatedObject<CommandData>>.requireSingleCommand(klass: Class<C>): <ERROR CLASS>
        inline fun <reified T : CommandData> Collection<AuthenticatedObject<CommandData>>.select(signer: CompositeKey? = null, party: Party? = null): <ERROR CLASS>
        inline fun <reified T : CommandData> Collection<AuthenticatedObject<CommandData>>.select(signers: Collection<CompositeKey>?, parties: Collection<Party>?): <ERROR CLASS>
      kotlin.collections.Collection
        Module Contents fun <A> Collection<ObservableValue<out A>>.sequence(): ObservableList<A>
      kotlin.collections.Iterable
        Module Contents inline fun <reified T : ContractState> Iterable<StateAndRef<ContractState>>.filterStatesOfType(): List<StateAndRef<T>>
        fun <T> Iterable<ContractState>.sumFungibleOrNull(): <ERROR CLASS>
        fun <T> Iterable<ContractState>.sumFungibleOrZero(token: Issued<T>): <ERROR CLASS>
        fun <T> Iterable<Amount<T>>.sumOrNull(): Nothing?
        fun <T> Iterable<Amount<T>>.sumOrThrow(): <ERROR CLASS>
        fun <T> Iterable<Amount<T>>.sumOrZero(currency: T): Amount<T>
      kotlin.collections.Iterable
        Module Contents fun Iterable<WithKey>.byKeys(): <ERROR CLASS>
        val Iterable<CompositeKey>.keys: Set<PublicKey>
      kotlin.collections.Iterable
        Module Contents fun Iterable<ServiceInfo>.containsType(type: ServiceType): <ERROR CLASS>
      kotlin.collections.Iterable
        Module Contents fun <T> Iterable<T>.noneOrSingle(predicate: (T) -> Boolean): T?
        fun <T> Iterable<T>.noneOrSingle(): T?
        fun Iterable<BigDecimal>.sum(): BigDecimal
      kotlin.collections.Iterable
        Module Contents fun Iterable<ContractState>.sumCash(): Amount<Issued<Currency>>
        fun Iterable<ContractState>.sumCashBy(owner: CompositeKey): Amount<Issued<Currency>>
        fun Iterable<ContractState>.sumCashOrNull(): Amount<Issued<Currency>>?
        fun Iterable<ContractState>.sumCashOrZero(currency: Issued<Currency>): Amount<Issued<Currency>>
        fun Iterable<ContractState>.sumCommodities(): <ERROR CLASS>
        fun Iterable<ContractState>.sumCommoditiesOrNull(): <ERROR CLASS>
        fun Iterable<ContractState>.sumCommoditiesOrZero(currency: Issued<Commodity>): <ERROR CLASS>
        fun <P> Iterable<ContractState>.sumObligations(): Amount<Issued<Terms<P>>>
        fun <P> Iterable<ContractState>.sumObligationsOrNull(): Amount<Issued<Terms<P>>>?
        fun <P> Iterable<ContractState>.sumObligationsOrZero(issuanceDef: Issued<Terms<P>>): Amount<Issued<Terms<P>>>
      kotlin.collections.List
        Module Contents fun <T> List<T>.indexOfOrThrow(item: T): Int
        fun <T> List<T>.randomOrNull(): T?
        fun <T> List<T>.randomOrNull(predicate: (T) -> Boolean): <ERROR CLASS>
    package net.corda.client.fxutils
      Module Contents class AggregatedList<A, E : Any, K : Any> : TransformationList<A, E>
        Module Contents AggregatedList(list: ObservableList<out E>, toKey: (E) -> K, assemble: (K, ObservableList<E>) -> A)
        val assemble: (K, ObservableList<E>) -> A
        fun get(index: Int): A?
        fun getSourceIndex(index: Int): Int
        val size: Int
        protected fun sourceChanged(c: Change<out E>): Unit
        val toKey: (E) -> K
      object AmountBindings
        Module Contents fun exchange(currency: ObservableValue<Currency>, exchangeRate: ObservableValue<ExchangeRate>): ObservableValue<<ERROR CLASS><Currency, (Amount<Currency>) -> Long>>
        fun <T> sum(amounts: ObservableList<Amount<T>>, token: T): <ERROR CLASS>
        fun sumAmountExchange(amounts: ObservableList<Amount<Currency>>, currency: ObservableValue<Currency>, exchangeRate: ObservableValue<ExchangeRate>): ObservableValue<Amount<Currency>>
      class AssociatedList<K, out A, B> : ReadOnlyBackedObservableMapBase<K, B, Unit>
        Module Contents AssociatedList(sourceList: ObservableList<out A>, toKey: (A) -> K, assemble: (K, A) -> B)
        val sourceList: ObservableList<out A>
      class ChosenList<E> : ObservableListBase<E>
        Module Contents ChosenList(chosenListObservable: ObservableValue<out ObservableList<out E>>)
        fun get(index: Int): E
        val size: Int
      class ConcatenatedList<A> : TransformationList<A, ObservableList<A>>
        Module Contents ConcatenatedList(sourceList: ObservableList<ObservableList<A>>)
        fun get(index: Int): A
        fun getSourceIndex(index: Int): Int
        val size: Int
        protected fun sourceChanged(change: Change<out ObservableList<A>>): Unit
      class FlattenedList<A> : TransformationList<A, ObservableValue<out A>>
        Module Contents FlattenedList(sourceList: ObservableList<out ObservableValue<out A>>)
        class WrappedObservableValue<A>
          Module Contents WrappedObservableValue(observableValue: ObservableValue<A>)
          val observableValue: ObservableValue<A>
        fun get(index: Int): A
        fun getSourceIndex(index: Int): Int
        val indexMap: HashMap<WrappedObservableValue<out A>, <ERROR CLASS><Int, ChangeListener<A>>>
        val size: Int
        protected fun sourceChanged(c: Change<out ObservableValue<out A>>): Unit
        val sourceList: ObservableList<out ObservableValue<out A>>
      class LeftOuterJoinedMap<K : Any, A, B, C> : ReadOnlyBackedObservableMapBase<K, C, SimpleObjectProperty<B?>>
        Module Contents LeftOuterJoinedMap(leftTable: ObservableMap<K, out A>, rightTable: ObservableMap<K, out B>, assemble: (K, A, ObservableValue<B?>) -> C)
        val leftTable: ObservableMap<K, out A>
        val rightTable: ObservableMap<K, out B>
      class MapValuesList<K, A, C> : ObservableList<C>
        Module Contents fun <K, A, C> create(sourceMap: ObservableMap<K, A>, assemble: (Entry<K, A>) -> C): MapValuesList<K, A, C>
        val sourceMap: ObservableMap<K, A>
      class MappedList<A, B> : TransformationList<B, A>
        Module Contents MappedList(list: ObservableList<A>, function: (A) -> B)
        val function: (A) -> B
        fun get(index: Int): B
        fun getSourceIndex(index: Int): Int
        val size: Int
        protected fun sourceChanged(change: Change<out A>): Unit
      open class ReadOnlyBackedObservableMapBase<K, A, B> : ObservableMap<K, A>
        Module Contents ReadOnlyBackedObservableMapBase()
        open fun addListener(listener: InvalidationListener): Unit
        open fun addListener(listener: MapChangeListener<in K, in A>?): Unit
        protected val backingMap: HashMap<K, <ERROR CLASS><A, B>>
        open fun clear(): Unit
        open fun containsKey(key: K): Boolean
        open fun containsValue(value: A): <ERROR CLASS>
        open val entries: MutableSet<MutableEntry<K, A>>
        protected fun fireChange(change: Change<out K, out A>): Unit
        open fun get(key: K): <ERROR CLASS>
        open fun isEmpty(): Boolean
        open val keys: MutableSet<K>
        open fun put(key: K, value: A): A
        open fun putAll(from: Map<out K, A>): Unit
        open fun remove(key: K): A
        open fun removeListener(listener: InvalidationListener?): Unit
        open fun removeListener(listener: MapChangeListener<in K, in A>?): Unit
        open val size: Int
        open val values: MutableCollection<A>
      class ReplayedList<A> : TransformationList<A, A>
        Module Contents ReplayedList(sourceList: ObservableList<A>)
        fun get(index: Int): A
        fun getSourceIndex(index: Int): Int
        val replayedList: ArrayList<A>
        val size: Int
        protected fun sourceChanged(c: Change<out A>): Unit
      fun <T, R> <ERROR CLASS><T>.fold(accumulator: R, folderFun: (R, T) -> Unit): R
      fun <A, B> <ERROR CLASS><A>.foldToObservableValue(initial: B, folderFun: (A, B) -> B): ObservableValue<B>
      javafx.beans.value.ObservableValue
        Module Contents fun <A, B> ObservableValue<out A>.bind(function: (A) -> ObservableValue<B>): ObservableValue<B>
        fun <A, B> ObservableValue<out A>.bindOut(function: (A) -> ObservableValue<out B>): ObservableValue<out B>
        fun ObservableValue<*>.isNotNull(): BooleanBinding
        fun <A, B> ObservableValue<out A>.map(function: (A) -> B): ObservableValue<B>
      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
        Module Contents fun <A, R> (A) -> R.lift(arg0: ObservableValue<A>): ObservableValue<R>
      kotlin.Function2
        Module Contents fun <A, B, R> (A, B) -> R.lift(arg0: ObservableValue<A>, arg1: ObservableValue<B>): ObservableValue<R>
      kotlin.Function3
        Module Contents fun <A, B, C, R> (A, B, C) -> R.lift(arg0: ObservableValue<A>, arg1: ObservableValue<B>, arg2: ObservableValue<C>): ObservableValue<R>
      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
        Module Contents fun <A> Collection<ObservableValue<out A>>.sequence(): ObservableList<A>
      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, A>
      fun <A> <ERROR CLASS><A>.recordInSequence(): ObservableList<A>
    package net.corda.client.mock
      Module Contents class EventGenerator
        Module Contents EventGenerator(parties: List<Party>, notary: Party, currencies: List<Currency> = listOf(USD, GBP, CHF), issuers: List<Party> = parties)
        val amountGenerator: Generator<Amount<Currency>>
        val amountIssuedGenerator: Generator<Amount<Issued<Currency>>>
        val bankOfCordaExitGenerator: <ERROR CLASS>
        val bankOfCordaIssueGenerator: <ERROR CLASS>
        val cashStateGenerator: <ERROR CLASS>
        val clientCommandGenerator: <ERROR CLASS>
        val consumedGenerator: Generator<Set<StateRef>>
        val currencies: List<Currency>
        val currencyGenerator: Generator<Currency>
        val exitCashGenerator: Generator<ExitCash>
        val issueCashGenerator: Generator<IssueCash>
        val issueRefGenerator: Generator<OpaqueBytes>
        val issuedGenerator: Generator<Issued<Currency>>
        val issuerGenerator: Generator<PartyAndReference>
        val issuers: List<Party>
        val moveCashGenerator: Generator<PayCash>
        val notary: Party
        val parties: List<Party>
        val partyGenerator: Generator<Party>
        val producedGenerator: Generator<Set<StateAndRef<ContractState>>>
        val publicKeyGenerator: <ERROR CLASS>
      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
        Module Contents ContractStateModel()
        val cash: ObservableList<Amount<Issued<Currency>>>
        val cashStates: ObservableList<StateAndRef<State>>
      data class Diff<out T : ContractState>
        Module Contents Diff(added: Collection<StateAndRef<T>>, removed: Collection<StateAndRef<T>>)
        val added: Collection<StateAndRef<T>>
        val removed: Collection<StateAndRef<T>>
      interface ExchangeRate
        Module Contents abstract fun rate(from: Currency, to: Currency): Double
      class ExchangeRateModel
        Module Contents ExchangeRateModel()
        val exchangeRate: ObservableValue<ExchangeRate>
      data class FlowStatus
        Module Contents FlowStatus(status: String)
        val status: String
      data class GatheredTransactionData
        Module Contents GatheredTransactionData(transaction: PartiallyResolvedTransaction, stateMachines: ObservableList<out StateMachineData>)
        val stateMachines: ObservableList<out StateMachineData>
        val transaction: PartiallyResolvedTransaction
      object Models
        Module Contents fun <M : Any> get(klass: KClass<M>, origin: KClass<*>): M
        inline fun <reified M : Any> get(origin: KClass<*>): M
        fun <M : Any> initModel(klass: KClass<M>): <ERROR CLASS>
      class NetworkIdentityModel
        Module Contents NetworkIdentityModel()
        fun lookup(compositeKey: CompositeKey): ObservableValue<NodeInfo?>
        fun lookup(publicKey: PublicKey): ObservableValue<NodeInfo?>
        val myIdentity: ObservableValue<NodeInfo?>
        val networkIdentities: ObservableList<NodeInfo>
        val notaries: ObservableList<NodeInfo>
        val parties: ObservableList<NodeInfo>
      class NodeMonitorModel
        Module Contents NodeMonitorModel()
        val networkMap: <ERROR CLASS><MapChange>
        val progressTracking: <ERROR CLASS><ProgressTrackingEvent>
        val proxyObservable: SimpleObjectProperty<CordaRPCOps?>
        fun register(nodeHostAndPort: <ERROR CLASS>, sslConfig: NodeSSLConfiguration, username: String, password: String): Unit
        val stateMachineTransactionMapping: <ERROR CLASS><StateMachineTransactionMapping>
        val stateMachineUpdates: <ERROR CLASS><StateMachineUpdate>
        val transactions: <ERROR CLASS><SignedTransaction>
        val vaultUpdates: <ERROR CLASS><Update>
      data class PartiallyResolvedTransaction
        Module Contents PartiallyResolvedTransaction(transaction: SignedTransaction, inputs: List<ObservableValue<InputResolution>>)
        sealed class InputResolution
          Module Contents class Resolved : InputResolution
            Module Contents Resolved(stateAndRef: StateAndRef<ContractState>)
            val stateAndRef: StateAndRef<ContractState>
          class Unresolved : InputResolution
            Module Contents Unresolved(stateRef: StateRef)
          val stateRef: StateRef
        fun fromSignedTransaction(transaction: SignedTransaction, transactions: ObservableMap<SecureHash, SignedTransaction>): PartiallyResolvedTransaction
        val id: SecureHash
        val inputs: List<ObservableValue<InputResolution>>
        val transaction: SignedTransaction
      data class ProgressTrackingEvent
        Module Contents ProgressTrackingEvent(stateMachineId: StateMachineRunId, message: String)
        fun createStreamFromStateMachineInfo(stateMachine: StateMachineInfo): <ERROR CLASS><ProgressTrackingEvent>?
        val message: String
        val stateMachineId: StateMachineRunId
      data class StateMachineData
        Module Contents StateMachineData(id: StateMachineRunId, flowStatus: ObservableValue<FlowStatus?>, stateMachineStatus: ObservableValue<StateMachineStatus>)
        val flowStatus: ObservableValue<FlowStatus?>
        val id: StateMachineRunId
        val stateMachineStatus: ObservableValue<StateMachineStatus>
      sealed class StateMachineStatus
        Module Contents class Added : StateMachineStatus
          Module Contents Added(stateMachineName: String)
        class Removed : StateMachineStatus
          Module Contents Removed(stateMachineName: String)
        val stateMachineName: String
        open fun toString(): String
      sealed class TrackedDelegate<M : Any>
        Module Contents class EventSinkDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents EventSinkDelegate(klass: KClass<M>, eventSinkProperty: (M) -> <ERROR CLASS><T>)
          val eventSinkProperty: (M) -> <ERROR CLASS><T>
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
        class EventStreamDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents EventStreamDelegate(klass: KClass<M>, eventStreamProperty: (M) -> <ERROR CLASS><T>)
          val eventStreamProperty: (M) -> <ERROR CLASS><T>
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
        class ObjectPropertyDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObjectPropertyDelegate(klass: KClass<M>, objectPropertyProperty: (M) -> ObjectProperty<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObjectProperty<T>
          val objectPropertyProperty: (M) -> ObjectProperty<T>
        class ObservableDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObservableDelegate(klass: KClass<M>, observableProperty: (M) -> <ERROR CLASS><T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
          val observableProperty: (M) -> <ERROR CLASS><T>
        class ObservableListDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObservableListDelegate(klass: KClass<M>, observableListProperty: (M) -> ObservableList<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObservableList<T>
          val observableListProperty: (M) -> ObservableList<T>
        class ObservableListReadOnlyDelegate<M : Any, out T> : TrackedDelegate<M>
          Module Contents ObservableListReadOnlyDelegate(klass: KClass<M>, observableListReadOnlyProperty: (M) -> ObservableList<out T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObservableList<out T>
          val observableListReadOnlyProperty: (M) -> ObservableList<out T>
        class ObservableValueDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObservableValueDelegate(klass: KClass<M>, observableValueProperty: (M) -> ObservableValue<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): ObservableValue<T>
          val observableValueProperty: (M) -> ObservableValue<T>
        class ObserverDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents ObserverDelegate(klass: KClass<M>, observerProperty: (M) -> <ERROR CLASS><T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T>
          val observerProperty: (M) -> <ERROR CLASS><T>
        class SubjectDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents SubjectDelegate(klass: KClass<M>, subjectProperty: (M) -> <ERROR CLASS><T, T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): <ERROR CLASS><T, T>
          val subjectProperty: (M) -> <ERROR CLASS><T, T>
        class WritableValueDelegate<M : Any, T> : TrackedDelegate<M>
          Module Contents WritableValueDelegate(klass: KClass<M>, writableValueProperty: (M) -> WritableValue<T>)
          operator fun getValue(thisRef: Any, property: KProperty<*>): WritableValue<T>
          val writableValueProperty: (M) -> WritableValue<T>
        val klass: KClass<M>
      sealed class TransactionCreateStatus
        Module Contents class Failed : TransactionCreateStatus
          Module Contents Failed(message: String?)
        class Started : TransactionCreateStatus
          Module Contents Started(message: String?)
        val message: String?
        open fun toString(): String
      class TransactionDataModel
        Module Contents TransactionDataModel()
        val partiallyResolvedTransactions: <ERROR CLASS>
      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
      Module Contents val CP_LEGACY_PROGRAM_ID: CommercialPaperLegacy
      val CP_PROGRAM_ID: CommercialPaper
      class CommercialPaper : Contract
        Module Contents CommercialPaper()
        interface Clauses
          Module Contents class Group : GroupClauseVerifier<State, Commands, Issued<Terms>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State, Issued<Terms>>>
          class Issue : AbstractIssue<State, Commands, Terms>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State>, outputs: List<State>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms>?): Set<Commands>
          class Move : Clause<State, Commands, Issued<Terms>>
            Module Contents Move()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State>, outputs: List<State>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms>?): Set<Commands>
          class Redeem : Clause<State, Commands, Issued<Terms>>
            Module Contents Redeem()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State>, outputs: List<State>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms>?): Set<Commands>
        interface Commands : CommandData
          Module Contents data class Issue : IssueCommand, Commands
            Module Contents Issue(nonce: Long = random63BitValue())
            val nonce: Long
          data class Move : Move, Commands
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
          class Redeem : TypeOnlyCommandData, Commands
            Module Contents Redeem()
        data class State : OwnableState, QueryableState
          Module Contents State(issuance: PartyAndReference, owner: CompositeKey, faceValue: Amount<Issued<Currency>>, maturityDate: Instant)
          val contract: CommercialPaper
          val faceValue: Amount<Issued<Currency>>
          fun generateMappedObject(schema: MappedSchema): PersistentState
          val issuance: PartyAndReference
          val maturityDate: Instant
          val owner: CompositeKey
          val participants: List<CompositeKey>
          fun supportedSchemas(): Iterable<MappedSchema>
          fun toString(): String
          val token: Issued<Terms>
          fun withFaceValue(newFaceValue: Amount<Issued<Currency>>): <ERROR CLASS>
          fun withIssuance(newIssuance: PartyAndReference): <ERROR CLASS>
          fun withMaturityDate(newMaturityDate: Instant): <ERROR CLASS>
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
          fun withOwner(newOwner: CompositeKey): <ERROR CLASS>
        data class Terms
          Module Contents Terms(asset: Issued<Currency>, maturityDate: Instant)
          val asset: Issued<Currency>
          val maturityDate: Instant
        fun generateIssue(issuance: PartyAndReference, faceValue: Amount<Issued<Currency>>, maturityDate: Instant, notary: Party): TransactionBuilder
        fun generateMove(tx: TransactionBuilder, paper: StateAndRef<State>, newOwner: CompositeKey): Unit
        fun generateRedeem(tx: TransactionBuilder, paper: StateAndRef<State>, vault: VaultService): Unit
        val legalContractReference: SecureHash
        fun verify(tx: TransactionForContract): Unit
      class CommercialPaperLegacy : Contract
        Module Contents CommercialPaperLegacy()
        interface Commands : CommandData
          Module Contents class Issue : TypeOnlyCommandData, Commands
            Module Contents Issue()
          class Move : TypeOnlyCommandData, Commands
            Module Contents Move()
          class Redeem : TypeOnlyCommandData, Commands
            Module Contents Redeem()
        data class State : OwnableState
          Module Contents State(issuance: PartyAndReference, owner: CompositeKey, faceValue: Amount<Issued<Currency>>, maturityDate: Instant)
          val contract: CommercialPaperLegacy
          val faceValue: Amount<Issued<Currency>>
          val issuance: PartyAndReference
          val maturityDate: Instant
          val owner: CompositeKey
          val participants: <ERROR CLASS>
          fun toString(): String
          fun withFaceValue(newFaceValue: Amount<Issued<Currency>>): <ERROR CLASS>
          fun withIssuance(newIssuance: PartyAndReference): <ERROR CLASS>
          fun withMaturityDate(newMaturityDate: Instant): <ERROR CLASS>
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
          fun withOwner(newOwner: CompositeKey): <ERROR CLASS>
          fun withoutOwner(): State
        fun generateIssue(issuance: PartyAndReference, faceValue: Amount<Issued<Currency>>, maturityDate: Instant, notary: Party): TransactionBuilder
        fun generateMove(tx: TransactionBuilder, paper: StateAndRef<State>, newOwner: CompositeKey): Unit
        fun generateRedeem(tx: TransactionBuilder, paper: StateAndRef<State>, vault: VaultService): Unit
        val legalContractReference: SecureHash
        fun verify(tx: TransactionForContract): Unit
      infix fun State.owned by(owner: CompositeKey): State
      infix fun <ERROR CLASS>.owned by(newOwner: CompositeKey): <ERROR CLASS>
      infix fun State.with notary(notary: Party): TransactionState<State>
    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
          Module Contents class ConserveAmount : AbstractConserveAmount<State, Commands, Currency>
            Module Contents ConserveAmount()
          class Group : GroupClauseVerifier<State, Commands, Issued<Currency>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State, Issued<Currency>>>
          class Issue : AbstractIssue<State, Commands, Currency>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
        interface Commands : Commands
          Module Contents data class Exit : Commands, Exit<Currency>
            Module Contents Exit(amount: Amount<Issued<Currency>>)
            val amount: Amount<Issued<Currency>>
          data class Issue : Issue, Commands
            Module Contents Issue(nonce: Long = newSecureRandom().nextLong())
            val nonce: Long
          data class Move : Move, Commands
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
        data class State : FungibleAsset<Currency>, QueryableState
          Module Contents State(deposit: PartyAndReference, amount: Amount<Currency>, owner: CompositeKey)
          State(amount: Amount<Issued<Currency>>, owner: CompositeKey, encumbrance: Int? = null)
          val amount: Amount<Issued<Currency>>
          val contract: Cash
          val encumbrance: Int?
          val exitKeys: <ERROR CLASS>
          fun generateMappedObject(schema: MappedSchema): PersistentState
          fun move(newAmount: Amount<Issued<Currency>>, newOwner: CompositeKey): FungibleAsset<Currency>
          val owner: CompositeKey
          val participants: <ERROR CLASS>
          fun supportedSchemas(): Iterable<MappedSchema>
          fun toString(): String
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        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
          Module Contents class ConserveAmount : AbstractConserveAmount<State, Commands, Commodity>
            Module Contents ConserveAmount()
          class Group : GroupClauseVerifier<State, Commands, Issued<Commodity>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State, Issued<Commodity>>>
          class Issue : AbstractIssue<State, Commands, Commodity>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
        interface Commands : Commands
          Module Contents data class Exit : Commands, Exit<Commodity>
            Module Contents Exit(amount: Amount<Issued<Commodity>>)
            val amount: Amount<Issued<Commodity>>
          data class Issue : Issue, Commands
            Module Contents Issue(nonce: Long = newSecureRandom().nextLong())
            val nonce: Long
          data class Move : Move, Commands
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
        data class State : FungibleAsset<Commodity>
          Module Contents State(deposit: PartyAndReference, amount: Amount<Commodity>, owner: CompositeKey)
          State(amount: Amount<Issued<Commodity>>, owner: CompositeKey)
          val amount: Amount<Issued<Commodity>>
          val contract: CommodityContract
          val exitKeys: MutableSet<CompositeKey>
          fun move(newAmount: Amount<Issued<Commodity>>, newOwner: CompositeKey): FungibleAsset<Commodity>
          val owner: CompositeKey
          val participants: <ERROR CLASS>
          fun toString(): String
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        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>>
            Module Contents ConserveAmount()
          class Group<P> : GroupClauseVerifier<State<P>, Commands, Issued<Terms<P>>>
            Module Contents Group()
            fun groupStates(tx: TransactionForContract): List<InOutGroup<State<P>, Issued<Terms<P>>>>
          class Issue<P> : AbstractIssue<State<P>, Commands, Terms<P>>
            Module Contents Issue()
            val requiredCommands: Set<Class<out CommandData>>
          class Net<C : CommandData, P> : NetClause<C, P>
            Module Contents Net()
            val lifecycleClause: VerifyLifecycle<ContractState, C, Unit, P>
            fun toString(): String
            fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
          class SetLifecycle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
            Module Contents SetLifecycle()
            val requiredCommands: Set<Class<out CommandData>>
            fun toString(): String
            fun verify(tx: TransactionForContract, inputs: List<State<P>>, outputs: List<State<P>>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms<P>>?): Set<Commands>
          class Settle<P> : Clause<State<P>, Commands, Issued<Terms<P>>>
            Module Contents Settle()
            val requiredCommands: Set<Class<out CommandData>>
            fun verify(tx: TransactionForContract, inputs: List<State<P>>, outputs: List<State<P>>, commands: List<AuthenticatedObject<Commands>>, groupingKey: Issued<Terms<P>>?): Set<Commands>
          class VerifyLifecycle<S : ContractState, C : CommandData, T : Any, P> : Clause<S, C, T>
            Module Contents VerifyLifecycle()
            fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: T?): Set<C>
        interface Commands : Commands
          Module Contents data class Exit<P> : Commands, Exit<Terms<P>>
            Module Contents Exit(amount: Amount<Issued<Terms<P>>>)
            val amount: Amount<Issued<Terms<P>>>
          data class Issue : Issue, Commands
            Module Contents Issue(nonce: Long = random63BitValue())
            val nonce: Long
          data class Move : Commands, Move
            Module Contents Move(contractHash: SecureHash? = null)
            val contractHash: SecureHash?
          data class Net : NetCommand, Commands
            Module Contents Net(type: NetType)
            val type: NetType
          data class SetLifecycle : Commands
            Module Contents SetLifecycle(lifecycle: Lifecycle)
            val inverse: Lifecycle
            val lifecycle: Lifecycle
          data class Settle<P> : Commands
            Module Contents Settle(amount: Amount<Issued<Terms<P>>>)
            val amount: Amount<Issued<Terms<P>>>
        enum class Lifecycle
          Module Contents DEFAULTED
          NORMAL
        data class State<P> : FungibleAsset<Terms<P>>, NettableState<State<P>, MultilateralNetState<P>>
          Module Contents State(lifecycle: Lifecycle = Lifecycle.NORMAL, obligor: Party, template: Terms<P>, quantity: Long, beneficiary: CompositeKey)
          val amount: Amount<Issued<Terms<P>>>
          val beneficiary: CompositeKey
          val bilateralNetState: BilateralNetState<P>
          val contract: Obligation<Currency>
          val dueBefore: Instant
          val exitKeys: Collection<CompositeKey>
          var lifecycle: Lifecycle
          fun move(newAmount: Amount<Issued<Terms<P>>>, newOwner: CompositeKey): State<P>
          val multilateralNetState: MultilateralNetState<P>
          fun net(other: State<P>): State<P>
          val obligor: Party
          val owner: CompositeKey
          val participants: List<CompositeKey>
          val quantity: Long
          val template: Terms<P>
          fun toString(): String
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        data class Terms<P>
          Module Contents Terms(acceptableContracts: NonEmptySet<SecureHash>, acceptableIssuedProducts: NonEmptySet<Issued<P>>, dueBefore: Instant, timeTolerance: Duration = Duration.ofSeconds(30))
          val acceptableContracts: NonEmptySet<SecureHash>
          val acceptableIssuedProducts: NonEmptySet<Issued<P>>
          val dueBefore: Instant
          val product: P
          val timeTolerance: Duration
        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
        Module Contents OnLedgerAsset()
        abstract val conserveClause: AbstractConserveAmount<S, C, T>
        abstract fun deriveState(txState: TransactionState<S>, amount: Amount<Issued<T>>, owner: CompositeKey): TransactionState<S>
        abstract fun extractCommands(commands: Collection<AuthenticatedObject<CommandData>>): Collection<AuthenticatedObject<C>>
        fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<T>>, assetStates: List<StateAndRef<S>>): CompositeKey
        abstract fun generateExitCommand(amount: Amount<Issued<T>>): Exit<T>
        abstract fun generateIssueCommand(): Issue
        abstract fun generateMoveCommand(): Move
      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(product: Terms<P>, states: 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
        Module Contents fun Iterable<ContractState>.sumCash(): Amount<Issued<Currency>>
        fun Iterable<ContractState>.sumCashBy(owner: CompositeKey): Amount<Issued<Currency>>
        fun Iterable<ContractState>.sumCashOrNull(): Amount<Issued<Currency>>?
        fun Iterable<ContractState>.sumCashOrZero(currency: Issued<Currency>): Amount<Issued<Currency>>
        fun Iterable<ContractState>.sumCommodities(): <ERROR CLASS>
        fun Iterable<ContractState>.sumCommoditiesOrNull(): <ERROR CLASS>
        fun Iterable<ContractState>.sumCommoditiesOrZero(currency: Issued<Commodity>): <ERROR CLASS>
        fun <P> Iterable<ContractState>.sumObligations(): Amount<Issued<Terms<P>>>
        fun <P> Iterable<ContractState>.sumObligationsOrNull(): Amount<Issued<Terms<P>>>?
        fun <P> Iterable<ContractState>.sumObligationsOrZero(issuanceDef: Issued<Terms<P>>): Amount<Issued<Terms<P>>>
      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>>
        Module Contents AbstractIssue(sum: List<S>.() -> Amount<Issued<T>>, sumOrZero: List<S>.(Issued<T>) -> Amount<Issued<T>>)
        val sum: List<S>.() -> Amount<Issued<T>>
        val sumOrZero: List<S>.(Issued<T>) -> Amount<Issued<T>>
        open fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Issued<T>?): Set<C>
      data class BilateralNetState<P> : NetState<P>
        Module Contents BilateralNetState(partyKeys: Set<CompositeKey>, template: Terms<P>)
        val partyKeys: Set<CompositeKey>
        val template: Terms<P>
      data class MultilateralNetState<P> : NetState<P>
        Module Contents MultilateralNetState(template: Terms<P>)
        val template: Terms<P>
      open class NetClause<C : CommandData, P> : Clause<ContractState, C, Unit>
        Module Contents NetClause()
        open val requiredCommands: Set<Class<out CommandData>>
        open fun verify(tx: TransactionForContract, inputs: List<ContractState>, outputs: List<ContractState>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
        fun verifyNetCommand(inputs: List<State<P>>, outputs: List<State<P>>, command: AuthenticatedObject<NetCommand>, netState: NetState<P>): Unit
      interface NetState<P>
        Module Contents abstract val template: Terms<P>
      open class NoZeroSizedOutputs<in S : FungibleAsset<T>, C : CommandData, T : Any> : Clause<S, C, Issued<T>>
        Module Contents NoZeroSizedOutputs()
        open fun toString(): String
        open fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Issued<T>?): Set<C>
    package net.corda.contracts.testing
      Module Contents class CommandDataGenerator
        Module Contents CommandDataGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): CommandData
      class CommandGenerator
        Module Contents CommandGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Command
      class ContractStateGenerator
        Module Contents ContractStateGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): ContractState
      class ExitGenerator
        Module Contents ExitGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Exit
      class IssueGenerator
        Module Contents IssueGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Issue
      class MoveGenerator
        Module Contents MoveGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Move
      class SignedTransactionGenerator
        Module Contents SignedTransactionGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): SignedTransaction
      class WiredTransactionGenerator
        Module Contents WiredTransactionGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): WireTransaction
      fun calculateRandomlySizedAmounts(howMuch: Amount<Currency>, min: Int, max: Int, rng: Random): LongArray
      fun ServiceHub.fillWithSomeTestCash(howMuch: Amount<Currency>, outputNotary: Party = DUMMY_NOTARY, atLeastThisManyStates: Int = 3, atMostThisManyStates: Int = 10, rng: Random = Random(), ref: OpaqueBytes = OpaqueBytes(ByteArray(1, { 1 })), ownedBy: CompositeKey? = null, issuedBy: PartyAndReference = DUMMY_CASH_ISSUER, issuerKey: KeyPair = DUMMY_CASH_ISSUER_KEY): Vault
    package net.corda.core
      Module Contents data class ErrorOr<out A>
        Module Contents ErrorOr(value: A)
        fun <B : Any> bind(function: (A) -> ErrorOr<B>): ErrorOr<B>
        inline fun <T : Any> catch(body: () -> T): ErrorOr<T>
        fun <B, C> combine(other: ErrorOr<B>, function: (A, B) -> C): ErrorOr<C>
        val error: Throwable?
        fun getOrThrow(): A
        fun <B> map(function: (A) -> B): <ERROR CLASS>
        fun <T> match(onValue: (A) -> T, onError: (Throwable) -> T): T
        fun of(t: Throwable): ErrorOr<Nothing>
        val value: A?
      abstract class RetryableException : Exception
        Module Contents RetryableException(message: String)
      val RunOnCallerThread: Executor
      class ThreadBox<out T>
        Module Contents ThreadBox(content: T, lock: ReentrantLock = ReentrantLock())
        inline fun <R> alreadyLocked(body: T.() -> R): R
        fun checkNotLocked(): <ERROR CLASS>
        val content: T
        val lock: ReentrantLock
        inline fun <R> locked(body: T.() -> R): R
      class TransientProperty<out T>
        Module Contents TransientProperty(initializer: () -> T)
        operator fun getValue(thisRef: Any?, property: KProperty<*>): T
      fun <T> <ERROR CLASS><T>.bufferUntilSubscribed(): <ERROR CLASS><T>
      inline fun <T> <ERROR CLASS><T>.catch(block: () -> T): Unit
      fun extractZipFile(zipPath: Path, toPath: Path): Unit
      fun <T> <ERROR CLASS><T>.failure(executor: Executor, body: (Throwable) -> Unit): <ERROR CLASS>
      infix fun <T> <ERROR CLASS><T>.failure(body: (Throwable) -> Unit): <ERROR CLASS><T>
      infix fun <F, T> <ERROR CLASS><F>.flatMap(mapper: (F) -> <ERROR CLASS><T>): <ERROR CLASS><T>
      fun <T> future(block: () -> T): <ERROR CLASS><T>
      java.io.InputStream
        Module Contents fun InputStream.copyTo(target: Path, vararg options: CopyOption): Long
      java.nio.file.Path
        Module Contents fun Path.createDirectories(vararg attrs: FileAttribute<*>): Path
        fun Path.createDirectory(vararg attrs: FileAttribute<*>): Path
        fun Path.deleteIfExists(): Boolean
        operator fun Path.div(other: String): Path
        fun Path.exists(vararg options: LinkOption): Boolean
        fun Path.isDirectory(vararg options: LinkOption): Boolean
        fun Path.isRegularFile(vararg options: LinkOption): Boolean
        inline fun <R> Path.list(block: (Stream<Path>) -> R): R
        fun Path.moveTo(target: Path, vararg options: CopyOption): Path
        inline fun <R> Path.read(vararg options: OpenOption, block: (InputStream) -> R): R
        fun Path.readAll(): ByteArray
        inline fun <R> Path.readLines(charset: Charset = UTF_8, block: (Stream<String>) -> R): R
        val Path.size: Long
        inline fun Path.write(createDirs: Boolean = false, vararg options: OpenOption = emptyArray(), block: (OutputStream) -> Unit): Unit
        fun Path.writeLines(lines: Iterable<CharSequence>, charset: Charset = UTF_8, vararg options: OpenOption): Path
      java.time.temporal.Temporal
        Module Contents infix fun Temporal.until(endExclusive: Temporal): Duration
      java.util.concurrent.Future
        Module Contents fun <T> Future<T>.getOrThrow(timeout: Duration? = null): T
      kotlin.Double
        Module Contents val Double.bd: BigDecimal
      kotlin.Int
        Module Contents val Int.bd: BigDecimal
        infix fun Int.checkedAdd(b: Int): Int
        val Int.days: Duration
        val Int.hours: Duration
        val Int.millis: Duration
        val Int.minutes: Duration
        val Int.seconds: Duration
      kotlin.Long
        Module Contents val Long.bd: BigDecimal
        infix fun Long.checkedAdd(b: Long): Long
      kotlin.String
        Module Contents fun String.abbreviate(maxWidth: Int): String
        val String.bd: BigDecimal
      kotlin.Throwable
        Module Contents val Throwable.rootCause: Throwable
      kotlin.collections.Iterable
        Module Contents fun <T> Iterable<T>.noneOrSingle(predicate: (T) -> Boolean): T?
        fun <T> Iterable<T>.noneOrSingle(): T?
        fun Iterable<BigDecimal>.sum(): BigDecimal
      kotlin.collections.List
        Module Contents fun <T> List<T>.indexOfOrThrow(item: T): Int
        fun <T> List<T>.randomOrNull(): T?
        fun <T> List<T>.randomOrNull(predicate: (T) -> Boolean): <ERROR CLASS>
      fun <T> logElapsedTime(label: String, logger: <ERROR CLASS>? = null, body: () -> T): T
      infix fun <F, T> <ERROR CLASS><F>.map(mapper: (F) -> T): <ERROR CLASS><T>
      fun random63BitValue(): Long
      fun <T> <ERROR CLASS><T>.success(executor: Executor, body: (T) -> Unit): <ERROR CLASS>
      infix fun <T> <ERROR CLASS><T>.success(body: (T) -> Unit): <ERROR CLASS><T>
      fun <T> <ERROR CLASS><T>.tee(vararg teeTo: <ERROR CLASS><T>): <ERROR CLASS><T>
      fun <T> <ERROR CLASS><T>.then(executor: Executor, body: () -> Unit): <ERROR CLASS>
      infix fun <T> <ERROR CLASS><T>.then(body: () -> Unit): <ERROR CLASS><T>
      fun <A> <ERROR CLASS><A>.toObservable(): <ERROR CLASS><A>
    package net.corda.core.contracts
      Module Contents enum class AccrualAdjustment
        Module Contents Adjusted
        Unadjusted
      data class Amount<T> : Comparable<Amount<T>>
        Module Contents Amount(amount: BigDecimal, currency: T)
        Amount(quantity: Long, token: T)
        fun compareTo(other: Amount<T>): Int
        operator fun div(other: Long): Amount<T>
        operator fun div(other: Int): Amount<T>
        operator fun minus(other: Amount<T>): Amount<T>
        operator fun plus(other: Amount<T>): Amount<T>
        val quantity: Long
        operator fun times(other: Long): Amount<T>
        operator fun times(other: Int): Amount<T>
        fun toString(): String
        val token: T
      interface Attachment : NamedByHash
        Module Contents open fun extractFile(path: String, outputTo: OutputStream): Unit
        abstract fun open(): InputStream
        open fun openAsJAR(): JarInputStream
      data class AuthenticatedObject<out T : Any>
        Module Contents AuthenticatedObject(signers: List<CompositeKey>, signingParties: List<Party>, value: T)
        val signers: List<CompositeKey>
        val signingParties: List<Party>
        val value: T
      interface BilateralNettableState<N : BilateralNettableState<N>>
        Module Contents abstract val bilateralNetState: Any
        abstract fun net(other: N): N
      open class BusinessCalendar
        Module Contents val TEST_CALENDAR_DATA: <ERROR CLASS>
        class UnknownCalendar : Exception
          Module Contents UnknownCalendar(name: String)
        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
        Module Contents Command(data: CommandData, key: CompositeKey)
        Command(value: CommandData, signers: List<CompositeKey>)
        val signers: List<CompositeKey>
        fun toString(): String
        val value: CommandData
      interface CommandData
      data class Commodity
        Module Contents Commodity(commodityCode: String, displayName: String, defaultFractionDigits: Int = 0)
        val commodityCode: String
        val defaultFractionDigits: Int
        val displayName: String
        fun getInstance(commodityCode: String): Commodity?
      interface Contract
        Module Contents abstract val legalContractReference: SecureHash
        abstract fun verify(tx: TransactionForContract): Unit
      interface ContractState
        Module Contents abstract val contract: Contract
        open val encumbrance: Int?
        abstract val participants: List<CompositeKey>
      fun DOLLARS(amount: Int): Amount<Currency>
      fun DOLLARS(amount: Double): Amount<Currency>
      val DUMMY_PROGRAM_ID: DummyContract
      enum class DateRollConvention
        Module Contents Actual
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        Following
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        ModifiedFollowing
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        ModifiedPrevious
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        Previous
          Module Contents fun direction(): DateRollDirection
          val isModified: Boolean
        abstract fun direction(): DateRollDirection
        abstract val isModified: Boolean
      enum class DateRollDirection
        Module Contents BACKWARD
        FORWARD
        val value: Long
      enum class DayCountBasisDay
        Module Contents D30
        D30E
        D30F
        D30G
        D30N
        D30P
        D30Z
        DActual
        DActualJ
        DBus_SaoPaulo
        fun toString(): String
      enum class DayCountBasisYear
        Module Contents Y252
        Y360
        Y365
        Y365B
        Y365F
        Y365L
        Y365Q
        Y366
        YActual
        YActualA
        YICMA
        YISMA
        fun toString(): String
      interface DealState : LinearState
        Module Contents abstract fun generateAgreement(notary: Party): TransactionBuilder
        abstract val parties: List<Party>
        abstract val ref: String
      data class DummyContract : Contract
        Module Contents DummyContract(legalContractReference: SecureHash = SecureHash.sha256(""))
        interface Commands : CommandData
          Module Contents class Create : TypeOnlyCommandData, Commands
            Module Contents Create()
          class Move : TypeOnlyCommandData, Commands
            Module Contents Move()
        data class MultiOwnerState : ContractState, State
          Module Contents MultiOwnerState(magicNumber: Int = 0, owners: List<CompositeKey>)
          val contract: DummyContract
          val magicNumber: Int
          val owners: List<CompositeKey>
          val participants: List<CompositeKey>
        data class SingleOwnerState : OwnableState, State
          Module Contents SingleOwnerState(magicNumber: Int = 0, owner: CompositeKey)
          val contract: DummyContract
          val magicNumber: Int
          val owner: CompositeKey
          val participants: List<CompositeKey>
          fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS>
        interface State : ContractState
          Module Contents abstract val magicNumber: Int
        fun generateInitial(owner: PartyAndReference, magicNumber: Int, notary: Party): TransactionBuilder
        val legalContractReference: SecureHash
        fun move(prior: StateAndRef<SingleOwnerState>, newOwner: CompositeKey): <ERROR CLASS>
        fun move(priors: List<StateAndRef<SingleOwnerState>>, newOwner: CompositeKey): TransactionBuilder
        fun verify(tx: TransactionForContract): Unit
      data class DummyState : ContractState
        Module Contents DummyState(magicNumber: Int = 0)
        val contract: DummyContract
        val magicNumber: Int
        val participants: List<CompositeKey>
      val EUR: Currency
      data class Expression
        Module Contents Expression(expr: String)
        val expr: String
      object ExpressionDeserializer
        Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): Expression
      object ExpressionSerializer
        Module Contents fun serialize(expr: Expression, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
      val FCOJ: Commodity
      fun FCOJ(amount: Int): Amount<Commodity>
      data class Fix : CommandData
        Module Contents Fix(of: FixOf, value: BigDecimal)
        val of: FixOf
        val value: BigDecimal
      data class FixOf
        Module Contents FixOf(name: String, forDay: LocalDate, ofTenor: Tenor)
        val forDay: LocalDate
        val name: String
        val ofTenor: Tenor
      interface FixableDealState : DealState
        Module Contents abstract fun generateFix(ptx: TransactionBuilder, oldState: StateAndRef<*>, fix: Fix): Unit
        abstract fun nextFixingOf(): FixOf?
        abstract val oracleType: ServiceType
      enum class Frequency
        Module Contents Annual
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        BiWeekly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Daily
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Monthly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Quarterly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        SemiAnnual
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        Weekly
          Module Contents fun offset(d: LocalDate, n: Long): LocalDate
        val annualCompoundCount: Int
        abstract fun offset(d: LocalDate, n: Long = 1): LocalDate
      interface FungibleAsset<T> : OwnableState
        Module Contents interface Commands : CommandData
          Module Contents interface Exit<T> : Commands
            Module Contents abstract val amount: Amount<Issued<T>>
          interface Issue : IssueCommand, Commands
          interface Move : MoveCommand, Commands
        abstract val amount: Amount<Issued<T>>
        abstract val exitKeys: Collection<CompositeKey>
        abstract fun move(newAmount: Amount<Issued<T>>, newOwner: CompositeKey): FungibleAsset<T>
        abstract val owner: CompositeKey
      val GBP: Currency
      class InsufficientBalanceException : Exception
        Module Contents InsufficientBalanceException(amountMissing: Amount<*>)
        val amountMissing: Amount<*>
        fun toString(): String
      interface IssuanceDefinition
      interface IssueCommand : CommandData
        Module Contents abstract val nonce: Long
      data class Issued<out P>
        Module Contents Issued(issuer: PartyAndReference, product: P)
        val issuer: PartyAndReference
        val product: P
        fun toString(): String
      interface LinearState : ContractState
        Module Contents class ClauseVerifier<S : LinearState, C : CommandData> : Clause<S, C, Unit>
          Module Contents ClauseVerifier()
          fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: Unit?): Set<C>
        abstract fun isRelevant(ourKeys: Set<PublicKey>): Boolean
        abstract val linearId: UniqueIdentifier
      interface MoveCommand : CommandData
        Module Contents abstract val contractHash: SecureHash?
      interface MultilateralNettableState<out T : Any>
        Module Contents abstract val multilateralNetState: T
      interface NamedByHash
        Module Contents abstract val id: SecureHash
      interface NetCommand : CommandData
        Module Contents abstract val type: NetType
      enum class NetType
        Module Contents CLOSE_OUT
        PAYMENT
      interface NettableState<N : BilateralNettableState<N>, T : Any> : BilateralNettableState<N>, MultilateralNettableState<T>
      interface OwnableState : ContractState
        Module Contents abstract val owner: CompositeKey
        abstract fun withNewOwner(newOwner: CompositeKey): <ERROR CLASS><CommandData, OwnableState>
      fun POUNDS(amount: Int): Amount<Currency>
      data class PartyAndReference
        Module Contents PartyAndReference(party: Party, reference: OpaqueBytes)
        val party: Party
        val reference: OpaqueBytes
        fun toString(): String
      enum class PaymentRule
        Module Contents InAdvance
        InArrears
      object Requirements
        Module Contents inline infix fun String.by(expr: Boolean): Unit
      fun SWISS_FRANCS(amount: Int): Amount<Currency>
      interface SchedulableState : ContractState
        Module Contents abstract fun nextScheduledActivity(thisStateRef: StateRef, flowLogicRefFactory: FlowLogicRefFactory): ScheduledActivity?
      interface Scheduled
        Module Contents abstract val scheduledAt: Instant
      data class ScheduledActivity : Scheduled
        Module Contents ScheduledActivity(logicRef: FlowLogicRef, scheduledAt: Instant)
        val logicRef: FlowLogicRef
        val scheduledAt: Instant
      data class ScheduledStateRef : Scheduled
        Module Contents ScheduledStateRef(ref: StateRef, scheduledAt: Instant)
        val ref: StateRef
        val scheduledAt: Instant
      data class StateAndRef<out T : ContractState>
        Module Contents StateAndRef(state: TransactionState<T>, ref: StateRef)
        val ref: StateRef
        val state: TransactionState<T>
      data class StateRef
        Module Contents StateRef(txhash: SecureHash, index: Int)
        val index: Int
        fun toString(): String
        val txhash: SecureHash
      data class Tenor
        Module Contents Tenor(name: String)
        enum class TimeUnit
          Module Contents Day
          Month
          Week
          Year
          val code: String
        fun daysToMaturity(startDate: LocalDate, calendar: BusinessCalendar): Int
        val name: String
        fun toString(): String
      data class Timestamp
        Module Contents Timestamp(time: Instant, tolerance: Duration)
        Timestamp(after: Instant?, before: Instant?)
        val after: Instant?
        val before: Instant?
        val midpoint: Instant
      class TransactionConflictException : Exception
        Module Contents TransactionConflictException(conflictRef: StateRef, tx1: LedgerTransaction, tx2: LedgerTransaction)
        val conflictRef: StateRef
        val tx1: LedgerTransaction
        val tx2: LedgerTransaction
      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>
          Module Contents InOutGroup(inputs: List<T>, outputs: List<T>, groupingKey: K)
          val groupingKey: K
          val inputs: List<T>
          val outputs: List<T>
        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>>
        Module Contents TransactionGraphSearch(transactions: ReadOnlyTransactionStorage, startPoints: List<WireTransaction>)
        class Query
          Module Contents Query(withCommandOfType: Class<out CommandData>? = null, followInputsOfType: Class<out ContractState>? = null)
          val followInputsOfType: Class<out ContractState>?
          val withCommandOfType: Class<out CommandData>?
        fun call(): List<WireTransaction>
        var query: Query
        val startPoints: List<WireTransaction>
        val transactions: ReadOnlyTransactionStorage
      class TransactionResolutionException : Exception
        Module Contents TransactionResolutionException(hash: SecureHash)
        val hash: SecureHash
        fun toString(): String
      data class TransactionState<out T : ContractState>
        Module Contents TransactionState(data: T, notary: Party)
        val data: T
        val notary: Party
        fun withNotary(newNotary: Party): TransactionState<T>
      sealed class TransactionType
        Module Contents class General : TransactionType
          Module Contents General()
          class Builder : TransactionBuilder
            Module Contents Builder(notary: Party?)
          fun getRequiredSigners(tx: LedgerTransaction): <ERROR CLASS>
          fun verifyTransaction(tx: LedgerTransaction): Unit
        class NotaryChange : TransactionType
          Module Contents NotaryChange()
          class Builder : TransactionBuilder
            Module Contents Builder(notary: Party)
            fun addInputState(stateAndRef: StateAndRef<*>): Unit
          fun getRequiredSigners(tx: LedgerTransaction): <ERROR CLASS>
          fun verifyTransaction(tx: LedgerTransaction): Unit
        open fun equals(other: Any?): Boolean
        abstract fun getRequiredSigners(tx: LedgerTransaction): Set<CompositeKey>
        open fun hashCode(): <ERROR CLASS>
        fun verify(tx: LedgerTransaction): Unit
        fun verifySigners(tx: LedgerTransaction): Set<CompositeKey>
        abstract fun verifyTransaction(tx: LedgerTransaction): Unit
      sealed class TransactionVerificationException : Exception
        Module Contents class ContractRejection : TransactionVerificationException
          Module Contents ContractRejection(tx: LedgerTransaction, contract: Contract, cause: Throwable?)
          val contract: Contract
        enum class Direction
          Module Contents INPUT
          OUTPUT
        class InvalidNotaryChange : TransactionVerificationException
          Module Contents InvalidNotaryChange(tx: LedgerTransaction)
        class MoreThanOneNotary : TransactionVerificationException
          Module Contents MoreThanOneNotary(tx: LedgerTransaction)
        class NotaryChangeInWrongTransactionType : TransactionVerificationException
          Module Contents NotaryChangeInWrongTransactionType(tx: LedgerTransaction, outputNotary: Party)
          val outputNotary: Party
          fun toString(): String
        class SignersMissing : TransactionVerificationException
          Module Contents SignersMissing(tx: LedgerTransaction, missing: List<CompositeKey>)
          val missing: List<CompositeKey>
          fun toString(): String
        class TransactionMissingEncumbranceException : TransactionVerificationException
          Module Contents TransactionMissingEncumbranceException(tx: LedgerTransaction, missing: Int, inOut: Direction)
          val inOut: Direction
          val message: String?
          val missing: Int
        val tx: LedgerTransaction
      abstract class TypeOnlyCommandData : CommandData
        Module Contents TypeOnlyCommandData()
        open fun equals(other: Any?): Boolean
        open fun hashCode(): <ERROR CLASS>
      val USD: Currency
      data class UniqueIdentifier : Comparable<UniqueIdentifier>
        Module Contents UniqueIdentifier(externalId: String? = null, id: UUID = UUID.randomUUID())
        fun compareTo(other: UniqueIdentifier): Int
        fun equals(other: Any?): Boolean
        val externalId: String?
        fun fromString(name: String): UniqueIdentifier
        fun hashCode(): Int
        val id: UUID
        fun toString(): String
      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
        Module Contents fun LocalDate.isWorkingDay(accordingToCalendar: BusinessCalendar): Boolean
      java.util.Currency
        Module Contents infix fun Currency.issued by(deposit: PartyAndReference): Issued<Currency>
        infix fun Currency.issuedBy(deposit: PartyAndReference): Issued<Currency>
      kotlin.Double
        Module Contents val Double.DOLLARS: Amount<Currency>
      kotlin.Int
        Module Contents val Int.DOLLARS: Amount<Currency>
        val Int.FCOJ: Amount<Commodity>
        val Int.POUNDS: Amount<Currency>
        val Int.SWISS_FRANCS: Amount<Currency>
      kotlin.collections.Collection
        Module Contents inline fun <reified T : CommandData> Collection<AuthenticatedObject<CommandData>>.requireSingleCommand(): <ERROR CLASS>
        fun <C : CommandData> Collection<AuthenticatedObject<CommandData>>.requireSingleCommand(klass: Class<C>): <ERROR CLASS>
        inline fun <reified T : CommandData> Collection<AuthenticatedObject<CommandData>>.select(signer: CompositeKey? = null, party: Party? = null): <ERROR CLASS>
        inline fun <reified T : CommandData> Collection<AuthenticatedObject<CommandData>>.select(signers: Collection<CompositeKey>?, parties: Collection<Party>?): <ERROR CLASS>
      kotlin.collections.Iterable
        Module Contents inline fun <reified T : ContractState> Iterable<StateAndRef<ContractState>>.filterStatesOfType(): List<StateAndRef<T>>
        fun <T> Iterable<ContractState>.sumFungibleOrNull(): <ERROR CLASS>
        fun <T> Iterable<ContractState>.sumFungibleOrZero(token: Issued<T>): <ERROR CLASS>
        fun <T> Iterable<Amount<T>>.sumOrNull(): Nothing?
        fun <T> Iterable<Amount<T>>.sumOrThrow(): <ERROR CLASS>
        fun <T> Iterable<Amount<T>>.sumOrZero(currency: T): Amount<T>
      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>
        Module Contents Clause()
        open fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
        val log: <ERROR CLASS>
        open val requiredCommands: Set<Class<out CommandData>>
        abstract fun verify(tx: TransactionForContract, inputs: List<S>, outputs: List<S>, commands: List<AuthenticatedObject<C>>, groupingKey: K?): Set<C>
      abstract class CompositeClause<in S : ContractState, C : CommandData, in K : Any> : Clause<S, C, K>
        Module Contents CompositeClause()
        abstract val clauses: List<Clause<S, C, K>>
        open fun getExecutionPath(commands: List<AuthenticatedObject<C>>): List<Clause<*, *, *>>
        abstract fun matchedClauses(commands: List<AuthenticatedObject<C>>): List<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 class CertificateStream
        Module Contents CertificateStream(input: InputStream)
        val input: InputStream
        fun nextCertificate(): X509Certificate
      sealed class CompositeKey
        Module Contents class Builder
          Module Contents Builder()
          fun addKey(key: CompositeKey, weight: Int = 1): Builder
          fun addKeys(vararg keys: CompositeKey): Builder
          fun addKeys(keys: List<CompositeKey>): Builder
          fun build(threshold: Int? = null): Node
        class Leaf : CompositeKey
          Module Contents Leaf(publicKey: PublicKey)
          fun equals(other: Any?): Boolean
          fun hashCode(): Int
          fun isFulfilledBy(keys: Iterable<PublicKey>): <ERROR CLASS>
          val keys: Set<PublicKey>
          val publicKey: PublicKey
          fun toString(): String
        class Node : CompositeKey
          Module Contents Node(threshold: Int, children: List<CompositeKey>, weights: List<Int>)
          val children: List<CompositeKey>
          fun equals(other: Any?): Boolean
          fun hashCode(): Int
          fun isFulfilledBy(keys: Iterable<PublicKey>): Boolean
          val keys: Set<PublicKey>
          val threshold: Int
          fun toString(): String
          val weights: List<Int>
        fun containsAny(otherKeys: Iterable<PublicKey>): <ERROR CLASS>
        abstract fun isFulfilledBy(keys: Iterable<PublicKey>): Boolean
        fun isFulfilledBy(key: PublicKey): <ERROR CLASS>
        abstract val keys: Set<PublicKey>
        fun parseFromBase58(encoded: String): <ERROR CLASS>
        val singleKey: PublicKey
        fun toBase58String(): String
      open class DigitalSignature : OpaqueBytes
        Module Contents DigitalSignature(bits: ByteArray)
        class LegallyIdentifiable : WithKey
          Module Contents LegallyIdentifiable(signer: Party, bits: ByteArray)
          val signer: Party
        open class WithKey : DigitalSignature
          Module Contents WithKey(by: PublicKey, bits: ByteArray)
          val by: PublicKey
          fun verifyWithECDSA(content: ByteArray): Unit
          fun verifyWithECDSA(content: OpaqueBytes): Unit
      class DummyPublicKey : PublicKey, Comparable<PublicKey>
        Module Contents DummyPublicKey(s: String)
        fun compareTo(other: PublicKey): Int
        fun equals(other: Any?): Boolean
        fun getAlgorithm(): String
        fun getEncoded(): <ERROR CLASS>
        fun getFormat(): String
        fun hashCode(): Int
        val s: String
        fun toString(): String
      class MerkleTreeException : Exception
        Module Contents MerkleTreeException(reason: String)
        val reason: String
        fun toString(): String
      val NullCompositeKey: CompositeKey
      object NullPublicKey : PublicKey, Comparable<PublicKey>
        Module Contents fun compareTo(other: PublicKey): Int
        fun getAlgorithm(): String
        fun getEncoded(): ByteArray
        fun getFormat(): String
        fun toString(): String
      object NullSignature : WithKey
      class PartialMerkleTree
        Module Contents PartialMerkleTree(root: PartialTree)
        sealed class PartialTree
          Module Contents class IncludedLeaf : PartialTree
            Module Contents IncludedLeaf(hash: SecureHash)
            val hash: SecureHash
          class Leaf : PartialTree
            Module Contents Leaf(hash: SecureHash)
            val hash: SecureHash
          class Node : PartialTree
            Module Contents Node(left: PartialTree, right: PartialTree)
            val left: PartialTree
            val right: PartialTree
        fun build(merkleRoot: MerkleTree, includeHashes: List<SecureHash>): PartialMerkleTree
        val root: PartialTree
        fun verify(merkleRootHash: SecureHash, hashesToCheck: List<SecureHash>): Boolean
      data class Party
        Module Contents Party(name: String, owningKey: PublicKey)
        Party(name: String, owningKey: CompositeKey)
        val name: String
        val owningKey: CompositeKey
        fun ref(bytes: OpaqueBytes): PartyAndReference
        fun ref(vararg bytes: Byte): PartyAndReference
        fun toString(): String
      sealed class SecureHash : OpaqueBytes
        Module Contents class SHA256 : SecureHash
          Module Contents SHA256(bytes: ByteArray)
        fun parse(str: String): <ERROR CLASS>
        fun prefixChars(prefixLen: Int = 6): <ERROR CLASS>
        fun randomSHA256(): SHA256
        fun sha256(bytes: ByteArray): SHA256
        fun sha256(str: String): <ERROR CLASS>
        fun sha256Twice(bytes: ByteArray): SHA256
        open fun toString(): <ERROR CLASS>
      open class SignedData<T : Any>
        Module Contents SignedData(raw: SerializedBytes<T>, sig: WithKey)
        val raw: SerializedBytes<T>
        val sig: WithKey
        fun verified(): T
        protected open fun verifyData(data: T): Unit
      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
        Module Contents fun addWhitelistEntries(serverNames: List<String>): Unit
        fun addWhitelistEntry(serverName: String): Unit
        val originalTrustProviderAlgorithm: String
        fun register(): Unit
        val whitelist: Set<String>
      class WhitelistTrustManagerSpi : TrustManagerFactorySpi
        Module Contents WhitelistTrustManagerSpi()
        protected fun engineGetTrustManagers(): Array<out TrustManager>
        protected fun engineInit(keyStore: KeyStore?): Unit
        protected fun engineInit(managerFactoryParameters: ManagerFactoryParameters?): Unit
        val originalProvider: TrustManagerFactory
      object X509Utilities
        Module Contents data class CACertAndKey
          Module Contents CACertAndKey(certificate: X509Certificate, keyPair: KeyPair)
          val certificate: X509Certificate
          val keyPair: KeyPair
        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(keyStoreFilePath: Path, storePassword: String, keyPassword: String, caKeyStore: KeyStore, caKeyPassword: String, commonName: 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(commonName: 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 <ERROR CLASS>.commonName: String
      val ed25519Curve: <ERROR CLASS>
      fun entropyToKeyPair(entropy: BigInteger): KeyPair
      fun generateKeyPair(): KeyPair
      java.security.KeyPair
        Module Contents operator fun KeyPair.component1(): PrivateKey
        operator fun KeyPair.component2(): PublicKey
        fun KeyPair.signWithECDSA(bytesToSign: ByteArray): WithKey
        fun KeyPair.signWithECDSA(bytesToSign: OpaqueBytes): WithKey
        fun KeyPair.signWithECDSA(bytesToSign: OpaqueBytes, party: Party): LegallyIdentifiable
        fun KeyPair.signWithECDSA(bytesToSign: ByteArray, party: Party): LegallyIdentifiable
      java.security.PrivateKey
        Module Contents fun PrivateKey.signWithECDSA(bytes: ByteArray): DigitalSignature
        fun PrivateKey.signWithECDSA(bytesToSign: ByteArray, publicKey: PublicKey): WithKey
      java.security.PublicKey
        Module Contents val PublicKey.composite: CompositeKey
        fun PublicKey.toBase58String(): <ERROR CLASS>
        fun PublicKey.toStringShort(): String
        fun PublicKey.verifyWithECDSA(content: ByteArray, signature: DigitalSignature): Unit
      kotlin.ByteArray
        Module Contents fun ByteArray.sha256(): SHA256
      kotlin.collections.Iterable
        Module Contents fun Iterable<WithKey>.byKeys(): <ERROR CLASS>
        val Iterable<CompositeKey>.keys: Set<PublicKey>
      fun newSecureRandom(): SecureRandom
      fun parsePublicKeyBase58(base58String: String): <ERROR CLASS>
      fun registerWhitelistTrustManager(): Unit
      fun OpaqueBytes.sha256(): SHA256
    package net.corda.core.flows
      Module Contents data class AppContext
        Module Contents AppContext(attachments: List<SecureHash>)
        val attachments: List<SecureHash>
        val classLoader: ClassLoader
      abstract class FlowLogic<out T>
        Module Contents FlowLogic()
        abstract fun call(): T
        lateinit var fsm: FlowStateMachine<*>
        open fun getCounterpartyMarker(party: Party): Class<*>
        val logger: <ERROR CLASS>
        open val progressTracker: ProgressTracker?
        inline fun <reified T : Any> receive(otherParty: Party): UntrustworthyData<T>
        fun <T : Any> receive(receiveType: Class<T>, otherParty: Party): UntrustworthyData<T>
        fun send(otherParty: Party, payload: Any): Unit
        inline fun <reified T : Any> sendAndReceive(otherParty: Party, payload: Any): UntrustworthyData<T>
        fun <T : Any> sendAndReceive(receiveType: Class<T>, otherParty: Party, payload: Any): UntrustworthyData<T>
        val serviceHub: ServiceHub
        fun <R> subFlow(subLogic: FlowLogic<R>, shareParentSessions: Boolean = false): R
        fun track(): <ERROR CLASS><String, <ERROR CLASS><String>>?
      data class FlowLogicRef
        Module Contents val appContext: AppContext
        val args: Map<String, Any?>
        val flowLogicClassName: String
      class FlowLogicRefFactory : SingletonSerializeAsToken
        Module Contents FlowLogicRefFactory()
        FlowLogicRefFactory(flowWhitelist: Map<String, Set<String>>)
        fun create(type: Class<out FlowLogic<*>>, vararg args: Any?): FlowLogicRef
        fun createKotlin(flowLogicClassName: String, args: Map<String, Any?>, attachments: List<SecureHash> = emptyList()): FlowLogicRef
        fun createKotlin(type: Class<out FlowLogic<*>>, args: Map<String, Any?>): FlowLogicRef
        fun toFlowLogic(ref: FlowLogicRef): FlowLogic<*>
      class FlowSessionException : Exception
        Module Contents FlowSessionException(message: String)
      interface FlowStateMachine<R>
        Module Contents abstract val id: StateMachineRunId
        abstract val logger: <ERROR CLASS>
        abstract fun <T : Any> receive(otherParty: Party, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        abstract val resultFuture: <ERROR CLASS><R>
        abstract fun send(otherParty: Party, payload: Any, sessionFlow: FlowLogic<*>): Unit
        abstract fun <T : Any> sendAndReceive(otherParty: Party, payload: Any, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        abstract val serviceHub: ServiceHub
      class IllegalFlowLogicException : IllegalArgumentException
        Module Contents IllegalFlowLogicException(type: Class<*>, msg: String)
      data class StateMachineRunId
        Module Contents fun createRandom(): StateMachineRunId
        fun toString(): String
        val uuid: UUID
        fun wrap(uuid: UUID): StateMachineRunId
    package net.corda.core.math
      Module Contents class CubicSplineInterpolator : Interpolator
        Module Contents CubicSplineInterpolator(xs: DoubleArray, ys: DoubleArray)
        fun create(xs: DoubleArray, ys: DoubleArray): CubicSplineInterpolator
        fun interpolate(x: Double): Double
      interface Interpolator
        Module Contents abstract fun interpolate(x: Double): Double
      interface InterpolatorFactory
        Module Contents abstract fun create(xs: DoubleArray, ys: DoubleArray): Interpolator
      class LinearInterpolator : Interpolator
        Module Contents LinearInterpolator(xs: DoubleArray, ys: DoubleArray)
        fun create(xs: DoubleArray, ys: DoubleArray): LinearInterpolator
        fun interpolate(x: Double): Double
      class Polynomial
        Module Contents Polynomial(coefficients: DoubleArray)
        fun getValue(x: Double): <ERROR CLASS>
      class SplineFunction
        Module Contents SplineFunction(segmentMap: TreeMap<Double, Polynomial>)
        fun getValue(x: Double): Double
    package net.corda.core.messaging
      Module Contents object Ack : DeserializeAsKotlinObjectDef
      interface AllPossibleRecipients : MessageRecipients
      interface CordaRPCOps : RPCOps
        Module Contents abstract fun addVaultTransactionNote(txnId: SecureHash, txnNote: String): Unit
        abstract fun attachmentExists(id: SecureHash): Boolean
        abstract fun currentNodeTime(): Instant
        abstract fun getVaultTransactionNotes(txnId: SecureHash): Iterable<String>
        @RPCReturnsObservables abstract fun networkMapUpdates(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
        abstract fun nodeIdentity(): NodeInfo
        abstract fun partyFromKey(key: CompositeKey): Party?
        abstract fun partyFromName(name: String): Party?
        @RPCReturnsObservables abstract fun <T : Any> startFlowDynamic(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowHandle<T>
        @RPCReturnsObservables abstract fun stateMachineRecordedTransactionMapping(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
        @RPCReturnsObservables abstract fun stateMachinesAndUpdates(): <ERROR CLASS><List<StateMachineInfo>, <ERROR CLASS><StateMachineUpdate>>
        abstract fun uploadAttachment(jar: InputStream): SecureHash
        @RPCReturnsObservables abstract fun vaultAndUpdates(): <ERROR CLASS><List<StateAndRef<ContractState>>, <ERROR CLASS><Update>>
        @RPCReturnsObservables abstract fun verifiedTransactions(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
      data class FlowHandle<A>
        Module Contents FlowHandle(id: StateMachineRunId, progress: <ERROR CLASS><String>, returnValue: <ERROR CLASS><A>)
        val id: StateMachineRunId
        val progress: <ERROR CLASS><String>
        val returnValue: <ERROR CLASS><A>
      interface Message
        Module Contents abstract val data: ByteArray
        abstract val debugTimestamp: Instant
        abstract val topicSession: TopicSession
        abstract val uniqueMessageId: UUID
      interface MessageHandlerRegistration
      interface MessageRecipientGroup : MessageRecipients
      interface MessageRecipients
      interface MessagingService
        Module Contents abstract fun addMessageHandler(topic: String = "", sessionID: Long = DEFAULT_SESSION_ID, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        abstract fun addMessageHandler(topicSession: TopicSession, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        abstract fun createMessage(topicSession: TopicSession, data: ByteArray, uuid: UUID = UUID.randomUUID()): Message
        abstract fun getAddressOfParty(partyInfo: PartyInfo): MessageRecipients
        abstract val myAddress: SingleMessageRecipient
        abstract fun removeMessageHandler(registration: MessageHandlerRegistration): Unit
        abstract fun send(message: Message, target: MessageRecipients): Unit
      interface RPCOps
        Module Contents abstract val protocolVersion: Int
      @Target([AnnotationTarget.FUNCTION]) annotation class RPCReturnsObservables
        Module Contents RPCReturnsObservables()
      interface ReceivedMessage : Message
        Module Contents abstract val peer: <ERROR CLASS>
      interface SingleMessageRecipient : MessageRecipients
      data class StateMachineInfo
        Module Contents StateMachineInfo(id: StateMachineRunId, flowLogicClassName: String, progressTrackerStepAndUpdates: <ERROR CLASS><String, <ERROR CLASS><String>>?)
        val flowLogicClassName: String
        val id: StateMachineRunId
        val progressTrackerStepAndUpdates: <ERROR CLASS><String, <ERROR CLASS><String>>?
      sealed class StateMachineUpdate
        Module Contents class Added : StateMachineUpdate
          Module Contents Added(stateMachineInfo: StateMachineInfo)
          val stateMachineInfo: StateMachineInfo
          fun toString(): String
        class Removed : StateMachineUpdate
          Module Contents Removed(id: StateMachineRunId)
          fun toString(): String
        val id: StateMachineRunId
      data class TopicSession
        Module Contents TopicSession(topic: String, sessionID: Long = DEFAULT_SESSION_ID)
        fun isBlank(): Boolean
        val sessionID: Long
        fun toString(): String
        val topic: String
      object TopicStringValidator
        Module Contents fun check(tag: String): <ERROR CLASS>
      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: (ReceivedMessage) -> Unit): Unit
      inline fun MessagingService.runOnNextMessage(topicSession: TopicSession, crossinline callback: (ReceivedMessage) -> 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
      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.core.node
      Module Contents class AttachmentsClassLoader : SecureClassLoader
        Module Contents AttachmentsClassLoader(attachments: List<Attachment>, parent: ClassLoader = ClassLoader.getSystemClassLoader())
        class OverlappingAttachments : Exception
          Module Contents OverlappingAttachments(path: String)
          val path: String
          fun toString(): String
        protected fun findClass(name: String): Class<*>
        protected fun findResource(name: String): URL?
        fun getResourceAsStream(name: String): InputStream?
      object CityDatabase
        Module Contents operator fun get(name: String): PhysicalLocation?
      abstract class CordaPluginRegistry
        Module Contents CordaPluginRegistry(webApis: List<Function<CordaRPCOps, out Any>> = emptyList(), staticServeDirs: Map<String, String> = emptyMap(), requiredFlows: Map<String, Set<String>> = emptyMap(), servicePlugins: List<Function<PluginServiceHub, out Any>> = emptyList())
        open fun registerRPCKryoTypes(kryo: <ERROR CLASS>): Boolean
        open val requiredFlows: Map<String, Set<String>>
        open val servicePlugins: List<Function<PluginServiceHub, out Any>>
        open val staticServeDirs: Map<String, String>
        open val webApis: List<Function<CordaRPCOps, out Any>>
      data class NodeInfo
        Module Contents NodeInfo(address: SingleMessageRecipient, legalIdentity: Party, advertisedServices: List<ServiceEntry> = emptyList(), physicalLocation: PhysicalLocation? = null)
        val address: SingleMessageRecipient
        var advertisedServices: List<ServiceEntry>
        val legalIdentity: Party
        val notaryIdentity: Party
        val physicalLocation: PhysicalLocation?
        fun serviceIdentities(type: ServiceType): List<Party>
      data class PhysicalLocation
        Module Contents PhysicalLocation(coordinate: WorldCoordinate, description: String)
        val coordinate: WorldCoordinate
        val description: String
      interface PluginServiceHub : ServiceHub
        Module Contents abstract fun getFlowFactory(markerClass: Class<*>): (Party) -> FlowLogic<*>
        abstract fun registerFlowInitiator(markerClass: KClass<*>, flowFactory: (Party) -> FlowLogic<*>): Unit
      data class ServiceEntry
        Module Contents ServiceEntry(info: ServiceInfo, identity: Party)
        val identity: Party
        val info: ServiceInfo
      interface ServiceHub
        Module Contents abstract val clock: Clock
        abstract val identityService: IdentityService
        abstract fun <T : Any> invokeFlowAsync(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowStateMachine<T>
        abstract val keyManagementService: KeyManagementService
        open val legalIdentityKey: KeyPair
        open fun loadState(stateRef: StateRef): TransactionState<*>
        abstract val myInfo: NodeInfo
        abstract val networkMapCache: NetworkMapCache
        abstract val networkService: MessagingService
        open val notaryIdentityKey: KeyPair
        abstract fun recordTransactions(txs: Iterable<SignedTransaction>): Unit
        abstract val schedulerService: SchedulerService
        abstract val storageService: StorageService
        open fun <T : ContractState> toStateAndRef(ref: StateRef): StateAndRef<T>
        abstract val vaultService: VaultService
      data class WorldCoordinate
        Module Contents WorldCoordinate(latitude: Double, longitude: Double)
        val latitude: Double
        val longitude: Double
        fun project(screenWidth: Double, screenHeight: Double, topLatitude: Double, bottomLatitude: Double, leftLongitude: Double, rightLongitude: Double): <ERROR CLASS><Double, Double>
      fun ServiceHub.recordTransactions(vararg txs: SignedTransaction): Unit
    package net.corda.core.node.services
      Module Contents interface AttachmentStorage
        Module Contents abstract fun importAttachment(jar: InputStream): SecureHash
        abstract fun openAttachment(id: SecureHash): Attachment?
      val DEFAULT_SESSION_ID: Long
      interface IdentityService
        Module Contents abstract fun getAllIdentities(): Iterable<Party>
        abstract fun partyFromKey(key: CompositeKey): Party?
        abstract fun partyFromName(name: String): Party?
        abstract fun registerIdentity(party: Party): Unit
      interface KeyManagementService
        Module Contents abstract fun freshKey(): KeyPair
        abstract val keys: Map<PublicKey, PrivateKey>
        open fun toKeyPair(publicKey: PublicKey): KeyPair
        open fun toKeyPair(publicKeys: Iterable<PublicKey>): <ERROR CLASS>
        open fun toPrivate(publicKey: PublicKey): PrivateKey
      sealed class NetworkCacheError : Exception
        Module Contents class DeregistrationFailed : NetworkCacheError
          Module Contents DeregistrationFailed()
      interface NetworkMapCache
        Module Contents sealed class MapChange
          Module Contents class Added : MapChange
            Module Contents Added(node: NodeInfo)
          class Modified : MapChange
            Module Contents Modified(node: NodeInfo, previousNode: NodeInfo)
            val previousNode: NodeInfo
          class Removed : MapChange
            Module Contents Removed(node: NodeInfo)
          val node: NodeInfo
        abstract fun addMapService(net: MessagingService, networkMapAddress: SingleMessageRecipient, subscribe: Boolean, ifChangedSinceVer: Int? = null): <ERROR CLASS><Unit>
        abstract fun addNode(node: NodeInfo): Unit
        abstract val changed: <ERROR CLASS><MapChange>
        abstract fun deregisterForUpdates(net: MessagingService, service: NodeInfo): <ERROR CLASS><Unit>
        open fun getAnyNotary(type: ServiceType? = null): Party?
        open fun getNodeByLegalIdentityKey(compositeKey: CompositeKey): NodeInfo?
        open fun getNodeByLegalName(name: String): NodeInfo?
        open fun getNodesByAdvertisedServiceIdentityKey(compositeKey: CompositeKey): List<NodeInfo>
        open fun getNodesWithService(serviceType: ServiceType): List<NodeInfo>
        open fun getNotary(name: String): Party?
        abstract fun getPartyInfo(party: Party): PartyInfo?
        open fun getRecommended(type: ServiceType, contract: Contract, vararg party: Party): NodeInfo?
        open fun isNotary(party: Party): Boolean
        abstract val mapServiceRegistered: <ERROR CLASS><Unit>
        abstract val networkMapNodes: List<NodeInfo>
        open val notaryNodes: List<NodeInfo>
        abstract val partyNodes: List<NodeInfo>
        open val regulatorNodes: List<NodeInfo>
        abstract fun removeNode(node: NodeInfo): Unit
        abstract fun runWithoutMapService(): Unit
        abstract fun track(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
      sealed class PartyInfo
        Module Contents class Node : PartyInfo
          Module Contents Node(node: NodeInfo)
          val node: NodeInfo
          val party: Party
        class Service : PartyInfo
          Module Contents Service(service: ServiceEntry)
          val party: Party
          val service: ServiceEntry
        abstract val party: Party
      interface ReadOnlyTransactionStorage
        Module Contents abstract fun getTransaction(id: SecureHash): SignedTransaction?
        abstract fun track(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
        abstract val updates: <ERROR CLASS><SignedTransaction>
      interface SchedulerService
        Module Contents abstract fun scheduleStateActivity(action: ScheduledStateRef): Unit
        abstract fun unscheduleStateActivity(ref: StateRef): Unit
      data class ServiceInfo
        Module Contents ServiceInfo(type: ServiceType, name: String? = null)
        val name: String?
        fun parse(encoded: String): ServiceInfo
        fun toString(): String
        val type: ServiceType
      sealed class ServiceType
        Module Contents val corda: ServiceType
        open operator fun equals(other: Any?): Boolean
        fun getServiceType(namespace: String, typeId: String): ServiceType
        fun getSubType(subTypeId: String): ServiceType
        open fun hashCode(): Int
        val id: String
        fun isNotary(): Boolean
        fun isSubTypeOf(superType: ServiceType): Boolean
        val notary: ServiceType
        fun parse(id: String): ServiceType
        val regulator: ServiceType
        open fun toString(): String
      interface StateMachineRecordedTransactionMappingStorage
        Module Contents abstract fun addMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash): Unit
        abstract fun track(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
      data class StateMachineTransactionMapping
        Module Contents StateMachineTransactionMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash)
        val stateMachineRunId: StateMachineRunId
        val transactionId: SecureHash
      interface StorageService
        Module Contents abstract val attachments: AttachmentStorage
        abstract val stateMachineRecordedTransactionMapping: StateMachineRecordedTransactionMappingStorage
        abstract val validatedTransactions: ReadOnlyTransactionStorage
      class TimestampChecker
        Module Contents TimestampChecker(clock: Clock = Clock.systemUTC(), tolerance: Duration = 30.seconds)
        val clock: Clock
        fun isValid(timestampCommand: Timestamp): Boolean
        val tolerance: Duration
      interface TransactionStorage : ReadOnlyTransactionStorage
        Module Contents abstract fun addTransaction(transaction: SignedTransaction): Boolean
      interface TxWritableStorageService : StorageService
        Module Contents abstract val validatedTransactions: TransactionStorage
      class UniquenessException : Exception
        Module Contents UniquenessException(error: Conflict)
        val error: Conflict
      interface UniquenessProvider
        Module Contents data class Conflict
          Module Contents Conflict(stateHistory: Map<StateRef, ConsumingTx>)
          val stateHistory: Map<StateRef, ConsumingTx>
        data class ConsumingTx
          Module Contents ConsumingTx(id: SecureHash, inputIndex: Int, requestingParty: Party)
          val id: SecureHash
          val inputIndex: Int
          val requestingParty: Party
        abstract fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      class Vault
        Module Contents Vault(states: List<StateAndRef<ContractState>>)
        val NoUpdate: Update
        data class Update
          Module Contents Update(consumed: Set<StateAndRef<ContractState>>, produced: Set<StateAndRef<ContractState>>)
          val consumed: Set<StateAndRef<ContractState>>
          inline fun <reified T : ContractState> containsType(): Boolean
          operator fun plus(rhs: Update): Update
          val produced: Set<StateAndRef<ContractState>>
          fun toString(): String
        val states: List<StateAndRef<ContractState>>
        inline fun <reified T : ContractState> statesOfType(): List<StateAndRef<T>>
      interface VaultService
        Module Contents abstract fun addNoteToTransaction(txnId: SecureHash, noteText: String): Unit
        abstract 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): Unit
        abstract fun notifyAll(txns: Iterable<WireTransaction>): Unit
        abstract val rawUpdates: <ERROR CLASS><Update>
        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
        Module Contents fun Iterable<ServiceInfo>.containsType(type: ServiceType): <ERROR CLASS>
      inline fun <reified T : LinearState> VaultService.linearHeadsOfType(): <ERROR CLASS>
    package net.corda.core.schemas
      Module Contents abstract class MappedSchema
        Module Contents MappedSchema(schemaFamily: Class<*>, version: Int, mappedTypes: Iterable<Class<*>>)
        val mappedTypes: Iterable<Class<*>>
        val name: String
        open fun toString(): String
        val version: Int
      open class PersistentState
        Module Contents PersistentState(stateRef: PersistentStateRef? = null)
        var stateRef: PersistentStateRef?
      data class PersistentStateRef : Serializable
        Module Contents PersistentStateRef(stateRef: StateRef)
        PersistentStateRef()
        PersistentStateRef(txId: String?, index: Int?)
        var index: Int?
        var txId: String?
      interface QueryableState : ContractState
        Module Contents abstract fun generateMappedObject(schema: MappedSchema): PersistentState
        abstract fun supportedSchemas(): Iterable<MappedSchema>
    package net.corda.core.serialization
      Module Contents val ATTACHMENT_STORAGE: String
      object CompositeKeyLeafSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Leaf>): Leaf
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: Leaf): Unit
      object CompositeKeyNodeSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Node>): Node
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: Node): Unit
      interface DeserializeAsKotlinObjectDef
      object Ed25519PrivateKeySerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<<ERROR CLASS>>): <ERROR CLASS>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: <ERROR CLASS>): Unit
      object Ed25519PublicKeySerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<<ERROR CLASS>>): <ERROR CLASS>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: <ERROR CLASS>): Unit
      class ImmutableClassSerializer<T : Any>
        Module Contents ImmutableClassSerializer(klass: KClass<T>)
        val constructor: <ERROR CLASS>
        val klass: KClass<T>
        val props: <ERROR CLASS>
        val propsByName: <ERROR CLASS>
        fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<T>): T
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: T): Unit
      object InputStreamSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<InputStream>): InputStream
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, stream: InputStream): Unit
      object KotlinObjectSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<DeserializeAsKotlinObjectDef>): DeserializeAsKotlinObjectDef
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: DeserializeAsKotlinObjectDef): Unit
      class MissingAttachmentsException : Exception
        Module Contents MissingAttachmentsException(ids: List<SecureHash>)
        val ids: List<SecureHash>
      class NoReferencesSerializer<T>
        Module Contents NoReferencesSerializer(baseSerializer: <ERROR CLASS><T>)
        val baseSerializer: <ERROR CLASS><T>
        fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<T>): T
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: T): Unit
      open class OpaqueBytes
        Module Contents OpaqueBytes(bytes: ByteArray)
        val bytes: ByteArray
        open fun equals(other: Any?): Boolean
        open fun hashCode(): Int
        fun of(vararg b: Byte): OpaqueBytes
        fun open(): ByteArrayInputStream
        val size: Int
        open fun toString(): String
      object OrderedSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<HashMap<Any, Any>>): HashMap<Any, Any>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: HashMap<Any, Any>): Unit
      object ReferencesAwareJavaSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Any>): Any
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: Any): Unit
      interface SerializationToken
        Module Contents abstract fun fromToken(context: SerializeAsTokenContext): Any
      interface SerializeAsToken
        Module Contents abstract fun toToken(context: SerializeAsTokenContext): SerializationToken
      class SerializeAsTokenContext
        Module Contents SerializeAsTokenContext(toBeTokenized: Any, kryo: <ERROR CLASS> = createKryo())
      class SerializeAsTokenSerializer<T : SerializeAsToken>
        Module Contents SerializeAsTokenSerializer()
        fun clearContext(kryo: <ERROR CLASS>): Unit
        fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<T>): T
        fun setContext(kryo: <ERROR CLASS>, context: SerializeAsTokenContext): Unit
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: T): Unit
      class SerializedBytes<T : Any> : OpaqueBytes
        Module Contents SerializedBytes(bytes: ByteArray)
        val hash: SecureHash
        fun writeToFile(path: Path): Path
      object SerializedBytesSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<SerializedBytes<Any>>): SerializedBytes<Any>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: SerializedBytes<Any>): Unit
      data class SingletonSerializationToken : SerializationToken
        Module Contents SingletonSerializationToken(toBeTokenized: SerializeAsToken)
        fun fromToken(context: SerializeAsTokenContext): Any
        fun registerWithContext(token: SingletonSerializationToken, toBeTokenized: SerializeAsToken, context: SerializeAsTokenContext): SerializationToken
      abstract class SingletonSerializeAsToken : SerializeAsToken
        Module Contents SingletonSerializeAsToken()
        open fun toToken(context: SerializeAsTokenContext): SerializationToken
      val THREAD_LOCAL_KRYO: <ERROR CLASS>
      object WireTransactionSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<WireTransaction>): WireTransaction
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: WireTransaction): Unit
      var <ERROR CLASS>.attachmentStorage: AttachmentStorage?
      fun createKryo(k: <ERROR CLASS> = Kryo()): <ERROR CLASS>
      fun <T : Any> OpaqueBytes.deserialize(kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): T
      fun SerializedBytes<WireTransaction>.deserialize(kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): WireTransaction
      fun <T : Any> SerializedBytes<T>.deserialize(kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): T
      fun extendKryoHash(kryo: <ERROR CLASS>): <ERROR CLASS>
      kotlin.ByteArray
        Module Contents fun <T : Any> ByteArray.deserialize(kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): T
        fun ByteArray.opaque(): OpaqueBytes
        fun ByteArray.toHexString(): <ERROR CLASS>
      kotlin.String
        Module Contents fun String.parseAsHex(): <ERROR CLASS>
      inline fun <reified T : Any> <ERROR CLASS>.noReferencesWithin(): Unit
      fun <ERROR CLASS>.readBytesWithLength(): ByteArray
      fun <T : Any> T.serialize(kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): SerializedBytes<T>
      inline fun <T> <ERROR CLASS>.useClassLoader(cl: ClassLoader, body: () -> T): T
      fun <ERROR CLASS>.writeBytesWithLength(byteArray: ByteArray): Unit
    package net.corda.core.testing
      Module Contents class AmountGenerator<T>
        Module Contents AmountGenerator(tokenGenerator: <ERROR CLASS><T>)
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Amount<T>
        val tokenGenerator: <ERROR CLASS><T>
      class CompositeKeyGenerator
        Module Contents CompositeKeyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): CompositeKey
      class CurrencyGenerator
        Module Contents CurrencyGenerator()
        val currencies: <ERROR CLASS>
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Currency
      class DurationGenerator
        Module Contents DurationGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Duration
      class InstantGenerator
        Module Contents InstantGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Instant
      class IssuedGenerator<T>
        Module Contents IssuedGenerator(productGenerator: <ERROR CLASS><T>)
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Issued<T>
        val productGenerator: <ERROR CLASS><T>
      class PartyAndReferenceGenerator
        Module Contents PartyAndReferenceGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): PartyAndReference
      class PartyGenerator
        Module Contents PartyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Party
      class PrivateKeyGenerator
        Module Contents PrivateKeyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): PrivateKey
      class PublicKeyGenerator
        Module Contents PublicKeyGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): PublicKey
      class SecureHashGenerator
        Module Contents SecureHashGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): SecureHash
      class StateRefGenerator
        Module Contents StateRefGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): StateRef
      class TimestampGenerator
        Module Contents TimestampGenerator()
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): Timestamp
      class TransactionStateGenerator<T : ContractState>
        Module Contents TransactionStateGenerator(stateGenerator: <ERROR CLASS><T>)
        fun generate(random: <ERROR CLASS>, status: <ERROR CLASS>): TransactionState<T>
        val stateGenerator: <ERROR CLASS><T>
      fun <A> <ERROR CLASS><A>.generateList(random: <ERROR CLASS>, status: <ERROR CLASS>): List<A>
    package net.corda.core.transactions
      Module Contents abstract class BaseTransaction : NamedByHash
        Module Contents BaseTransaction(inputs: List<*>, outputs: List<TransactionState<ContractState>>, notary: Party?, mustSign: List<CompositeKey>, type: TransactionType, timestamp: Timestamp?)
        protected fun checkInvariants(): Unit
        open fun equals(other: Any?): Boolean
        open fun hashCode(): Int
        open val inputs: List<*>
        val mustSign: List<CompositeKey>
        val notary: Party?
        val outputs: List<TransactionState<ContractState>>
        val timestamp: Timestamp?
        val type: TransactionType
      class FilterFuns
        Module Contents FilterFuns(filterInputs: (StateRef) -> Boolean = { false }, filterOutputs: (TransactionState<ContractState>) -> Boolean = { false }, filterAttachments: (SecureHash) -> Boolean = { false }, filterCommands: (Command) -> Boolean = { false })
        val filterAttachments: (SecureHash) -> Boolean
        val filterCommands: (Command) -> Boolean
        val filterInputs: (StateRef) -> Boolean
        val filterOutputs: (TransactionState<ContractState>) -> Boolean
        fun <T : Any> genericFilter(elem: T): Boolean
      class FilteredLeaves
        Module Contents FilteredLeaves(inputs: List<StateRef>, outputs: List<TransactionState<ContractState>>, attachments: List<SecureHash>, commands: List<Command>)
        val attachments: List<SecureHash>
        val commands: List<Command>
        fun getFilteredHashes(): List<SecureHash>
        val inputs: List<StateRef>
        val outputs: List<TransactionState<ContractState>>
      class FilteredTransaction
        Module Contents FilteredTransaction(filteredLeaves: FilteredLeaves, partialMerkleTree: PartialMerkleTree)
        fun buildMerkleTransaction(wtx: WireTransaction, filterFuns: FilterFuns): FilteredTransaction
        val filteredLeaves: FilteredLeaves
        val partialMerkleTree: PartialMerkleTree
        fun verify(merkleRootHash: SecureHash): Boolean
      class LedgerTransaction : BaseTransaction
        Module Contents LedgerTransaction(inputs: List<StateAndRef<*>>, outputs: List<TransactionState<ContractState>>, commands: List<AuthenticatedObject<CommandData>>, attachments: List<Attachment>, id: SecureHash, notary: Party?, signers: List<CompositeKey>, timestamp: Timestamp?, type: TransactionType)
        val attachments: List<Attachment>
        val commands: List<AuthenticatedObject<CommandData>>
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        val id: SecureHash
        val inputs: List<StateAndRef<*>>
        fun <T : ContractState> outRef(index: Int): StateAndRef<T>
        fun toTransactionForContract(): TransactionForContract
        fun verify(): Unit
      sealed class MerkleTree
        Module Contents class DuplicatedLeaf : MerkleTree
          Module Contents DuplicatedLeaf(value: SecureHash)
          val value: SecureHash
        class Leaf : MerkleTree
          Module Contents Leaf(value: SecureHash)
          val value: SecureHash
        class Node : MerkleTree
          Module Contents Node(value: SecureHash, left: MerkleTree, right: MerkleTree)
          val left: MerkleTree
          val right: MerkleTree
          val value: SecureHash
        fun getMerkleTree(allLeavesHashes: List<SecureHash>): MerkleTree
        val hash: SecureHash
        fun hashNodes(right: MerkleTree): MerkleTree
      data class SignedTransaction : NamedByHash
        Module Contents SignedTransaction(txBits: SerializedBytes<WireTransaction>, sigs: List<WithKey>, id: SecureHash)
        class SignaturesMissingException : NamedByHash, SignatureException
          Module Contents SignaturesMissingException(missing: Set<CompositeKey>, descriptions: List<String>, id: SecureHash)
          val descriptions: List<String>
          val id: SecureHash
          val missing: Set<CompositeKey>
          fun toString(): String
        fun checkSignaturesAreValid(): Unit
        val id: SecureHash
        operator fun plus(sig: WithKey): SignedTransaction
        operator fun plus(sigList: Collection<WithKey>): SignedTransaction
        val sigs: List<WithKey>
        fun toLedgerTransaction(services: ServiceHub): LedgerTransaction
        val tx: WireTransaction
        val txBits: SerializedBytes<WireTransaction>
        fun verifySignatures(vararg allowedToBeMissing: CompositeKey): WireTransaction
        fun withAdditionalSignature(sig: WithKey): SignedTransaction
        fun withAdditionalSignatures(sigList: Iterable<WithKey>): SignedTransaction
      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
        Module Contents WireTransaction(inputs: List<StateRef>, attachments: List<SecureHash>, outputs: List<TransactionState<ContractState>>, commands: List<Command>, notary: Party?, signers: List<CompositeKey>, type: TransactionType, timestamp: Timestamp?)
        val allLeavesHashes: List<SecureHash>
        val attachments: List<SecureHash>
        var cachedTree: MerkleTree?
        val commands: List<Command>
        fun deserialize(data: SerializedBytes<WireTransaction>, kryo: <ERROR CLASS> = THREAD_LOCAL_KRYO.get()): WireTransaction
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        val id: SecureHash
        val inputs: List<StateRef>
        val merkleTree: MerkleTree
        fun <T : ContractState> outRef(index: Int): StateAndRef<T>
        fun <T : ContractState> outRef(state: ContractState): StateAndRef<T>
        val serialized: SerializedBytes<WireTransaction>
        fun toLedgerTransaction(services: ServiceHub): LedgerTransaction
        fun toString(): String
      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
      Module Contents class ApiUtils
        Module Contents ApiUtils(rpc: CordaRPCOps)
        val rpc: CordaRPCOps
        fun withParty(partyKeyStr: String, notFound: (String) -> <ERROR CLASS> = defaultNotFound, found: (Party) -> <ERROR CLASS>): <ERROR CLASS>
      val DUMMY_KEY_1: KeyPair
      val DUMMY_KEY_2: KeyPair
      val DUMMY_NOTARY: Party
      val DUMMY_NOTARY_KEY: KeyPair
      val DUMMY_PUBKEY_1: CompositeKey
      val DUMMY_PUBKEY_2: CompositeKey
      object Emoji
        Module Contents const val CODE_BAG_OF_CASH: String
        const val CODE_COOL_GUY: String
        const val CODE_DIAMOND: String
        const val CODE_GREEN_TICK: String
        const val CODE_LEFT_ARROW: String
        const val CODE_NEWSPAPER: String
        const val CODE_PAPERCLIP: String
        const val CODE_RIGHT_ARROW: String
        const val CODE_SANTA_CLAUS: String
        val bagOfCash: String
        val coolGuy: String
        val diamond: String
        val emojiMode: ThreadLocal<Any>
        val hasEmojiTerminal: <ERROR CLASS>
        val leftArrow: String
        val newspaper: String
        val paperclip: String
        inline fun <T> renderIfSupported(body: () -> T): T
        fun renderIfSupported(obj: Any): String
        val rightArrow: String
        val santaClaus: String
      object LogHelper
        Module Contents fun reset(vararg names: String): Unit
        fun reset(vararg classes: KClass<*>): <ERROR CLASS>
        fun setLevel(vararg loggerNames: String): Unit
        fun setLevel(vararg classes: KClass<*>): <ERROR CLASS>
      class NonEmptySet<T> : MutableSet<T>
        Module Contents NonEmptySet(initial: T)
        inner class Iterator<out T, T> : MutableIterator<T>
          Module Contents Iterator(iterator: MutableIterator<T>)
          fun hasNext(): Boolean
          val iterator: MutableIterator<T>
          fun next(): T
          fun remove(): Unit
        fun add(element: T): Boolean
        fun addAll(elements: Collection<T>): Boolean
        fun clear(): Nothing
        fun contains(element: T): Boolean
        fun containsAll(elements: Collection<T>): Boolean
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        fun isEmpty(): Boolean
        fun iterator(): MutableIterator<T>
        fun remove(element: T): Boolean
        fun removeAll(elements: Collection<T>): Boolean
        fun retainAll(elements: Collection<T>): Boolean
        val size: Int
        fun toString(): String
      object NonEmptySetSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<NonEmptySet<Any>>): NonEmptySet<Any>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, obj: NonEmptySet<Any>): Unit
      class ProgressTracker
        Module Contents ProgressTracker(vararg steps: Step)
        sealed class Change
          Module Contents class Position : Change
            Module Contents Position(tracker: ProgressTracker, newStep: Step)
            val newStep: Step
            fun toString(): String
            val tracker: ProgressTracker
          class Rendering : Change
            Module Contents Rendering(tracker: ProgressTracker, ofStep: Step)
            val ofStep: Step
            fun toString(): String
            val tracker: ProgressTracker
          class Structural : Change
            Module Contents Structural(tracker: ProgressTracker, parent: Step)
            val parent: Step
            fun toString(): String
            val tracker: ProgressTracker
        object DONE : Step
          Module Contents fun equals(other: Any?): Boolean
        inner class RelabelableStep : Step
          Module Contents RelabelableStep(currentLabel: String)
          open val changes: <ERROR CLASS>
          var currentLabel: String
          open val label: String
        class Step
          Module Contents Step(label: String)
          open val changes: <ERROR CLASS><Change>
          open fun childProgressTracker(): ProgressTracker?
          open val label: String
        object UNSTARTED : Step
          Module Contents fun equals(other: Any?): Boolean
        val allSteps: List<<ERROR CLASS><Int, Step>>
        val changes: <ERROR CLASS><Change>
        var currentStep: Step
        val currentStepRecursive: Step
        fun getChildProgressTracker(step: Step): ProgressTracker?
        fun nextStep(): Step
        var parent: ProgressTracker?
        fun setChildProgressTracker(step: Step, childProgressTracker: ProgressTracker): Unit
        var stepIndex: Int
        val steps: Array<Step>
        val topLevelTracker: ProgressTracker
      val TEST_TX_TIME: Instant
      data class TimeWindow
        Module Contents TimeWindow(start: Instant, duration: Duration)
        val duration: Duration
        val end: Instant
        val start: Instant
      class UntrustworthyData<out T>
        Module Contents UntrustworthyData(fromUntrustedWorld: T)
        val data: T
        inline fun <R> unwrap(validator: (T) -> R): R
        inline fun <R> validate(validator: (T) -> R): R
      inline fun <ERROR CLASS>.debug(msg: () -> String): Unit
      inline fun <reified T : Any> loggerFor(): <ERROR CLASS>
      fun <T> nonEmptySetOf(initial: T, vararg elements: T): NonEmptySet<T>
      inline fun <ERROR CLASS>.trace(msg: () -> String): Unit
    package net.corda.flows
      Module Contents abstract class AbstractStateReplacementFlow<T>
        Module Contents AbstractStateReplacementFlow()
        abstract class Acceptor<T> : FlowLogic<Unit>
          Module Contents Acceptor(otherSide: Party, progressTracker: ProgressTracker = tracker())
          object APPROVING : Step
          object REJECTING : Step
          object VERIFYING : Step
          open fun call(): Unit
          val otherSide: Party
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
          protected abstract fun verifyProposal(maybeProposal: UntrustworthyData<Proposal<T>>): Proposal<T>
        abstract class Instigator<out S : ContractState, T> : FlowLogic<StateAndRef<S>>
          Module Contents Instigator(originalState: StateAndRef<S>, modification: T, progressTracker: ProgressTracker = tracker())
          object NOTARY : Step
          object SIGNING : Step
          protected abstract fun assembleProposal(stateRef: StateRef, modification: T, stx: SignedTransaction): Proposal<T>
          protected abstract fun assembleTx(): <ERROR CLASS><SignedTransaction, List<CompositeKey>>
          open fun call(): StateAndRef<S>
          val modification: T
          val originalState: StateAndRef<S>
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
        interface Proposal<out T>
          Module Contents abstract val modification: T
          abstract val stateRef: StateRef
          abstract val stx: SignedTransaction
        data class Result
          Module Contents val error: StateReplacementRefused?
          fun noError(sig: WithKey): Result
          val sig: WithKey?
          fun withError(error: StateReplacementRefused): Result
      class BroadcastTransactionFlow : FlowLogic<Unit>
        Module Contents BroadcastTransactionFlow(notarisedTransaction: SignedTransaction, participants: Set<Party>)
        data class NotifyTxRequest
          Module Contents NotifyTxRequest(tx: SignedTransaction)
          val tx: SignedTransaction
        fun call(): Unit
        val notarisedTransaction: SignedTransaction
        val participants: Set<Party>
      sealed class CashCommand
        Module Contents class ExitCash : CashCommand
          Module Contents ExitCash(amount: Amount<Currency>, issueRef: OpaqueBytes)
          val amount: Amount<Currency>
          val issueRef: OpaqueBytes
        class IssueCash : CashCommand
          Module Contents IssueCash(amount: Amount<Currency>, issueRef: OpaqueBytes, recipient: Party, notary: Party)
          val amount: Amount<Currency>
          val issueRef: OpaqueBytes
          val notary: Party
          val recipient: Party
        class PayCash : CashCommand
          Module Contents PayCash(amount: Amount<Issued<Currency>>, recipient: Party)
          val amount: Amount<Issued<Currency>>
          val recipient: Party
      class CashFlow : FlowLogic<CashFlowResult>
        Module Contents CashFlow(command: CashCommand)
        CashFlow(command: CashCommand, progressTracker: ProgressTracker)
        object EXITING : Step
        object ISSUING : Step
        object PAYING : Step
        fun call(): CashFlowResult
        val command: CashCommand
        val progressTracker: ProgressTracker
        fun tracker(): ProgressTracker
      sealed class CashFlowResult
        Module Contents class Failed : CashFlowResult
          Module Contents Failed(message: String?)
          val message: String?
          fun toString(): String
        class Success : CashFlowResult
          Module Contents Success(id: StateMachineRunId, transaction: SignedTransaction?, message: String?)
          val id: StateMachineRunId
          val message: String?
          fun toString(): String
          val transaction: SignedTransaction?
      class FetchAttachmentsFlow : FetchDataFlow<Attachment, ByteArray>
        Module Contents FetchAttachmentsFlow(requests: Set<SecureHash>, otherSide: Party)
        protected fun convert(wire: ByteArray): Attachment
        protected fun load(txid: SecureHash): Attachment?
        protected fun maybeWriteToDisk(downloaded: List<Attachment>): Unit
      abstract class FetchDataFlow<T : NamedByHash, in W : Any> : FlowLogic<Result<T>>
        Module Contents FetchDataFlow(requests: Set<SecureHash>, otherSide: Party)
        open class BadAnswer : Exception
          Module Contents BadAnswer()
        class DownloadedVsRequestedDataMismatch : BadAnswer
          Module Contents DownloadedVsRequestedDataMismatch(requested: SecureHash, got: SecureHash)
          val got: SecureHash
          val requested: SecureHash
        class HashNotFound : BadAnswer
          Module Contents HashNotFound(requested: SecureHash)
          val requested: SecureHash
        data class Request
          Module Contents Request(hashes: List<SecureHash>)
          val hashes: List<SecureHash>
        data class Result<out T : NamedByHash>
          Module Contents Result(fromDisk: List<T>, downloaded: List<T>)
          val downloaded: List<T>
          val fromDisk: List<T>
        open fun call(): Result<T>
        protected open fun convert(wire: W): T
        protected abstract fun load(txid: SecureHash): T?
        protected open fun maybeWriteToDisk(downloaded: List<T>): Unit
        protected val otherSide: Party
        protected val requests: Set<SecureHash>
      class FetchTransactionsFlow : FetchDataFlow<SignedTransaction, SignedTransaction>
        Module Contents FetchTransactionsFlow(requests: Set<SecureHash>, otherSide: Party)
        protected fun load(txid: SecureHash): SignedTransaction?
      class FinalityFlow : FlowLogic<Unit>
        Module Contents FinalityFlow(transaction: SignedTransaction, participants: Set<Party>)
        FinalityFlow(transaction: SignedTransaction, participants: Set<Party>, progressTracker: ProgressTracker)
        object BROADCASTING : Step
        object NOTARISING : Step
        fun call(): Unit
        val participants: Set<Party>
        val progressTracker: ProgressTracker
        fun tracker(): ProgressTracker
        val transaction: SignedTransaction
      class InputStateRefResolveFailed : Exception
        Module Contents InputStateRefResolveFailed(stateRefs: List<StateRef>)
      object IssuerFlow
        Module Contents data class IssuanceRequestState
          Module Contents IssuanceRequestState(amount: Amount<Currency>, issueToParty: Party, issuerPartyRef: OpaqueBytes)
          val amount: Amount<Currency>
          val issueToParty: Party
          val issuerPartyRef: OpaqueBytes
        class IssuanceRequester : FlowLogic<SignedTransaction>
          Module Contents IssuanceRequester(amount: Amount<Currency>, issueToParty: Party, issueToPartyRef: OpaqueBytes, issuerBankParty: Party)
          val amount: Amount<Currency>
          fun call(): SignedTransaction
          val issueToParty: Party
          val issueToPartyRef: OpaqueBytes
          val issuerBankParty: Party
        class Issuer : FlowLogic<SignedTransaction>
          Module Contents Issuer(otherParty: Party)
          object AWAITING_REQUEST : Step
          object ISSUING : Step
          object SENDING_CONFIRM : Step
          class Service
            Module Contents Service(services: PluginServiceHub)
          object TRANSFERRING : Step
          fun call(): SignedTransaction
          val otherParty: Party
          val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
      object NotaryChangeFlow : AbstractStateReplacementFlow<Party>
        Module Contents class Acceptor : Acceptor<Party>
          Module Contents Acceptor(otherSide: Party, progressTracker: ProgressTracker = tracker())
          val progressTracker: ProgressTracker
          protected fun verifyProposal(maybeProposal: UntrustworthyData<Proposal<Party>>): Proposal<Party>
        class Instigator<T : ContractState> : Instigator<T, Party>
          Module Contents Instigator(originalState: StateAndRef<T>, newNotary: Party, progressTracker: ProgressTracker = tracker())
          protected fun assembleProposal(stateRef: StateRef, modification: Party, stx: SignedTransaction): Proposal<Party>
          protected fun assembleTx(): <ERROR CLASS><SignedTransaction, List<CompositeKey>>
        data class Proposal : Proposal<Party>
          Module Contents Proposal(stateRef: StateRef, modification: Party, stx: SignedTransaction)
          val modification: Party
          val stateRef: StateRef
          val stx: SignedTransaction
      sealed class NotaryError
        Module Contents class Conflict : NotaryError
          Module Contents Conflict(tx: WireTransaction, conflict: SignedData<Conflict>)
          val conflict: SignedData<Conflict>
          fun toString(): String
          val tx: WireTransaction
        class SignaturesMissing : NotaryError
          Module Contents SignaturesMissing(missingSigners: Set<CompositeKey>)
          val missingSigners: Set<CompositeKey>
          fun toString(): String
        class TimestampInvalid : NotaryError
          Module Contents TimestampInvalid()
        class TransactionInvalid : NotaryError
          Module Contents TransactionInvalid()
      class NotaryException : Exception
        Module Contents NotaryException(error: NotaryError)
        val error: NotaryError
        fun toString(): String
      object NotaryFlow
        Module Contents class Client : FlowLogic<WithKey>
          Module Contents Client(stx: SignedTransaction)
          Client(stx: SignedTransaction, progressTracker: ProgressTracker)
          object REQUESTING : Step
          object VALIDATING : Step
          open fun call(): WithKey
          lateinit var notaryParty: Party
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
        sealed class Result
          Module Contents class Error : Result
            Module Contents Error(error: NotaryError)
            val error: NotaryError
          class Success : Result
            Module Contents Success(sig: WithKey)
            val sig: WithKey
        class Service : FlowLogic<Unit>
          Module Contents Service(otherSide: Party, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
          open fun beforeCommit(stx: SignedTransaction): Unit
          open fun call(): Unit
          val otherSide: Party
          val timestampChecker: TimestampChecker
          val uniquenessProvider: UniquenessProvider
        data class SignRequest
          Module Contents SignRequest(tx: SignedTransaction)
          val tx: SignedTransaction
      class ResolveTransactionsFlow : FlowLogic<List<LedgerTransaction>>
        Module Contents ResolveTransactionsFlow(stx: SignedTransaction, otherSide: Party)
        ResolveTransactionsFlow(wtx: WireTransaction, otherSide: Party)
        ResolveTransactionsFlow(txHashes: Set<SecureHash>, otherSide: Party)
        class ExcessivelyLargeTransactionGraph : Exception
          Module Contents ExcessivelyLargeTransactionGraph()
        fun call(): List<LedgerTransaction>
        var transactionCountLimit: Int
      interface ServiceRequestMessage
        Module Contents abstract val replyTo: SingleMessageRecipient
        abstract val sessionID: Long
      class StateReplacementException : Exception
        Module Contents StateReplacementException(error: StateReplacementRefused)
        val error: StateReplacementRefused
      class StateReplacementRefused
        Module Contents StateReplacementRefused(identity: Party, state: StateRef, detail: String?)
        val detail: String?
        val identity: Party
        val state: StateRef
        fun toString(): String
      object TwoPartyDealFlow
        Module Contents class Acceptor : Secondary<AutoOffer>
          Module Contents Acceptor(otherParty: Party, progressTracker: ProgressTracker = Secondary.tracker())
          protected open fun assembleSharedTX(handshake: Handshake<AutoOffer>): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
          open val otherParty: Party
          open val progressTracker: ProgressTracker
          protected open fun validateHandshake(handshake: Handshake<AutoOffer>): Handshake<AutoOffer>
        data class AutoOffer
          Module Contents AutoOffer(notary: Party, dealBeingOffered: DealState)
          val dealBeingOffered: DealState
          val notary: Party
        class DealMismatchException : Exception
          Module Contents DealMismatchException(expectedDeal: ContractState, actualDeal: ContractState)
          val actualDeal: ContractState
          val expectedDeal: ContractState
          fun toString(): String
        class DealRefMismatchException : Exception
          Module Contents DealRefMismatchException(expectedDeal: StateRef, actualDeal: StateRef)
          val actualDeal: StateRef
          val expectedDeal: StateRef
          fun toString(): String
        data class Handshake<out T>
          Module Contents Handshake(payload: T, publicKey: CompositeKey)
          val payload: T
          val publicKey: CompositeKey
        class Instigator : Primary
          Module Contents Instigator(otherParty: Party, payload: AutoOffer, myKeyPair: KeyPair, progressTracker: ProgressTracker = Primary.tracker())
          open val myKeyPair: KeyPair
          open val notaryNode: NodeInfo
          open val otherParty: Party
          open val payload: AutoOffer
          open val progressTracker: ProgressTracker
        interface MarkerForBogusRegulatorFlow
        abstract class Primary : FlowLogic<SignedTransaction>
          Module Contents Primary(progressTracker: ProgressTracker = Primary.tracker())
          object AWAITING_PROPOSAL : Step
          object COPYING_TO_REGULATOR : Step
          object NOTARY : Step
          object RECORDING : Step
          object SENDING_SIGS : Step
          object SIGNING : Step
          object VERIFYING : Step
          open fun call(): SignedTransaction
          open fun computeOurSignature(partialTX: SignedTransaction): WithKey
          open fun getCounterpartyMarker(party: Party): Class<*>
          fun getPartialTransaction(): UntrustworthyData<SignedTransaction>
          abstract val myKeyPair: KeyPair
          abstract val notaryNode: NodeInfo
          abstract val otherParty: Party
          abstract val payload: Any
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
          fun verifyPartialTransaction(untrustedPartialTX: UntrustworthyData<SignedTransaction>): SignedTransaction
        abstract class Secondary<U> : FlowLogic<SignedTransaction>
          Module Contents Secondary(progressTracker: ProgressTracker = Secondary.tracker())
          object RECEIVING : Step
          object RECORDING : Step
          object SIGNING : Step
          object SWAPPING_SIGNATURES : Step
          object VERIFYING : Step
          protected abstract fun assembleSharedTX(handshake: Handshake<U>): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
          open fun call(): SignedTransaction
          abstract val otherParty: Party
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
          protected abstract fun validateHandshake(handshake: Handshake<U>): Handshake<U>
        class SignaturesFromPrimary
          Module Contents SignaturesFromPrimary(sellerSig: WithKey, notarySig: WithKey)
          val notarySig: WithKey
          val sellerSig: WithKey
      object TwoPartyTradeFlow
        Module Contents class AssetMismatchException : Exception
          Module Contents AssetMismatchException(expectedTypeName: String, typeName: String)
          val expectedTypeName: String
          fun toString(): String
          val typeName: String
        class Buyer : FlowLogic<SignedTransaction>
          Module Contents Buyer(otherParty: Party, notary: Party, acceptablePrice: Amount<Currency>, typeToBuy: Class<out OwnableState>)
          object RECEIVING : Step
          object SIGNING : Step
          object SWAPPING_SIGNATURES : Step
          object VERIFYING : Step
          val acceptablePrice: Amount<Currency>
          open fun call(): SignedTransaction
          val notary: Party
          val otherParty: Party
          open val progressTracker: ProgressTracker
          val typeToBuy: Class<out OwnableState>
        class Seller : FlowLogic<SignedTransaction>
          Module Contents Seller(otherParty: Party, notaryNode: NodeInfo, assetToSell: StateAndRef<OwnableState>, price: Amount<Currency>, myKeyPair: KeyPair, progressTracker: ProgressTracker = Seller.tracker())
          object AWAITING_PROPOSAL : Step
          object NOTARY : Step
          object SENDING_SIGS : Step
          object SIGNING : Step
          object VERIFYING : Step
          val assetToSell: StateAndRef<OwnableState>
          open fun calculateOurSignature(partialTX: SignedTransaction): WithKey
          open fun call(): SignedTransaction
          val myKeyPair: KeyPair
          val notaryNode: NodeInfo
          val otherParty: Party
          val price: Amount<Currency>
          open val progressTracker: ProgressTracker
          fun tracker(): ProgressTracker
        data class SellerTradeInfo
          Module Contents SellerTradeInfo(assetForSale: StateAndRef<OwnableState>, price: Amount<Currency>, sellerOwnerKey: CompositeKey)
          val assetForSale: StateAndRef<OwnableState>
          val price: Amount<Currency>
          val sellerOwnerKey: CompositeKey
        data class SignaturesFromSeller
          Module Contents SignaturesFromSeller(sellerSig: WithKey, notarySig: WithKey)
          val notarySig: WithKey
          val sellerSig: WithKey
        class UnacceptablePriceException : Exception
          Module Contents UnacceptablePriceException(givenPrice: Amount<Currency>)
          val givenPrice: Amount<Currency>
      class ValidatingNotaryFlow : Service
        Module Contents ValidatingNotaryFlow(otherSide: Party, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
        fun beforeCommit(stx: SignedTransaction): Unit
      fun <R : Any> MessagingService.sendRequest(topic: String, request: ServiceRequestMessage, target: SingleMessageRecipient): <ERROR CLASS><R>
    package net.corda.node
      Module Contents fun main(args: Array<String>): Unit
      fun printBasicNodeInfo(description: String, info: String? = null): Unit
    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
        Module Contents ContractClassRef(className: String)
        val className: String
      interface ContractDefRef
      data class ContractLedgerRef : ContractDefRef
        Module Contents ContractLedgerRef(hash: SecureHash)
        val hash: SecureHash
      data class FlowClassRef : FlowRef
        Module Contents FlowClassRef(className: String)
        val className: String
      data class FlowInstanceRef
        Module Contents FlowInstanceRef(flowInstance: SecureHash, flowClass: FlowClassRef, flowStepId: String)
        val flowClass: FlowClassRef
        val flowInstance: SecureHash
        val flowStepId: String
      interface FlowRef
      data class FlowRequiringAttention
        Module Contents FlowRequiringAttention(ref: FlowInstanceRef, prompt: String, choiceIdsToMessages: Map<SecureHash, String>, dueBy: Instant)
        val choiceIdsToMessages: Map<SecureHash, String>
        val dueBy: Instant
        val prompt: String
        val ref: FlowInstanceRef
      interface StatesQuery
        Module Contents interface Criteria
          Module Contents object AllDeals : Criteria
          data class Deal : Criteria
            Module Contents Deal(ref: String)
            val ref: String
        data class Selection : StatesQuery
          Module Contents Selection(criteria: Criteria)
          val criteria: Criteria
        fun select(criteria: Criteria): Selection
      data class TransactionBuildStep
        Module Contents TransactionBuildStep(generateMethodName: String, args: Map<String, Any?>)
        val args: Map<String, Any?>
        val generateMethodName: String
    package net.corda.node.driver
      Module Contents abstract class DriverBasedTest
        Module Contents DriverBasedTest()
        protected sealed class RunTestToken
        protected fun DriverDSLExposedInterface.runTest(): RunTestToken
        protected abstract fun setup(): RunTestToken
        fun start(): Unit
        fun stop(): Unit
      open class DriverDSL : DriverDSLInternalInterface
        Module Contents DriverDSL(portAllocation: PortAllocation, debugPortAllocation: PortAllocation, driverDirectory: Path, useTestClock: Boolean, isDebug: Boolean)
        class State
          Module Contents State()
          val clients: LinkedList<NodeMessagingClient>
          val registeredProcesses: LinkedList<<ERROR CLASS><Process>>
        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: <ERROR CLASS><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?>): <ERROR CLASS><NodeHandle>
        open fun startNotaryCluster(notaryName: String, clusterSize: Int, type: ServiceType, rpcUsers: List<User>): <ERROR CLASS><<ERROR CLASS><Party, List<NodeHandle>>>
        val useTestClock: Boolean
        open fun waitForAllNodesToFinish(): Unit
      interface DriverDSLExposedInterface
        Module Contents abstract fun startNode(providedName: String? = null, advertisedServices: Set<ServiceInfo> = emptySet(), rpcUsers: List<User> = emptyList(), customOverrides: Map<String, Any?> = emptyMap()): <ERROR CLASS><NodeHandle>
        abstract fun startNotaryCluster(notaryName: String, clusterSize: Int = 3, type: ServiceType = RaftValidatingNotaryService.type, rpcUsers: List<User> = emptyList()): Future<<ERROR CLASS><Party, List<NodeHandle>>>
        abstract fun waitForAllNodesToFinish(): Unit
      interface DriverDSLInternalInterface : DriverDSLExposedInterface
        Module Contents abstract fun shutdown(): Unit
        abstract fun start(): Unit
      data class NodeHandle
        Module Contents NodeHandle(nodeInfo: NodeInfo, config: <ERROR CLASS>, process: Process)
        val config: <ERROR CLASS>
        val nodeInfo: NodeInfo
        val process: Process
      sealed class PortAllocation
        Module Contents class Incremental : PortAllocation
          Module Contents Incremental(startingPort: Int)
          fun nextPort(): Int
          val portCounter: AtomicInteger
        class RandomFree : PortAllocation
          Module Contents RandomFree()
          fun nextPort(): Int
        fun nextHostAndPort(): <ERROR CLASS>
        abstract fun nextPort(): Int
      fun addressMustBeBound(executorService: ScheduledExecutorService, hostAndPort: <ERROR CLASS>): <ERROR CLASS><Unit>
      fun addressMustNotBeBound(executorService: ScheduledExecutorService, hostAndPort: <ERROR CLASS>): <ERROR CLASS><Unit>
      fun <A> driver(isDebug: Boolean = false, driverDirectory: Path = Paths.get("build", getTimestampAsDirectoryName()), portAllocation: PortAllocation = PortAllocation.Incremental(10000), debugPortAllocation: PortAllocation = PortAllocation.Incremental(5005), useTestClock: Boolean = false, dsl: DriverDSLExposedInterface.() -> A): A
      fun <DI : DriverDSLExposedInterface, D : DriverDSLInternalInterface, A> genericDriver(driverDsl: D, coerce: (D) -> DI, dsl: DI.() -> A): A
      fun getTimestampAsDirectoryName(): String
      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
        Module Contents AbstractNode(configuration: NodeConfiguration, networkMapService: SingleMessageRecipient?, advertisedServices: Set<ServiceInfo>, platformClock: Clock)
        class DatabaseConfigurationException : Exception
          Module Contents DatabaseConfigurationException(msg: String)
        val PRIVATE_KEY_FILE_NAME: String
        val PUBLIC_IDENTITY_FILE_NAME: String
        protected val _servicesThatAcceptUploads: ArrayList<AcceptsFileUpload>
        protected open fun acceptableLiveFiberCountOnStop(): Int
        val advertisedServices: Set<ServiceInfo>
        lateinit var api: APIServer
        lateinit var checkpointStorage: CheckpointStorage
        open val configuration: NodeConfiguration
        protected open fun constructStorageService(attachments: NodeAttachmentService, transactionStorage: TransactionStorage, stateMachineRecordedTransactionMappingStorage: StateMachineRecordedTransactionMappingStorage): StorageServiceImpl
        protected fun createNodeDir(): Unit
        val customServices: ArrayList<Any>
        lateinit var database: <ERROR CLASS>
        protected var dbCloser: Runnable?
        val defaultFlowWhiteList: Map<Class<out FlowLogic<*>>, Set<Class<*>>>
        open fun findMyLocation(): PhysicalLocation?
        inline fun <reified T : Any> findService(): <ERROR CLASS>
        lateinit var flowLogicFactory: FlowLogicRefFactory
        protected open fun generateKeyPair(): KeyPair
        lateinit var identity: IdentityService
        var inNodeNetworkMapService: NetworkMapService?
        var inNodeNotaryService: NotaryService?
        lateinit var info: NodeInfo
        protected open fun initialiseDatabasePersistence(insideTransaction: () -> Unit): Unit
        protected open fun initialiseStorageService(dir: Path): <ERROR CLASS><TxWritableStorageService, CheckpointStorage>
        var isPreviousCheckpointsPresent: Boolean
        lateinit var keyManagement: KeyManagementService
        protected abstract val log: <ERROR CLASS>
        protected fun makeAttachmentStorage(dir: Path): NodeAttachmentService
        protected open fun makeIdentityService(): IdentityService
        protected open fun makeKeyManagementService(): KeyManagementService
        protected abstract fun makeMessagingService(): MessagingServiceInternal
        protected open fun makeNetworkMapService(): Unit
        protected open fun makeNotaryService(type: ServiceType): NotaryService
        protected open fun makeSchemaService(): SchemaService
        protected fun makeServiceEntries(): List<ServiceEntry>
        protected abstract fun makeUniquenessProvider(type: ServiceType): UniquenessProvider
        protected open fun makeVaultService(): VaultService
        lateinit var net: MessagingServiceInternal
        lateinit var netMapCache: NetworkMapCache
        val networkMapRegistrationFuture: <ERROR CLASS><Unit>
        var networkMapSeq: Long
        val networkMapService: SingleMessageRecipient?
        protected open fun noNetworkMapConfigured(): <ERROR CLASS><Unit>
        protected fun obtainLegalIdentity(): Party
        protected fun obtainLegalIdentityKey(): KeyPair
        protected val partyKeys: <ERROR CLASS>
        val platformClock: Clock
        open val pluginRegistries: List<CordaPluginRegistry>
        protected val runOnStop: ArrayList<Runnable>
        lateinit var scheduler: NodeSchedulerService
        lateinit var schemas: SchemaService
        protected abstract val serverThread: AffinityExecutor
        val services: ServiceHubInternal
        val servicesThatAcceptUploads: List<AcceptsFileUpload>
        open fun setup(): AbstractNode
        lateinit var smm: StateMachineManager
        open fun start(): AbstractNode
        protected abstract fun startMessagingService(rpcOps: RPCOps): Unit
        var started: Boolean
        open fun stop(): Unit
        lateinit var storage: TxWritableStorageService
        var uniquenessProvider: UniquenessProvider?
        lateinit var vault: VaultService
      class ConfigurationException : Exception
        Module Contents ConfigurationException(message: String)
      class CordaRPCOpsImpl : CordaRPCOps
        Module Contents CordaRPCOpsImpl(services: ServiceHub, smm: StateMachineManager, database: <ERROR CLASS>)
        fun addVaultTransactionNote(txnId: SecureHash, txnNote: String): Unit
        fun attachmentExists(id: SecureHash): Boolean
        fun currentNodeTime(): Instant
        val database: <ERROR CLASS>
        fun getVaultTransactionNotes(txnId: SecureHash): Iterable<String>
        fun networkMapUpdates(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
        fun nodeIdentity(): NodeInfo
        fun partyFromKey(key: CompositeKey): Party?
        fun partyFromName(name: String): Party?
        val protocolVersion: Int
        val services: ServiceHub
        val smm: StateMachineManager
        fun <T : Any> startFlowDynamic(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowHandle<T>
        fun stateMachineRecordedTransactionMapping(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
        fun stateMachinesAndUpdates(): <ERROR CLASS><List<StateMachineInfo>, <ERROR CLASS><StateMachineUpdate>>
        fun uploadAttachment(jar: InputStream): SecureHash
        fun vaultAndUpdates(): <ERROR CLASS><List<StateAndRef<ContractState>>, <ERROR CLASS><Update>>
        fun verifiedTransactions(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
      class Node : AbstractNode
        Module Contents Node(configuration: FullNodeConfiguration, networkMapAddress: SingleMessageRecipient?, advertisedServices: Set<ServiceInfo>, clock: Clock = NodeClock())
        val configuration: FullNodeConfiguration
        protected fun initialiseDatabasePersistence(insideTransaction: () -> Unit): Unit
        protected val log: <ERROR CLASS>
        protected fun makeMessagingService(): MessagingServiceInternal
        protected fun makeUniquenessProvider(type: ServiceType): UniquenessProvider
        var messageBroker: ArtemisMessagingServer?
        fun run(): Unit
        protected val serverThread: ServiceAffinityExecutor
        fun setup(): Node
        fun start(): Node
        protected fun startMessagingService(rpcOps: RPCOps): Unit
        fun stop(): Unit
        lateinit var webServer: <ERROR CLASS>
    package net.corda.node.serialization
      Module Contents class NodeClock : Clock, SerializeAsToken
        Module Contents NodeClock(delegateClock: Clock = Clock.systemUTC())
        fun getZone(): ZoneId
        fun instant(): Instant
        fun toToken(context: SerializeAsTokenContext): SerializationToken
        fun withZone(zone: ZoneId): Clock
    package net.corda.node.services
      Module Contents object NotaryChange
        Module Contents class Plugin : CordaPluginRegistry
          Module Contents Plugin()
          val servicePlugins: <ERROR CLASS>
        class Service : SingletonSerializeAsToken
          Module Contents Service(services: PluginServiceHub)
      interface RPCUserService
        Module Contents abstract fun getUser(username: String): User?
        abstract val users: List<User>
      class RPCUserServiceImpl : RPCUserService
        Module Contents RPCUserServiceImpl(config: FullNodeConfiguration)
        fun getUser(username: String): User?
        val users: List<User>
      data class User
        Module Contents User(username: String, password: String, permissions: Set<String>)
        val password: String
        val permissions: Set<String>
        fun toString(): String
        val username: String
      fun startFlowPermission(className: String): String
      fun <P : FlowLogic<*>> startFlowPermission(clazz: Class<P>): String
      inline fun <reified P : FlowLogic<*>> startFlowPermission(): String
    package net.corda.node.services.api
      Module Contents abstract class AbstractNodeService : SingletonSerializeAsToken
        Module Contents AbstractNodeService(services: ServiceHubInternal)
        protected inline fun <reified Q : ServiceRequestMessage, reified R : Any> addMessageHandler(topic: String, crossinline handler: (Q) -> R, crossinline exceptionConsumer: (Message, Exception) -> Unit): MessageHandlerRegistration
        protected inline fun <reified Q : ServiceRequestMessage, reified R : Any> addMessageHandler(topic: String, crossinline handler: (Q) -> R): MessageHandlerRegistration
        val net: MessagingServiceInternal
        val services: ServiceHubInternal
      interface AcceptsFileUpload
        Module Contents abstract val acceptableFileExtensions: List<String>
        abstract val dataTypePrefix: String
        abstract fun upload(data: InputStream): String
      class Checkpoint
        Module Contents Checkpoint(serializedFiber: SerializedBytes<FlowStateMachineImpl<*>>)
        fun equals(other: Any?): Boolean
        fun hashCode(): Int
        val id: SecureHash
        val serializedFiber: SerializedBytes<FlowStateMachineImpl<*>>
        fun toString(): String
      interface CheckpointStorage
        Module Contents abstract fun addCheckpoint(checkpoint: Checkpoint): Unit
        abstract fun forEach(block: (Checkpoint) -> Boolean): Unit
        abstract fun removeCheckpoint(checkpoint: Checkpoint): Unit
      interface MessagingServiceBuilder<out T : MessagingServiceInternal>
        Module Contents abstract fun start(): <ERROR CLASS><out T>
      interface MessagingServiceInternal : MessagingService
        Module Contents abstract fun stop(): Unit
      class MonitoringService : SingletonSerializeAsToken
        Module Contents MonitoringService(metrics: <ERROR CLASS>)
        val metrics: <ERROR CLASS>
      interface RegulatorService
        Module Contents val type: ServiceType
      interface SchemaService
        Module Contents data class SchemaOptions
          Module Contents SchemaOptions(databaseSchema: String?, tablePrefix: String?)
          val databaseSchema: String?
          val tablePrefix: String?
        abstract fun generateMappedObject(state: QueryableState, schema: MappedSchema): PersistentState
        abstract val schemaOptions: Map<MappedSchema, SchemaOptions>
        abstract fun selectSchemas(state: QueryableState): Iterable<MappedSchema>
      abstract class ServiceHubInternal : PluginServiceHub
        Module Contents ServiceHubInternal()
        abstract val flowLogicRefFactory: FlowLogicRefFactory
        open fun <T : Any> invokeFlowAsync(logicType: Class<out FlowLogic<T>>, vararg args: Any?): FlowStateMachine<T>
        abstract val monitoringService: MonitoringService
        abstract val networkService: MessagingServiceInternal
        abstract val schemaService: SchemaService
        abstract fun <T> startFlow(logic: FlowLogic<T>): FlowStateMachine<T>
    package net.corda.node.services.config
      Module Contents object ConfigHelper
        Module Contents fun loadConfig(baseDirectoryPath: Path, configFileOverride: Path? = null, allowMissingConfig: Boolean = false, configOverrides: Map<String, Any?> = emptyMap()): <ERROR CLASS>
        val log: <ERROR CLASS>
      class FullNodeConfiguration : NodeConfiguration
        Module Contents FullNodeConfiguration(config: <ERROR CLASS>)
        val artemisAddress: <ERROR CLASS>
        val basedir: Path
        val config: <ERROR CLASS>
        fun createNode(): Node
        val dataSourceProperties: Properties
        val devMode: Boolean
        val emailAddress: String
        val exportJMXto: String
        val extraAdvertisedServiceIds: String
        val keyStorePassword: String
        val messagingServerAddress: <ERROR CLASS>?
        val myLegalName: String
        val nearestCity: String
        val networkMapAddress: <ERROR CLASS>?
        val notaryClusterAddresses: List<<ERROR CLASS>>
        val notaryNodeAddress: <ERROR CLASS>?
        val rpcUsers: List<User>
        val trustStorePassword: String
        val useHTTPS: Boolean
        val useTestClock: Boolean
        val webAddress: <ERROR CLASS>
      interface NodeConfiguration : NodeSSLConfiguration
        Module Contents abstract val basedir: Path
        open val certificatesPath: Path
        open val dataSourceProperties: Properties
        abstract val devMode: Boolean
        abstract val emailAddress: String
        abstract val exportJMXto: String
        abstract val myLegalName: String
        abstract val nearestCity: String
      interface NodeSSLConfiguration
        Module Contents abstract val certificatesPath: Path
        abstract val keyStorePassword: String
        open val keyStorePath: Path
        abstract val trustStorePassword: String
        open val trustStorePath: Path
      class OptionalConfig<out T>
        Module Contents OptionalConfig(conf: <ERROR CLASS>, lambda: () -> T)
        val conf: <ERROR CLASS>
        operator fun getValue(receiver: Any, metadata: KProperty<*>): T
        val lambda: () -> T
      fun configureTestSSL(): NodeSSLConfiguration
      fun NodeConfiguration.configureWithDevSSLCertificate(): Unit
      inline fun <reified T : Any> <ERROR CLASS>.getListOrElse(path: String, default: <ERROR CLASS>.() -> List<T>): List<T>
      fun <T> <ERROR CLASS>.getOrElse(lambda: () -> T): OptionalConfig<T>
      fun <ERROR CLASS>.getProperties(path: String): Properties
      operator fun <T> <ERROR CLASS>.getValue(receiver: Any, metadata: KProperty<*>): T
    package net.corda.node.services.events
      Module Contents class NodeSchedulerService : SchedulerService, SingletonSerializeAsToken
        Module Contents NodeSchedulerService(database: <ERROR CLASS>, services: ServiceHubInternal, flowLogicRefFactory: FlowLogicRefFactory, schedulerTimerExecutor: Executor = Executors.newSingleThreadExecutor())
        class RunScheduled : FlowLogic<Unit>
          Module Contents RunScheduled(scheduledState: ScheduledStateRef, scheduler: NodeSchedulerService)
          object RUNNING : Step
          fun call(): Unit
          val progressTracker: ProgressTracker
          val scheduledState: ScheduledStateRef
          val scheduler: NodeSchedulerService
          fun tracker(): ProgressTracker
        fun scheduleStateActivity(action: ScheduledStateRef): Unit
        fun start(): Unit
        val unfinishedSchedules: <ERROR CLASS>
        fun unscheduleStateActivity(ref: StateRef): Unit
      class ScheduledActivityObserver
        Module Contents ScheduledActivityObserver(services: ServiceHubInternal)
        val services: ServiceHubInternal
    package net.corda.node.services.identity
      Module Contents class InMemoryIdentityService : SingletonSerializeAsToken, IdentityService
        Module Contents InMemoryIdentityService()
        fun getAllIdentities(): Iterable<Party>
        fun partyFromKey(key: CompositeKey): Party?
        fun partyFromName(name: String): Party?
        fun registerIdentity(party: Party): Unit
    package net.corda.node.services.keys
      Module Contents class E2ETestKeyManagementService : SingletonSerializeAsToken, KeyManagementService
        Module Contents E2ETestKeyManagementService(initialKeys: Set<KeyPair>)
        fun freshKey(): KeyPair
        val keys: Map<PublicKey, PrivateKey>
      class PersistentKeyManagementService : SingletonSerializeAsToken, KeyManagementService
        Module Contents PersistentKeyManagementService(initialKeys: Set<KeyPair>)
        fun freshKey(): KeyPair
        val keys: Map<PublicKey, PrivateKey>
    package net.corda.node.services.messaging
      Module Contents abstract class ArtemisMessagingComponent : SingletonSerializeAsToken
        Module Contents ArtemisMessagingComponent()
        interface ArtemisAddress : MessageRecipients
          Module Contents abstract val queueName: <ERROR CLASS>
        interface ArtemisPeerAddress : ArtemisAddress, SingleMessageRecipient
          Module Contents abstract val hostAndPort: <ERROR CLASS>
        const val CLIENTS_PREFIX: String
        protected enum class ConnectionDirection
          Module Contents INBOUND
          OUTBOUND
        const val INTERNAL_PREFIX: String
        val NETWORK_MAP_ADDRESS: String
        const val NODE_USER: String
        const val NOTIFICATIONS_ADDRESS: String
        data class NetworkMapAddress : SingleMessageRecipient, ArtemisPeerAddress
          Module Contents NetworkMapAddress(hostAndPort: <ERROR CLASS>)
          val hostAndPort: <ERROR CLASS>
          val queueName: <ERROR CLASS>
        data class NodeAddress : ArtemisPeerAddress
          Module Contents NodeAddress(queueName: <ERROR CLASS>, hostAndPort: <ERROR CLASS>)
          fun asPeer(peerIdentity: CompositeKey, hostAndPort: <ERROR CLASS>): NodeAddress
          fun asService(serviceIdentity: CompositeKey, hostAndPort: <ERROR CLASS>): NodeAddress
          val hostAndPort: <ERROR CLASS>
          val queueName: <ERROR CLASS>
          fun toString(): String
        const val P2P_QUEUE: String
        const val PEERS_PREFIX: String
        const val PEER_USER: String
        const val RPC_QUEUE_REMOVALS_QUEUE: String
        const val RPC_REQUESTS_QUEUE: String
        const val SERVICES_PREFIX: String
        data class ServiceAddress : ArtemisAddress, MessageRecipientGroup
          Module Contents ServiceAddress(identity: CompositeKey)
          val identity: CompositeKey
          val queueName: <ERROR CLASS>
        fun checkStorePasswords(): Unit
        abstract val config: NodeSSLConfiguration
        protected fun Path.expectedOnDefaultFileSystem(): Unit
        protected fun tcpTransport(direction: ConnectionDirection, host: String, port: Int): <ERROR CLASS>
        fun toHostAndPort(target: MessageRecipients): <ERROR CLASS>
      class ArtemisMessagingServer : ArtemisMessagingComponent
        Module Contents ArtemisMessagingServer(config: NodeConfiguration, myHostPort: <ERROR CLASS>, networkMapCache: NetworkMapCache, userService: RPCUserService)
        class NodeLoginModule : LoginModule
          Module Contents NodeLoginModule()
          const val NODE_ROLE: String
          const val PEER_ROLE: String
          const val RPC_ROLE: String
          fun abort(): Boolean
          fun commit(): Boolean
          fun initialize(subject: Subject, callbackHandler: CallbackHandler, sharedState: Map<String, *>, options: Map<String, *>): Unit
          fun login(): Boolean
          fun logout(): Boolean
        val config: NodeConfiguration
        fun deployBridgeIfAbsent(queueName: <ERROR CLASS>, hostAndPort: <ERROR CLASS>): Unit
        val myHostPort: <ERROR CLASS>
        val networkMapCache: NetworkMapCache
        fun start(): Unit
        fun stop(): Unit
        val userService: RPCUserService
      val CURRENT_RPC_USER: ThreadLocal<User>
      object ClassSerializer
        Module Contents fun read(kryo: <ERROR CLASS>, input: <ERROR CLASS>, type: Class<Class<*>>): Class<*>
        fun write(kryo: <ERROR CLASS>, output: <ERROR CLASS>, clazz: Class<*>): Unit
      data class ClientRPCRequestMessage
        Module Contents ClientRPCRequestMessage(args: SerializedBytes<Array<Any>>, replyToAddress: String, observationsToAddress: String?, methodName: String, user: User)
        const val METHOD_NAME: String
        const val OBSERVATIONS_TO: String
        const val REPLY_TO: String
        val args: SerializedBytes<Array<Any>>
        val methodName: String
        val observationsToAddress: String?
        val replyToAddress: String
        val user: User
      class CordaRPCClient : Closeable, ArtemisMessagingComponent
        Module Contents CordaRPCClient(host: <ERROR CLASS>, config: NodeSSLConfiguration)
        fun close(): Unit
        val config: NodeSSLConfiguration
        val host: <ERROR CLASS>
        fun proxy(timeout: Duration? = null, minVersion: Int = 0): CordaRPCOps
        fun start(username: String, password: String): Unit
      class CordaRPCClientImpl
        Module Contents CordaRPCClientImpl(session: <ERROR CLASS>, sessionLock: ReentrantLock, username: String)
        fun <T : RPCOps> proxyFor(rpcInterface: Class<T>, timeout: Duration? = null, minVersion: Int = 0): T
      data class MarshalledObservation
        Module Contents MarshalledObservation(forHandle: Int, what: <ERROR CLASS><out <ERROR CLASS>>)
        val forHandle: Int
        val what: <ERROR CLASS><out <ERROR CLASS>>
      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
          Module Contents Handler(topicSession: TopicSession, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit)
          val callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit
          val topicSession: TopicSession
        const val SESSION_ID_PROPERTY: String
        const val TOPIC_PROPERTY: String
        fun addMessageHandler(topic: String, sessionID: Long, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        fun addMessageHandler(topicSession: TopicSession, callback: (ReceivedMessage, MessageHandlerRegistration) -> Unit): MessageHandlerRegistration
        val config: NodeConfiguration
        fun createMessage(topicSession: TopicSession, data: ByteArray, uuid: UUID): Message
        val database: <ERROR CLASS>
        val executor: AffinityExecutor
        fun getAddressOfParty(partyInfo: PartyInfo): MessageRecipients
        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
        Module Contents PermissionException(msg: String)
      abstract class RPCDispatcher
        Module Contents RPCDispatcher(ops: RPCOps, userService: RPCUserService, nodeLegalName: String)
        fun dispatch(msg: ClientRPCRequestMessage): Unit
        protected open fun getUser(message: <ERROR CLASS>): User
        val nodeLegalName: String
        val ops: RPCOps
        abstract fun send(data: SerializedBytes<*>, toAddress: String): Unit
        fun start(rpcConsumer: <ERROR CLASS>, rpcNotificationConsumer: <ERROR CLASS>?, onExecutor: AffinityExecutor): Unit
        val userService: RPCUserService
      open class RPCException : RuntimeException
        Module Contents RPCException(msg: String)
        RPCException(msg: String, cause: Throwable?)
        class DeadlineExceeded : RPCException
          Module Contents DeadlineExceeded(rpcName: String)
      @Target([AnnotationTarget.FUNCTION]) annotation class RPCSinceVersion
        Module Contents RPCSinceVersion(version: Int)
        val version: Int
      fun createRPCKryo(observableSerializer: <ERROR CLASS><<ERROR CLASS><Any>>? = null): <ERROR CLASS>
      fun requirePermission(permission: String): Unit
      val rpcLog: <ERROR CLASS>
    package net.corda.node.services.network
      Module Contents abstract class AbstractNetworkMapService : NetworkMapService, AbstractNodeService
        Module Contents AbstractNetworkMapService(services: ServiceHubInternal)
        protected val _mapVersion: AtomicInteger
        fun getUnacknowledgedCount(subscriber: SingleMessageRecipient, mapVersion: Int): Int?
        val mapVersion: Int
        val maxSizeRegistrationRequestBytes: Int
        val maxUnacknowledgedUpdates: Int
        open val nodes: List<NodeInfo>
        fun notifySubscribers(wireReg: WireNodeRegistration, mapVersion: Int): Unit
        fun processAcknowledge(req: UpdateAcknowledge): Unit
        fun processFetchAllRequest(req: FetchMapRequest): FetchMapResponse
        fun processQueryRequest(req: QueryIdentityRequest): QueryIdentityResponse
        fun processRegistrationChangeRequest(req: RegistrationRequest): RegistrationResponse
        fun processSubscriptionRequest(req: SubscribeRequest): SubscribeResponse
        protected abstract val registeredNodes: MutableMap<Party, NodeRegistrationInfo>
        protected fun setup(): Unit
        protected abstract val subscribers: ThreadBox<MutableMap<SingleMessageRecipient, LastAcknowledgeInfo>>
        fun unregisterNetworkHandlers(): Unit
      open class InMemoryNetworkMapCache : SingletonSerializeAsToken, NetworkMapCache
        Module Contents InMemoryNetworkMapCache()
        open fun addMapService(net: MessagingService, networkMapAddress: SingleMessageRecipient, subscribe: Boolean, ifChangedSinceVer: Int?): <ERROR CLASS><Unit>
        open fun addNode(node: NodeInfo): Unit
        open val changed: <ERROR CLASS><MapChange>
        open fun deregisterForUpdates(net: MessagingService, service: NodeInfo): <ERROR CLASS><Unit>
        open fun getPartyInfo(party: Party): PartyInfo?
        val logger: <ERROR CLASS>
        open val mapServiceRegistered: <ERROR CLASS><Unit>
        open val networkMapNodes: List<NodeInfo>
        open val partyNodes: List<NodeInfo>
        fun processUpdatePush(req: Update): Unit
        protected var registeredNodes: MutableMap<Party, NodeInfo>
        open fun removeNode(node: NodeInfo): Unit
        open fun runWithoutMapService(): Unit
        open fun track(): <ERROR CLASS><List<NodeInfo>, <ERROR CLASS><MapChange>>
      class InMemoryNetworkMapService : AbstractNetworkMapService
        Module Contents InMemoryNetworkMapService(services: ServiceHubInternal)
        protected val registeredNodes: MutableMap<Party, NodeRegistrationInfo>
        protected val subscribers: <ERROR CLASS>
      data class LastAcknowledgeInfo
        Module Contents LastAcknowledgeInfo(mapVersion: Int)
        val mapVersion: Int
      interface NetworkMapService
        Module Contents val DEFAULT_EXPIRATION_PERIOD: Period
        val FETCH_FLOW_TOPIC: String
        class FetchMapRequest : ServiceRequestMessage
          Module Contents FetchMapRequest(subscribe: Boolean, ifChangedSinceVersion: Int?, replyTo: SingleMessageRecipient, sessionID: Long = random63BitValue())
          val ifChangedSinceVersion: Int?
          val replyTo: SingleMessageRecipient
          val sessionID: Long
          val subscribe: Boolean
        data class FetchMapResponse
          Module Contents FetchMapResponse(nodes: Collection<NodeRegistration>?, version: Int)
          val nodes: Collection<NodeRegistration>?
          val version: Int
        val PUSH_ACK_FLOW_TOPIC: String
        val PUSH_FLOW_TOPIC: String
        val QUERY_FLOW_TOPIC: String
        class QueryIdentityRequest : ServiceRequestMessage
          Module Contents QueryIdentityRequest(identity: Party, replyTo: SingleMessageRecipient, sessionID: Long)
          val identity: Party
          val replyTo: SingleMessageRecipient
          val sessionID: Long
        data class QueryIdentityResponse
          Module Contents QueryIdentityResponse(node: NodeInfo?)
          val node: NodeInfo?
        val REGISTER_FLOW_TOPIC: String
        class RegistrationRequest : ServiceRequestMessage
          Module Contents RegistrationRequest(wireReg: WireNodeRegistration, replyTo: SingleMessageRecipient, sessionID: Long = random63BitValue())
          val replyTo: SingleMessageRecipient
          val sessionID: Long
          val wireReg: WireNodeRegistration
        data class RegistrationResponse
          Module Contents RegistrationResponse(success: Boolean)
          val success: Boolean
        val SUBSCRIPTION_FLOW_TOPIC: String
        class SubscribeRequest : ServiceRequestMessage
          Module Contents SubscribeRequest(subscribe: Boolean, replyTo: SingleMessageRecipient, sessionID: Long = random63BitValue())
          val replyTo: SingleMessageRecipient
          val sessionID: Long
          val subscribe: Boolean
        data class SubscribeResponse
          Module Contents SubscribeResponse(confirmed: Boolean)
          val confirmed: Boolean
        data class Update
          Module Contents Update(wireReg: WireNodeRegistration, mapVersion: Int, replyTo: MessageRecipients)
          val mapVersion: Int
          val replyTo: MessageRecipients
          val wireReg: WireNodeRegistration
        data class UpdateAcknowledge
          Module Contents UpdateAcknowledge(mapVersion: Int, replyTo: MessageRecipients)
          val mapVersion: Int
          val replyTo: MessageRecipients
        val logger: <ERROR CLASS>
        abstract val nodes: List<NodeInfo>
        val type: ServiceType
      sealed class NodeMapError : Exception
        Module Contents class InvalidSignature : NodeMapError
          Module Contents InvalidSignature()
        class InvalidSubscriber : NodeMapError
          Module Contents InvalidSubscriber()
        class UnknownChangeType : NodeMapError
          Module Contents UnknownChangeType()
      class NodeRegistration
        Module Contents NodeRegistration(node: NodeInfo, serial: Long, type: AddOrRemove, expires: Instant)
        var expires: Instant
        val node: NodeInfo
        val serial: Long
        fun toString(): String
        fun toWire(privateKey: PrivateKey): WireNodeRegistration
        val type: AddOrRemove
      data class NodeRegistrationInfo
        Module Contents NodeRegistrationInfo(reg: NodeRegistration, mapVersion: Int)
        val mapVersion: Int
        val reg: NodeRegistration
      class PersistentNetworkMapService : AbstractNetworkMapService
        Module Contents PersistentNetworkMapService(services: ServiceHubInternal)
        protected val registeredNodes: MutableMap<Party, NodeRegistrationInfo>
        protected val subscribers: ThreadBox<JDBCHashMap<SingleMessageRecipient, LastAcknowledgeInfo>>
      class WireNodeRegistration : SignedData<NodeRegistration>
        Module Contents WireNodeRegistration(raw: SerializedBytes<NodeRegistration>, sig: WithKey)
        protected fun verifyData(data: NodeRegistration): Unit
    package net.corda.node.services.persistence
      Module Contents class DBCheckpointStorage : CheckpointStorage
        Module Contents DBCheckpointStorage()
        fun addCheckpoint(checkpoint: Checkpoint): Unit
        fun forEach(block: (Checkpoint) -> Boolean): Unit
        fun removeCheckpoint(checkpoint: Checkpoint): Unit
      class DBTransactionMappingStorage : StateMachineRecordedTransactionMappingStorage
        Module Contents DBTransactionMappingStorage()
        fun addMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash): Unit
        fun track(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
      class DBTransactionStorage : TransactionStorage
        Module Contents DBTransactionStorage()
        fun addTransaction(transaction: SignedTransaction): Boolean
        fun getTransaction(id: SecureHash): SignedTransaction?
        fun track(): <ERROR CLASS><List<SignedTransaction>, <ERROR CLASS><SignedTransaction>>
        val transactions: Iterable<SignedTransaction>
        val updates: <ERROR CLASS><SignedTransaction>
        val updatesPublisher: <ERROR CLASS>
      object DataVending
        Module Contents class Plugin : CordaPluginRegistry
          Module Contents Plugin()
          val servicePlugins: <ERROR CLASS>
        class Service : SingletonSerializeAsToken
          Module Contents Service(services: PluginServiceHub)
          class NotifyTransactionHandler : FlowLogic<Unit>
            Module Contents NotifyTransactionHandler(otherParty: Party)
            fun call(): Unit
            val otherParty: Party
          val logger: <ERROR CLASS>
      class InMemoryStateMachineRecordedTransactionMappingStorage : StateMachineRecordedTransactionMappingStorage
        Module Contents InMemoryStateMachineRecordedTransactionMappingStorage()
        fun addMapping(stateMachineRunId: StateMachineRunId, transactionId: SecureHash): Unit
        fun track(): <ERROR CLASS><List<StateMachineTransactionMapping>, <ERROR CLASS><StateMachineTransactionMapping>>
      class NodeAttachmentService : AttachmentStorage, AcceptsFileUpload
        Module Contents NodeAttachmentService(storePath: Path, metrics: <ERROR CLASS>)
        class OnDiskHashMismatch : Exception
          Module Contents OnDiskHashMismatch(file: Path, actual: SecureHash)
          val actual: SecureHash
          val file: Path
          fun toString(): String
        val acceptableFileExtensions: <ERROR CLASS>
        var automaticallyExtractAttachments: Boolean
        var checkAttachmentsOnLoad: Boolean
        val dataTypePrefix: String
        fun importAttachment(jar: InputStream): SecureHash
        fun openAttachment(id: SecureHash): Attachment?
        val storePath: Path
        fun upload(data: InputStream): <ERROR CLASS>
      open class StorageServiceImpl : SingletonSerializeAsToken, TxWritableStorageService
        Module Contents StorageServiceImpl(attachments: AttachmentStorage, validatedTransactions: TransactionStorage, stateMachineRecordedTransactionMapping: StateMachineRecordedTransactionMappingStorage)
        open val attachments: AttachmentStorage
        open val stateMachineRecordedTransactionMapping: StateMachineRecordedTransactionMappingStorage
        open val validatedTransactions: TransactionStorage
    package net.corda.node.services.schema
      Module Contents class HibernateObserver
        Module Contents HibernateObserver(services: ServiceHubInternal)
        class NodeDatabaseConnectionProvider
          Module Contents NodeDatabaseConnectionProvider()
          fun closeConnection(conn: Connection): Unit
          fun getConnection(): Connection
          fun isUnwrappableAs(unwrapType: Class<*>?): Boolean
          fun supportsAggressiveRelease(): Boolean
          fun <T> unwrap(unwrapType: Class<T>): T
        val logger: <ERROR CLASS>
        val schemaService: SchemaService
        val sessionFactories: ConcurrentHashMap<MappedSchema, <ERROR CLASS>>
      class NodeSchemaService : SchemaService, SingletonSerializeAsToken
        Module Contents NodeSchemaService()
        fun generateMappedObject(state: QueryableState, schema: MappedSchema): PersistentState
        val schemaOptions: Map<MappedSchema, SchemaOptions>
        fun selectSchemas(state: QueryableState): Iterable<MappedSchema>
    package net.corda.node.services.statemachine
      Module Contents interface FlowIORequest
        Module Contents abstract val session: FlowSession
        abstract val stackTraceInCaseOfProblems: StackSnapshot
      class FlowStateMachineImpl<R> : FlowStateMachine<R>
        Module Contents FlowStateMachineImpl(id: StateMachineRunId, logic: FlowLogic<R>, scheduler: FiberScheduler)
        fun currentStateMachine(): FlowStateMachineImpl<*>?
        val id: StateMachineRunId
        val logger: <ERROR CLASS>
        val logic: FlowLogic<R>
        fun <T : Any> receive(otherParty: Party, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        val resultFuture: <ERROR CLASS><R>
        fun run(): R
        fun send(otherParty: Party, payload: Any, sessionFlow: FlowLogic<*>): Unit
        fun <T : Any> sendAndReceive(otherParty: Party, payload: Any, receiveType: Class<T>, sessionFlow: FlowLogic<*>): UntrustworthyData<T>
        lateinit var serviceHub: ServiceHubInternal
      data class ReceiveOnly<T : SessionMessage> : ReceiveRequest<T>
        Module Contents ReceiveOnly(session: FlowSession, receiveType: Class<T>)
        val receiveType: Class<T>
        val session: FlowSession
        val stackTraceInCaseOfProblems: StackSnapshot
      interface ReceiveRequest<T : SessionMessage> : FlowIORequest
        Module Contents abstract val receiveType: Class<T>
      data class SendAndReceive<T : SessionMessage> : SendRequest, ReceiveRequest<T>
        Module Contents SendAndReceive(session: FlowSession, message: SessionMessage, receiveType: Class<T>)
        val message: SessionMessage
        val receiveType: Class<T>
        val session: FlowSession
        val stackTraceInCaseOfProblems: StackSnapshot
      data class SendOnly : SendRequest
        Module Contents SendOnly(session: FlowSession, message: SessionMessage)
        val message: SessionMessage
        val session: FlowSession
        val stackTraceInCaseOfProblems: StackSnapshot
      interface SendRequest : FlowIORequest
        Module Contents abstract val message: SessionMessage
      class StackSnapshot : Throwable
        Module Contents StackSnapshot()
      class StateMachineManager
        Module Contents StateMachineManager(serviceHub: ServiceHubInternal, tokenizableServices: List<Any>, checkpointStorage: CheckpointStorage, executor: AffinityExecutor, database: <ERROR CLASS>)
        data class Change
          Module Contents Change(logic: FlowLogic<*>, addOrRemove: AddOrRemove, id: StateMachineRunId)
          val addOrRemove: AddOrRemove
          val id: StateMachineRunId
          val logic: FlowLogic<*>
        interface ExistingSessionMessage : SessionMessage
          Module Contents abstract val recipientSessionId: Long
        inner class FiberScheduler
          Module Contents FiberScheduler()
        data class FlowSession
          Module Contents FlowSession(flow: FlowLogic<*>, ourSessionId: Long, state: FlowSessionState, waitingForResponse: Boolean = false)
          val flow: FlowLogic<*>
          val ourSessionId: Long
          val psm: FlowStateMachineImpl<*>
          val receivedMessages: ConcurrentLinkedQueue<ReceivedSessionMessage<ExistingSessionMessage>>
          var state: FlowSessionState
          var waitingForResponse: Boolean
        sealed class FlowSessionState
          Module Contents class Initiated : FlowSessionState
            Module Contents Initiated(peerParty: Party, peerSessionId: Long)
            val peerParty: Party
            val peerSessionId: Long
            val sendToParty: Party
          class Initiating : FlowSessionState
            Module Contents Initiating(otherParty: Party)
            val otherParty: Party
            val sendToParty: Party
          abstract val sendToParty: Party
        data class ReceivedSessionMessage<out M : SessionMessage>
          Module Contents ReceivedSessionMessage(sendingParty: Party, message: M)
          val message: M
          val sendingParty: Party
        data class SessionConfirm : SessionInitResponse
          Module Contents SessionConfirm(initiatorSessionId: Long, initiatedSessionId: Long)
          val initiatedSessionId: Long
          val initiatorSessionId: Long
          val recipientSessionId: Long
        data class SessionData : ExistingSessionMessage
          Module Contents SessionData(recipientSessionId: Long, payload: Any)
          val payload: Any
          val recipientSessionId: Long
          fun toString(): String
        data class SessionEnd : ExistingSessionMessage
          Module Contents SessionEnd(recipientSessionId: Long)
          val recipientSessionId: Long
        data class SessionInit : SessionMessage
          Module Contents SessionInit(initiatorSessionId: Long, flowName: String, firstPayload: Any?)
          val firstPayload: Any?
          val flowName: String
          val initiatorSessionId: Long
        interface SessionInitResponse : ExistingSessionMessage
        interface SessionMessage
        data class SessionReject : SessionInitResponse
          Module Contents SessionReject(initiatorSessionId: Long, errorMessage: String)
          val errorMessage: String
          val initiatorSessionId: Long
          val recipientSessionId: Long
        fun <T> add(logic: FlowLogic<T>): FlowStateMachine<T>
        val allStateMachines: List<FlowLogic<*>>
        val changes: <ERROR CLASS><Change>
        val checkpointStorage: CheckpointStorage
        val database: <ERROR CLASS>
        val executor: AffinityExecutor
        fun <P : FlowLogic<T>, T> findStateMachines(flowClass: Class<P>): List<<ERROR CLASS><P, <ERROR CLASS><T>>>
        val scheduler: FiberScheduler
        val serviceHub: ServiceHubInternal
        fun start(): Unit
        fun stop(allowedUnsuspendedFiberCount: Int = 0): Unit
        fun track(): <ERROR CLASS><List<FlowStateMachineImpl<*>>, <ERROR CLASS><Change>>
        val unfinishedFibers: <ERROR CLASS>
    package net.corda.node.services.transactions
      Module Contents class DistributedImmutableMap<K : Any, V : Any>
        Module Contents DistributedImmutableMap(db: <ERROR CLASS>, tableName: String)
        object Commands
          Module Contents class Get<out K, V>
            Module Contents Get(key: K)
            val key: K
          class PutAll<K, V>
            Module Contents PutAll(entries: Map<K, V>)
            fun compaction(): <ERROR CLASS>
            val entries: Map<K, V>
          class Size
            Module Contents Size()
        val db: <ERROR CLASS>
        fun get(commit: <ERROR CLASS><Get<K, V>>): V?
        fun install(reader: <ERROR CLASS>): Unit
        fun put(commit: <ERROR CLASS><PutAll<K, V>>): Map<K, V>
        fun size(commit: <ERROR CLASS><Size>): Int
        fun snapshot(writer: <ERROR CLASS>): Unit
      class InMemoryUniquenessProvider : UniquenessProvider
        Module Contents InMemoryUniquenessProvider()
        fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      abstract class NotaryService : SingletonSerializeAsToken
        Module Contents NotaryService(services: ServiceHubInternal)
        abstract fun createFlow(otherParty: Party): Service
      class PersistentUniquenessProvider : UniquenessProvider, SingletonSerializeAsToken
        Module Contents PersistentUniquenessProvider()
        fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      class RaftUniquenessProvider : UniquenessProvider, SingletonSerializeAsToken
        Module Contents RaftUniquenessProvider(storagePath: Path, myAddress: <ERROR CLASS>, clusterAddresses: List<<ERROR CLASS>>, db: <ERROR CLASS>, config: NodeSSLConfiguration)
        fun commit(states: List<StateRef>, txId: SecureHash, callerIdentity: Party): Unit
      class RaftValidatingNotaryService : NotaryService
        Module Contents RaftValidatingNotaryService(services: ServiceHubInternal, timestampChecker: TimestampChecker, uniquenessProvider: RaftUniquenessProvider)
        fun createFlow(otherParty: Party): ValidatingNotaryFlow
        val timestampChecker: TimestampChecker
        val type: ServiceType
        val uniquenessProvider: RaftUniquenessProvider
      class SimpleNotaryService : NotaryService
        Module Contents SimpleNotaryService(services: ServiceHubInternal, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
        fun createFlow(otherParty: Party): Service
        val timestampChecker: TimestampChecker
        val type: ServiceType
        val uniquenessProvider: UniquenessProvider
      class ValidatingNotaryService : NotaryService
        Module Contents ValidatingNotaryService(services: ServiceHubInternal, timestampChecker: TimestampChecker, uniquenessProvider: UniquenessProvider)
        fun createFlow(otherParty: Party): ValidatingNotaryFlow
        val timestampChecker: TimestampChecker
        val type: ServiceType
        val uniquenessProvider: UniquenessProvider
    package net.corda.node.services.vault
      Module Contents class CashBalanceAsMetricsObserver
        Module Contents CashBalanceAsMetricsObserver(serviceHubInternal: ServiceHubInternal, database: <ERROR CLASS>)
        val database: <ERROR CLASS>
        val serviceHubInternal: ServiceHubInternal
      class NodeVaultService : SingletonSerializeAsToken, VaultService
        Module Contents NodeVaultService(services: ServiceHub)
        fun addNoteToTransaction(txnId: SecureHash, noteText: String): Unit
        val cashBalances: Map<Currency, Amount<Currency>>
        val currentVault: Vault
        fun generateSpend(tx: TransactionBuilder, amount: Amount<Currency>, to: CompositeKey, onlyFromParties: Set<Party>?): <ERROR CLASS><TransactionBuilder, List<CompositeKey>>
        fun getTransactionNotes(txnId: SecureHash): Iterable<String>
        val linearHeads: Map<UniqueIdentifier, StateAndRef<LinearState>>
        val log: <ERROR CLASS>
        fun notifyAll(txns: Iterable<WireTransaction>): Unit
        val rawUpdates: <ERROR CLASS><Update>
        fun track(): <ERROR CLASS><Vault, <ERROR CLASS><Update>>
        val updates: <ERROR CLASS><Update>
    package net.corda.node.servlets
      Module Contents class AttachmentDownloadServlet
        Module Contents AttachmentDownloadServlet()
        fun doGet(req: <ERROR CLASS>, resp: <ERROR CLASS>): Unit
      class Config
        Module Contents Config(services: ServiceHub)
        val defaultObjectMapper: <ERROR CLASS>
        fun getContext(type: Class<*>): <ERROR CLASS>
        val services: ServiceHub
      class DataUploadServlet
        Module Contents DataUploadServlet()
        fun doPost(req: <ERROR CLASS>, resp: <ERROR CLASS>): Unit
      class ResponseFilter
        Module Contents ResponseFilter()
        fun filter(requestContext: <ERROR CLASS>, responseContext: <ERROR CLASS>): Unit
    package net.corda.node.utilities
      Module Contents class ANSIProgressObserver
        Module Contents ANSIProgressObserver(smm: StateMachineManager)
        val smm: StateMachineManager
      object ANSIProgressRenderer
        Module Contents var progressTracker: ProgressTracker?
      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 = DEFAULT_MAX_BUCKETS)
        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>
        Module Contents AbstractJDBCHashSet(table: T, loadOnInit: Boolean = false, maxBuckets: Int = DEFAULT_MAX_BUCKETS)
        open fun add(element: K): Boolean
        protected abstract fun addElementToInsert(insert: <ERROR CLASS>, entry: K, finalizables: MutableList<() -> Unit>): Unit
        open fun clear(): Unit
        open fun contains(element: K): Boolean
        protected abstract fun elementFromRow(row: <ERROR CLASS>): K
        protected val innerMap: AbstractJDBCHashMap<K, Unit, T>
        open fun isEmpty(): Boolean
        open fun iterator(): MutableIterator<K>
        open fun remove(element: K): Boolean
        open val size: Int
        protected val table: T
      enum class AddOrRemove
        Module Contents ADD
        REMOVE
      interface AffinityExecutor : Executor
        Module Contents class Gate : AffinityExecutor
          Module Contents Gate(alwaysQueue: Boolean = false)
          fun execute(command: Runnable): Unit
          fun flush(): Unit
          val isOnThread: Boolean
          val taskQueueSize: Int
          fun waitAndRun(): Unit
        open class ServiceAffinityExecutor : AffinityExecutor, ThreadPoolExecutor
          Module Contents ServiceAffinityExecutor(threadName: String, numThreads: Int)
          protected open fun afterExecute(r: Runnable, t: Throwable?): Unit
          open fun flush(): Unit
          open val isOnThread: Boolean
          val logger: <ERROR CLASS>
        open fun checkOnThread(): Unit
        open fun executeASAP(runnable: () -> Unit): Unit
        open fun <T> fetchFrom(fetcher: () -> T): T
        abstract fun flush(): Unit
        abstract val isOnThread: Boolean
      object CompositeKeyColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      val DEFAULT_MAX_BUCKETS: Int
      class FiberBox<out T>
        Module Contents FiberBox(content: T, lock: Lock = ReentrantLock())
        fun <R> read(body: T.() -> R): R
        fun <R> readWithDeadline(clock: Clock, deadline: Instant, body: T.() -> R): R
        fun <R> write(body: T.() -> R): R
      object InstantColumnType
        Module Contents fun nonNullValueToString(value: Any): String
        fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      class JDBCHashMap<K : Any, V : Any> : AbstractJDBCHashMap<K, V, BlobMapTable>
        Module Contents JDBCHashMap(tableName: String, loadOnInit: Boolean = false, maxBuckets: Int = DEFAULT_MAX_BUCKETS)
        class BlobMapTable : JDBCHashedTable
          Module Contents BlobMapTable(tableName: String)
          val key: <ERROR CLASS>
          val value: <ERROR CLASS>
        protected fun addKeyToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
        protected fun addValueToInsert(insert: <ERROR CLASS>, entry: Entry<K, V>, finalizables: MutableList<() -> Unit>): Unit
        protected fun keyFromRow(row: <ERROR CLASS>): K
        protected fun valueFromRow(row: <ERROR CLASS>): V
      class JDBCHashSet<K : Any> : AbstractJDBCHashSet<K, BlobSetTable>
        Module Contents JDBCHashSet(tableName: String, loadOnInit: Boolean = false, maxBuckets: Int = DEFAULT_MAX_BUCKETS)
        class BlobSetTable : JDBCHashedTable
          Module Contents BlobSetTable(tableName: String)
          val key: <ERROR CLASS>
        protected fun addElementToInsert(insert: <ERROR CLASS>, entry: K, finalizables: MutableList<() -> Unit>): Unit
        protected fun elementFromRow(row: <ERROR CLASS>): K
      open class JDBCHashedTable
        Module Contents JDBCHashedTable(tableName: String)
        val keyHash: <ERROR CLASS>
        val seqNo: <ERROR CLASS>
      object JsonSupport
        Module Contents object CalendarDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): BusinessCalendar
        object CompositeKeyDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): CompositeKey
        object CompositeKeySerializer
          Module Contents fun serialize(obj: CompositeKey, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        object LocalDateDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): LocalDate
        object LocalDateKeyDeserializer
          Module Contents fun deserializeKey(text: String, p1: <ERROR CLASS>): Any?
        object NodeInfoDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): NodeInfo
        object NodeInfoSerializer
          Module Contents fun serialize(value: NodeInfo, gen: <ERROR CLASS>, serializers: <ERROR CLASS>): Unit
        object PartyDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): Party
        object PartySerializer
          Module Contents fun serialize(obj: Party, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        object PublicKeyDeserializer
          Module Contents fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): <ERROR CLASS>
        object PublicKeySerializer
          Module Contents fun serialize(obj: <ERROR CLASS>, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        class SecureHashDeserializer<T : SecureHash>
          Module Contents SecureHashDeserializer()
          fun deserialize(parser: <ERROR CLASS>, context: <ERROR CLASS>): T
        object SecureHashSerializer
          Module Contents fun serialize(obj: SecureHash, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        class ServiceHubObjectMapper
          Module Contents ServiceHubObjectMapper(identities: IdentityService)
          val identities: IdentityService
        object ToStringSerializer
          Module Contents fun serialize(obj: Any, generator: <ERROR CLASS>, provider: <ERROR CLASS>): Unit
        fun createDefaultMapper(identities: IdentityService): <ERROR CLASS>
      object LocalDateColumnType
        Module Contents fun nonNullValueToString(value: Any): String
        fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      object LocalDateTimeColumnType
        Module Contents fun nonNullValueToString(value: Any): String
        fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      abstract class MutableClock : Clock
        Module Contents MutableClock()
        val mutationCount: Long
        val mutations: <ERROR CLASS><Long>
        protected fun notifyMutationObservers(): Unit
      const val NODE_DATABASE_PREFIX: String
      data class PartyColumns
        Module Contents PartyColumns(name: <ERROR CLASS><String>, owningKey: <ERROR CLASS><CompositeKey>)
        val name: <ERROR CLASS><String>
        val owningKey: <ERROR CLASS><CompositeKey>
      object PublicKeyColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      object SecureHashColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      object ServiceIdentityGenerator
        Module Contents fun generateToDisk(dirs: List<Path>, serviceId: String, serviceName: String, threshold: Int = 1): Unit
      data class StateRefColumns
        Module Contents StateRefColumns(txId: <ERROR CLASS><SecureHash>, index: <ERROR CLASS><Int>)
        val index: <ERROR CLASS><Int>
        val txId: <ERROR CLASS><SecureHash>
      class StrandLocalTransactionManager
        Module Contents StrandLocalTransactionManager(initWithDatabase: <ERROR CLASS>)
        data class Boundary
          Module Contents Boundary(txId: UUID)
          val txId: UUID
        fun currentOrNull(): <ERROR CLASS>?
        var database: <ERROR CLASS>
        val manager: StrandLocalTransactionManager
        fun newTransaction(isolation: Int): <ERROR CLASS>
        fun restoreThreadLocalTx(context: <ERROR CLASS><<ERROR CLASS>?, <ERROR CLASS>?>): Unit
        fun setThreadLocalTx(tx: <ERROR CLASS>?): <ERROR CLASS><<ERROR CLASS>?, <ERROR CLASS>?>
        val transactionBoundaries: <ERROR CLASS><Boundary>
        val transactionId: UUID
      class TestClock : MutableClock, SerializeAsToken
        Module Contents TestClock(delegateClock: Clock = Clock.systemUTC())
        fun getZone(): ZoneId
        fun instant(): Instant
        fun toToken(context: SerializeAsTokenContext): SerializationToken
        fun updateDate(date: LocalDate): Boolean
        fun withZone(zone: ZoneId): Clock
      data class TxnNoteColumns
        Module Contents TxnNoteColumns(txId: <ERROR CLASS><SecureHash>, note: <ERROR CLASS><String>)
        val note: <ERROR CLASS><String>
        val txId: <ERROR CLASS><SecureHash>
      object UUIDStringColumnType
        Module Contents fun notNullValueToDB(value: Any): Any
        fun sqlType(): String
        fun valueFromDB(value: Any): Any
      fun <T : Any> <ERROR CLASS><T>.bufferUntilDatabaseCommit(): <ERROR CLASS><T>
      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>
      fun <T : Any> <ERROR CLASS><T>.wrapWithDatabaseTransaction(db: <ERROR CLASS>? = null): <ERROR CLASS><T>
    package net.corda.node.utilities.certsigning
      Module Contents class CertificateSigner
        Module Contents CertificateSigner(config: NodeConfiguration, certService: CertificateSigningService)
        fun buildKeyStore(): Unit
        val certService: CertificateSigningService
        val config: NodeConfiguration
        val log: <ERROR CLASS>
        val pollInterval: Duration
      interface CertificateSigningService
        Module Contents abstract fun retrieveCertificates(requestId: String): Array<Certificate>?
        abstract fun submitRequest(request: <ERROR CLASS>): String
      class HTTPCertificateSigningService : CertificateSigningService
        Module Contents HTTPCertificateSigningService(server: URL)
        val clientVersion: String
        fun retrieveCertificates(requestId: String): Array<Certificate>?
        val server: URL
        fun submitRequest(request: <ERROR CLASS>): String
      object ParamsSpec
        Module Contents val baseDirectoryArg: <ERROR CLASS>
        val configFileArg: <ERROR CLASS>
        val parser: <ERROR CLASS>
      fun main(args: Array<String>): Unit
    package net.corda.schemas
      Module Contents object CashSchema
      object CashSchemaV1 : MappedSchema
        Module Contents class PersistentCashState : PersistentState
          Module Contents PersistentCashState(encumbrance: Int?, owner: String, pennies: Long, currency: String, issuerParty: String, issuerRef: ByteArray)
          var currency: String
          var encumbrance: Int?
          var issuerParty: String
          var issuerRef: ByteArray
          var owner: String
          var pennies: Long
      object CommercialPaperSchema
      object CommercialPaperSchemaV1 : MappedSchema
        Module Contents class PersistentCommericalPaperState : PersistentState
          Module Contents PersistentCommericalPaperState(issuanceParty: String, issuanceRef: ByteArray, owner: String, maturity: Instant, faceValue: Long, currency: String, faceValueIssuerParty: String, faceValueIssuerRef: ByteArray)
          var currency: String
          var faceValue: Long
          var faceValueIssuerParty: String
          var faceValueIssuerRef: ByteArray
          var issuanceParty: String
          var issuanceRef: ByteArray
          var maturity: Instant
          var owner: String